You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@dubbo.apache.org by al...@apache.org on 2022/05/29 01:38:25 UTC

[dubbo-go-samples] branch 1.5 updated: rm consul (#380)

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

alexstocks pushed a commit to branch 1.5
in repository https://gitbox.apache.org/repos/asf/dubbo-go-samples.git


The following commit(s) were added to refs/heads/1.5 by this push:
     new 980d1af5 rm consul (#380)
980d1af5 is described below

commit 980d1af52e02839133480765866531489b2dbea1
Author: zhaoyunxing <zh...@apache.org>
AuthorDate: Sun May 29 09:38:20 2022 +0800

    rm consul (#380)
---
 registry/servicediscovery/consul/README.md         |  47 ----------
 registry/servicediscovery/consul/README_zh.md      |  46 ---------
 .../consul/go-client/cmd/client.go                 | 104 ---------------------
 .../consul/go-client/cmd/version.go                |  22 -----
 .../consul/go-client/conf/client.yml               |  77 ---------------
 .../servicediscovery/consul/go-client/conf/log.yml |  28 ------
 .../consul/go-client/pkg/pojo/user.go              |  42 ---------
 .../consul/go-server/cmd/server.go                 |  87 -----------------
 .../consul/go-server/cmd/version.go                |  22 -----
 .../consul/go-server/conf/client.yml               |  77 ---------------
 .../servicediscovery/consul/go-server/conf/log.yml |  28 ------
 .../consul/go-server/conf/server.yml               |  74 ---------------
 .../consul/go-server/docker/docker-compose.yml     |   9 --
 .../consul/go-server/pkg/pojo/user.go              |  58 ------------
 .../go-server/tests/integration/main_test.go       |  75 ---------------
 .../tests/integration/userprovider_test.go         |  39 --------
 16 files changed, 835 deletions(-)

diff --git a/registry/servicediscovery/consul/README.md b/registry/servicediscovery/consul/README.md
deleted file mode 100644
index c5780de4..00000000
--- a/registry/servicediscovery/consul/README.md
+++ /dev/null
@@ -1,47 +0,0 @@
-# Consul Service Discovery Example
-### 1. Introduction
-[Consul](https://www.consul.io/docs/intro) is a service mesh solution providing a full featured control plane with service discovery, configuration, and segmentation functionality.\
-Dubbogo can use consul as service discovery middleware and metadata reporter. \
-Before using consul, pls make sure consul server is running in your environment and match the config below.\
-
-### 2. Important config
-```yaml
-registries: # registry config
-  "demoServiceDiscovery": 
-    protocol: "service-discovery" # choose service-discovery as service registry config protocol
-    params:
-      service_discovery: "consul_dis"
-      name_mapping: "in-memory"
-      metadata: "default"
-
-service_discovery:
-  consul_dis: # this key sould match config above
-    protocol: "consul" # this is real protocol that sd based
-    remote_ref: "consul1" # this is the remoting network config of target protocol
-
-remote: 
-  consul1: # this key should match config service_discovery's remote_ref
-    address: "127.0.0.1:8500" # consul address
-    timeout: "5s" 
-
-# if you want to report metadata by consul, you can add config below:
-metadata_report:
-  protocol: "consul"
-  remote_ref: "consul1"
-```
-### 3. Import block
-To use consul as service discovery, make sure you add import in you server and client:
-```go
-import(
-    _ "github.com/apache/dubbo-go/metadata/report/consul"
-    _ "github.com/apache/dubbo-go/registry/servicediscovery"
-)
-	
-```
-
-if you want to use consul to report, make sure you add import:
-```go
-import(
-    _ "github.com/apache/dubbo-go/metadata/report/consul"
-)
-```
\ No newline at end of file
diff --git a/registry/servicediscovery/consul/README_zh.md b/registry/servicediscovery/consul/README_zh.md
deleted file mode 100644
index b494a3ab..00000000
--- a/registry/servicediscovery/consul/README_zh.md
+++ /dev/null
@@ -1,46 +0,0 @@
-# Consul 服务发现示例
-### 1. 介绍
-[Consul](https://www.consul.io/docs/intro)
-是一个服务网格解决方案,它提供了一个具有服务发现、配置和分段功能的全功能控制平面。
-在通过dubbogo使用consul之前,请保证consul已经在您的环境正确运行,并且和下面的ip:port配置一致。
-
-### 2. Important config
-```yaml
-registries: # registry config
-  "demoServiceDiscovery": 
-    protocol: "service-discovery" # choose service-discovery as service registry config protocol
-    params:
-      service_discovery: "consul_dis"
-      name_mapping: "in-memory"
-      metadata: "default"
-
-service_discovery:
-  consul_dis: # this key sould match config above
-    protocol: "consul" # this is real protocol that sd based
-    remote_ref: "consul1" # this is the remoting network config of target protocol
-
-remote: 
-  consul1: # this key should match config service_discovery's remote_ref
-    address: "127.0.0.1:8500" # consul 服务地址
-    timeout: "5s" 
-
-# if you want to report metadata by consul, you can add config below:
-metadata_report:
-  protocol: "consul"
-  remote_ref: "consul1"
-```
-### 3. Import 引入依赖
-使用consul作为服务注册中心,请将引入以下依赖:
-```go
-import(
-    _ "github.com/apache/dubbo-go/metadata/report/consul"
-    _ "github.com/apache/dubbo-go/registry/servicediscovery"
-)
-	
-```
-如果您希望使用consul来报告数据,请引入以下依赖:
-```go
-import(
-    _ "github.com/apache/dubbo-go/metadata/report/consul"
-)
-```
\ No newline at end of file
diff --git a/registry/servicediscovery/consul/go-client/cmd/client.go b/registry/servicediscovery/consul/go-client/cmd/client.go
deleted file mode 100644
index 0be5b6cb..00000000
--- a/registry/servicediscovery/consul/go-client/cmd/client.go
+++ /dev/null
@@ -1,104 +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 main
-
-import (
-	"context"
-	"fmt"
-	"os"
-	"os/signal"
-	"syscall"
-	"time"
-)
-
-import (
-	hessian "github.com/apache/dubbo-go-hessian2"
-	_ "github.com/apache/dubbo-go/cluster/cluster_impl"
-	_ "github.com/apache/dubbo-go/cluster/loadbalance"
-	"github.com/apache/dubbo-go/common/logger"
-	_ "github.com/apache/dubbo-go/common/proxy/proxy_factory"
-	"github.com/apache/dubbo-go/config"
-	_ "github.com/apache/dubbo-go/filter/filter_impl"
-	_ "github.com/apache/dubbo-go/metadata/mapping/dynamic"
-	_ "github.com/apache/dubbo-go/metadata/report/consul"
-	_ "github.com/apache/dubbo-go/metadata/service/remote"
-	_ "github.com/apache/dubbo-go/protocol/dubbo"
-	_ "github.com/apache/dubbo-go/registry/consul"
-	_ "github.com/apache/dubbo-go/registry/protocol"
-	_ "github.com/apache/dubbo-go/registry/servicediscovery"
-
-	gxlog "github.com/dubbogo/gost/log"
-)
-
-import (
-	"github.com/apache/dubbo-go-samples/registry/servicediscovery/consul/go-client/pkg/pojo"
-)
-
-var (
-	survivalTimeout int = 10e9
-)
-
-var userProvider = new(pojo.UserProvider)
-
-func init() {
-	config.SetConsumerService(userProvider)
-	hessian.RegisterPOJO(&pojo.User{})
-}
-
-// they are necessary:
-// 		export CONF_CONSUMER_FILE_PATH="xxx"
-// 		export APP_LOG_CONF_FILE="xxx"
-func main() {
-	config.Load()
-	time.Sleep(3e9)
-
-	gxlog.CInfo("\n\n\nstart to test dubbo\n")
-	user := &pojo.User{}
-	for i := 0; i < 5; i++ {
-		err := userProvider.GetUser(context.TODO(), []interface{}{"A001"}, user)
-		if err != nil {
-			panic(err)
-		}
-		gxlog.CInfo("response result: %v\n", user)
-	}
-	initSignal()
-}
-
-func initSignal() {
-	signals := make(chan os.Signal, 1)
-	// It is not possible to block SIGKILL or syscall.SIGSTOP
-	signal.Notify(signals, os.Interrupt, os.Kill, syscall.SIGHUP,
-		syscall.SIGQUIT, syscall.SIGTERM, syscall.SIGINT)
-	for {
-		sig := <-signals
-		logger.Infof("get signal %s", sig.String())
-		switch sig {
-		case syscall.SIGHUP:
-			// reload()
-		default:
-			time.AfterFunc(time.Duration(survivalTimeout), func() {
-				logger.Warnf("app exit now by force...")
-				os.Exit(1)
-			})
-
-			// The program exits normally or timeout forcibly exits.
-			fmt.Println("app exit now...")
-			return
-		}
-	}
-}
diff --git a/registry/servicediscovery/consul/go-client/cmd/version.go b/registry/servicediscovery/consul/go-client/cmd/version.go
deleted file mode 100644
index ae51f45d..00000000
--- a/registry/servicediscovery/consul/go-client/cmd/version.go
+++ /dev/null
@@ -1,22 +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 main
-
-var (
-	Version = "2.7.5"
-)
diff --git a/registry/servicediscovery/consul/go-client/conf/client.yml b/registry/servicediscovery/consul/go-client/conf/client.yml
deleted file mode 100644
index 88970af5..00000000
--- a/registry/servicediscovery/consul/go-client/conf/client.yml
+++ /dev/null
@@ -1,77 +0,0 @@
-# dubbo client yaml configure file
-
-
-check: true
-# client
-request_timeout : "3s"
-# connect timeout
-connect_timeout : "3s"
-
-# application config
-application:
-  organization : "ikurento.com"
-  name  : "user-info-client"
-  module : "dubbogo user-info client"
-  version : "0.0.1"
-  owner : "ZX"
-  environment : "dev"
-
-
-registries:
-  "demoServiceDiscovery":
-    protocol: "service-discovery"
-    params:
-      service_discovery: "consul_dis"
-      name_mapping: "in-memory"
-      metadata: "default"
-
-remote:
-  consul1:
-    address: "127.0.0.1:8500"
-    timeout: "5s"
-
-metadata_report:
-  protocol: "consul"
-  remote_ref: "consul1"
-
-service_discovery:
-  consul_dis:
-    protocol: "consul"
-    remote_ref: "consul1"
-
-
-references:
-  "UserProvider":
-    # 可以指定多个registry,使用逗号隔开;不指定默认向所有注册中心注册
-    registry: "demoServiceDiscovery"
-    protocol : "dubbo"
-    provide_by: "UserInfoServer"
-    interface : "com.ikurento.user.UserProvider"
-    cluster: "failover"
-    methods :
-    - name: "GetUser"
-      retries: 3
-
-
-protocol_conf:
-  dubbo:
-    reconnect_interval: 0
-    connection_number: 1
-    heartbeat_period: "5s"
-    session_timeout: "180s"
-    pool_size: 64
-    pool_ttl: 600
-    getty_session_param:
-      compress_encoding: false
-      tcp_no_delay: true
-      tcp_keep_alive: true
-      keep_alive_period: "120s"
-      tcp_r_buf_size: 262144
-      tcp_w_buf_size: 65536
-      pkg_rq_size: 1024
-      pkg_wq_size: 512
-      tcp_read_timeout: "1s"
-      tcp_write_timeout: "5s"
-      wait_timeout: "1s"
-      max_msg_len: 1024000
-      session_name: "client"
diff --git a/registry/servicediscovery/consul/go-client/conf/log.yml b/registry/servicediscovery/consul/go-client/conf/log.yml
deleted file mode 100644
index 3ed242d2..00000000
--- a/registry/servicediscovery/consul/go-client/conf/log.yml
+++ /dev/null
@@ -1,28 +0,0 @@
-
-level: "debug"
-development: true
-disableCaller: false
-disableStacktrace: false
-sampling:
-encoding: "console"
-
-# encoder
-encoderConfig:
-  messageKey: "message"
-  levelKey: "level"
-  timeKey: "time"
-  nameKey: "logger"
-  callerKey: "caller"
-  stacktraceKey: "stacktrace"
-  lineEnding: ""
-  levelEncoder: "capitalColor"
-  timeEncoder: "iso8601"
-  durationEncoder: "seconds"
-  callerEncoder: "short"
-  nameEncoder: ""
-
-outputPaths:
-  - "stderr"
-errorOutputPaths:
-  - "stderr"
-initialFields:
diff --git a/registry/servicediscovery/consul/go-client/pkg/pojo/user.go b/registry/servicediscovery/consul/go-client/pkg/pojo/user.go
deleted file mode 100644
index d4a119da..00000000
--- a/registry/servicediscovery/consul/go-client/pkg/pojo/user.go
+++ /dev/null
@@ -1,42 +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 pojo
-
-import (
-	"context"
-	"time"
-)
-
-type User struct {
-	ID   string
-	Name string
-	Age  int32
-	Time time.Time
-}
-
-type UserProvider struct {
-	GetUser func(ctx context.Context, req []interface{}, rsp *User) error
-}
-
-func (u *UserProvider) Reference() string {
-	return "UserProvider"
-}
-
-func (User) JavaClassName() string {
-	return "com.ikurento.user.User"
-}
diff --git a/registry/servicediscovery/consul/go-server/cmd/server.go b/registry/servicediscovery/consul/go-server/cmd/server.go
deleted file mode 100644
index ffc58573..00000000
--- a/registry/servicediscovery/consul/go-server/cmd/server.go
+++ /dev/null
@@ -1,87 +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 main
-
-import (
-	"fmt"
-	"os"
-	"os/signal"
-	"syscall"
-	"time"
-)
-
-import (
-	hessian "github.com/apache/dubbo-go-hessian2"
-	_ "github.com/apache/dubbo-go/cluster/cluster_impl"
-	_ "github.com/apache/dubbo-go/cluster/loadbalance"
-	"github.com/apache/dubbo-go/common/logger"
-	_ "github.com/apache/dubbo-go/common/proxy/proxy_factory"
-	"github.com/apache/dubbo-go/config"
-	_ "github.com/apache/dubbo-go/filter/filter_impl"
-	_ "github.com/apache/dubbo-go/metadata/mapping/memory"
-	_ "github.com/apache/dubbo-go/metadata/report/consul"
-	_ "github.com/apache/dubbo-go/metadata/service/remote"
-	_ "github.com/apache/dubbo-go/protocol/dubbo"
-	_ "github.com/apache/dubbo-go/protocol/jsonrpc"
-	_ "github.com/apache/dubbo-go/registry/consul"
-	_ "github.com/apache/dubbo-go/registry/protocol"
-	_ "github.com/apache/dubbo-go/registry/servicediscovery"
-)
-
-import (
-	"github.com/apache/dubbo-go-samples/registry/servicediscovery/consul/go-server/pkg/pojo"
-)
-
-var (
-	survivalTimeout = int(3e9)
-)
-
-// they are necessary:
-// 		export CONF_PROVIDER_FILE_PATH="xxx"
-// 		export APP_LOG_CONF_FILE="xxx"
-func main() {
-
-	// ------for hessian2------
-	hessian.RegisterPOJO(&pojo.User{})
-	config.Load()
-
-	initSignal()
-}
-
-func initSignal() {
-	signals := make(chan os.Signal, 1)
-	// It is not possible to block SIGKILL or syscall.SIGSTOP
-	signal.Notify(signals, os.Interrupt, os.Kill, syscall.SIGHUP, syscall.SIGQUIT, syscall.SIGTERM, syscall.SIGINT)
-	for {
-		sig := <-signals
-		logger.Infof("get signal %s", sig.String())
-		switch sig {
-		case syscall.SIGHUP:
-			// reload()
-		default:
-			time.AfterFunc(time.Duration(survivalTimeout), func() {
-				logger.Warnf("app exit now by force...")
-				os.Exit(1)
-			})
-
-			// The program exits normally or timeout forcibly exits.
-			fmt.Println("provider app exit now...")
-			return
-		}
-	}
-}
diff --git a/registry/servicediscovery/consul/go-server/cmd/version.go b/registry/servicediscovery/consul/go-server/cmd/version.go
deleted file mode 100644
index ae51f45d..00000000
--- a/registry/servicediscovery/consul/go-server/cmd/version.go
+++ /dev/null
@@ -1,22 +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 main
-
-var (
-	Version = "2.7.5"
-)
diff --git a/registry/servicediscovery/consul/go-server/conf/client.yml b/registry/servicediscovery/consul/go-server/conf/client.yml
deleted file mode 100644
index 75175c81..00000000
--- a/registry/servicediscovery/consul/go-server/conf/client.yml
+++ /dev/null
@@ -1,77 +0,0 @@
-# dubbo client yaml configure file
-
-
-check: true
-# client
-request_timeout : "3s"
-# connect timeout
-connect_timeout : "3s"
-
-# application config
-application:
-  organization : "ikurento.com"
-  name  : "user-info-client"
-  module : "dubbogo user-info client"
-  version : "0.0.1"
-  owner : "ZX"
-  environment : "dev"
-
-
-registries:
-  "demoServiceDiscovery":
-    protocol: "service-discovery"
-    params:
-      service_discovery: "consul_dis"
-      name_mapping: "in-memory"
-      metadata: "default"
-
-remote:
-  consul1:
-    address: "127.0.0.1:8500"
-    timeout: "5s"
-
-metadata_report:
-  protocol: "consul"
-  remote_ref: "consul1"
-
-service_discovery:
-  consul_dis:
-    protocol: "consul"
-    remote_ref: "consul1"
-
-
-references:
-  "UserProvider":
-    # 可以指定多个registry,使用逗号隔开;不指定默认向所有注册中心注册
-    registry: "demoServiceDiscovery"
-    protocol : "dubbo"
-    provide_by: "UserInfoServer"
-    interface : "com.ikurento.user.UserProvider"
-    cluster: "failover"
-    methods :
-      - name: "GetUser"
-        retries: 3
-
-
-protocol_conf:
-  dubbo:
-    reconnect_interval: 0
-    connection_number: 1
-    heartbeat_period: "5s"
-    session_timeout: "180s"
-    pool_size: 64
-    pool_ttl: 600
-    getty_session_param:
-      compress_encoding: false
-      tcp_no_delay: true
-      tcp_keep_alive: true
-      keep_alive_period: "120s"
-      tcp_r_buf_size: 262144
-      tcp_w_buf_size: 65536
-      pkg_rq_size: 1024
-      pkg_wq_size: 512
-      tcp_read_timeout: "1s"
-      tcp_write_timeout: "5s"
-      wait_timeout: "1s"
-      max_msg_len: 1024000
-      session_name: "client"
diff --git a/registry/servicediscovery/consul/go-server/conf/log.yml b/registry/servicediscovery/consul/go-server/conf/log.yml
deleted file mode 100644
index 3ed242d2..00000000
--- a/registry/servicediscovery/consul/go-server/conf/log.yml
+++ /dev/null
@@ -1,28 +0,0 @@
-
-level: "debug"
-development: true
-disableCaller: false
-disableStacktrace: false
-sampling:
-encoding: "console"
-
-# encoder
-encoderConfig:
-  messageKey: "message"
-  levelKey: "level"
-  timeKey: "time"
-  nameKey: "logger"
-  callerKey: "caller"
-  stacktraceKey: "stacktrace"
-  lineEnding: ""
-  levelEncoder: "capitalColor"
-  timeEncoder: "iso8601"
-  durationEncoder: "seconds"
-  callerEncoder: "short"
-  nameEncoder: ""
-
-outputPaths:
-  - "stderr"
-errorOutputPaths:
-  - "stderr"
-initialFields:
diff --git a/registry/servicediscovery/consul/go-server/conf/server.yml b/registry/servicediscovery/consul/go-server/conf/server.yml
deleted file mode 100644
index 01525a52..00000000
--- a/registry/servicediscovery/consul/go-server/conf/server.yml
+++ /dev/null
@@ -1,74 +0,0 @@
-# dubbo server yaml configure file
-
-
-# application config
-application:
-  organization: "ikurento.com"
-  name: "UserInfoServer"
-  module: "dubbogo user-info server"
-  version: "0.0.1"
-  owner: "ZX"
-  environment: "dev"
-
-
-registries:
-  "demoServiceDiscovery":
-    protocol: "service-discovery"
-    params:
-      service_discovery: "consul-dis"
-      name_mapping: "in-memory"
-      metadata: "default"
-
-remote:
-  consul1:
-    address: "127.0.0.1:8500"
-    timeout: "5s"
-
-metadata_report:
-  protocol: "consul"
-  remote_ref: "consul1"
-
-service_discovery:
-  consul-dis:
-    protocol: "consul"
-    remote_ref: "consul1"
-
-services:
-  "UserProvider":
-    # 可以指定多个registry,使用逗号隔开;不指定默认向所有注册中心注册
-    registry: "demoServiceDiscovery"
-    protocol: "dubbo"
-    # 相当于dubbo.xml中的interface
-    interface: "com.ikurento.user.UserProvider"
-    loadbalance: "random"
-    warmup: "100"
-    cluster: "failover"
-    methods:
-      - name: "GetUser"
-        retries: 1
-        loadbalance: "random"
-
-protocols:
-  "dubbo":
-    name: "dubbo"
-    port: 20001
-
-
-protocol_conf:
-  dubbo:
-    session_number: 700
-    session_timeout: "180s"
-    getty_session_param:
-      compress_encoding: false
-      tcp_no_delay: true
-      tcp_keep_alive: true
-      keep_alive_period: "120s"
-      tcp_r_buf_size: 262144
-      tcp_w_buf_size: 65536
-      pkg_rq_size: 1024
-      pkg_wq_size: 512
-      tcp_read_timeout: "1s"
-      tcp_write_timeout: "5s"
-      wait_timeout: "1s"
-      max_msg_len: 1024000
-      session_name: "server"
diff --git a/registry/servicediscovery/consul/go-server/docker/docker-compose.yml b/registry/servicediscovery/consul/go-server/docker/docker-compose.yml
deleted file mode 100644
index 5f9a5b16..00000000
--- a/registry/servicediscovery/consul/go-server/docker/docker-compose.yml
+++ /dev/null
@@ -1,9 +0,0 @@
-version: '3'
-
-services:
-  consul:
-    image: consul:latest
-    ports:
-      - 8500:8500
-    restart: on-failure
-    command: agent -server -bind=0.0.0.0 -client=0.0.0.0 -node=consul_Server1 -bootstrap-expect=1 -ui
\ No newline at end of file
diff --git a/registry/servicediscovery/consul/go-server/pkg/pojo/user.go b/registry/servicediscovery/consul/go-server/pkg/pojo/user.go
deleted file mode 100644
index 4e594635..00000000
--- a/registry/servicediscovery/consul/go-server/pkg/pojo/user.go
+++ /dev/null
@@ -1,58 +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 pojo
-
-import (
-	"context"
-	"time"
-)
-
-import (
-	"github.com/apache/dubbo-go/config"
-
-	gxlog "github.com/dubbogo/gost/log"
-)
-
-func init() {
-	config.SetProviderService(new(UserProvider))
-}
-
-type User struct {
-	ID   string
-	Name string
-	Age  int32
-	Time time.Time
-}
-
-type UserProvider struct {
-}
-
-func (u *UserProvider) GetUser(ctx context.Context, req []interface{}) (*User, error) {
-	gxlog.CInfo("req: %v\n", req)
-	rsp := User{"A001", "Alex Stocks", 18, time.Now()}
-	gxlog.CInfo("rsp: %v\n", rsp)
-	return &rsp, nil
-}
-
-func (u *UserProvider) Reference() string {
-	return "UserProvider"
-}
-
-func (u User) JavaClassName() string {
-	return "com.ikurento.user.User"
-}
diff --git a/registry/servicediscovery/consul/go-server/tests/integration/main_test.go b/registry/servicediscovery/consul/go-server/tests/integration/main_test.go
deleted file mode 100644
index 88a7662e..00000000
--- a/registry/servicediscovery/consul/go-server/tests/integration/main_test.go
+++ /dev/null
@@ -1,75 +0,0 @@
-// +build integration
-
-/*
- * 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 integration
-
-import (
-	"context"
-	"os"
-	"testing"
-	"time"
-)
-
-import (
-	hessian "github.com/apache/dubbo-go-hessian2"
-	_ "github.com/apache/dubbo-go/cluster/cluster_impl"
-	_ "github.com/apache/dubbo-go/cluster/loadbalance"
-	_ "github.com/apache/dubbo-go/common/proxy/proxy_factory"
-	"github.com/apache/dubbo-go/config"
-	_ "github.com/apache/dubbo-go/filter/filter_impl"
-	_ "github.com/apache/dubbo-go/metadata/mapping/memory"
-	_ "github.com/apache/dubbo-go/metadata/report/consul"
-	_ "github.com/apache/dubbo-go/metadata/service/inmemory"
-	_ "github.com/apache/dubbo-go/metadata/service/remote"
-	_ "github.com/apache/dubbo-go/protocol/dubbo"
-	_ "github.com/apache/dubbo-go/protocol/jsonrpc"
-	_ "github.com/apache/dubbo-go/registry/consul"
-	_ "github.com/apache/dubbo-go/registry/protocol"
-	_ "github.com/apache/dubbo-go/registry/servicediscovery"
-)
-
-var userProvider = new(UserProvider)
-
-func TestMain(m *testing.M) {
-	config.SetConsumerService(userProvider)
-	hessian.RegisterPOJO(&User{})
-	config.Load()
-	time.Sleep(3 * time.Second)
-
-	os.Exit(m.Run())
-}
-
-type User struct {
-	ID   string
-	Name string
-	Age  int32
-	Time time.Time
-}
-
-type UserProvider struct {
-	GetUser func(ctx context.Context, req []interface{}, rsp *User) error
-}
-
-func (u *UserProvider) Reference() string {
-	return "UserProvider"
-}
-
-func (User) JavaClassName() string {
-	return "com.ikurento.user.User"
-}
diff --git a/registry/servicediscovery/consul/go-server/tests/integration/userprovider_test.go b/registry/servicediscovery/consul/go-server/tests/integration/userprovider_test.go
deleted file mode 100644
index 7183e644..00000000
--- a/registry/servicediscovery/consul/go-server/tests/integration/userprovider_test.go
+++ /dev/null
@@ -1,39 +0,0 @@
-// +build integration
-
-/*
- * 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 integration
-
-import (
-	"context"
-	"testing"
-)
-
-import (
-	"github.com/stretchr/testify/assert"
-)
-
-func TestGetUser(t *testing.T) {
-	user := &User{}
-	err := userProvider.GetUser(context.TODO(), []interface{}{"A001"}, user)
-	assert.Nil(t, err)
-	assert.Equal(t, "A001", user.ID)
-	assert.Equal(t, "Alex Stocks", user.Name)
-	assert.Equal(t, int32(18), user.Age)
-	assert.NotNil(t, user.Time)
-}