You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@servicecomb.apache.org by GitBox <gi...@apache.org> on 2020/12/02 04:02:21 UTC

[GitHub] [servicecomb-service-center] DFSOrange opened a new pull request #771: [SCB-2094] implement mongo dumpcache interface

DFSOrange opened a new pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771


   
   


----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] DFSOrange commented on a change in pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
DFSOrange commented on a change in pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771#discussion_r534117257



##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)
+			return false
+		}
+		cache.Microservices = append(cache.Microservices, &dump.Microservice{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpServicePrefix, tmp.Domain, tmp.Project, tmp.ServiceInfo.ServiceId),
+				Rev:   0,
+				Value: tmp.ServiceInfo,
+			},
+			Value: tmp.ServiceInfo,
+		})
+	}
+	return true
+}
+
+func SetDumpInstances(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionInstance, bson.M{})
+	if err != nil {
+		log.Error("SetDumpInstances access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Instance
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpInstances decode failed", err)
+			return false
+		}
+		cache.Instances = append(cache.Instances, &dump.Instance{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpInstancePrefix, tmp.Domain, tmp.Project, tmp.InstanceInfo.ServiceId, tmp.InstanceInfo.InstanceId),

Review comment:
       这个system_util属于mongo下的实现,如果这样做可能看上去mongo依赖了etcd里的代码。

##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)

Review comment:
       etcd的这里只是更新缓存到cache中,没有类似和数据库的交互错误




----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] tianxiaoliang commented on a change in pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
tianxiaoliang commented on a change in pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771#discussion_r534106962



##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)
+			return false
+		}
+		cache.Microservices = append(cache.Microservices, &dump.Microservice{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpServicePrefix, tmp.Domain, tmp.Project, tmp.ServiceInfo.ServiceId),
+				Rev:   0,
+				Value: tmp.ServiceInfo,
+			},
+			Value: tmp.ServiceInfo,
+		})
+	}
+	return true
+}
+
+func SetDumpInstances(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionInstance, bson.M{})
+	if err != nil {
+		log.Error("SetDumpInstances access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Instance
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpInstances decode failed", err)
+			return false
+		}
+		cache.Instances = append(cache.Instances, &dump.Instance{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpInstancePrefix, tmp.Domain, tmp.Project, tmp.InstanceInfo.ServiceId, tmp.InstanceInfo.InstanceId),

Review comment:
       generatorDumpKey这个方法,应该和etcd实现调用同一个

##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"

Review comment:
       复用etcd同一个常量




----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] tianxiaoliang commented on pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
tianxiaoliang commented on pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771#issuecomment-737182333


   @DFSOrange @xzccfzy 各位请注意,全是这类问题,一定要保证,方法复用,最近频繁出类似代码,请提交前,再次思考,不要暴露相似问题


----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] tianxiaoliang commented on a change in pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
tianxiaoliang commented on a change in pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771#discussion_r534025853



##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)

Review comment:
       这些错误描述要和etcd实现统一




----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] DFSOrange commented on a change in pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
DFSOrange commented on a change in pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771#discussion_r535200944



##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)

Review comment:
       > 这些错误描述要和etcd实现统一
   
   etcd的这里只是更新缓存到cache中,没有类似和数据库的交互错误

##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)

Review comment:
       etcd的这里只是更新缓存到cache中,没有类似和数据库的交互错误

##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)
+			return false
+		}
+		cache.Microservices = append(cache.Microservices, &dump.Microservice{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpServicePrefix, tmp.Domain, tmp.Project, tmp.ServiceInfo.ServiceId),
+				Rev:   0,
+				Value: tmp.ServiceInfo,
+			},
+			Value: tmp.ServiceInfo,
+		})
+	}
+	return true
+}
+
+func SetDumpInstances(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionInstance, bson.M{})
+	if err != nil {
+		log.Error("SetDumpInstances access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Instance
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpInstances decode failed", err)
+			return false
+		}
+		cache.Instances = append(cache.Instances, &dump.Instance{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpInstancePrefix, tmp.Domain, tmp.Project, tmp.InstanceInfo.ServiceId, tmp.InstanceInfo.InstanceId),

Review comment:
       > generatorDumpKey这个方法,应该和etcd实现调用同一个
   
   这个system_util属于mongo下的实现,如果这样做可能看上去mongo依赖了etcd里的代码。

##########
File path: datasource/mongo/system_util.go
##########
@@ -0,0 +1,87 @@
+/*
+ * 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 mongo
+
+import (
+	"context"
+
+	"github.com/apache/servicecomb-service-center/datasource/mongo/client"
+	"github.com/apache/servicecomb-service-center/pkg/dump"
+	"github.com/apache/servicecomb-service-center/pkg/log"
+	"go.mongodb.org/mongo-driver/bson"
+
+	"strings"
+)
+
+const (
+	DumpServicePrefix  = "/cse-sr/ms/files"
+	DumpInstancePrefix = "/cse-sr/inst/files"
+)
+
+func SetDumpServices(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionService, bson.M{})
+	if err != nil {
+		log.Error("SetDumpServices access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Service
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpServices decode failed", err)
+			return false
+		}
+		cache.Microservices = append(cache.Microservices, &dump.Microservice{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpServicePrefix, tmp.Domain, tmp.Project, tmp.ServiceInfo.ServiceId),
+				Rev:   0,
+				Value: tmp.ServiceInfo,
+			},
+			Value: tmp.ServiceInfo,
+		})
+	}
+	return true
+}
+
+func SetDumpInstances(ctx context.Context, cache *dump.Cache) bool {
+	res, err := client.GetMongoClient().Find(ctx, CollectionInstance, bson.M{})
+	if err != nil {
+		log.Error("SetDumpInstances access mongo failed", err)
+		return false
+	}
+	for res.Next(ctx) {
+		var tmp *Instance
+		err := res.Decode(&tmp)
+		if err != nil {
+			log.Error("SetDumpInstances decode failed", err)
+			return false
+		}
+		cache.Instances = append(cache.Instances, &dump.Instance{
+			KV: &dump.KV{
+				Key:   generatorDumpKey(DumpInstancePrefix, tmp.Domain, tmp.Project, tmp.InstanceInfo.ServiceId, tmp.InstanceInfo.InstanceId),

Review comment:
       这个system_util属于mongo下的实现,如果这样做可能看上去mongo依赖了etcd里的代码。




----------------------------------------------------------------
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.

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



[GitHub] [servicecomb-service-center] DFSOrange closed pull request #771: [SCB-2094] implement mongo dumpcache interface

Posted by GitBox <gi...@apache.org>.
DFSOrange closed pull request #771:
URL: https://github.com/apache/servicecomb-service-center/pull/771


   


----------------------------------------------------------------
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.

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