482 lines
		
	
	
		
			11 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			482 lines
		
	
	
		
			11 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
| // Package kubernetes implements kubernetes micro runtime
 | |
| package kubernetes
 | |
| 
 | |
| import (
 | |
| 	"fmt"
 | |
| 	"sync"
 | |
| 	"time"
 | |
| 
 | |
| 	"github.com/micro/go-micro/runtime"
 | |
| 	"github.com/micro/go-micro/runtime/kubernetes/client"
 | |
| 	"github.com/micro/go-micro/util/log"
 | |
| )
 | |
| 
 | |
| // action to take on runtime service
 | |
| type action int
 | |
| 
 | |
| const (
 | |
| 	start action = iota
 | |
| 	update
 | |
| 	stop
 | |
| )
 | |
| 
 | |
| // task is queued into runtime queue
 | |
| type task struct {
 | |
| 	action  action
 | |
| 	service *service
 | |
| }
 | |
| 
 | |
| type kubernetes struct {
 | |
| 	sync.RWMutex
 | |
| 	// options configure runtime
 | |
| 	options runtime.Options
 | |
| 	// indicates if we're running
 | |
| 	running bool
 | |
| 	// task queue for kubernetes services
 | |
| 	queue chan *task
 | |
| 	// used to stop the runtime
 | |
| 	closed chan bool
 | |
| 	// client is kubernetes client
 | |
| 	client client.Kubernetes
 | |
| }
 | |
| 
 | |
| // getService queries kubernetes for micro service
 | |
| // NOTE: this function is not thread-safe
 | |
| func (k *kubernetes) getService(labels map[string]string) ([]*runtime.Service, error) {
 | |
| 	// get the service status
 | |
| 	serviceList := new(client.ServiceList)
 | |
| 	r := &client.Resource{
 | |
| 		Kind:  "service",
 | |
| 		Value: serviceList,
 | |
| 	}
 | |
| 
 | |
| 	// get the service from k8s
 | |
| 	if err := k.client.Get(r, labels); err != nil {
 | |
| 		return nil, err
 | |
| 	}
 | |
| 
 | |
| 	// get the deployment status
 | |
| 	depList := new(client.DeploymentList)
 | |
| 	d := &client.Resource{
 | |
| 		Kind:  "deployment",
 | |
| 		Value: depList,
 | |
| 	}
 | |
| 
 | |
| 	// get the deployment from k8s
 | |
| 	if err := k.client.Get(d, labels); err != nil {
 | |
| 		return nil, err
 | |
| 	}
 | |
| 
 | |
| 	// service map
 | |
| 	svcMap := make(map[string]*runtime.Service)
 | |
| 
 | |
| 	// collect info from kubernetes service
 | |
| 	for _, kservice := range serviceList.Items {
 | |
| 		// name of the service
 | |
| 		name := kservice.Metadata.Labels["name"]
 | |
| 		// version of the service
 | |
| 		version := kservice.Metadata.Labels["version"]
 | |
| 
 | |
| 		// save as service
 | |
| 		svcMap[name+version] = &runtime.Service{
 | |
| 			Name:     name,
 | |
| 			Version:  version,
 | |
| 			Metadata: make(map[string]string),
 | |
| 		}
 | |
| 
 | |
| 		// copy annotations metadata into service metadata
 | |
| 		for k, v := range kservice.Metadata.Annotations {
 | |
| 			svcMap[name+version].Metadata[k] = v
 | |
| 		}
 | |
| 	}
 | |
| 
 | |
| 	// collect additional info from kubernetes deployment
 | |
| 	for _, kdep := range depList.Items {
 | |
| 		// name of the service
 | |
| 		name := kdep.Metadata.Labels["name"]
 | |
| 		// versio of the service
 | |
| 		version := kdep.Metadata.Labels["version"]
 | |
| 
 | |
| 		// access existing service map based on name + version
 | |
| 		if svc, ok := svcMap[name+version]; ok {
 | |
| 			// we're expecting our own service name in metadata
 | |
| 			if _, ok := kdep.Metadata.Annotations["name"]; !ok {
 | |
| 				continue
 | |
| 			}
 | |
| 
 | |
| 			// set the service name, version and source
 | |
| 			// based on existing annotations we stored
 | |
| 			svc.Name = kdep.Metadata.Annotations["name"]
 | |
| 			svc.Version = kdep.Metadata.Annotations["version"]
 | |
| 			svc.Source = kdep.Metadata.Annotations["source"]
 | |
| 
 | |
| 			// delete from metadata
 | |
| 			delete(kdep.Metadata.Annotations, "name")
 | |
| 			delete(kdep.Metadata.Annotations, "version")
 | |
| 			delete(kdep.Metadata.Annotations, "source")
 | |
| 
 | |
| 			// copy all annotations metadata into service metadata
 | |
| 			for k, v := range kdep.Metadata.Annotations {
 | |
| 				svc.Metadata[k] = v
 | |
| 			}
 | |
| 
 | |
| 			// parse out deployment status and inject into service metadata
 | |
| 			if len(kdep.Status.Conditions) > 0 {
 | |
| 				status := kdep.Status.Conditions[0].Type
 | |
| 				// pick the last known condition type and mark the service status with it
 | |
| 				log.Debugf("Runtime setting %s service deployment status: %v", name, status)
 | |
| 				svc.Metadata["status"] = status
 | |
| 			}
 | |
| 
 | |
| 			// parse out deployment build
 | |
| 			if build, ok := kdep.Spec.Template.Metadata.Annotations["build"]; ok {
 | |
| 				buildTime, err := time.Parse(time.RFC3339, build)
 | |
| 				if err != nil {
 | |
| 					log.Debugf("Runtime failed parsing build time for %s: %v", name, err)
 | |
| 					continue
 | |
| 				}
 | |
| 				svc.Metadata["build"] = fmt.Sprintf("%d", buildTime.Unix())
 | |
| 				continue
 | |
| 			}
 | |
| 			// if no build annotation is found, set it to current time
 | |
| 			svc.Metadata["build"] = fmt.Sprintf("%d", time.Now().Unix())
 | |
| 		}
 | |
| 	}
 | |
| 
 | |
| 	// collect all the services and return
 | |
| 	services := make([]*runtime.Service, 0, len(serviceList.Items))
 | |
| 
 | |
| 	for _, service := range svcMap {
 | |
| 		services = append(services, service)
 | |
| 	}
 | |
| 
 | |
| 	return services, nil
 | |
| }
 | |
| 
 | |
| // run runs the runtime management loop
 | |
| func (k *kubernetes) run(events <-chan runtime.Event) {
 | |
| 	t := time.NewTicker(time.Second * 10)
 | |
| 	defer t.Stop()
 | |
| 
 | |
| 	for {
 | |
| 		select {
 | |
| 		case <-t.C:
 | |
| 			// TODO: figure out what to do here
 | |
| 			// - do we even need the ticker for k8s services?
 | |
| 		case task := <-k.queue:
 | |
| 			// The task queue is used to take actions e.g (CRUD - R)
 | |
| 			switch task.action {
 | |
| 			case start:
 | |
| 				log.Debugf("Runtime starting new service: %s", task.service.Name)
 | |
| 				if err := task.service.Start(k.client); err != nil {
 | |
| 					log.Debugf("Runtime failed to start service %s: %v", task.service.Name, err)
 | |
| 					continue
 | |
| 				}
 | |
| 			case stop:
 | |
| 				log.Debugf("Runtime stopping service: %s", task.service.Name)
 | |
| 				if err := task.service.Stop(k.client); err != nil {
 | |
| 					log.Debugf("Runtime failed to stop service %s: %v", task.service.Name, err)
 | |
| 					continue
 | |
| 				}
 | |
| 			case update:
 | |
| 				log.Debugf("Runtime updating service: %s", task.service.Name)
 | |
| 				if err := task.service.Update(k.client); err != nil {
 | |
| 					log.Debugf("Runtime failed to update service %s: %v", task.service.Name, err)
 | |
| 					continue
 | |
| 				}
 | |
| 			default:
 | |
| 				log.Debugf("Runtime received unknown action for service: %s", task.service.Name)
 | |
| 			}
 | |
| 		case event := <-events:
 | |
| 			// NOTE: we only handle Update events for now
 | |
| 			log.Debugf("Runtime received notification event: %v", event)
 | |
| 			switch event.Type {
 | |
| 			case runtime.Update:
 | |
| 				// only process if there's an actual service
 | |
| 				// we do not update all the things individually
 | |
| 				if len(event.Service) == 0 {
 | |
| 					continue
 | |
| 				}
 | |
| 
 | |
| 				// format the name
 | |
| 				name := client.Format(event.Service)
 | |
| 
 | |
| 				// set the default labels
 | |
| 				labels := map[string]string{
 | |
| 					"micro": k.options.Type,
 | |
| 					"name":  name,
 | |
| 				}
 | |
| 
 | |
| 				if len(event.Version) > 0 {
 | |
| 					labels["version"] = event.Version
 | |
| 				}
 | |
| 
 | |
| 				// get the deployment status
 | |
| 				deployed := new(client.DeploymentList)
 | |
| 
 | |
| 				// get the existing service rather than creating a new one
 | |
| 				err := k.client.Get(&client.Resource{
 | |
| 					Kind:  "deployment",
 | |
| 					Value: deployed,
 | |
| 				}, labels)
 | |
| 
 | |
| 				if err != nil {
 | |
| 					log.Debugf("Runtime update failed to get service %s: %v", event.Service, err)
 | |
| 					continue
 | |
| 				}
 | |
| 
 | |
| 				// technically we should not receive multiple versions but hey ho
 | |
| 				for _, service := range deployed.Items {
 | |
| 					// check the name matches
 | |
| 					if service.Metadata.Name != name {
 | |
| 						continue
 | |
| 					}
 | |
| 
 | |
| 					// update build time annotation
 | |
| 					if service.Spec.Template.Metadata.Annotations == nil {
 | |
| 						service.Spec.Template.Metadata.Annotations = make(map[string]string)
 | |
| 
 | |
| 					}
 | |
| 
 | |
| 					// check the existing build timestamp
 | |
| 					if build, ok := service.Spec.Template.Metadata.Annotations["build"]; ok {
 | |
| 						buildTime, err := time.Parse(time.RFC3339, build)
 | |
| 						if err == nil && !event.Timestamp.After(buildTime) {
 | |
| 							continue
 | |
| 						}
 | |
| 					}
 | |
| 
 | |
| 					// update the build time
 | |
| 					service.Spec.Template.Metadata.Annotations["build"] = event.Timestamp.Format(time.RFC3339)
 | |
| 
 | |
| 					log.Debugf("Runtime updating service: %s deployment: %s", event.Service, service.Metadata.Name)
 | |
| 					if err := k.client.Update(deploymentResource(&service)); err != nil {
 | |
| 						log.Debugf("Runtime failed to update service %s: %v", event.Service, err)
 | |
| 						continue
 | |
| 					}
 | |
| 				}
 | |
| 			}
 | |
| 		case <-k.closed:
 | |
| 			log.Debugf("Runtime stopped")
 | |
| 			return
 | |
| 		}
 | |
| 	}
 | |
| }
 | |
| 
 | |
| // Init initializes runtime options
 | |
| func (k *kubernetes) Init(opts ...runtime.Option) error {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	for _, o := range opts {
 | |
| 		o(&k.options)
 | |
| 	}
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Creates a service
 | |
| func (k *kubernetes) Create(s *runtime.Service, opts ...runtime.CreateOption) error {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	options := runtime.CreateOptions{
 | |
| 		Type: k.options.Type,
 | |
| 	}
 | |
| 	for _, o := range opts {
 | |
| 		o(&options)
 | |
| 	}
 | |
| 
 | |
| 	// quickly prevalidate the name and version
 | |
| 	name := s.Name
 | |
| 	if len(s.Version) > 0 {
 | |
| 		name = name + "-" + s.Version
 | |
| 	}
 | |
| 
 | |
| 	// format as we'll format in the deployment
 | |
| 	name = client.Format(name)
 | |
| 
 | |
| 	// create new kubernetes micro service
 | |
| 	service := newService(s, options)
 | |
| 
 | |
| 	log.Debugf("Runtime queueing service %s version %s for start action", service.Name, service.Version)
 | |
| 
 | |
| 	// push into start queue
 | |
| 	k.queue <- &task{
 | |
| 		action:  start,
 | |
| 		service: service,
 | |
| 	}
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Read returns all instances of given service
 | |
| func (k *kubernetes) Read(opts ...runtime.ReadOption) ([]*runtime.Service, error) {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	// set the default labels
 | |
| 	labels := map[string]string{
 | |
| 		"micro": k.options.Type,
 | |
| 	}
 | |
| 
 | |
| 	var options runtime.ReadOptions
 | |
| 	for _, o := range opts {
 | |
| 		o(&options)
 | |
| 	}
 | |
| 
 | |
| 	if len(options.Service) > 0 {
 | |
| 		labels["name"] = client.Format(options.Service)
 | |
| 	}
 | |
| 
 | |
| 	// add version to labels if a version has been supplied
 | |
| 	if len(options.Version) > 0 {
 | |
| 		labels["version"] = options.Version
 | |
| 	}
 | |
| 
 | |
| 	if len(options.Type) > 0 {
 | |
| 		labels["micro"] = options.Type
 | |
| 	}
 | |
| 
 | |
| 	return k.getService(labels)
 | |
| }
 | |
| 
 | |
| // List the managed services
 | |
| func (k *kubernetes) List() ([]*runtime.Service, error) {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	labels := map[string]string{
 | |
| 		"micro": k.options.Type,
 | |
| 	}
 | |
| 
 | |
| 	log.Debugf("Runtime listing all micro services")
 | |
| 
 | |
| 	return k.getService(labels)
 | |
| }
 | |
| 
 | |
| // Update the service in place
 | |
| func (k *kubernetes) Update(s *runtime.Service) error {
 | |
| 	// create new kubernetes micro service
 | |
| 	service := newService(s, runtime.CreateOptions{
 | |
| 		Type: k.options.Type,
 | |
| 	})
 | |
| 
 | |
| 	// update build time annotation
 | |
| 	service.kdeploy.Spec.Template.Metadata.Annotations["build"] = time.Now().Format(time.RFC3339)
 | |
| 
 | |
| 	log.Debugf("Runtime queueing service %s for update action", service.Name)
 | |
| 
 | |
| 	// queue service for removal
 | |
| 	k.queue <- &task{
 | |
| 		action:  update,
 | |
| 		service: service,
 | |
| 	}
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Delete removes a service
 | |
| func (k *kubernetes) Delete(s *runtime.Service) error {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	// create new kubernetes micro service
 | |
| 	service := newService(s, runtime.CreateOptions{
 | |
| 		Type: k.options.Type,
 | |
| 	})
 | |
| 
 | |
| 	log.Debugf("Runtime queueing service %s for delete action", service.Name)
 | |
| 
 | |
| 	// queue service for removal
 | |
| 	k.queue <- &task{
 | |
| 		action:  stop,
 | |
| 		service: service,
 | |
| 	}
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Start starts the runtime
 | |
| func (k *kubernetes) Start() error {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	// already running
 | |
| 	if k.running {
 | |
| 		return nil
 | |
| 	}
 | |
| 
 | |
| 	// set running
 | |
| 	k.running = true
 | |
| 	k.closed = make(chan bool)
 | |
| 
 | |
| 	var events <-chan runtime.Event
 | |
| 	if k.options.Notifier != nil {
 | |
| 		var err error
 | |
| 		events, err = k.options.Notifier.Notify()
 | |
| 		if err != nil {
 | |
| 			// TODO: should we bail here?
 | |
| 			log.Debugf("Runtime failed to start update notifier")
 | |
| 		}
 | |
| 	}
 | |
| 
 | |
| 	go k.run(events)
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // Stop shuts down the runtime
 | |
| func (k *kubernetes) Stop() error {
 | |
| 	k.Lock()
 | |
| 	defer k.Unlock()
 | |
| 
 | |
| 	if !k.running {
 | |
| 		return nil
 | |
| 	}
 | |
| 
 | |
| 	select {
 | |
| 	case <-k.closed:
 | |
| 		return nil
 | |
| 	default:
 | |
| 		close(k.closed)
 | |
| 		// set not running
 | |
| 		k.running = false
 | |
| 		// stop the notifier too
 | |
| 		if k.options.Notifier != nil {
 | |
| 			return k.options.Notifier.Close()
 | |
| 		}
 | |
| 	}
 | |
| 
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| // String implements stringer interface
 | |
| func (k *kubernetes) String() string {
 | |
| 	return "kubernetes"
 | |
| }
 | |
| 
 | |
| // NewRuntime creates new kubernetes runtime
 | |
| func NewRuntime(opts ...runtime.Option) runtime.Runtime {
 | |
| 	// get default options
 | |
| 	options := runtime.Options{
 | |
| 		// Create labels with type "micro": "service"
 | |
| 		Type: "service",
 | |
| 	}
 | |
| 
 | |
| 	// apply requested options
 | |
| 	for _, o := range opts {
 | |
| 		o(&options)
 | |
| 	}
 | |
| 
 | |
| 	// kubernetes client
 | |
| 	client := client.NewClientInCluster()
 | |
| 
 | |
| 	return &kubernetes{
 | |
| 		options: options,
 | |
| 		closed:  make(chan bool),
 | |
| 		queue:   make(chan *task, 128),
 | |
| 		client:  client,
 | |
| 	}
 | |
| }
 |