From 76e8d668751341854482663e6166637d8693aa91 Mon Sep 17 00:00:00 2001 From: Mickael BOURNEUF Date: Fri, 28 Feb 2025 12:47:13 +0100 Subject: [PATCH] Modification sur la structure du cluster --- cmd/monitor/events/qemu.go | 209 +++++++++++--- cmd/monitor/events/server.go | 6 +- go.sum | 2 - pkg/api/domain/domain.go | 113 ++++---- pkg/api/domain/events.go | 110 +++++++- pkg/api/node.go | 44 --- pkg/api/node/node.go | 44 +++ pkg/api/proto/domain.pb.go | 261 ++++++++++-------- pkg/api/proto/domain.proto | 6 +- pkg/api/proto/node.pb.go | 105 ++++--- pkg/api/proto/node.proto | 12 +- pkg/api/proto/node_grpc.pb.go | 53 ++-- pkg/api/raft/node.go | 30 +- pkg/api/raft/schema.go | 4 +- pkg/api/raft/worker.go | 24 +- pkg/api/server.go | 4 +- pkg/schema/deevirt/domain.go | 12 + pkg/schema/deevirt/node.go | 10 + .../protobuf/types/known/emptypb/empty.pb.go | 150 ---------- vendor/modules.txt | 1 - 20 files changed, 674 insertions(+), 526 deletions(-) delete mode 100644 pkg/api/node.go create mode 100644 pkg/api/node/node.go create mode 100644 pkg/schema/deevirt/domain.go create mode 100644 pkg/schema/deevirt/node.go delete mode 100644 vendor/google.golang.org/protobuf/types/known/emptypb/empty.pb.go diff --git a/cmd/monitor/events/qemu.go b/cmd/monitor/events/qemu.go index e231698..6d7e5a2 100644 --- a/cmd/monitor/events/qemu.go +++ b/cmd/monitor/events/qemu.go @@ -1,52 +1,191 @@ package events import ( - "libvirt.org/go/libvirt" + "context" + "encoding/json" + "fmt" + "io" + "log" + "strings" + "time" + + "google.golang.org/grpc" + "google.golang.org/grpc/credentials/insecure" + "google.golang.org/protobuf/types/known/timestamppb" + go_libvirt "libvirt.org/go/libvirt" + + "deevirt.fr/compute/pkg/api/libvirt" + pb "deevirt.fr/compute/pkg/api/proto" + "deevirt.fr/compute/pkg/config" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" ) -type Qemu struct { - NodeID string - CompanyID string - DatacenterID string - Config []byte - DomainID string - State int - Event *libvirt.DomainQemuMonitorEvent +type qemu struct { + clientVirt *go_libvirt.Connect + config *config.Config + nodes deevirt_schema.NodeStore } -func QemuEvents(c *libvirt.Connect, d *libvirt.Domain, event *libvirt.DomainQemuMonitorEvent) { - /*var desc schema.Domain +func NewQemu(c *go_libvirt.Connect) qemu { config, _ := config.New() - ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second) + return qemu{ + clientVirt: c, + config: config, + } +} + +/* +Si l'hote est isolé, il faut impérativement arrêter les VMs. +*/ +func (q qemu) stonith(ctx context.Context) { + log.Printf("Perte de la communication avec les manager, procédure d'urgence enclenché.") + for { + select { + case <-ctx.Done(): + // Le service est de retour, on annule le stonith + log.Printf("L'accessibilité avec les manager est revenue, la procédure d'urgence est avortée.") + return + case <-time.After(10 * time.Second): + // On controle l'accessibilité des autres serveurs via libvirt, si un serveur est accessible, on peut supposer un problème avec le manager + for _, domData := range q.nodes { + _, err := libvirt.New(domData.IpManagement, q.config.LibvirtTLS) + if err == nil { + log.Printf("Au moins un noeud est joignable, la procédure d'urgence est avortée.") + return + } + } + + // Manager inaccessible et autres noeuds libvirt aussi + log.Printf("Urgence ! Arrêt de toutes les VMs en cours d'exécution") + doms, _ := q.clientVirt.ListAllDomains(go_libvirt.CONNECT_LIST_DOMAINS_ACTIVE | go_libvirt.CONNECT_LIST_DOMAINS_PAUSED) + for _, dom := range doms { + dom.Destroy() + } + } + } +} + +/* +On se connecte au manager afin d'envoyer une pulsation de disponibilité toutes les 1 secondes. +*/ +func (q qemu) heartbeat() { + var destroyCtx context.Context + var destroyCancel context.CancelFunc + + ctx, cancel := context.WithCancel(context.Background()) defer cancel() - domainID, _ := d.GetUUIDString() - xmlDesc, _ := d.GetXMLDesc(libvirt.DOMAIN_XML_INACTIVE) - state, _, _ := d.GetState() - err := xml.Unmarshal([]byte(xmlDesc), &desc) - if err != nil { - log.Fatalln(err) - } + var retryPolicy = `{ + "methodConfig": [{ + "retryPolicy": { + "MaxAttempts": 40, + "InitialBackoff": "1s", + "MaxBackoff": "10s", + "BackoffMultiplier": 1.0, + "retryableStatusCodes": ["UNAVAILABLE", "DEADLINE_EXCEEDED"] + }, + "waitForReady": true + }], + "loadBalancingConfig": [{ + "round_robin": {} + }] + }` - e, _ := json.Marshal(&Qemu{ - NodeID: config.NodeID, - CompanyID: desc.Metadata.DeevirtInstance.DeevirtCompanyID, - DatacenterID: desc.Metadata.DeevirtInstance.DeevirtDatacenterID, - Config: []byte(xmlDesc), - DomainID: domainID, - State: int(state), - Event: event, - }) - - conn, err := grpc.NewClient(strings.Join(config.Manager.Peers, ","), grpc.WithTransportCredentials(insecure.NewCredentials())) + conn, err := grpc.NewClient(strings.Join(q.config.Manager.Peers, ","), grpc.WithTransportCredentials(insecure.NewCredentials()), grpc.WithDefaultServiceConfig(retryPolicy)) if err != nil { - log.Fatalf("Erreur de connexion : %v", err) + fmt.Printf("%v", err) + return } defer conn.Close() - client := pb.NewDomainClient(conn) - client.Event(ctx, &pb.DomainEventRequest{ - Event: e, - })*/ + for { + client := pb.NewNodeClient(conn) + stream, err := client.Alive(ctx) + if err == nil { + go func() { + for { + resp, err := stream.Recv() + if err == io.EOF || err != nil { + log.Println("🔌 Connexion fermée par le serveur") + break + } else { + nodeStore := deevirt_schema.NodeStore{} + json.Unmarshal(resp.Nodes, &nodeStore) + q.nodes = nodeStore + } + } + }() + + for { + req := &pb.NodeAliveRequest{ + Timestamp: timestamppb.New(time.Now()), + } + + if err := stream.Send(req); err != nil { + if destroyCancel == nil { + destroyCtx, destroyCancel = context.WithTimeout(ctx, 10*time.Second) + go q.stonith(destroyCtx) + } + break + } + + if destroyCancel != nil { + destroyCancel() + destroyCancel = nil + } + + time.Sleep(10 * time.Second) + } + + } + + time.Sleep(1 * time.Second) + } + +} + +func (q qemu) lifecycle(c *go_libvirt.Connect, d *go_libvirt.Domain, event *go_libvirt.DomainEventLifecycle) { + if event.Event == go_libvirt.DOMAIN_EVENT_UNDEFINED { + // On ne s'intéresse pas à la suppression d'une configuration. Le manager est le seul point d'entré de valide ! + return + } + + fmt.Printf("%v\n", event) + ctx, cancel := context.WithTimeout(context.Background(), 10*time.Second) + defer cancel() + + domID, err := d.GetUUIDString() + if err != nil { + return + } + + domState, _, err := d.GetState() + if err != nil { + return + } + + res, err := json.Marshal(event) + if err != nil { + return + } + + conn, err := grpc.NewClient(strings.Join(q.config.Manager.Peers, ","), grpc.WithTransportCredentials(insecure.NewCredentials())) + if err != nil { + return + } + defer conn.Close() + + client := pb.NewDomainClient(conn) + client.Event(ctx, &pb.DomainEventRequest{ + NodeId: q.config.NodeID, + DomainId: domID, + Type: "DomainEventLifecycle", + State: int64(domState), + Event: res, + }) +} + +func (q qemu) Events() { + q.clientVirt.DomainEventLifecycleRegister(nil, q.lifecycle) } diff --git a/cmd/monitor/events/server.go b/cmd/monitor/events/server.go index d1d4990..b74f61e 100644 --- a/cmd/monitor/events/server.go +++ b/cmd/monitor/events/server.go @@ -22,7 +22,11 @@ func Server() { conn.SetKeepAlive(5, 3) - conn.DomainQemuMonitorEventRegister(nil, "(.*)", QemuEvents, libvirt.CONNECT_DOMAIN_QEMU_MONITOR_EVENT_REGISTER_REGEX) + q := NewQemu(conn) + q.Events() + go q.heartbeat() + + //conn.DomainQemuMonitorEventRegister(nil, "(.*)", QemuEvents, libvirt.CONNECT_DOMAIN_QEMU_MONITOR_EVENT_REGISTER_REGEX) for { libvirt.EventRunDefaultImpl() diff --git a/go.sum b/go.sum index ff4d679..d85de87 100644 --- a/go.sum +++ b/go.sum @@ -231,8 +231,6 @@ golang.org/x/net v0.0.0-20201021035429-f5854403a974/go.mod h1:sp8m0HH+o8qH0wwXwY golang.org/x/net v0.35.0 h1:T5GQRQb2y08kTAByq9L4/bz8cipCdA8FbRTXewonqY8= golang.org/x/net v0.35.0/go.mod h1:EglIi67kWsHKlRzzVMUD93VMSWGFOMSZgxFjparz1Qk= golang.org/x/oauth2 v0.0.0-20190226205417-e64efc72b421/go.mod h1:gOpvHmFTYa4IltrdGE7lF6nIHvwfUNPOp7c8zoXwtLw= -golang.org/x/oauth2 v0.26.0 h1:afQXWNNaeC4nvZ0Ed9XvCCzXM6UHJG7iCg0W4fPqSBE= -golang.org/x/oauth2 v0.26.0/go.mod h1:XYTD2NtWslqkgxebSiOHnXEap4TF09sJSc7H1sXbhtI= golang.org/x/oauth2 v0.27.0 h1:da9Vo7/tDv5RH/7nZDz1eMGS/q1Vv1N/7FCrBhI9I3M= golang.org/x/oauth2 v0.27.0/go.mod h1:onh5ek6nERTohokkhCD/y2cV4Do3fxFHFuAejCkRWT8= golang.org/x/sync v0.0.0-20181108010431-42b317875d0f/go.mod h1:RxMgew5VJxzue5/jJTE5uejpjVlOe/izrB70Jof72aM= diff --git a/pkg/api/domain/domain.go b/pkg/api/domain/domain.go index efad7fa..7c77d5d 100644 --- a/pkg/api/domain/domain.go +++ b/pkg/api/domain/domain.go @@ -5,7 +5,6 @@ import ( "encoding/json" "fmt" "log" - "regexp" "time" "go.uber.org/zap" @@ -17,6 +16,7 @@ import ( "deevirt.fr/compute/pkg/api/raft" "deevirt.fr/compute/pkg/config" "deevirt.fr/compute/pkg/scheduler" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" ) type Domain struct { @@ -27,7 +27,7 @@ type Domain struct { } func (d *Domain) connectNode(NodeId string) (*libvirt.Connect, error) { - var jCluster raft.NodeStore + var jCluster deevirt_schema.NodeStore cluster, _ := d.Store.Get("/etc/libvirt/cluster") json.Unmarshal(cluster, &jCluster) @@ -51,7 +51,7 @@ func (d *Domain) connectDomain(ctx context.Context, domainID string) (string, *l DomainId: domainID, }) - var jCluster raft.NodeStore + var jCluster deevirt_schema.NodeStore cluster, _ := d.Store.Get("/etc/libvirt/cluster") json.Unmarshal(cluster, &jCluster) @@ -61,58 +61,60 @@ func (d *Domain) connectDomain(ctx context.Context, domainID string) (string, *l } func (d *Domain) List(ctx context.Context, in *proto.DomainListAllRequest) (*proto.DomainListAllResponse, error) { - test, _ := d.Store.Ls("/etc/libvirt/qemu", raft.LsOptions{ - Recursive: true, + domainsListResponse := []*proto.DomainListResponse{} + + domains, err := d.Store.Ls("/etc/libvirt/domain", raft.LsOptions{ + Recursive: false, Data: true, }) + if err != nil { + return nil, status.Errorf(codes.Internal, "Error read a store %v", err) + } - domains := []*proto.DomainListResponse{} + for domId, data := range domains { + domData := deevirt_schema.DomainStore{} + json.Unmarshal(data, &domData) - for k, v := range test { - re := regexp.MustCompile("([^/]+)/([^/]+)") - matches := re.FindStringSubmatch(k) - if matches != nil { - var dStore raft.DomainStore - json.Unmarshal(v, &dStore) + nodeData, _ := d.Store.Get(fmt.Sprintf("/etc/libvirt/%s/%s/%s", domData.Type, domData.NodeId, domId)) + domNodeData := deevirt_schema.DomainToNodeStore{} + json.Unmarshal(nodeData, &domNodeData) - domains = append(domains, &proto.DomainListResponse{ - NodeId: matches[1], - DomainId: matches[2], - Config: dStore.Config, - State: int64(dStore.State), - }) - } + domainsListResponse = append(domainsListResponse, &proto.DomainListResponse{ + NodeId: domData.NodeId, + DomainId: domId, + Config: string(domData.Config), + State: int64(domNodeData.State), + }) } return &proto.DomainListAllResponse{ - Domains: domains, + Domains: domainsListResponse, }, nil } -func (d *Domain) Get(ctx context.Context, in *proto.DomainListRequest) (*proto.DomainListResponse, error) { - dom, _ := d.Store.Ls("/etc/libvirt/qemu", raft.LsOptions{ - Recursive: true, - Data: false, - }) +func (d *Domain) Get(ctx context.Context, req *proto.DomainListRequest) (*proto.DomainListResponse, error) { + domainsListResponse := proto.DomainListResponse{} - for k := range dom { - re := regexp.MustCompile("([^/]+)/([^/]+)") - matches := re.FindStringSubmatch(k) - if matches != nil && matches[2] == in.DomainId { - var dStore raft.DomainStore - data, _ := d.Store.Get(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", matches[1], matches[2])) - json.Unmarshal(data, &dStore) - - return &proto.DomainListResponse{ - NodeId: matches[1], - DomainId: matches[2], - Config: dStore.Config, - State: int64(dStore.State), - }, nil - } + domain, err := d.Store.Get(fmt.Sprintf("/etc/libvirt/domain/%s", req.DomainId)) + if err != nil { + return nil, status.Errorf(codes.Internal, "Error read a store %v", err) } - return &proto.DomainListResponse{}, nil + domData := deevirt_schema.DomainStore{} + json.Unmarshal(domain, &domData) + + nodeData, _ := d.Store.Get(fmt.Sprintf("/etc/libvirt/%s/%s/%s", domData.Type, domData.NodeId, req.DomainId)) + domNodeData := deevirt_schema.DomainToNodeStore{} + json.Unmarshal(nodeData, &domNodeData) + + domainsListResponse = proto.DomainListResponse{ + NodeId: domData.NodeId, + DomainId: req.DomainId, + Config: string(domData.Config), + State: int64(domNodeData.State), + } + + return &domainsListResponse, nil } func (d *Domain) Migrate(in *proto.DomainMigrateRequest, stream proto.Domain_MigrateServer) error { @@ -134,49 +136,40 @@ func (d *Domain) Migrate(in *proto.DomainMigrateRequest, stream proto.Domain_Mig return status.Errorf(codes.Internal, "Connexion error to libvirt %v", err) } - res, err := s.GetTopNode(1) + topNode, err := s.GetTopNode(1) if err != nil { return status.Errorf(codes.Internal, "Connexion error to libvirt %v", err) } + newNode := topNode[0] + + if nodeID == newNode.NodeID { + d.Logger.Sugar().Errorf("Attempt to migrate guest to the same host %v", newNode.NodeID) + return status.Errorf(codes.Internal, "Attempt to migrate guest to the same host %v", newNode.NodeID) + } ctx1, cancel := context.WithCancel(context.Background()) - ch := make(chan []byte) migrate := func(cancel context.CancelFunc) { defer cancel() - c_new, err := d.connectNode(res[0].NodeID) + c_new, err := d.connectNode(newNode.NodeID) if err != nil { + d.Store.Delete(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", newNode.NodeID, in.DomainId)) d.Logger.Sugar().Infof("Connexion error to libvirt %v", err.Error()) return } defer c_new.Close() - - new_dom, err := dom.Migrate(c_new, libvirt.MIGRATE_LIVE|libvirt.MIGRATE_PERSIST_DEST|libvirt.MIGRATE_UNDEFINE_SOURCE, "", "", 0) + _, err = dom.Migrate(c_new, libvirt.MIGRATE_LIVE|libvirt.MIGRATE_PERSIST_DEST|libvirt.MIGRATE_UNDEFINE_SOURCE, "", "", 0) if err != nil { d.Logger.Sugar().Infof("Migration error %v", err.Error()) return } - - newDomConfig, _ := new_dom.GetXMLDesc(libvirt.DOMAIN_XML_INACTIVE) - newDomState, _, _ := new_dom.GetState() - - new, _ := json.Marshal(raft.DomainStore{ - Config: newDomConfig, - State: int(newDomState), - Migrate: false, - }) - - ch <- new } go migrate(cancel) for { select { - case result := <-ch: - d.Store.Set(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", res[0].NodeID, in.DomainId), result) - d.Store.Delete(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", nodeID, in.DomainId)) case <-ctx1.Done(): return nil default: diff --git a/pkg/api/domain/events.go b/pkg/api/domain/events.go index 3e14720..26252a5 100644 --- a/pkg/api/domain/events.go +++ b/pkg/api/domain/events.go @@ -2,24 +2,114 @@ package domain import ( "context" + "encoding/json" + "encoding/xml" + "fmt" + "log" + "strings" + "deevirt.fr/compute/pkg/amqp" "deevirt.fr/compute/pkg/api/proto" + "deevirt.fr/compute/pkg/schema" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" "libvirt.org/go/libvirt" ) -type Events struct { - NodeID string - CompanyID string - DatacenterID string - Config []byte - DomainID string - State int - Event *libvirt.DomainQemuMonitorEvent -} - type EventsDetail map[string]string +func (d *Domain) domainEventLifecycle(nodeId string, domainId string, state int64, event *libvirt.DomainEventLifecycle) { + d.Logger.Sugar().Infof("%s => %s: Evènement %v", nodeId, domainId, event) + + domStore := deevirt_schema.DomainStore{} + domData, err := d.Store.Get(fmt.Sprintf("/etc/libvirt/domain/%s", domainId)) + if err != nil || len(domData) == 0 { + d.Logger.Sugar().Errorf("Critique !!, la VM %s n'existe pas ou comporte une erreur importante !", domainId) + } + json.Unmarshal(domData, &domStore) + + switch event.Event { + case libvirt.DOMAIN_EVENT_DEFINED: + // Changement de noeud ! + oldNodeId := strings.Clone(domStore.NodeId) + dom2node, _ := json.Marshal(deevirt_schema.DomainToNodeStore{ + State: int(state), + }) + d.Store.Set(fmt.Sprintf("/etc/libvirt/domain/qemu/%s/%s", nodeId, domainId), dom2node) + + domStore.NodeId = nodeId + dom2store, _ := json.Marshal(domStore) + d.Store.Set(fmt.Sprintf("/etc/libvirt/domain/%s", domainId), dom2store) + + println(oldNodeId) + + d.Store.Delete(fmt.Sprintf("/etc/libvirt/domain/qemu/%s/%s", oldNodeId, domainId)) + case libvirt.DOMAIN_EVENT_STARTED: + switch event.Detail { + case int(libvirt.DOMAIN_EVENT_STARTED_MIGRATED): + // On ne fait rien, migration en cours + return + } + case libvirt.DOMAIN_EVENT_SUSPENDED: + switch event.Detail { + case int(libvirt.DOMAIN_EVENT_SUSPENDED_MIGRATED): + // On ne fait rien, migration en cours + return + } + case libvirt.DOMAIN_EVENT_RESUMED: + switch event.Detail { + case int(libvirt.DOMAIN_EVENT_RESUMED_MIGRATED): + // On ne fait rien, migration en cours + return + } + } + + // MAJ de l'état + nodeData, _ := d.Store.Get(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", nodeId, domainId)) + domNodeData := deevirt_schema.DomainToNodeStore{} + json.Unmarshal(nodeData, &domNodeData) + + domNodeData.State = int(state) + dom2node, _ := json.Marshal(domNodeData) + d.Store.Set(fmt.Sprintf("/etc/libvirt/domain/qemu/%s/%s", nodeId, domainId), dom2node) + + // AMQP - On envoi l'évènement brut + e, _ := json.Marshal(struct { + Type string + State int + }{ + Type: "DomainState", + State: int(state), + }) + + desc := schema.Domain{} + err = xml.Unmarshal([]byte(domStore.Config), &desc) + if err != nil { + log.Fatalln(err) + } + a, _ := amqp.NewAMQP() + a.Publisher("vmcenter", + "events."+desc.Metadata.DeevirtInstance.DeevirtCompanyID+ + "."+desc.Metadata.DeevirtInstance.DeevirtDatacenterID+ + "."+domainId, + e) + defer a.Close() +} + func (d *Domain) Event(ctx context.Context, req *proto.DomainEventRequest) (*proto.DomainEventResponse, error) { + switch req.Type { + case "DomainEventLifecycle": + event := libvirt.DomainEventLifecycle{} + if json.Unmarshal(req.Event, &event) == nil { + d.domainEventLifecycle(req.NodeId, req.DomainId, req.State, &event) + } + } + + /*events := Events{ + NodeID: req.DomainId, + DomainID: req.DomainId, + Event: e, + }*/ + /*var events Events err := json.Unmarshal(req.Event, &events) diff --git a/pkg/api/node.go b/pkg/api/node.go deleted file mode 100644 index 8d9c07c..0000000 --- a/pkg/api/node.go +++ /dev/null @@ -1,44 +0,0 @@ -package api - -import ( - "context" - "encoding/json" - "fmt" - - "google.golang.org/protobuf/types/known/emptypb" - - "deevirt.fr/compute/pkg/api/proto" - "deevirt.fr/compute/pkg/api/raft" - "deevirt.fr/compute/pkg/config" -) - -type Node struct { - Config *config.Config - Store *raft.Store - proto.UnimplementedNodeServer -} - -func (d *Node) LibvirtQemu(ctx context.Context, in *proto.NodeLibvirtQemuRequest) (*emptypb.Empty, error) { - node := []struct { - Uuid string `json:"uuid"` - Config string `json:"config"` - State int `json:"state"` - Migrate bool `json:"migrate"` - }{} - - err := json.Unmarshal(in.Domains, &node) - if err != nil { - fmt.Println("Erreur:", err) - } - - /*for _, n := range node { - fmt.Printf("%v", n) - }*/ - - d.Store.Set(fmt.Sprintf("/etc/libvirt/qemu/%s/", d.Config.NodeID), in.Domains) - - t, _ := d.Store.Get(fmt.Sprintf("/etc/libvirt/qemu/%s/", d.Config.NodeID)) - fmt.Printf("%v", t) - - return &emptypb.Empty{}, nil -} diff --git a/pkg/api/node/node.go b/pkg/api/node/node.go new file mode 100644 index 0000000..4355e05 --- /dev/null +++ b/pkg/api/node/node.go @@ -0,0 +1,44 @@ +package node + +import ( + "encoding/json" + "io" + "log" + + "deevirt.fr/compute/pkg/api/proto" + "deevirt.fr/compute/pkg/api/raft" + "deevirt.fr/compute/pkg/config" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" +) + +type Node struct { + Config *config.Config + Store *raft.Store + proto.UnimplementedNodeServer +} + +func (n *Node) Alive(stream proto.Node_AliveServer) error { + println("Alive") + + for { + req, err := stream.Recv() + if err == io.EOF || err != nil { + log.Println("Client closed the connection") + return nil + } + + log.Printf("Received heartbeat: %v", req) + + cluster := deevirt_schema.NodeStore{} + res, _ := n.Store.Get("/etc/libvirt/cluster") + json.Unmarshal(res, &cluster) + cluster[n.Config.NodeID].LastUpdate = req.Timestamp + + d, _ := json.Marshal(cluster) + n.Store.Set("/etc/libvirt/cluster", d) + + stream.Send(&proto.NodeAliveQemuResponse{ + Nodes: res, + }) + } +} diff --git a/pkg/api/proto/domain.pb.go b/pkg/api/proto/domain.pb.go index 578f764..0f30aa4 100644 --- a/pkg/api/proto/domain.pb.go +++ b/pkg/api/proto/domain.pb.go @@ -89,7 +89,11 @@ type DomainEventRequest struct { sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - Event []byte `protobuf:"bytes,1,opt,name=event,proto3" json:"event,omitempty"` + NodeId string `protobuf:"bytes,1,opt,name=node_id,json=nodeId,proto3" json:"node_id,omitempty"` + DomainId string `protobuf:"bytes,2,opt,name=domain_id,json=domainId,proto3" json:"domain_id,omitempty"` + Type string `protobuf:"bytes,3,opt,name=type,proto3" json:"type,omitempty"` + State int64 `protobuf:"varint,4,opt,name=state,proto3" json:"state,omitempty"` + Event []byte `protobuf:"bytes,5,opt,name=event,proto3" json:"event,omitempty"` } func (x *DomainEventRequest) Reset() { @@ -124,6 +128,34 @@ func (*DomainEventRequest) Descriptor() ([]byte, []int) { return file_proto_domain_proto_rawDescGZIP(), []int{0} } +func (x *DomainEventRequest) GetNodeId() string { + if x != nil { + return x.NodeId + } + return "" +} + +func (x *DomainEventRequest) GetDomainId() string { + if x != nil { + return x.DomainId + } + return "" +} + +func (x *DomainEventRequest) GetType() string { + if x != nil { + return x.Type + } + return "" +} + +func (x *DomainEventRequest) GetState() int64 { + if x != nil { + return x.State + } + return 0 +} + func (x *DomainEventRequest) GetEvent() []byte { if x != nil { return x.Event @@ -930,119 +962,126 @@ var File_proto_domain_proto protoreflect.FileDescriptor var file_proto_domain_proto_rawDesc = []byte{ 0x0a, 0x12, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x12, 0x07, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x22, 0x2a, 0x0a, - 0x12, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x12, 0x14, 0x0a, 0x05, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x0c, 0x52, 0x05, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x22, 0x15, 0x0a, 0x13, 0x44, 0x6f, 0x6d, - 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x22, 0x16, 0x0a, 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, - 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x22, 0x4e, 0x0a, 0x15, 0x44, 0x6f, 0x6d, 0x61, - 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x12, 0x35, 0x0a, 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x18, 0x01, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, - 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x52, - 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x22, 0x30, 0x0a, 0x11, 0x44, 0x6f, 0x6d, 0x61, - 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1b, 0x0a, - 0x09, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x08, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x22, 0x78, 0x0a, 0x12, 0x44, 0x6f, - 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x12, 0x17, 0x0a, 0x07, 0x6e, 0x6f, 0x64, 0x65, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x06, 0x6e, 0x6f, 0x64, 0x65, 0x49, 0x64, 0x12, 0x1b, 0x0a, 0x09, 0x64, 0x6f, 0x6d, - 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x08, 0x64, 0x6f, - 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x12, 0x16, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, 0x14, + 0x72, 0x6f, 0x74, 0x6f, 0x12, 0x07, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x22, 0x8a, 0x01, + 0x0a, 0x12, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x12, 0x17, 0x0a, 0x07, 0x6e, 0x6f, 0x64, 0x65, 0x5f, 0x69, 0x64, 0x18, + 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x6e, 0x6f, 0x64, 0x65, 0x49, 0x64, 0x12, 0x1b, 0x0a, + 0x09, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, + 0x52, 0x08, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x79, + 0x70, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x74, 0x79, 0x70, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x03, 0x52, 0x05, 0x73, - 0x74, 0x61, 0x74, 0x65, 0x22, 0x46, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, 0x72, - 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x17, 0x0a, 0x07, 0x6e, - 0x6f, 0x64, 0x65, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x6e, 0x6f, - 0x64, 0x65, 0x49, 0x64, 0x12, 0x16, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x32, 0x0a, 0x14, - 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1a, 0x0a, 0x08, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, 0x73, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x03, 0x52, 0x08, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, 0x73, - 0x22, 0x2a, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, 0x76, 0x6d, 0x5f, 0x69, 0x64, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x76, 0x6d, 0x49, 0x64, 0x22, 0x16, 0x0a, 0x14, - 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x2a, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, - 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, 0x76, - 0x6d, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x76, 0x6d, 0x49, 0x64, - 0x22, 0x16, 0x0a, 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x33, 0x0a, 0x14, 0x44, 0x6f, 0x6d, 0x61, - 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x1b, 0x0a, 0x09, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x08, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x22, 0x37, 0x0a, - 0x15, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1e, 0x0a, 0x0a, 0x70, 0x65, 0x72, 0x63, 0x65, 0x6e, - 0x74, 0x61, 0x67, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x02, 0x52, 0x0a, 0x70, 0x65, 0x72, 0x63, - 0x65, 0x6e, 0x74, 0x61, 0x67, 0x65, 0x22, 0x57, 0x0a, 0x12, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, - 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, - 0x76, 0x6d, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x76, 0x6d, 0x49, - 0x64, 0x12, 0x2c, 0x0a, 0x06, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x0e, 0x32, 0x14, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, - 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x06, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x22, - 0x15, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x3a, 0x0a, 0x23, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, - 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, - 0x6f, 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, + 0x74, 0x61, 0x74, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x18, 0x05, 0x20, + 0x01, 0x28, 0x0c, 0x52, 0x05, 0x65, 0x76, 0x65, 0x6e, 0x74, 0x22, 0x15, 0x0a, 0x13, 0x44, 0x6f, + 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x22, 0x16, 0x0a, 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, + 0x6c, 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x22, 0x4e, 0x0a, 0x15, 0x44, 0x6f, 0x6d, + 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, + 0x73, 0x65, 0x12, 0x35, 0x0a, 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x18, 0x01, 0x20, + 0x03, 0x28, 0x0b, 0x32, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, + 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, + 0x52, 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x22, 0x30, 0x0a, 0x11, 0x44, 0x6f, 0x6d, + 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1b, + 0x0a, 0x09, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, + 0x09, 0x52, 0x08, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x22, 0x78, 0x0a, 0x12, 0x44, + 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x12, 0x17, 0x0a, 0x07, 0x6e, 0x6f, 0x64, 0x65, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x09, 0x52, 0x06, 0x6e, 0x6f, 0x64, 0x65, 0x49, 0x64, 0x12, 0x1b, 0x0a, 0x09, 0x64, 0x6f, + 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x08, 0x64, + 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x12, 0x16, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, + 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x12, + 0x14, 0x0a, 0x05, 0x73, 0x74, 0x61, 0x74, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x03, 0x52, 0x05, + 0x73, 0x74, 0x61, 0x74, 0x65, 0x22, 0x46, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, + 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x17, 0x0a, 0x07, + 0x6e, 0x6f, 0x64, 0x65, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x6e, + 0x6f, 0x64, 0x65, 0x49, 0x64, 0x12, 0x16, 0x0a, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x18, + 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x63, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x22, 0x32, 0x0a, + 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, + 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1a, 0x0a, 0x08, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, + 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x03, 0x52, 0x08, 0x70, 0x72, 0x6f, 0x67, 0x72, 0x65, 0x73, + 0x73, 0x22, 0x2a, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, + 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, 0x76, 0x6d, 0x5f, 0x69, + 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x76, 0x6d, 0x49, 0x64, 0x22, 0x16, 0x0a, + 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, + 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x2a, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, + 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, + 0x76, 0x6d, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x76, 0x6d, 0x49, + 0x64, 0x22, 0x16, 0x0a, 0x14, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x6c, 0x65, 0x74, + 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x33, 0x0a, 0x14, 0x44, 0x6f, 0x6d, + 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, + 0x74, 0x12, 0x1b, 0x0a, 0x09, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x5f, 0x69, 0x64, 0x18, 0x01, + 0x20, 0x01, 0x28, 0x09, 0x52, 0x08, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x49, 0x64, 0x22, 0x37, + 0x0a, 0x15, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x52, + 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1e, 0x0a, 0x0a, 0x70, 0x65, 0x72, 0x63, 0x65, + 0x6e, 0x74, 0x61, 0x67, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x02, 0x52, 0x0a, 0x70, 0x65, 0x72, + 0x63, 0x65, 0x6e, 0x74, 0x61, 0x67, 0x65, 0x22, 0x57, 0x0a, 0x12, 0x44, 0x6f, 0x6d, 0x61, 0x69, + 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, 0x0a, 0x05, 0x76, 0x6d, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x76, 0x6d, - 0x49, 0x64, 0x22, 0x38, 0x0a, 0x24, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x76, 0x69, - 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, 0x6f, 0x6e, 0x73, 0x6f, - 0x6c, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x10, 0x0a, 0x03, 0x75, 0x72, - 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x75, 0x72, 0x69, 0x2a, 0x70, 0x0a, 0x0b, - 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x12, 0x0d, 0x0a, 0x09, 0x55, - 0x4e, 0x44, 0x45, 0x46, 0x49, 0x4e, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x53, 0x54, - 0x41, 0x52, 0x54, 0x10, 0x01, 0x12, 0x0a, 0x0a, 0x06, 0x52, 0x45, 0x42, 0x4f, 0x4f, 0x54, 0x10, - 0x02, 0x12, 0x0c, 0x0a, 0x08, 0x53, 0x48, 0x55, 0x54, 0x44, 0x4f, 0x57, 0x4e, 0x10, 0x03, 0x12, - 0x09, 0x0a, 0x05, 0x50, 0x41, 0x55, 0x53, 0x45, 0x10, 0x04, 0x12, 0x0a, 0x0a, 0x06, 0x52, 0x45, - 0x53, 0x55, 0x4d, 0x45, 0x10, 0x05, 0x12, 0x09, 0x0a, 0x05, 0x52, 0x45, 0x53, 0x45, 0x54, 0x10, - 0x06, 0x12, 0x0b, 0x0a, 0x07, 0x44, 0x45, 0x53, 0x54, 0x52, 0x4f, 0x59, 0x10, 0x07, 0x32, 0xc8, - 0x04, 0x0a, 0x06, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x12, 0x47, 0x0a, 0x04, 0x4c, 0x69, 0x73, - 0x74, 0x12, 0x1d, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, - 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x1e, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, - 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x22, 0x00, 0x12, 0x40, 0x0a, 0x03, 0x47, 0x65, 0x74, 0x12, 0x1a, 0x2e, 0x64, 0x65, 0x65, 0x76, - 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, - 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, 0x0a, 0x06, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x12, 0x1c, - 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, - 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x64, - 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, 0x72, 0x65, - 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, 0x0a, - 0x06, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x12, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, - 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, - 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, 0x0a, 0x06, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x12, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, - 0x6e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, - 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, - 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, - 0x4c, 0x0a, 0x07, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x12, 0x1d, 0x2e, 0x64, 0x65, 0x65, - 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, - 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x64, 0x65, 0x65, 0x76, - 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, - 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x30, 0x01, 0x12, 0x44, 0x0a, - 0x05, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x12, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, - 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x1a, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, - 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x22, 0x00, 0x12, 0x44, 0x0a, 0x05, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x2e, 0x64, - 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, - 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, - 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x32, 0x81, 0x01, 0x0a, 0x15, 0x44, 0x6f, - 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, - 0x69, 0x63, 0x73, 0x12, 0x68, 0x0a, 0x07, 0x43, 0x6f, 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x12, 0x2c, - 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, - 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, 0x6f, - 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, 0x2e, 0x64, - 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x76, + 0x49, 0x64, 0x12, 0x2c, 0x0a, 0x06, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x18, 0x02, 0x20, 0x01, + 0x28, 0x0e, 0x32, 0x14, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, + 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x06, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, + 0x22, 0x15, 0x0a, 0x13, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, + 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x3a, 0x0a, 0x23, 0x44, 0x6f, 0x6d, 0x61, 0x69, + 0x6e, 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, + 0x43, 0x6f, 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x13, + 0x0a, 0x05, 0x76, 0x6d, 0x5f, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x76, + 0x6d, 0x49, 0x64, 0x22, 0x38, 0x0a, 0x24, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, 0x6f, 0x6e, 0x73, - 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x42, 0x09, 0x5a, - 0x07, 0x2e, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x10, 0x0a, 0x03, 0x75, + 0x72, 0x69, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x75, 0x72, 0x69, 0x2a, 0x70, 0x0a, + 0x0b, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x12, 0x0d, 0x0a, 0x09, + 0x55, 0x4e, 0x44, 0x45, 0x46, 0x49, 0x4e, 0x45, 0x44, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, 0x53, + 0x54, 0x41, 0x52, 0x54, 0x10, 0x01, 0x12, 0x0a, 0x0a, 0x06, 0x52, 0x45, 0x42, 0x4f, 0x4f, 0x54, + 0x10, 0x02, 0x12, 0x0c, 0x0a, 0x08, 0x53, 0x48, 0x55, 0x54, 0x44, 0x4f, 0x57, 0x4e, 0x10, 0x03, + 0x12, 0x09, 0x0a, 0x05, 0x50, 0x41, 0x55, 0x53, 0x45, 0x10, 0x04, 0x12, 0x0a, 0x0a, 0x06, 0x52, + 0x45, 0x53, 0x55, 0x4d, 0x45, 0x10, 0x05, 0x12, 0x09, 0x0a, 0x05, 0x52, 0x45, 0x53, 0x45, 0x54, + 0x10, 0x06, 0x12, 0x0b, 0x0a, 0x07, 0x44, 0x45, 0x53, 0x54, 0x52, 0x4f, 0x59, 0x10, 0x07, 0x32, + 0xc8, 0x04, 0x0a, 0x06, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x12, 0x47, 0x0a, 0x04, 0x4c, 0x69, + 0x73, 0x74, 0x12, 0x1d, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, + 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, + 0x74, 0x1a, 0x1e, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, + 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x41, 0x6c, 0x6c, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, + 0x65, 0x22, 0x00, 0x12, 0x40, 0x0a, 0x03, 0x47, 0x65, 0x74, 0x12, 0x1a, 0x2e, 0x64, 0x65, 0x65, + 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, + 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4c, 0x69, 0x73, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, 0x0a, 0x06, 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x12, + 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, + 0x43, 0x72, 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, + 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x43, 0x72, + 0x65, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, + 0x0a, 0x06, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x12, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, + 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, + 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1d, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, + 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x55, 0x70, 0x64, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, + 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x47, 0x0a, 0x06, 0x44, 0x65, 0x6c, 0x65, 0x74, + 0x65, 0x12, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, + 0x69, 0x6e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, + 0x1d, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, + 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, + 0x12, 0x4c, 0x0a, 0x07, 0x4d, 0x69, 0x67, 0x72, 0x61, 0x74, 0x65, 0x12, 0x1d, 0x2e, 0x64, 0x65, + 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, + 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x64, 0x65, 0x65, + 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x4d, 0x69, 0x67, 0x72, 0x61, + 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x30, 0x01, 0x12, 0x44, + 0x0a, 0x05, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x12, 0x1b, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, + 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x71, + 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, + 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x50, 0x6f, 0x77, 0x65, 0x72, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, + 0x73, 0x65, 0x22, 0x00, 0x12, 0x44, 0x0a, 0x05, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x12, 0x1b, 0x2e, + 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, + 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1c, 0x2e, 0x64, 0x65, 0x65, + 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x45, 0x76, 0x65, 0x6e, 0x74, + 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x32, 0x81, 0x01, 0x0a, 0x15, 0x44, + 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, + 0x68, 0x69, 0x63, 0x73, 0x12, 0x68, 0x0a, 0x07, 0x43, 0x6f, 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x12, + 0x2c, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, + 0x44, 0x65, 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, + 0x6f, 0x6e, 0x73, 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2d, 0x2e, + 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x44, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x44, 0x65, + 0x76, 0x69, 0x63, 0x65, 0x73, 0x47, 0x72, 0x61, 0x70, 0x68, 0x69, 0x63, 0x73, 0x43, 0x6f, 0x6e, + 0x73, 0x6f, 0x6c, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x42, 0x09, + 0x5a, 0x07, 0x2e, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, + 0x33, } var ( diff --git a/pkg/api/proto/domain.proto b/pkg/api/proto/domain.proto index 36925e3..a0c22f7 100644 --- a/pkg/api/proto/domain.proto +++ b/pkg/api/proto/domain.proto @@ -19,7 +19,11 @@ service Domain { } message DomainEventRequest { - bytes event = 1; + string node_id = 1; + string domain_id = 2; + string type = 3; + int64 state = 4; + bytes event = 5; } message DomainEventResponse {} diff --git a/pkg/api/proto/node.pb.go b/pkg/api/proto/node.pb.go index 7fae0d2..eea0a77 100644 --- a/pkg/api/proto/node.pb.go +++ b/pkg/api/proto/node.pb.go @@ -9,7 +9,7 @@ package proto import ( protoreflect "google.golang.org/protobuf/reflect/protoreflect" protoimpl "google.golang.org/protobuf/runtime/protoimpl" - emptypb "google.golang.org/protobuf/types/known/emptypb" + timestamppb "google.golang.org/protobuf/types/known/timestamppb" reflect "reflect" sync "sync" ) @@ -21,16 +21,16 @@ const ( _ = protoimpl.EnforceVersion(protoimpl.MaxVersion - 20) ) -type NodeLibvirtQemuRequest struct { +type NodeAliveRequest struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields - Domains []byte `protobuf:"bytes,1,opt,name=domains,proto3" json:"domains,omitempty"` + Timestamp *timestamppb.Timestamp `protobuf:"bytes,1,opt,name=timestamp,proto3" json:"timestamp,omitempty"` } -func (x *NodeLibvirtQemuRequest) Reset() { - *x = NodeLibvirtQemuRequest{} +func (x *NodeAliveRequest) Reset() { + *x = NodeAliveRequest{} if protoimpl.UnsafeEnabled { mi := &file_proto_node_proto_msgTypes[0] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) @@ -38,13 +38,13 @@ func (x *NodeLibvirtQemuRequest) Reset() { } } -func (x *NodeLibvirtQemuRequest) String() string { +func (x *NodeAliveRequest) String() string { return protoimpl.X.MessageStringOf(x) } -func (*NodeLibvirtQemuRequest) ProtoMessage() {} +func (*NodeAliveRequest) ProtoMessage() {} -func (x *NodeLibvirtQemuRequest) ProtoReflect() protoreflect.Message { +func (x *NodeAliveRequest) ProtoReflect() protoreflect.Message { mi := &file_proto_node_proto_msgTypes[0] if protoimpl.UnsafeEnabled && x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) @@ -56,26 +56,28 @@ func (x *NodeLibvirtQemuRequest) ProtoReflect() protoreflect.Message { return mi.MessageOf(x) } -// Deprecated: Use NodeLibvirtQemuRequest.ProtoReflect.Descriptor instead. -func (*NodeLibvirtQemuRequest) Descriptor() ([]byte, []int) { +// Deprecated: Use NodeAliveRequest.ProtoReflect.Descriptor instead. +func (*NodeAliveRequest) Descriptor() ([]byte, []int) { return file_proto_node_proto_rawDescGZIP(), []int{0} } -func (x *NodeLibvirtQemuRequest) GetDomains() []byte { +func (x *NodeAliveRequest) GetTimestamp() *timestamppb.Timestamp { if x != nil { - return x.Domains + return x.Timestamp } return nil } -type NodeLibvirtQemuResponse struct { +type NodeAliveQemuResponse struct { state protoimpl.MessageState sizeCache protoimpl.SizeCache unknownFields protoimpl.UnknownFields + + Nodes []byte `protobuf:"bytes,1,opt,name=nodes,proto3" json:"nodes,omitempty"` } -func (x *NodeLibvirtQemuResponse) Reset() { - *x = NodeLibvirtQemuResponse{} +func (x *NodeAliveQemuResponse) Reset() { + *x = NodeAliveQemuResponse{} if protoimpl.UnsafeEnabled { mi := &file_proto_node_proto_msgTypes[1] ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) @@ -83,13 +85,13 @@ func (x *NodeLibvirtQemuResponse) Reset() { } } -func (x *NodeLibvirtQemuResponse) String() string { +func (x *NodeAliveQemuResponse) String() string { return protoimpl.X.MessageStringOf(x) } -func (*NodeLibvirtQemuResponse) ProtoMessage() {} +func (*NodeAliveQemuResponse) ProtoMessage() {} -func (x *NodeLibvirtQemuResponse) ProtoReflect() protoreflect.Message { +func (x *NodeAliveQemuResponse) ProtoReflect() protoreflect.Message { mi := &file_proto_node_proto_msgTypes[1] if protoimpl.UnsafeEnabled && x != nil { ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) @@ -101,29 +103,39 @@ func (x *NodeLibvirtQemuResponse) ProtoReflect() protoreflect.Message { return mi.MessageOf(x) } -// Deprecated: Use NodeLibvirtQemuResponse.ProtoReflect.Descriptor instead. -func (*NodeLibvirtQemuResponse) Descriptor() ([]byte, []int) { +// Deprecated: Use NodeAliveQemuResponse.ProtoReflect.Descriptor instead. +func (*NodeAliveQemuResponse) Descriptor() ([]byte, []int) { return file_proto_node_proto_rawDescGZIP(), []int{1} } +func (x *NodeAliveQemuResponse) GetNodes() []byte { + if x != nil { + return x.Nodes + } + return nil +} + var File_proto_node_proto protoreflect.FileDescriptor var file_proto_node_proto_rawDesc = []byte{ 0x0a, 0x10, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x6e, 0x6f, 0x64, 0x65, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x12, 0x07, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x1a, 0x1b, 0x67, 0x6f, 0x6f, - 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x65, 0x6d, 0x70, - 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x32, 0x0a, 0x16, 0x4e, 0x6f, 0x64, 0x65, - 0x4c, 0x69, 0x62, 0x76, 0x69, 0x72, 0x74, 0x51, 0x65, 0x6d, 0x75, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x12, 0x18, 0x0a, 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x0c, 0x52, 0x07, 0x64, 0x6f, 0x6d, 0x61, 0x69, 0x6e, 0x73, 0x22, 0x19, 0x0a, 0x17, - 0x4e, 0x6f, 0x64, 0x65, 0x4c, 0x69, 0x62, 0x76, 0x69, 0x72, 0x74, 0x51, 0x65, 0x6d, 0x75, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x32, 0x50, 0x0a, 0x04, 0x4e, 0x6f, 0x64, 0x65, 0x12, - 0x48, 0x0a, 0x0b, 0x4c, 0x69, 0x62, 0x76, 0x69, 0x72, 0x74, 0x51, 0x65, 0x6d, 0x75, 0x12, 0x1f, - 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, 0x4e, 0x6f, 0x64, 0x65, 0x4c, 0x69, 0x62, - 0x76, 0x69, 0x72, 0x74, 0x51, 0x65, 0x6d, 0x75, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, - 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x42, 0x09, 0x5a, 0x07, 0x2e, 0x2f, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, + 0x74, 0x6f, 0x12, 0x07, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x1a, 0x1f, 0x67, 0x6f, 0x6f, + 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x74, 0x69, 0x6d, + 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x4c, 0x0a, 0x10, + 0x4e, 0x6f, 0x64, 0x65, 0x41, 0x6c, 0x69, 0x76, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, + 0x12, 0x38, 0x0a, 0x09, 0x74, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x18, 0x01, 0x20, + 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, + 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x54, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x52, + 0x09, 0x74, 0x69, 0x6d, 0x65, 0x73, 0x74, 0x61, 0x6d, 0x70, 0x22, 0x2d, 0x0a, 0x15, 0x4e, 0x6f, + 0x64, 0x65, 0x41, 0x6c, 0x69, 0x76, 0x65, 0x51, 0x65, 0x6d, 0x75, 0x52, 0x65, 0x73, 0x70, 0x6f, + 0x6e, 0x73, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x6e, 0x6f, 0x64, 0x65, 0x73, 0x18, 0x01, 0x20, 0x01, + 0x28, 0x0c, 0x52, 0x05, 0x6e, 0x6f, 0x64, 0x65, 0x73, 0x32, 0x50, 0x0a, 0x04, 0x4e, 0x6f, 0x64, + 0x65, 0x12, 0x48, 0x0a, 0x05, 0x41, 0x6c, 0x69, 0x76, 0x65, 0x12, 0x19, 0x2e, 0x64, 0x65, 0x65, + 0x76, 0x69, 0x72, 0x74, 0x2e, 0x4e, 0x6f, 0x64, 0x65, 0x41, 0x6c, 0x69, 0x76, 0x65, 0x52, 0x65, + 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x1e, 0x2e, 0x64, 0x65, 0x65, 0x76, 0x69, 0x72, 0x74, 0x2e, + 0x4e, 0x6f, 0x64, 0x65, 0x41, 0x6c, 0x69, 0x76, 0x65, 0x51, 0x65, 0x6d, 0x75, 0x52, 0x65, 0x73, + 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x28, 0x01, 0x30, 0x01, 0x42, 0x09, 0x5a, 0x07, 0x2e, + 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, } var ( @@ -140,18 +152,19 @@ func file_proto_node_proto_rawDescGZIP() []byte { var file_proto_node_proto_msgTypes = make([]protoimpl.MessageInfo, 2) var file_proto_node_proto_goTypes = []interface{}{ - (*NodeLibvirtQemuRequest)(nil), // 0: deevirt.NodeLibvirtQemuRequest - (*NodeLibvirtQemuResponse)(nil), // 1: deevirt.NodeLibvirtQemuResponse - (*emptypb.Empty)(nil), // 2: google.protobuf.Empty + (*NodeAliveRequest)(nil), // 0: deevirt.NodeAliveRequest + (*NodeAliveQemuResponse)(nil), // 1: deevirt.NodeAliveQemuResponse + (*timestamppb.Timestamp)(nil), // 2: google.protobuf.Timestamp } var file_proto_node_proto_depIdxs = []int32{ - 0, // 0: deevirt.Node.LibvirtQemu:input_type -> deevirt.NodeLibvirtQemuRequest - 2, // 1: deevirt.Node.LibvirtQemu:output_type -> google.protobuf.Empty - 1, // [1:2] is the sub-list for method output_type - 0, // [0:1] is the sub-list for method input_type - 0, // [0:0] is the sub-list for extension type_name - 0, // [0:0] is the sub-list for extension extendee - 0, // [0:0] is the sub-list for field type_name + 2, // 0: deevirt.NodeAliveRequest.timestamp:type_name -> google.protobuf.Timestamp + 0, // 1: deevirt.Node.Alive:input_type -> deevirt.NodeAliveRequest + 1, // 2: deevirt.Node.Alive:output_type -> deevirt.NodeAliveQemuResponse + 2, // [2:3] is the sub-list for method output_type + 1, // [1:2] is the sub-list for method input_type + 1, // [1:1] is the sub-list for extension type_name + 1, // [1:1] is the sub-list for extension extendee + 0, // [0:1] is the sub-list for field type_name } func init() { file_proto_node_proto_init() } @@ -161,7 +174,7 @@ func file_proto_node_proto_init() { } if !protoimpl.UnsafeEnabled { file_proto_node_proto_msgTypes[0].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*NodeLibvirtQemuRequest); i { + switch v := v.(*NodeAliveRequest); i { case 0: return &v.state case 1: @@ -173,7 +186,7 @@ func file_proto_node_proto_init() { } } file_proto_node_proto_msgTypes[1].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*NodeLibvirtQemuResponse); i { + switch v := v.(*NodeAliveQemuResponse); i { case 0: return &v.state case 1: diff --git a/pkg/api/proto/node.proto b/pkg/api/proto/node.proto index d84a331..06555d2 100644 --- a/pkg/api/proto/node.proto +++ b/pkg/api/proto/node.proto @@ -1,16 +1,18 @@ syntax="proto3"; -import "google/protobuf/empty.proto"; +import "google/protobuf/timestamp.proto"; option go_package = "./proto"; package deevirt; // The greeting service definition. service Node { - rpc LibvirtQemu (NodeLibvirtQemuRequest) returns(google.protobuf.Empty) {} + rpc Alive (stream NodeAliveRequest) returns(stream NodeAliveQemuResponse) {} } -message NodeLibvirtQemuRequest { - bytes domains = 1; +message NodeAliveRequest { + google.protobuf.Timestamp timestamp = 1; } -message NodeLibvirtQemuResponse {} +message NodeAliveQemuResponse { + bytes nodes = 1; +} diff --git a/pkg/api/proto/node_grpc.pb.go b/pkg/api/proto/node_grpc.pb.go index f811981..9060133 100644 --- a/pkg/api/proto/node_grpc.pb.go +++ b/pkg/api/proto/node_grpc.pb.go @@ -11,7 +11,6 @@ import ( grpc "google.golang.org/grpc" codes "google.golang.org/grpc/codes" status "google.golang.org/grpc/status" - emptypb "google.golang.org/protobuf/types/known/emptypb" ) // This is a compile-time assertion to ensure that this generated file @@ -20,7 +19,7 @@ import ( const _ = grpc.SupportPackageIsVersion9 const ( - Node_LibvirtQemu_FullMethodName = "/deevirt.Node/LibvirtQemu" + Node_Alive_FullMethodName = "/deevirt.Node/Alive" ) // NodeClient is the client API for Node service. @@ -29,7 +28,7 @@ const ( // // The greeting service definition. type NodeClient interface { - LibvirtQemu(ctx context.Context, in *NodeLibvirtQemuRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) + Alive(ctx context.Context, opts ...grpc.CallOption) (grpc.BidiStreamingClient[NodeAliveRequest, NodeAliveQemuResponse], error) } type nodeClient struct { @@ -40,23 +39,26 @@ func NewNodeClient(cc grpc.ClientConnInterface) NodeClient { return &nodeClient{cc} } -func (c *nodeClient) LibvirtQemu(ctx context.Context, in *NodeLibvirtQemuRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { +func (c *nodeClient) Alive(ctx context.Context, opts ...grpc.CallOption) (grpc.BidiStreamingClient[NodeAliveRequest, NodeAliveQemuResponse], error) { cOpts := append([]grpc.CallOption{grpc.StaticMethod()}, opts...) - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, Node_LibvirtQemu_FullMethodName, in, out, cOpts...) + stream, err := c.cc.NewStream(ctx, &Node_ServiceDesc.Streams[0], Node_Alive_FullMethodName, cOpts...) if err != nil { return nil, err } - return out, nil + x := &grpc.GenericClientStream[NodeAliveRequest, NodeAliveQemuResponse]{ClientStream: stream} + return x, nil } +// This type alias is provided for backwards compatibility with existing code that references the prior non-generic stream type by name. +type Node_AliveClient = grpc.BidiStreamingClient[NodeAliveRequest, NodeAliveQemuResponse] + // NodeServer is the server API for Node service. // All implementations must embed UnimplementedNodeServer // for forward compatibility. // // The greeting service definition. type NodeServer interface { - LibvirtQemu(context.Context, *NodeLibvirtQemuRequest) (*emptypb.Empty, error) + Alive(grpc.BidiStreamingServer[NodeAliveRequest, NodeAliveQemuResponse]) error mustEmbedUnimplementedNodeServer() } @@ -67,8 +69,8 @@ type NodeServer interface { // pointer dereference when methods are called. type UnimplementedNodeServer struct{} -func (UnimplementedNodeServer) LibvirtQemu(context.Context, *NodeLibvirtQemuRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method LibvirtQemu not implemented") +func (UnimplementedNodeServer) Alive(grpc.BidiStreamingServer[NodeAliveRequest, NodeAliveQemuResponse]) error { + return status.Errorf(codes.Unimplemented, "method Alive not implemented") } func (UnimplementedNodeServer) mustEmbedUnimplementedNodeServer() {} func (UnimplementedNodeServer) testEmbeddedByValue() {} @@ -91,36 +93,27 @@ func RegisterNodeServer(s grpc.ServiceRegistrar, srv NodeServer) { s.RegisterService(&Node_ServiceDesc, srv) } -func _Node_LibvirtQemu_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(NodeLibvirtQemuRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(NodeServer).LibvirtQemu(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: Node_LibvirtQemu_FullMethodName, - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(NodeServer).LibvirtQemu(ctx, req.(*NodeLibvirtQemuRequest)) - } - return interceptor(ctx, in, info, handler) +func _Node_Alive_Handler(srv interface{}, stream grpc.ServerStream) error { + return srv.(NodeServer).Alive(&grpc.GenericServerStream[NodeAliveRequest, NodeAliveQemuResponse]{ServerStream: stream}) } +// This type alias is provided for backwards compatibility with existing code that references the prior non-generic stream type by name. +type Node_AliveServer = grpc.BidiStreamingServer[NodeAliveRequest, NodeAliveQemuResponse] + // Node_ServiceDesc is the grpc.ServiceDesc for Node service. // It's only intended for direct use with grpc.RegisterService, // and not to be introspected or modified (even as a copy) var Node_ServiceDesc = grpc.ServiceDesc{ ServiceName: "deevirt.Node", HandlerType: (*NodeServer)(nil), - Methods: []grpc.MethodDesc{ + Methods: []grpc.MethodDesc{}, + Streams: []grpc.StreamDesc{ { - MethodName: "LibvirtQemu", - Handler: _Node_LibvirtQemu_Handler, + StreamName: "Alive", + Handler: _Node_Alive_Handler, + ServerStreams: true, + ClientStreams: true, }, }, - Streams: []grpc.StreamDesc{}, Metadata: "proto/node.proto", } diff --git a/pkg/api/raft/node.go b/pkg/api/raft/node.go index b936379..ce1a0a0 100644 --- a/pkg/api/raft/node.go +++ b/pkg/api/raft/node.go @@ -10,6 +10,7 @@ import ( "libvirt.org/go/libvirt" etcd_client "deevirt.fr/compute/pkg/etcd" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" //"deevirt.fr/compute/pkg/scheduler" ) @@ -23,22 +24,19 @@ type RaftNode struct { func (n *RaftNode) init() { println("bootstrap :") - nodes := make(NodeStore) + nodes := make(deevirt_schema.NodeStore) // Récupération des Noeuds ID etcd, _ := etcd_client.New(n.Store.conf.EtcdURI) defer etcd.Close() for key, value := range etcd_client.GetNodes(etcd, n.Store.conf.ClusterID) { - nodes[key] = &NodeStoreInfo{ - IpManagement: value.IpManagement, - Scoring: 0, - } - println(key) - println(value.IpManagement) - var libvirt_uri string + nodes[key] = &deevirt_schema.NodeStoreInfo{ + IpManagement: value.IpManagement, + } + if n.Store.conf.LibvirtTLS { libvirt_uri = fmt.Sprintf("qemu+tls://%s/system", value.IpManagement) } else { @@ -57,15 +55,17 @@ func (n *RaftNode) init() { uuid, _ := domain.GetUUIDString() state, _, _ := domain.GetState() - d, _ := json.Marshal(struct { - Config string `json:"config"` - State int `json:"state"` - Migrate bool `json:"Migrate"` - }{ - conf, int(state), false, + dStore, _ := json.Marshal(deevirt_schema.DomainStore{ + NodeId: key, + Type: "qemu", + Config: []byte(conf), }) + n.Store.Set(fmt.Sprintf("/etc/libvirt/domain/%s", uuid), dStore) - n.Store.Set(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", key, uuid), d) + dDomainToNode, _ := json.Marshal(deevirt_schema.DomainToNodeStore{ + State: int(state), + }) + n.Store.Set(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", key, uuid), dDomainToNode) } } diff --git a/pkg/api/raft/schema.go b/pkg/api/raft/schema.go index 100b77d..ee5650d 100644 --- a/pkg/api/raft/schema.go +++ b/pkg/api/raft/schema.go @@ -1,6 +1,6 @@ package raft -type NodeStore map[string]*NodeStoreInfo +/*type NodeStore map[string]*NodeStoreInfo type NodeStoreInfo struct { IpManagement string @@ -17,7 +17,7 @@ type DomainStore struct { type SchemaDomain struct { Config string `json:"config"` State int `json:"state"` -} +}*/ // Metrics type DomainUsage struct { diff --git a/pkg/api/raft/worker.go b/pkg/api/raft/worker.go index 8cc1ac6..ec45c6f 100644 --- a/pkg/api/raft/worker.go +++ b/pkg/api/raft/worker.go @@ -10,11 +10,11 @@ import ( "time" "go.uber.org/zap" - go_libvirt "libvirt.org/go/libvirt" "deevirt.fr/compute/pkg/api/libvirt" "deevirt.fr/compute/pkg/config" "deevirt.fr/compute/pkg/scheduler" + deevirt_schema "deevirt.fr/compute/pkg/schema/deevirt" ) type Worker struct { @@ -25,7 +25,7 @@ type Worker struct { store *Store config *config.Config - nodes NodeStore + nodes deevirt_schema.NodeStore log *zap.SugaredLogger } @@ -89,7 +89,7 @@ func (w *Worker) Stop() { func (w *Worker) Migrate(wg *sync.WaitGroup, nodeID string, newNodeID string, domainID string) { defer wg.Done() - c, err := libvirt.New(w.nodes[nodeID].IpManagement, w.store.conf.LibvirtTLS) + /*c, err := libvirt.New(w.nodes[nodeID].IpManagement, w.store.conf.LibvirtTLS) if err != nil { w.log.Infof("Connexion error to libvirt %v", err.Error()) return @@ -118,14 +118,14 @@ func (w *Worker) Migrate(wg *sync.WaitGroup, nodeID string, newNodeID string, do newDomConfig, _ := new_dom.GetXMLDesc(go_libvirt.DOMAIN_XML_INACTIVE) newDomState, _, _ := new_dom.GetState() - new, _ := json.Marshal(DomainStore{ + new, _ := json.Marshal(deevirt_schema.DomainStore{ Config: newDomConfig, State: int(newDomState), Migrate: false, }) w.store.Set(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", newNodeID, domainID), new) - w.store.Delete(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", nodeID, domainID)) + w.store.Delete(fmt.Sprintf("/etc/libvirt/qemu/%s/%s", nodeID, domainID))*/ } /* @@ -133,7 +133,7 @@ On controle périodiquement l'accessibilité à libvirt, indépendamment du prog Cette vérification assure un double controle pour la HA. */ func (w *Worker) handleLibvirtControl() { - var nodes NodeStore + var nodes deevirt_schema.NodeStore cluster, err := w.store.Get("/etc/libvirt/cluster") if err != nil { w.log.Errorf("Erreur lors de la récupération des données de cluster: %v", err) @@ -152,18 +152,18 @@ func (w *Worker) handleLibvirtControl() { c, err := libvirt.New(conf.IpManagement, w.store.conf.LibvirtTLS) if err != nil { w.log.Warnf("Impossible de créer la connexion libvirt pour %s: %v", conf.IpManagement, err) - conf.Alive = false + //conf.Alive = false continue // Passer à l'élément suivant } defer c.Close() // Assurer la fermeture de la connexion à la fin // Vérifier si le noeud est vivant - alive, err := c.IsAlive() + //alive, err := c.IsAlive() if err != nil { w.log.Warnf("Erreur lors de la vérification de la vie de %s: %v", conf.IpManagement, err) - conf.Alive = false + //conf.Alive = false } else { - conf.Alive = alive + //conf.Alive = alive } } @@ -230,7 +230,7 @@ func (w *Worker) handleNodeAlerts() error { } func (w *Worker) handleHAExecution(nodeID string) { - if w.nodes[nodeID].Alive { + /*if w.nodes[nodeID].Alive { // L'information n'est pas cohérente, on ne fait rien w.log.Infof("L'agent moniteur ne répond pas, mais le noeud reste fonctionnel") return @@ -287,7 +287,7 @@ func (w *Worker) handleHAExecution(nodeID string) { } w.log.Infof("HA of %s to %s for domain %s", nodeID, res[randomINode].NodeID, domId) - } + }*/ //_, err = c.DomainCreateXML(cDomStore.Config, go_libvirt.DOMAIN_START_VALIDATE) } diff --git a/pkg/api/server.go b/pkg/api/server.go index b01e8e0..ff2a94f 100644 --- a/pkg/api/server.go +++ b/pkg/api/server.go @@ -14,6 +14,8 @@ import ( "google.golang.org/grpc/reflection" "deevirt.fr/compute/pkg/api/domain" + "deevirt.fr/compute/pkg/api/node" + pb "deevirt.fr/compute/pkg/api/proto" "deevirt.fr/compute/pkg/api/raft" "deevirt.fr/compute/pkg/config" @@ -69,7 +71,7 @@ func Server() { } s := createGRPCServer(conf) - pb.RegisterNodeServer(s, &Node{ + pb.RegisterNodeServer(s, &node.Node{ Config: conf, Store: r, }) diff --git a/pkg/schema/deevirt/domain.go b/pkg/schema/deevirt/domain.go new file mode 100644 index 0000000..3b29223 --- /dev/null +++ b/pkg/schema/deevirt/domain.go @@ -0,0 +1,12 @@ +package deevirt_schema + +// Schema dans le store +type DomainStore struct { + Type string `json:"type"` + NodeId string `json:"nodeID"` + Config []byte `json:"config"` +} + +type DomainToNodeStore struct { + State int `json:"state"` +} diff --git a/pkg/schema/deevirt/node.go b/pkg/schema/deevirt/node.go new file mode 100644 index 0000000..5cca9de --- /dev/null +++ b/pkg/schema/deevirt/node.go @@ -0,0 +1,10 @@ +package deevirt_schema + +import "google.golang.org/protobuf/types/known/timestamppb" + +type NodeStore map[string]*NodeStoreInfo + +type NodeStoreInfo struct { + LastUpdate *timestamppb.Timestamp + IpManagement string +} diff --git a/vendor/google.golang.org/protobuf/types/known/emptypb/empty.pb.go b/vendor/google.golang.org/protobuf/types/known/emptypb/empty.pb.go deleted file mode 100644 index a5b8657..0000000 --- a/vendor/google.golang.org/protobuf/types/known/emptypb/empty.pb.go +++ /dev/null @@ -1,150 +0,0 @@ -// Protocol Buffers - Google's data interchange format -// Copyright 2008 Google Inc. All rights reserved. -// https://developers.google.com/protocol-buffers/ -// -// Redistribution and use in source and binary forms, with or without -// modification, are permitted provided that the following conditions are -// met: -// -// * Redistributions of source code must retain the above copyright -// notice, this list of conditions and the following disclaimer. -// * Redistributions in binary form must reproduce the above -// copyright notice, this list of conditions and the following disclaimer -// in the documentation and/or other materials provided with the -// distribution. -// * Neither the name of Google Inc. nor the names of its -// contributors may be used to endorse or promote products derived from -// this software without specific prior written permission. -// -// THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS -// "AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT -// LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR -// A PARTICULAR PURPOSE ARE DISCLAIMED. IN NO EVENT SHALL THE COPYRIGHT -// OWNER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, -// SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT -// LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, -// DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY -// THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT -// (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE -// OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. - -// Code generated by protoc-gen-go. DO NOT EDIT. -// source: google/protobuf/empty.proto - -package emptypb - -import ( - protoreflect "google.golang.org/protobuf/reflect/protoreflect" - protoimpl "google.golang.org/protobuf/runtime/protoimpl" - reflect "reflect" - sync "sync" - unsafe "unsafe" -) - -// A generic empty message that you can re-use to avoid defining duplicated -// empty messages in your APIs. A typical example is to use it as the request -// or the response type of an API method. For instance: -// -// service Foo { -// rpc Bar(google.protobuf.Empty) returns (google.protobuf.Empty); -// } -type Empty struct { - state protoimpl.MessageState `protogen:"open.v1"` - unknownFields protoimpl.UnknownFields - sizeCache protoimpl.SizeCache -} - -func (x *Empty) Reset() { - *x = Empty{} - mi := &file_google_protobuf_empty_proto_msgTypes[0] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) -} - -func (x *Empty) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*Empty) ProtoMessage() {} - -func (x *Empty) ProtoReflect() protoreflect.Message { - mi := &file_google_protobuf_empty_proto_msgTypes[0] - if x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use Empty.ProtoReflect.Descriptor instead. -func (*Empty) Descriptor() ([]byte, []int) { - return file_google_protobuf_empty_proto_rawDescGZIP(), []int{0} -} - -var File_google_protobuf_empty_proto protoreflect.FileDescriptor - -var file_google_protobuf_empty_proto_rawDesc = string([]byte{ - 0x0a, 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x12, 0x0f, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x22, 0x07, - 0x0a, 0x05, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x42, 0x7d, 0x0a, 0x13, 0x63, 0x6f, 0x6d, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x42, 0x0a, - 0x45, 0x6d, 0x70, 0x74, 0x79, 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x50, 0x01, 0x5a, 0x2e, 0x67, 0x6f, - 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x67, 0x6f, 0x6c, 0x61, 0x6e, 0x67, 0x2e, 0x6f, 0x72, 0x67, 0x2f, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x74, 0x79, 0x70, 0x65, 0x73, 0x2f, 0x6b, - 0x6e, 0x6f, 0x77, 0x6e, 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x70, 0x62, 0xf8, 0x01, 0x01, 0xa2, - 0x02, 0x03, 0x47, 0x50, 0x42, 0xaa, 0x02, 0x1e, 0x47, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x50, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x57, 0x65, 0x6c, 0x6c, 0x4b, 0x6e, 0x6f, 0x77, - 0x6e, 0x54, 0x79, 0x70, 0x65, 0x73, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, -}) - -var ( - file_google_protobuf_empty_proto_rawDescOnce sync.Once - file_google_protobuf_empty_proto_rawDescData []byte -) - -func file_google_protobuf_empty_proto_rawDescGZIP() []byte { - file_google_protobuf_empty_proto_rawDescOnce.Do(func() { - file_google_protobuf_empty_proto_rawDescData = protoimpl.X.CompressGZIP(unsafe.Slice(unsafe.StringData(file_google_protobuf_empty_proto_rawDesc), len(file_google_protobuf_empty_proto_rawDesc))) - }) - return file_google_protobuf_empty_proto_rawDescData -} - -var file_google_protobuf_empty_proto_msgTypes = make([]protoimpl.MessageInfo, 1) -var file_google_protobuf_empty_proto_goTypes = []any{ - (*Empty)(nil), // 0: google.protobuf.Empty -} -var file_google_protobuf_empty_proto_depIdxs = []int32{ - 0, // [0:0] is the sub-list for method output_type - 0, // [0:0] is the sub-list for method input_type - 0, // [0:0] is the sub-list for extension type_name - 0, // [0:0] is the sub-list for extension extendee - 0, // [0:0] is the sub-list for field type_name -} - -func init() { file_google_protobuf_empty_proto_init() } -func file_google_protobuf_empty_proto_init() { - if File_google_protobuf_empty_proto != nil { - return - } - type x struct{} - out := protoimpl.TypeBuilder{ - File: protoimpl.DescBuilder{ - GoPackagePath: reflect.TypeOf(x{}).PkgPath(), - RawDescriptor: unsafe.Slice(unsafe.StringData(file_google_protobuf_empty_proto_rawDesc), len(file_google_protobuf_empty_proto_rawDesc)), - NumEnums: 0, - NumMessages: 1, - NumExtensions: 0, - NumServices: 0, - }, - GoTypes: file_google_protobuf_empty_proto_goTypes, - DependencyIndexes: file_google_protobuf_empty_proto_depIdxs, - MessageInfos: file_google_protobuf_empty_proto_msgTypes, - }.Build() - File_google_protobuf_empty_proto = out.File - file_google_protobuf_empty_proto_goTypes = nil - file_google_protobuf_empty_proto_depIdxs = nil -} diff --git a/vendor/modules.txt b/vendor/modules.txt index c2890a7..deda170 100644 --- a/vendor/modules.txt +++ b/vendor/modules.txt @@ -288,7 +288,6 @@ google.golang.org/protobuf/types/descriptorpb google.golang.org/protobuf/types/gofeaturespb google.golang.org/protobuf/types/known/anypb google.golang.org/protobuf/types/known/durationpb -google.golang.org/protobuf/types/known/emptypb google.golang.org/protobuf/types/known/timestamppb # gopkg.in/ini.v1 v1.67.0 ## explicit