You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@apisix.apache.org by GitBox <gi...@apache.org> on 2021/02/09 02:58:06 UTC

[GitHub] [apisix-ingress-controller] lianghao208 opened a new pull request #252: feat: add support for Endpointslices

lianghao208 opened a new pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252


   Please answer these questions before submitting a pull request
   
   - Why submit this pull request?
   - [ ] Bugfix
   - [X] New feature provided
   - [ ] Improve performance
   - [ ] Backport patches
   
   - Related issues
   
   #201 
   


----------------------------------------------------------------
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] [apisix-ingress-controller] lianghao208 commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
lianghao208 commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-784142518


   @tokers 
   I haven't figured out a proper way to add e2e test case yet . To enable and disable endpointSlice feature, it needs to run on different versions of minikube, which needs to modify the github workflow, any suggestions?


----------------------------------------------------------------
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] [apisix-ingress-controller] tokers commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-784144189


   > @tokers
   > I haven't figured out a proper way to add e2e test case yet . To enable and disable endpointSlice feature, it needs to run on different versions of minikube, which needs to modify the github workflow, any suggestions?
   
   Just add another workflow with different minikube version, own test cases about endpointSlices will be run under this minikube, while in the normal environment, cases about endpointSlices should be skipped, you can check out the ginkgo help documents about how to skip or focus on specific test cases.


----------------------------------------------------------------
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] [apisix-ingress-controller] gxthrj closed pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
gxthrj closed pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252


   


-- 
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] [apisix-ingress-controller] lianghao208 removed a comment on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
lianghao208 removed a comment on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-781775007


   /retest


----------------------------------------------------------------
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] [apisix-ingress-controller] lianghao208 commented on a change in pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
lianghao208 commented on a change in pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#discussion_r572657698



##########
File path: pkg/ingress/controller/controller.go
##########
@@ -126,20 +123,28 @@ func NewController(cfg *config.Config) (*Controller, error) {
 		crdInformerFactory: sharedInformerFactory,
 		watchingNamespace:  watchingNamespace,
 
-		epInformer:             kube.CoreSharedInformerFactory.Core().V1().Endpoints().Informer(),
-		epLister:               kube.CoreSharedInformerFactory.Core().V1().Endpoints().Lister(),
 		svcInformer:            kube.CoreSharedInformerFactory.Core().V1().Services().Informer(),
 		svcLister:              kube.CoreSharedInformerFactory.Core().V1().Services().Lister(),
 		apisixUpstreamInformer: sharedInformerFactory.Apisix().V1().ApisixUpstreams().Informer(),
 		apisixUpstreamLister:   sharedInformerFactory.Apisix().V1().ApisixUpstreams().Lister(),
 	}
-	c.translator = kube.NewTranslator(&kube.TranslatorOptions{
-		EndpointsLister:      c.epLister,
-		ServiceLister:        c.svcLister,
-		ApisixUpstreamLister: c.apisixUpstreamLister,
-	})
 
-	c.endpointsController = c.newEndpointsController()
+	if c.cfg.EnableEndpointSlice {

Review comment:
       refer to: https://kubernetes.io/docs/tasks/administer-cluster/enabling-endpointslices/
   To determine whether Kubernetes cluster supports the EndpointsSlice resource, some checks needed to be done.
   - kubernetes version
   - whether endpointslice feature gate is enabled
   




----------------------------------------------------------------
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] [apisix-ingress-controller] tokers commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-783918896


   @lianghao208 Any updates?


----------------------------------------------------------------
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] [apisix-ingress-controller] tokers commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-775745311


   @lianghao208 PR is good to me, but we need some e2e cases to cover 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.

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



[GitHub] [apisix-ingress-controller] tokers commented on a change in pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on a change in pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#discussion_r572623095



##########
File path: conf/config-default.yaml
##########
@@ -30,6 +30,7 @@ log_output: "stderr" # the output file path of error log, default is stderr, whe
 http_listen: ":8080"   # the HTTP Server listen address, default is ":8080"
 enable_profiling: true # enable profileing via web interfaces
                        # host:port/debug/pprof, default is true.
+enable_endpointslice: false # enable endpointSlice support, default is false

Review comment:
       Missing a period `.`.

##########
File path: pkg/ingress/controller/endpointslice.go
##########
@@ -0,0 +1,251 @@
+// 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 controller
+
+import (
+	"context"
+
+	"go.uber.org/zap"
+	discoveryv1beta1 "k8s.io/api/discovery/v1beta1"
+	k8serrors "k8s.io/apimachinery/pkg/api/errors"
+	"k8s.io/client-go/tools/cache"
+	"k8s.io/client-go/util/workqueue"
+
+	"github.com/apache/apisix-ingress-controller/pkg/apisix"
+	apisixcache "github.com/apache/apisix-ingress-controller/pkg/apisix/cache"
+	"github.com/apache/apisix-ingress-controller/pkg/kube"
+	"github.com/apache/apisix-ingress-controller/pkg/log"
+	"github.com/apache/apisix-ingress-controller/pkg/seven/state"
+	"github.com/apache/apisix-ingress-controller/pkg/types"
+	apisixv1 "github.com/apache/apisix-ingress-controller/pkg/types/apisix/v1"
+)
+
+type endpointSliceController struct {
+	controller *Controller
+	workqueue  workqueue.RateLimitingInterface
+	workers    int
+	epInformer cache.SharedIndexInformer
+}
+
+func (c *Controller) newEndpointSliceController() *endpointSliceController {
+	ctl := &endpointSliceController{
+		controller: c,
+		workqueue:  workqueue.NewNamedRateLimitingQueue(workqueue.DefaultControllerRateLimiter(), "endpointslice"),
+		workers:    1,
+		epInformer: kube.CoreSharedInformerFactory.Discovery().V1beta1().EndpointSlices().Informer(),
+	}
+
+	ctl.epInformer.AddEventHandler(
+		cache.ResourceEventHandlerFuncs{
+			AddFunc:    ctl.onAdd,
+			UpdateFunc: ctl.onUpdate,
+			DeleteFunc: ctl.onDelete,
+		},
+	)
+
+	return ctl
+}
+
+func (c *endpointSliceController) run(ctx context.Context) {
+	log.Info("endpointslice controller started")
+	defer log.Info("endpointslice controller exited")
+
+	if ok := cache.WaitForCacheSync(ctx.Done(), c.epInformer.HasSynced); !ok {
+		log.Error("informers sync failed")
+		return
+	}
+
+	handler := func() {
+		for {
+			obj, shutdown := c.workqueue.Get()
+			if shutdown {
+				return
+			}
+
+			err := c.sync(ctx, obj.(*types.Event))
+			c.workqueue.Done(obj)
+			c.handleSyncErr(obj, err)
+		}
+	}
+
+	for i := 0; i < c.workers; i++ {
+		go handler()
+	}
+
+	<-ctx.Done()
+	c.workqueue.ShutDown()
+}
+
+func (c *endpointSliceController) sync(ctx context.Context, ev *types.Event) error {
+	ep := ev.Object.(*discoveryv1beta1.EndpointSlice)
+	svc, err := c.controller.svcLister.Services(ep.Namespace).Get(ep.Name)
+	if err != nil {
+		if k8serrors.IsNotFound(err) {
+			log.Warnf("service %s/%s was deleted", ep.Namespace, ep.Name)
+			return nil
+		}
+		log.Errorf("failed to get service %s/%s: %s", ep.Namespace, ep.Name, err)
+		return err
+	}
+	portMap := make(map[string]int32)
+	for _, port := range svc.Spec.Ports {
+		portMap[port.Name] = port.Port
+	}
+	clusters := c.controller.apisix.ListClusters()
+	for _, port := range ep.Ports {
+		svcPort, ok := portMap[*port.Name]
+		if !ok {
+			// This shouldn't happen.
+			log.Errorf("port %s in endpointslice %s/%s but not in service", *port.Name, ep.Namespace, ep.Name)
+			continue
+		}
+		nodes, err := c.controller.translator.TranslateUpstreamNodesFromEndpointSlice(ep, svcPort)
+		if err != nil {
+			log.Errorw("failed to translate upstream nodes",
+				zap.Error(err),
+				zap.Any("endpointslice", ep),
+				zap.Int32("port", svcPort),
+			)

Review comment:
       It seems we should return `err` here since error occurred. The same logic in endpoints controller should also be changed.

##########
File path: conf/config-default.yaml
##########
@@ -30,6 +30,7 @@ log_output: "stderr" # the output file path of error log, default is stderr, whe
 http_listen: ":8080"   # the HTTP Server listen address, default is ":8080"
 enable_profiling: true # enable profileing via web interfaces
                        # host:port/debug/pprof, default is true.
+enable_endpointslice: false # enable endpointSlice support, default is false

Review comment:
       What about putting this option to `kubernetes` section?

##########
File path: pkg/ingress/controller/controller.go
##########
@@ -126,20 +123,28 @@ func NewController(cfg *config.Config) (*Controller, error) {
 		crdInformerFactory: sharedInformerFactory,
 		watchingNamespace:  watchingNamespace,
 
-		epInformer:             kube.CoreSharedInformerFactory.Core().V1().Endpoints().Informer(),
-		epLister:               kube.CoreSharedInformerFactory.Core().V1().Endpoints().Lister(),
 		svcInformer:            kube.CoreSharedInformerFactory.Core().V1().Services().Informer(),
 		svcLister:              kube.CoreSharedInformerFactory.Core().V1().Services().Lister(),
 		apisixUpstreamInformer: sharedInformerFactory.Apisix().V1().ApisixUpstreams().Informer(),
 		apisixUpstreamLister:   sharedInformerFactory.Apisix().V1().ApisixUpstreams().Lister(),
 	}
-	c.translator = kube.NewTranslator(&kube.TranslatorOptions{
-		EndpointsLister:      c.epLister,
-		ServiceLister:        c.svcLister,
-		ApisixUpstreamLister: c.apisixUpstreamLister,
-	})
 
-	c.endpointsController = c.newEndpointsController()
+	if c.cfg.EnableEndpointSlice {

Review comment:
       We should whether the running Kubernetes cluster supports the EndpointsSlice resource, if not, Ingress controller shouldn't launch.

##########
File path: pkg/kube/translator.go
##########
@@ -120,17 +136,42 @@ func (t *translator) TranslateUpstreamConfig(au *configv1.ApisixUpstreamConfig)
 }
 
 func (t *translator) TranslateUpstream(namespace, name string, port int32) (*apisixv1.Upstream, error) {
-	endpoints, err := t.EndpointsLister.Endpoints(namespace).Get(name)
-	if err != nil {
+	var endpoints *corev1.Endpoints
+	var endpointSlice *discoveryvibeta1.EndpointSlice
+	var nodes []apisixv1.UpstreamNode
+	var err error
+	switch t.EndpointMode {
+	case EndpointSliceOnly:
+		endpointSlice, err = CoreSharedInformerFactory.Discovery().V1beta1().EndpointSlices().Lister().EndpointSlices(namespace).Get(name)
+		if err != nil {
+			return nil, &translateError{
+				field:  "endpointslice",
+				reason: err.Error(),
+			}
+		}
+		nodes, err = t.TranslateUpstreamNodesFromEndpointSlice(endpointSlice, port)
+		if err != nil {
+			return nil, err
+		}
+	case EndpointsOnly:
+		endpoints, err = CoreSharedInformerFactory.Core().V1().Endpoints().Lister().Endpoints(namespace).Get(name)
+		if err != nil {
+			return nil, &translateError{
+				field:  "endpoints",
+				reason: err.Error(),
+			}
+		}
+		nodes, err = t.TranslateUpstreamNodes(endpoints, port)
+		if err != nil {
+			return nil, err
+		}
+	default:

Review comment:
       Just panic is OK, since we never should have other EndpointMode value.

##########
File path: pkg/kube/translator.go
##########
@@ -120,17 +136,42 @@ func (t *translator) TranslateUpstreamConfig(au *configv1.ApisixUpstreamConfig)
 }
 
 func (t *translator) TranslateUpstream(namespace, name string, port int32) (*apisixv1.Upstream, error) {
-	endpoints, err := t.EndpointsLister.Endpoints(namespace).Get(name)
-	if err != nil {
+	var endpoints *corev1.Endpoints
+	var endpointSlice *discoveryvibeta1.EndpointSlice
+	var nodes []apisixv1.UpstreamNode
+	var err error

Review comment:
       Use `var` block instead of multiple single line `var` statements.
   ```suggestion
   	var (
   	    endpoints *corev1.Endpoints
   	    endpointSlice *discoveryvibeta1.EndpointSlice
   	    nodes []apisixv1.UpstreamNode
   	    err error
   	)
   ```
   
   

##########
File path: pkg/kube/translator.go
##########
@@ -56,7 +60,8 @@ type Translator interface {
 // TranslatorOptions contains options to help Translator
 // work well.
 type TranslatorOptions struct {
-	EndpointsLister      listerscorev1.EndpointsLister
+	// EndpointMode decides what source to use to get endpoint information

Review comment:
       what => which, it's object clauses.

##########
File path: pkg/kube/translator.go
##########
@@ -18,6 +18,7 @@ import (
 	"fmt"
 
 	corev1 "k8s.io/api/core/v1"
+	discoveryvibeta1 "k8s.io/api/discovery/v1beta1"

Review comment:
       Typo name, should be `discoveryv1beta1 `.




----------------------------------------------------------------
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] [apisix-ingress-controller] lianghao208 commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
lianghao208 commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-775645682


   @tokers @membphis PTAL, thanks!


----------------------------------------------------------------
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] [apisix-ingress-controller] tokers commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-799374815


   Ping @lianghao208 


----------------------------------------------------------------
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] [apisix-ingress-controller] gxthrj commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
gxthrj commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-799308400


   Need to due with some Conflicting files. @lianghao208 


----------------------------------------------------------------
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] [apisix-ingress-controller] codecov-io commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
codecov-io commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-784693208


   # [Codecov](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=h1) Report
   > Merging [#252](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=desc) (5a55ab8) into [master](https://codecov.io/gh/apache/apisix-ingress-controller/commit/fe68c79cefcabca07bf43354c7b9577d962e1650?el=desc) (fe68c79) will **increase** coverage by `48.34%`.
   > The diff coverage is `n/a`.
   
   [![Impacted file tree graph](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/graphs/tree.svg?width=650&height=150&src=pr&token=WPLQXPY3V0)](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=tree)
   
   ```diff
   @@             Coverage Diff              @@
   ##           master      #252       +/-   ##
   ============================================
   + Coverage   51.65%   100.00%   +48.34%     
   ============================================
     Files          34         1       -33     
     Lines        2358         1     -2357     
   ============================================
   - Hits         1218         1     -1217     
   + Misses        982         0      -982     
   + Partials      158         0      -158     
   ```
   
   
   | [Impacted Files](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=tree) | Coverage Δ | |
   |---|---|---|
   | [pkg/apisix/service.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2FwaXNpeC9zZXJ2aWNlLmdv) | | |
   | [pkg/api/server.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2FwaS9zZXJ2ZXIuZ28=) | | |
   | [pkg/apisix/apisix.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2FwaXNpeC9hcGlzaXguZ28=) | | |
   | [pkg/version/version.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL3ZlcnNpb24vdmVyc2lvbi5nbw==) | | |
   | [pkg/api/router/router.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2FwaS9yb3V0ZXIvcm91dGVyLmdv) | | |
   | [pkg/apisix/nonexistentclient.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2FwaXNpeC9ub25leGlzdGVudGNsaWVudC5nbw==) | | |
   | [pkg/seven/state/service\_worker.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL3NldmVuL3N0YXRlL3NlcnZpY2Vfd29ya2VyLmdv) | | |
   | [pkg/ingress/apisix/plugin.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2luZ3Jlc3MvYXBpc2l4L3BsdWdpbi5nbw==) | | |
   | [pkg/id/idgen.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2lkL2lkZ2VuLmdv) | | |
   | [pkg/ingress/apisix/annotation.go](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree#diff-cGtnL2luZ3Jlc3MvYXBpc2l4L2Fubm90YXRpb24uZ28=) | | |
   | ... and [22 more](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252/diff?src=pr&el=tree-more) | |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=continue).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=footer). Last update [fe68c79...5a55ab8](https://codecov.io/gh/apache/apisix-ingress-controller/pull/252?src=pr&el=lastupdated). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments).
   


----------------------------------------------------------------
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] [apisix-ingress-controller] tokers commented on a change in pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
tokers commented on a change in pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#discussion_r572629442



##########
File path: pkg/ingress/controller/controller.go
##########
@@ -254,7 +259,7 @@ func (c *Controller) run(ctx context.Context) {
 	}
 
 	c.goAttach(func() {
-		c.epInformer.Run(ctx.Done())
+		c.endpointsController.getInformer().Run(ctx.Done())

Review comment:
       I'm not sure whether I have the correct understanding of this `endpointsController`, but seems it doesn't have big advantages here to abstract it except we can write less `if` and `else` branches.




----------------------------------------------------------------
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] [apisix-ingress-controller] lianghao208 commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
lianghao208 commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-781775007


   /retest


----------------------------------------------------------------
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] [apisix-ingress-controller] gxthrj commented on pull request #252: feat: add support for Endpointslices

Posted by GitBox <gi...@apache.org>.
gxthrj commented on pull request #252:
URL: https://github.com/apache/apisix-ingress-controller/pull/252#issuecomment-851955081


   Close stale PR, feel free to reopen.


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