Istio-配置规则监听分发原理

我们对于istio的操作基本上都是通过修改CRD资源来进行实现,无论是istio服务的配置(istiooperators.install.istio.io) 还是流量规则(virtualservices、serviceentries…)
接下来让我们走进源码去看看istio对资源是如何进行监听、转换并推送给envoy的.
下面是创建virtualservices资源后,istio对其进行响应流程图.

istio中的规则资源对应envoy中的配置是一对多的关系,也就是说istio中的一个规则可能对多个envoy配置有影响,比如Virtualservices规则就对Cluster、route这两个配置有影响

创建informer资源

既然istio采用informer的形式对资源进行监听,那么我们就看看它的创建方式
该方法由NewServer()->initControllers()->initConfigController调用

func (s *Server) initK8SConfigStore(args *PilotArgs) error {
   if s.kubeClient == nil {
      return nil
   }
   //为istio涉及的CRD资源创建informer并为其添加监听事件,
   //事件触发的方法存放在configController.handler中
   // 增删改事件 都调用同一个方法
   configController, err := s.makeKubeConfigController(args)
   if err != nil {
      return err
   }
  // 这里创建WorkloadEntry资源控制器,WorkloadEntry资源这里不过多介绍
  // 该控制器完成对WorkloadEntry节点的健康检查以及优雅关闭功能
   s.XDSServer.WorkloadEntryController = workloadentry.NewController(configController, args.PodName, args.KeepaliveOptions.MaxServerConnectionAge)
   return nil
}

让我们进入makeKubeConfigController

func (s *Server) makeKubeConfigController(args *PilotArgs) (model.ConfigStoreController, error) {
  // 通过这个名字我们应该就有了大概的猜测
   return crdclient.New(s.kubeClient, args.Revision, args.RegistryOptions.KubeOptions.DomainSuffix)
}
func New(client kube.Client, revision, domainSuffix string) (model.ConfigStoreController, error) {
  // 获取CRD资源的schemas,它实现了crd资源从gvk到gvr,gvr到gvk转换的功能
	schemas := collections.Pilot
	if features.EnableGatewayAPI {
		schemas = collections.PilotGatewayAPI
	}
	return NewForSchemas(client, revision, domainSuffix, schemas)
}

// 让我们看一下collections.PilotGatewayAPI里有什么
	PilotGatewayAPI = collection.NewSchemasBuilder().
			MustAdd(IstioExtensionsV1Alpha1Wasmplugins).
		MustAdd(IstioNetworkingV1Alpha3Destinationrules).
			MustAdd(IstioNetworkingV1Alpha3Envoyfilters).
			MustAdd(IstioNetworkingV1Alpha3Gateways).
			MustAdd(IstioNetworkingV1Alpha3Serviceentries).
			MustAdd(IstioNetworkingV1Alpha3Sidecars).
			MustAdd(IstioNetworkingV1Alpha3Virtualservices).
			MustAdd(IstioNetworkingV1Alpha3Workloadentries).
			MustAdd(IstioNetworkingV1Alpha3Workloadgroups).
			MustAdd(IstioNetworkingV1Beta1Proxyconfigs).
		MustAdd(IstioSecurityV1Beta1Authorizationpolicies).
		MustAdd(IstioSecurityV1Beta1Peerauthentications).
		MustAdd(IstioSecurityV1Beta1Requestauthentications).
			MustAdd(IstioTelemetryV1Alpha1Telemetries).
			MustAdd(K8SGatewayApiV1Alpha2Gatewayclasses).
			MustAdd(K8SGatewayApiV1Alpha2Gateways).
			MustAdd(K8SGatewayApiV1Alpha2Httproutes).
			MustAdd(K8SGatewayApiV1Alpha2Referencepolicies).
			MustAdd(K8SGatewayApiV1Alpha2Tcproutes).
			MustAdd(K8SGatewayApiV1Alpha2Tlsroutes).
			Build()

进入 NewForSchemas

func NewForSchemas(client kube.Client, revision, domainSuffix string, schemas collection.Schemas) (model.ConfigStoreController, error) {
   schemasByCRDName := map[string]collection.Schema{}
   for _, s := range schemas.All() {
      // From the spec: "Its name MUST be in the format <.spec.name>.<.spec.group>."
      name := fmt.Sprintf("%s.%s", s.Resource().Plural(), s.Resource().Group())
      schemasByCRDName[name] = s
   }
   out := &Client{
      domainSuffix:     domainSuffix,
      schemas:          schemas,
      schemasByCRDName: schemasByCRDName,
      revision:         revision,
      queue:            queue.NewQueue(1 * time.Second),
      kinds:            map[config.GroupVersionKind]*cacheHandler{},
     // 定义了informer事件处理方法,所有资源中的增删改事件都会遍历该方法调用
      handlers:         map[config.GroupVersionKind][]model.EventHandler{},
      client:           client,
      istioClient:      client.Istio(),
      gatewayAPIClient: client.GatewayAPI(),
      crdMetadataInformer: client.MetadataInformer().ForResource(collections.K8SApiextensionsK8SIoV1Customresourcedefinitions.Resource().
         GroupVersionResource()).Informer(),
      beginSync:   atomic.NewBool(false),
      initialSync: atomic.NewBool(false),
   }

  // 会获取当前集群中的所有CRD,用来判断当前资源是否在当前的集群中注册
   known, err := knownCRDs(client.Ext())
   for _, s := range schemas.All() {
      // From the spec: "Its name MUST be in the format <.spec.name>.<.spec.group>."
      name := fmt.Sprintf("%s.%s", s.Resource().Plural(), s.Resource().Group())
      crd := true
      if _, f := collections.Builtin.Find(s.Name().String()); f {
         crd = false
      }
     // 只要判断是CRD资源那么就为其创建informer
      if !crd {
         handleCRDAdd(out, name, nil)
      } else {
         if _, f := known[name]; f {
            handleCRDAdd(out, name, nil)
         } else {
            scope.Warnf("Skipping CRD %v as it is not present", s.Resource().GroupVersionKind())
         }
      }
   }

   return out, nil
}

接下来就到了我们本文的重点了informer的创建

func handleCRDAdd(cl *Client, name string, stop <-chan struct{}) {
   // 获取当前资源的schemas
   s, f := cl.schemasByCRDName[name]
   resourceGVK := s.Resource().GroupVersionKind()
   gvr := s.Resource().GroupVersionResource()

   cl.kindsMu.Lock()
   var i informers.GenericInformer
   var ifactory starter
   var err error
  // 这里对当前资源进行类型判断
   switch s.Resource().Group() {
    // 如果是gateway资源
   case gvk.KubernetesGateway.Group:
      ifactory = cl.client.GatewayAPIInformer()
      i, err = cl.client.GatewayAPIInformer().ForResource(gvr)
     // 如果是pod 等资源
   case gvk.Pod.Group, gvk.Deployment.Group, gvk.MutatingWebhookConfiguration.Group:
      ifactory = cl.client.KubeInformer()
      i, err = cl.client.KubeInformer().ForResource(gvr)
   case gvk.CustomResourceDefinition.Group:
      ifactory = cl.client.ExtInformer()
      i, err = cl.client.ExtInformer().ForResource(gvr)
   default:
     // 如果不是上面以上资源那么就是isito资源
      ifactory = cl.client.IstioInformer()
      i, err = cl.client.IstioInformer().ForResource(gvr)
   }

  // 光创建了informer还不够,我们还需要添加监听事件,这里我就不展开了
  // 原理很简单使用informer的AddEventHandler方法,添加监听事件方法
  // 增删改 都实现同一个方法,该方法里面循环调用了上面的handler方法
   cl.kinds[resourceGVK] = createCacheHandler(cl, s, i)
   if w, f := crdWatches[resourceGVK]; f {
      scope.Infof("notifying watchers %v was created", resourceGVK)
      w.once.Do(func() {
         close(w.stop)
      })
   }
   if stop != nil {
      // Start informer factory, only if stop is defined. In startup case, we will not start here as
      // we will start all factories once we are ready to initialize.
      // For dynamically added CRDs, we need to start immediately though
      ifactory.Start(stop)
   }
}

添加handler方法

既然最终调用的是handler方法,那我们就看看handler中都有什么
有些资源的handler可能与大部队不太一样,因为实现原理与功能不一样
Serviceentries、Workloadentries、Workloadgroups这三个资源主要目的是提供服务注册的功能,Serviceentries提供了外部服务的注册、Workloadentries提供了内部服务自动注册的功能。
其余资源都使用下面方法

configHandler := func(prev config.Config, curr config.Config, event model.Event) {
  // 判断事件类型 更新资源状态
   defer func() {
      if event != model.EventDelete {
         s.statusReporter.AddInProgressResource(curr)
      } else {
         s.statusReporter.DeleteInProgressResource(curr)
      }
   }()
   // 判断是否要发送更新请求
   if event == model.EventUpdate && !needsPush(prev, curr) {
      log.Debugf("skipping push for %s as spec has not changed", prev.Key())
      return
   }
  // 封装更新请求
   pushReq := &model.PushRequest{
      Full: true,
      ConfigsUpdated: map[model.ConfigKey]struct{}{{
         // 这里并没有将修改后的配置信息全部放进来
         // 会在配置生成时根据名称与命名空间进行查询
         Kind:      curr.GroupVersionKind,
         Name:      curr.Name,
         Namespace: curr.Namespace,
      }: {}},
      // 版本,标识当前请求包的用途,比如配置更新.
      Reason: []model.TriggerReason{model.ConfigUpdate},
   }
   s.XDSServer.ConfigUpdate(pushReq)
}

分发

XDSServer.ConfigUpdate主要目的是将当前资源转化为envoy识别的配置然后发送给每个envoy

让我们继续往下追踪

`func _(_s *DiscoveryServer_) _ConfigUpdate_(_req *model.PushRequest_) {
     // 用于审计使用
   inboundConfigUpdates.Increment()
   // 当前服务收到的配置更新的数量
   s.InboundUpdates.Inc_()
   // 将上面的pushReq结构体发送给pushChannel
   s.pushChannel <- req
}

管道?那么谁在监听管道那,我们可以猜想一下,这里肯定是由一个服务器进行处理,显而易见就是DescoveryServer服务器,那么在它的那个阶段监听那?必然是start阶段.

func (s *DiscoveryServer) Start(stopCh <-chan struct{}) {
   // 启动_WorkloadEntryController用于对注册的边车应用进行健康检查_
   go s.WorkloadEntryController.Run(topCh)
  //  这里做了一步优化,它会将时间段内大量的req进行合并成一个包发送出去
   go s.handleUpdates_(_stopCh_)   -> debounce(s.pushChannel, stopCh, s.debounceOptions, s.Push, s.CommittedUpdates)
   // 审计功能
   go s.periodicRefreshMetrics(stopCh)
  // 这里的功能就是,对配置信息进行生成通过stream分发出去
   go s.sendPushes(stopCh)   -> doSendPushes(stopCh, s.concurrentPushLimit, s.pushQueue)
}

让我们一一分析
s.handleUpdates

// 接下来istio进行了抖动分析等优化措施来避免全量分发
func debounce(ch chan *model.PushRequest, stopCh <-chan struct{}, opts debounceOptions, pushFn func(req *model.PushRequest), updateSent *atomic.Int64) {
    
    ...
    
	push := func(req *model.PushRequest, debouncedEvents int) {
        // 这里会调用初始化req操作
		pushFn(req)
		updateSent.Add(int64(debouncedEvents))
		freeCh <- struct{}{}
	}
    
    ....

	for {
		select {
		case <-freeCh:
			free = true
			pushWorker()
		case r := <-ch:
			// If reason is not set, record it as an unknown reason
			if len(r.Reason) == 0 {
				r.Reason = []model.TriggerReason{model.UnknownTrigger}
			}
			if !opts.enableEDSDebounce && !r.Full {
				// trigger push now, just for EDS
				go func(req *model.PushRequest) {
					pushFn(req)
					updateSent.Inc()
				}(r)
				continue
			}

			lastConfigUpdateTime = time.Now()
			if debouncedEvents == 0 {
				timeChan = time.After(opts.debounceAfter)
				startDebounce = lastConfigUpdateTime
			}
			debouncedEvents++

			req = req.Merge(r)
		case <-timeChan:
			if free {
				pushWorker()
			}
		case <-stopCh:
			return
		}
	}
}


func (s *DiscoveryServer) Push(req *model.PushRequest) {
    // 如果为false则进行增量更新,而不是完全推送
	if !req.Full {
		req.Push = s.globalPushContext()
		s.dropCacheForRequest(req)
		s.AdsPushAll(versionInfo(), req)
		return
	}
	// 这里会初始化上下文信息
	oldPushContext := s.globalPushContext()
	if oldPushContext != nil {
		oldPushContext.OnConfigChange()
		// Push the previous push Envoy metrics.
		envoyfilter.RecordMetrics()
	}
	// PushContext is reset after a config change. Previous status is
	// saved.
	t0 := time.Now()

	versionLocal := time.Now().Format(time.RFC3339) + "/" + strconv.FormatUint(versionNum.Inc(), 10)
	push, err := s.initPushContext(req, oldPushContext, versionLocal)
	if err != nil {
		return
	}
	initContextTime := time.Since(t0)
	log.Debugf("InitContext %v for push took %s", versionLocal, initContextTime)
	pushContextInitTime.Record(initContextTime.Seconds())

	versionMutex.Lock()
	version = versionLocal
	versionMutex.Unlock()

	req.Push = push
	s.AdsPushAll(versionLocal, req)
}


// to the model ConfigStorageCache and Controller.
func (s *DiscoveryServer) AdsPushAll(version string, req *model.PushRequest) {
    ...
	s.startPush(req)
}

// Send a signal to all connections, with a push event.
func (s *DiscoveryServer) startPush(req *model.PushRequest) {
    
	req.Start = time.Now()
    // 这里会获取所有的client,该值是在envoy节点注册到istio时创建的
    // 下一章将会讲解istio服务注册
	for _, p := range s.AllClients() {
        // 这里会将conn 与 req包放入队列
		s.pushQueue.Enqueue(p, req)
	}
}



s.sendPushes
这里我们可以看到最终又又又放入了一个队列当中,那么谁去从这个队列当中取数据那? s.sendPushes登场了

func doSendPushes(stopCh <-chan struct{}, semaphore chan struct{}, queue *PushQueue) {
	for {
		select {
		case <-stopCh:
			return
		default:
			// We can send to it until it is full, then it will block until a pushes finishes and reads from it.
			// This limits the number of pushes that can happen concurrently
			semaphore <- struct{}{}

			// 从队列当中获取值
			client, push, shuttingdown := queue.Dequeue()
            // 发送通知信息用于审计
			recordPushTriggers(push.Reason...)
			// Signals that a push is done by reading from the semaphore, allowing another send on it.
			doneFunc := func() {
				queue.MarkDone(client)
				<-semaphore
			}

			proxiesQueueTime.Record(time.Since(push.Start).Seconds())
			var closed <-chan struct{}
            //做一些defer
			if client.stream != nil {
				closed = client.stream.Context().Done()
			} else {
				closed = client.deltaStream.Context().Done()
			}
			go func() {
                //封装成一个事件
				pushEv := &Event{
					pushRequest: push,
                    // 资源关闭方法,严谨
					done:        doneFunc,
				}

				select {
                    传给 client的管道,那么这里说明会传给每个client的管道当中
				case client.pushChannel <- pushEv:
					return
				case <-closed: // grpc stream was closed
					doneFunc()
					log.Infof("Client closed connection %v", client.conID)
				}
			}()
		}
	}
}

那么又又又有谁去处理每个client的管道那?
这里我们需要了解一些超纲知识
:::info
服务注册,istio使用grpc将服务注册api暴露出来,envoy在注册的时候访问该api,isito获取到连接进行身份验证之后会创建两个A,B(假设)管道,A管道接收envoy向istio发送的数据 B接收istio向envoy发送的数据,而B就是我们上面看到的client.pushChannel
:::
下面是envoy注册istio方法

func (s *DiscoveryServer) Stream(stream DiscoveryStream) error {
	// 创建连接 istio对envoy数据传输采用的流传输
	con := newConnection(peerAddr, stream)

    // 接受数据并放入到管道当中,如果是第一次请求还会进行初始化操作,比如创建workloadentry资源
	go s.receive(con, ids)

	for {
		select {
        // 这里是接受envoy发送到istio的数据,一般是发现请求
		case req, ok := <-con.reqChan:
			if ok {
				if err := s.processRequest(req, con); err != nil {
					return err
				}
			} else {
				// Remote side closed connection or error processing the request.
				return <-con.errorChan
			}
        // 这里就是我们上面说道的B管道,isito发送给envoy的数据
		case pushEv := <-con.pushChannel:
            // 调用pushConnection,马上就要到达关键之处了!!!!!!!!!!!!!
			err := s.pushConnection(con, pushEv)
			pushEv.done()
			if err != nil {
				return err
			}
		case <-con.stop:
			return nil
		}
	}
}
func (s *DiscoveryServer) pushConnection(con *Connection, pushEv *Event) error {
    // 这里获取当前con关注的资源
    // 比如 con只关注了cluster  route规则(envoy里的规则),那么在生成代码时就只生成关于这两个的规则
    // 假设 wrl 有[cluster 、 route]两个规则
	wrl, ignoreEvents := con.pushDetails()
	for _, w := range wrl {
        // 那么这里就会根据这两个规则生成,然后下发给当前连接
		if err := s.pushXds(con, w, pushRequest); err != nil {
			return err
		}
	}

	return nil
}

istio中的规则资源对应envoy中的配置是一对多的关系,也就是说istio中的一个规则可能对多个envoy配置有影响,比如Virtualservices规则就对Cluster、route这两个配置有影响

下面是一个规则生成配置的简单图

让我们继续往里深入 pushXds

func (s *DiscoveryServer) pushXds(con *Connection, w *model.WatchedResource, req *model.PushRequest) error {
	if w == nil {
		return nil
	}
    // 根据类型获取生成器,比如根据cluster获取cluster的生成器
	gen := s.findGenerator(w.TypeUrl, con)
	if gen == nil {
		return nil
	}

	t0 := time.Now()
    // 将istio规则转化生成为envoy规则
	res, logdata, err := gen.Generate(con.proxy, w, req)
	resp := &discovery.DiscoveryResponse{
		ControlPlane: ControlPlane(),
		TypeUrl:      w.TypeUrl,
		// TODO: send different version for incremental eds
		VersionInfo: req.Push.PushVersion,
		Nonce:       nonce(req.Push.LedgerVersion),
		Resources:   model.ResourcesToAny(res),
	}

	configSize := ResourceSize(res)
	configSizeBytes.With(typeTag.Value(w.TypeUrl)).Record(float64(configSize))
    // 通过stream流传输发送当前数据	
	if err := con.send(resp); 

	return nil
}

  • 2
    点赞
  • 2
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值