You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@dubbo.apache.org by GitBox <gi...@apache.org> on 2021/11/21 08:52:16 UTC

[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin opened a new pull request #302: Ftr/triple

LaurenceLiZhixin opened a new pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302


   - Ftr: triple support 


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974845264


   @PhilYue As we discussed tonight, after server reflection is done, the `github.com/mercari/grpc-http-proxy` could be replaced


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974845264


   @PhilYue As we discussed tonight, after server reflection is done, the `grpc-http-proxy` could be replaced


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753795822



##########
File path: pkg/adapter/dubboregistry/registry/registry.go
##########
@@ -75,9 +77,18 @@ func GetRegistry(name string, regConfig model.Registry, listener common2.Registr
 }
 
 // CreateAPIConfig returns router.API struct base on the input
-func CreateAPIConfig(urlPattern string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
+func CreateAPIConfig(urlPattern, location string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
 	dboBackendConfig.Method = methodString

Review comment:
       What is the purpose for the input param named `location`?




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974845264


   @PhilYue As we discussed tonight, after server reflection is done, the `github.com/mercari/grpc-http-proxy` could be replaced


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753820091



##########
File path: pkg/config/api_config.go
##########
@@ -27,8 +27,11 @@ import (
 
 import (
 	fc "github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+
 	etcdv3 "github.com/dubbogo/gost/database/kv/etcd/v3"
+
 	perrors "github.com/pkg/errors"
+
 	"go.etcd.io/etcd/api/v3/mvccpb"
 )

Review comment:
       Those blank line kind of strange, isn't it ?




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r754282806



##########
File path: pkg/config/api_config.go
##########
@@ -27,8 +27,11 @@ import (
 
 import (
 	fc "github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+
 	etcdv3 "github.com/dubbogo/gost/database/kv/etcd/v3"
+
 	perrors "github.com/pkg/errors"
+
 	"go.etcd.io/etcd/api/v3/mvccpb"
 )

Review comment:
       Cai boss said follow the code formatting tool




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (51dccc8) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/5bef4853016d8bfb0da4db715ccc5480cbcde7a6?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (5bef485) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   > :exclamation: Current head 51dccc8 differs from pull request most recent head df355c1. Consider uploading reports for the commit df355c1 to get more accurate results
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [5bef485...df355c1](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-976159211


   @MasterKenway I guess this pr is able to be merged.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-975075000


   我今天搞下nacos 支持,以及负载均衡,还有上述问题。import 块的问题都是按照 import-formatter 来规范的,这块是否还有问题?
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] AlexStocks commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
AlexStocks commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r755708827



##########
File path: pkg/adapter/dubboregistry/registry/nacos/interface_listener.go
##########
@@ -0,0 +1,201 @@
+/*
+ * 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 nacos
+
+import (
+	"fmt"
+	"strings"
+	"sync"
+	"time"
+)
+
+import (
+	dubboCommon "dubbo.apache.org/dubbo-go/v3/common"
+	"dubbo.apache.org/dubbo-go/v3/common/constant"
+	dubboConfig "dubbo.apache.org/dubbo-go/v3/config"
+	dubboRegistry "dubbo.apache.org/dubbo-go/v3/registry"
+
+	"github.com/apache/dubbo-go/common"
+
+	"github.com/nacos-group/nacos-sdk-go/clients/naming_client"
+	"github.com/nacos-group/nacos-sdk-go/vo"
+)
+
+import (
+	common2 "github.com/apache/dubbo-go-pixiu/pkg/adapter/dubboregistry/common"
+	"github.com/apache/dubbo-go-pixiu/pkg/adapter/dubboregistry/registry"
+	"github.com/apache/dubbo-go-pixiu/pkg/adapter/dubboregistry/remoting/zookeeper"
+	"github.com/apache/dubbo-go-pixiu/pkg/logger"
+)
+
+const (
+	MaxFailTimes = 2
+	ConnDelay    = 3 * time.Second
+)
+
+var _ registry.Listener = new(nacosIntfListener)
+
+type nacosIntfListener struct {
+	exit                 chan struct{}
+	client               naming_client.INamingClient
+	reg                  *NacosRegistry
+	wg                   sync.WaitGroup
+	dubbogoNacosRegistry dubboRegistry.Registry
+	addr                 string
+	adapterListener      common2.RegistryEventListener
+}
+
+// newNacosIntfListener returns a new nacosIntfListener with pre-defined path according to the registered type.
+func newNacosIntfListener(client naming_client.INamingClient, addr string, reg *NacosRegistry, adapterListener common2.RegistryEventListener) registry.Listener {
+	return &nacosIntfListener{
+		exit:            make(chan struct{}),
+		client:          client,
+		reg:             reg,
+		addr:            addr,
+		adapterListener: adapterListener,
+	}
+}
+
+func (z *nacosIntfListener) Close() {
+	close(z.exit)
+	z.wg.Wait()
+}
+
+func (z *nacosIntfListener) WatchAndHandle() {
+	var err error
+	z.dubbogoNacosRegistry, err = dubboConfig.NewRegistryConfigBuilder().
+		SetProtocol("nacos").
+		SetAddress(z.addr).
+		Build().GetInstance(common.CONSUMER)
+	if err != nil {
+		logger.Errorf("create nacos registry with address = %s error = %s", z.addr, err)
+		return
+	}
+	z.wg.Add(1)
+	go z.watch()
+}
+
+func (z *nacosIntfListener) watch() {
+	defer z.wg.Done()
+	var (
+		failTimes  int64 = 0
+		delayTimer       = time.NewTimer(ConnDelay * time.Duration(failTimes))
+	)
+	defer delayTimer.Stop()
+	for {
+		serviceList, err := z.client.GetAllServicesInfo(vo.GetAllServiceInfoParam{
+			PageSize: 100,
+		})
+		// error handling
+		if err != nil {
+			failTimes++
+			logger.Infof("watching nacos interface with error{%v}", err)
+			// Exit the watch if root node is in error
+			if err == zookeeper.ErrNilNode {
+				logger.Errorf("watching nacos services got errNilNode,so exit listen")
+				return
+			}
+			if failTimes > MaxFailTimes {
+				logger.Errorf("Error happens on nacos exceed max fail times: %s,so exit listen", MaxFailTimes)
+				return
+			}
+			delayTimer.Reset(ConnDelay * time.Duration(failTimes))
+			<-delayTimer.C
+			continue
+		}
+		failTimes = 0
+		if err := z.updateServiceList(serviceList.Doms); err != nil {
+			logger.Errorf("update service list failed %s", err)
+		}
+		time.Sleep(time.Second * 3)
+	}
+}
+
+type serviceInfo struct {
+	interfaceName string
+	version       string
+	group         string
+}
+
+func (s *serviceInfo) String() string {
+	return fmt.Sprintf("%s:%s:%s", s.interfaceName, s.version, s.group)
+}
+
+func fromServiceFullKey(fullKey string) *serviceInfo {
+	serviceInfoStrs := strings.Split(fullKey, ":")
+	if len(serviceInfoStrs) != 4 {
+		return nil
+	}
+	return &serviceInfo{
+		interfaceName: serviceInfoStrs[1],
+		version:       serviceInfoStrs[2],
+		group:         serviceInfoStrs[3],
+	}
+}
+
+func (z *nacosIntfListener) updateServiceList(serviceList []string) error {
+	// todo lock all svc listener
+
+	allSvcListener := z.reg.GetAllSvcListener()
+	subscribedServiceKeysMap := make(map[string]bool)
+	for k := range allSvcListener {
+		subscribedServiceKeysMap[k] = true
+	}
+	serviceNeedUpdate := make([]*serviceInfo, 0)

Review comment:
       make([]*serviceInfo, 0) 后面加这个 0 毫无意义




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (62cfd65) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/d1930df3e910c5f948380c703fbbce4f49490d2d?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (d1930df) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   > :exclamation: Current head 62cfd65 differs from pull request most recent head cdb6f1d. Consider uploading reports for the commit cdb6f1d to get more accurate results
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [d1930df...cdb6f1d](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (72c17ba) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/ec68432b71b733a1d87b7a182ded2004fed073d9?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (ec68432) will **decrease** coverage by `0.02%`.
   > The diff coverage is `0.00%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.98%   33.96%   -0.03%     
   ===========================================
     Files           61       61              
     Lines         3160     3162       +2     
   ===========================================
     Hits          1074     1074              
   - Misses        1974     1976       +2     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/model/cluster.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL21vZGVsL2NsdXN0ZXIuZ28=) | `0.00% <ø> (ø)` | |
   | ... and [3 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [ec68432...72c17ba](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753934161



##########
File path: pkg/adapter/dubboregistry/registry/registry.go
##########
@@ -75,9 +77,18 @@ func GetRegistry(name string, regConfig model.Registry, listener common2.Registr
 }
 
 // CreateAPIConfig returns router.API struct base on the input
-func CreateAPIConfig(urlPattern string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
+func CreateAPIConfig(urlPattern, location string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
 	dboBackendConfig.Method = methodString

Review comment:
       对于自动生成 api config 的场景,在adaptor层已经拿到了provider 的全量信息,完全可以拿出来provider的地址作为api config的一部分,在下面协议层调用时,无需再次服务发现,只做负载均衡即可。
   负载均衡也可以在 adaptor 层和协议层之间,以filter 的形式来做。 @MasterKenway 




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-976159211


   @MasterKenway The ci is queued? how to run it?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (7790be6) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/d1930df3e910c5f948380c703fbbce4f49490d2d?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (d1930df) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [d1930df...7790be6](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (1d3c525) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/ec68432b71b733a1d87b7a182ded2004fed073d9?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (ec68432) will **decrease** coverage by `0.02%`.
   > The diff coverage is `0.00%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.98%   33.96%   -0.03%     
   ===========================================
     Files           61       61              
     Lines         3160     3162       +2     
   ===========================================
     Hits          1074     1074              
   - Misses        1974     1976       +2     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/model/cluster.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL21vZGVsL2NsdXN0ZXIuZ28=) | `0.00% <ø> (ø)` | |
   | ... and [3 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [ec68432...1d3c525](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753795822



##########
File path: pkg/adapter/dubboregistry/registry/registry.go
##########
@@ -75,9 +77,18 @@ func GetRegistry(name string, regConfig model.Registry, listener common2.Registr
 }
 
 // CreateAPIConfig returns router.API struct base on the input
-func CreateAPIConfig(urlPattern string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
+func CreateAPIConfig(urlPattern, location string, dboBackendConfig config.DubboBackendConfig, methodString string, mappingParams []config.MappingParam) router.API {
 	dboBackendConfig.Method = methodString

Review comment:
       What is the purpose for the input param named `location`?

##########
File path: pkg/client/triple/triple.go
##########
@@ -0,0 +1,93 @@
+/*
+ * 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 triple
+
+import (
+	"context"
+	"io/ioutil"
+	"net/url"
+	"strings"
+	"sync"
+)
+
+import (
+	proxymeta "github.com/mercari/grpc-http-proxy/metadata"
+	"github.com/mercari/grpc-http-proxy/proxy"
+)
+
+import (
+	"github.com/apache/dubbo-go-pixiu/pkg/client"
+)
+
+// InitDefaultTripleClient init default dubbo client
+func InitDefaultTripleClient() {
+	tripleClient = NewTripleClient()
+}
+
+var tripleClient *Client
+var clientOnc sync.Once
+
+// NewTripleClient create dubbo client
+func NewTripleClient() *Client {
+	clientOnc.Do(func() {
+		tripleClient = &Client{}
+	})
+	return tripleClient
+}
+
+// Client client to generic invoke dubbo
+type Client struct {
+}
+
+func (tc *Client) Apply() error {
+	panic("implement me")
+}
+
+func (tc *Client) MapParams(req *client.Request) (reqData interface{}, err error) {
+	panic("implement me")
+}
+
+// Close clear GenericServicePool.
+func (dc *Client) Close() error {
+	return nil
+}
+
+// SingletonTripleClient singleton dubbo clent
+func SingletonTripleClient() *Client {
+	return NewTripleClient()
+}
+
+// Call invoke service
+func (dc *Client) Call(req *client.Request) (res interface{}, err error) {
+	address := strings.Split(req.API.IntegrationRequest.HTTPBackendConfig.URL, ":")
+	p := proxy.NewProxy()
+	targetURL := &url.URL{
+		Scheme: address[0],
+		Opaque: address[1],
+	}
+	if err := p.Connect(context.Background(), targetURL); err != nil {
+		panic(err)
+	}
+	meta := make(map[string][]string)
+	reqData, _ := ioutil.ReadAll(req.IngressRequest.Body)
+	call, err := p.Call(context.Background(), req.API.Method.IntegrationRequest.Interface, req.API.Method.IntegrationRequest.Method, reqData, (*proxymeta.Metadata)(&meta))
+	if err != nil {
+		panic(err)
+	}

Review comment:
       panic here?

##########
File path: pkg/config/api_config.go
##########
@@ -27,8 +27,11 @@ import (
 
 import (
 	fc "github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+
 	etcdv3 "github.com/dubbogo/gost/database/kv/etcd/v3"
+
 	perrors "github.com/pkg/errors"
+
 	"go.etcd.io/etcd/api/v3/mvccpb"
 )

Review comment:
       Those blank line kind of strange, isn't it ?

##########
File path: pkg/server/api_config_manager.go
##########
@@ -22,13 +22,14 @@ import (
 )
 
 import (
+	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/router"
+
 	"github.com/pkg/errors"
 )
 
 import (
 	"github.com/apache/dubbo-go-pixiu/pkg/model"
-	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
-	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/router"
 )
 

Review comment:
       Imports here is not correct as well




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (72c17ba) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/ec68432b71b733a1d87b7a182ded2004fed073d9?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (ec68432) will **decrease** coverage by `0.02%`.
   > The diff coverage is `0.00%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.98%   33.96%   -0.03%     
   ===========================================
     Files           61       61              
     Lines         3160     3162       +2     
   ===========================================
     Hits          1074     1074              
   - Misses        1974     1976       +2     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/model/cluster.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL21vZGVsL2NsdXN0ZXIuZ28=) | `0.00% <ø> (ø)` | |
   | ... and [3 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [ec68432...72c17ba](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (cdb6f1d) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/d1930df3e910c5f948380c703fbbce4f49490d2d?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (d1930df) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   > :exclamation: Current head cdb6f1d differs from pull request most recent head 7790be6. Consider uploading reports for the commit 7790be6 to get more accurate results
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [d1930df...7790be6](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r754773888



##########
File path: pkg/client/triple/triple.go
##########
@@ -0,0 +1,93 @@
+/*
+ * 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 triple
+
+import (
+	"context"
+	"io/ioutil"
+	"net/url"
+	"strings"
+	"sync"
+)
+
+import (
+	proxymeta "github.com/mercari/grpc-http-proxy/metadata"
+	"github.com/mercari/grpc-http-proxy/proxy"
+)
+
+import (
+	"github.com/apache/dubbo-go-pixiu/pkg/client"
+)
+
+// InitDefaultTripleClient init default dubbo client
+func InitDefaultTripleClient() {
+	tripleClient = NewTripleClient()
+}
+
+var tripleClient *Client
+var clientOnc sync.Once
+
+// NewTripleClient create dubbo client
+func NewTripleClient() *Client {
+	clientOnc.Do(func() {
+		tripleClient = &Client{}
+	})
+	return tripleClient
+}
+
+// Client client to generic invoke dubbo
+type Client struct {
+}
+
+func (tc *Client) Apply() error {
+	panic("implement me")
+}
+
+func (tc *Client) MapParams(req *client.Request) (reqData interface{}, err error) {
+	panic("implement me")
+}
+
+// Close clear GenericServicePool.
+func (dc *Client) Close() error {
+	return nil
+}
+
+// SingletonTripleClient singleton dubbo clent
+func SingletonTripleClient() *Client {
+	return NewTripleClient()
+}
+
+// Call invoke service
+func (dc *Client) Call(req *client.Request) (res interface{}, err error) {
+	address := strings.Split(req.API.IntegrationRequest.HTTPBackendConfig.URL, ":")
+	p := proxy.NewProxy()
+	targetURL := &url.URL{
+		Scheme: address[0],
+		Opaque: address[1],
+	}
+	if err := p.Connect(context.Background(), targetURL); err != nil {
+		panic(err)
+	}
+	meta := make(map[string][]string)
+	reqData, _ := ioutil.ReadAll(req.IngressRequest.Body)
+	call, err := p.Call(context.Background(), req.API.Method.IntegrationRequest.Interface, req.API.Method.IntegrationRequest.Method, reqData, (*proxymeta.Metadata)(&meta))
+	if err != nil {
+		panic(err)
+	}

Review comment:
       fixed




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] mark4z commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
mark4z commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r754223764



##########
File path: pkg/config/api_config.go
##########
@@ -27,8 +27,11 @@ import (
 
 import (
 	fc "github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+
 	etcdv3 "github.com/dubbogo/gost/database/kv/etcd/v3"
+
 	perrors "github.com/pkg/errors"
+
 	"go.etcd.io/etcd/api/v3/mvccpb"
 )

Review comment:
       > Those blank line kind of strange, isn't it ?
   
   +1




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] AlexStocks commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
AlexStocks commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r755710227



##########
File path: pkg/client/triple/triple.go
##########
@@ -0,0 +1,95 @@
+/*
+ * 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 triple
+
+import (
+	"context"
+	"io/ioutil"
+	"net/url"
+	"strings"
+	"sync"
+)
+
+import (
+	proxymeta "github.com/mercari/grpc-http-proxy/metadata"
+	"github.com/mercari/grpc-http-proxy/proxy"
+
+	"github.com/pkg/errors"
+)
+
+import (
+	"github.com/apache/dubbo-go-pixiu/pkg/client"
+)
+
+// InitDefaultTripleClient init default dubbo client
+func InitDefaultTripleClient() {
+	tripleClient = NewTripleClient()
+}
+
+var tripleClient *Client

Review comment:
       第一个 clientOnc 贼难看,写全称吧 clientOnce
   第二,var block
   var (
   tripleClient *Client
   clientOnce sync.Once
   )




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863






-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974845264


   @PhilYue As we discussed tonight, after server reflection is done, the `grpc-http-proxy` could be replaced


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] LaurenceLiZhixin commented on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
LaurenceLiZhixin commented on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-975075000


   我今天搞下nacos 支持,以及负载均衡,还有上述问题


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (df355c1) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/5bef4853016d8bfb0da4db715ccc5480cbcde7a6?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (5bef485) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [5bef485...df355c1](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] AlexStocks merged pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
AlexStocks merged pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (72c17ba) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/ec68432b71b733a1d87b7a182ded2004fed073d9?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (ec68432) will **decrease** coverage by `0.02%`.
   > The diff coverage is `0.00%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.98%   33.96%   -0.03%     
   ===========================================
     Files           61       61              
     Lines         3160     3162       +2     
   ===========================================
     Hits          1074     1074              
   - Misses        1974     1976       +2     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/model/cluster.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL21vZGVsL2NsdXN0ZXIuZ28=) | `0.00% <ø> (ø)` | |
   | ... and [3 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [ec68432...72c17ba](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] codecov-commenter edited a comment on pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
codecov-commenter edited a comment on pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#issuecomment-974780863


   # [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#302](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (86dd20b) into [develop](https://codecov.io/gh/apache/dubbo-go-pixiu/commit/5bef4853016d8bfb0da4db715ccc5480cbcde7a6?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (5bef485) will **decrease** coverage by `0.22%`.
   > The diff coverage is `14.28%`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/graphs/tree.svg?width=650&height=150&src=pr&token=NM3dY2xLkL&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   
   ```diff
   @@             Coverage Diff             @@
   ##           develop     #302      +/-   ##
   ===========================================
   - Coverage    33.93%   33.70%   -0.23%     
   ===========================================
     Files           61       61              
     Lines         3165     3198      +33     
   ===========================================
   + Hits          1074     1078       +4     
   - Misses        1979     2008      +29     
     Partials       112      112              
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...egistry/registry/zookeeper/application\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fbGlzdGVuZXIuZ28=) | `0.00% <ø> (ø)` | |
   | [...registry/zookeeper/application\_service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvYXBwbGljYXRpb25fc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [...oregistry/registry/zookeeper/interface\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvaW50ZXJmYWNlX2xpc3RlbmVyLmdv) | `10.00% <ø> (ø)` | |
   | [...apter/dubboregistry/registry/zookeeper/registry.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvcmVnaXN0cnkuZ28=) | `47.50% <ø> (ø)` | |
   | [...bboregistry/registry/zookeeper/service\_listener.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2FkYXB0ZXIvZHViYm9yZWdpc3RyeS9yZWdpc3RyeS96b29rZWVwZXIvc2VydmljZV9saXN0ZW5lci5nbw==) | `0.00% <0.00%> (ø)` | |
   | [pkg/client/dubbo/dubbo.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9kdWJiby9kdWJiby5nbw==) | `20.00% <0.00%> (-0.28%)` | :arrow_down: |
   | [pkg/client/http/http.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NsaWVudC9odHRwL2h0dHAuZ28=) | `42.16% <ø> (ø)` | |
   | [pkg/config/api\_config.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9hcGlfY29uZmlnLmdv) | `3.13% <ø> (ø)` | |
   | [pkg/config/config\_load.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2NvbmZpZy9jb25maWdfbG9hZC5nbw==) | `68.81% <ø> (ø)` | |
   | [pkg/filter/http/apiconfig/api/discovery\_service.go](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-cGtnL2ZpbHRlci9odHRwL2FwaWNvbmZpZy9hcGkvZGlzY292ZXJ5X3NlcnZpY2UuZ28=) | `41.40% <0.00%> (-1.00%)` | :arrow_down: |
   | ... and [5 more](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302/diff?src=pr&el=tree-more&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [5bef485...86dd20b](https://codecov.io/gh/apache/dubbo-go-pixiu/pull/302?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753820281



##########
File path: pkg/server/api_config_manager.go
##########
@@ -22,13 +22,14 @@ import (
 )
 
 import (
+	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
+	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/router"
+
 	"github.com/pkg/errors"
 )
 
 import (
 	"github.com/apache/dubbo-go-pixiu/pkg/model"
-	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/api/config"
-	"github.com/dubbogo/dubbo-go-pixiu-filter/pkg/router"
 )
 

Review comment:
       Imports here is not correct as well




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org


[GitHub] [dubbo-go-pixiu] MasterKenway commented on a change in pull request #302: Ftr/triple

Posted by GitBox <gi...@apache.org>.
MasterKenway commented on a change in pull request #302:
URL: https://github.com/apache/dubbo-go-pixiu/pull/302#discussion_r753796401



##########
File path: pkg/client/triple/triple.go
##########
@@ -0,0 +1,93 @@
+/*
+ * 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 triple
+
+import (
+	"context"
+	"io/ioutil"
+	"net/url"
+	"strings"
+	"sync"
+)
+
+import (
+	proxymeta "github.com/mercari/grpc-http-proxy/metadata"
+	"github.com/mercari/grpc-http-proxy/proxy"
+)
+
+import (
+	"github.com/apache/dubbo-go-pixiu/pkg/client"
+)
+
+// InitDefaultTripleClient init default dubbo client
+func InitDefaultTripleClient() {
+	tripleClient = NewTripleClient()
+}
+
+var tripleClient *Client
+var clientOnc sync.Once
+
+// NewTripleClient create dubbo client
+func NewTripleClient() *Client {
+	clientOnc.Do(func() {
+		tripleClient = &Client{}
+	})
+	return tripleClient
+}
+
+// Client client to generic invoke dubbo
+type Client struct {
+}
+
+func (tc *Client) Apply() error {
+	panic("implement me")
+}
+
+func (tc *Client) MapParams(req *client.Request) (reqData interface{}, err error) {
+	panic("implement me")
+}
+
+// Close clear GenericServicePool.
+func (dc *Client) Close() error {
+	return nil
+}
+
+// SingletonTripleClient singleton dubbo clent
+func SingletonTripleClient() *Client {
+	return NewTripleClient()
+}
+
+// Call invoke service
+func (dc *Client) Call(req *client.Request) (res interface{}, err error) {
+	address := strings.Split(req.API.IntegrationRequest.HTTPBackendConfig.URL, ":")
+	p := proxy.NewProxy()
+	targetURL := &url.URL{
+		Scheme: address[0],
+		Opaque: address[1],
+	}
+	if err := p.Connect(context.Background(), targetURL); err != nil {
+		panic(err)
+	}
+	meta := make(map[string][]string)
+	reqData, _ := ioutil.ReadAll(req.IngressRequest.Body)
+	call, err := p.Call(context.Background(), req.API.Method.IntegrationRequest.Interface, req.API.Method.IntegrationRequest.Method, reqData, (*proxymeta.Metadata)(&meta))
+	if err != nil {
+		panic(err)
+	}

Review comment:
       panic here?




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@dubbo.apache.org
For additional commands, e-mail: notifications-help@dubbo.apache.org