mirror of
				https://github.com/juanfont/headscale.git
				synced 2025-11-04 10:01:05 +01:00 
			
		
		
		
	
		
			
				
	
	
		
			1015 lines
		
	
	
		
			25 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			1015 lines
		
	
	
		
			25 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
package headscale
 | 
						||
 | 
						||
import (
 | 
						||
	"database/sql/driver"
 | 
						||
	"encoding/json"
 | 
						||
	"errors"
 | 
						||
	"fmt"
 | 
						||
	"sort"
 | 
						||
	"strconv"
 | 
						||
	"strings"
 | 
						||
	"time"
 | 
						||
 | 
						||
	"github.com/fatih/set"
 | 
						||
	v1 "github.com/juanfont/headscale/gen/go/headscale/v1"
 | 
						||
	"github.com/rs/zerolog/log"
 | 
						||
	"google.golang.org/protobuf/types/known/timestamppb"
 | 
						||
	"gorm.io/datatypes"
 | 
						||
	"inet.af/netaddr"
 | 
						||
	"tailscale.com/tailcfg"
 | 
						||
	"tailscale.com/types/key"
 | 
						||
)
 | 
						||
 | 
						||
const (
 | 
						||
	errMachineNotFound            = Error("machine not found")
 | 
						||
	errMachineAlreadyRegistered   = Error("machine already registered")
 | 
						||
	errMachineRouteIsNotAvailable = Error("route is not available on machine")
 | 
						||
	errMachineAddressesInvalid    = Error("failed to parse machine addresses")
 | 
						||
)
 | 
						||
 | 
						||
// Machine is a Headscale client.
 | 
						||
type Machine struct {
 | 
						||
	ID          uint64 `gorm:"primary_key"`
 | 
						||
	MachineKey  string `gorm:"type:varchar(64);unique_index"`
 | 
						||
	NodeKey     string
 | 
						||
	DiscoKey    string
 | 
						||
	IPAddresses MachineAddresses
 | 
						||
	Name        string
 | 
						||
	NamespaceID uint
 | 
						||
	Namespace   Namespace `gorm:"foreignKey:NamespaceID"`
 | 
						||
 | 
						||
	Registered     bool // temp
 | 
						||
	RegisterMethod string
 | 
						||
	AuthKeyID      uint
 | 
						||
	AuthKey        *PreAuthKey
 | 
						||
 | 
						||
	LastSeen             *time.Time
 | 
						||
	LastSuccessfulUpdate *time.Time
 | 
						||
	Expiry               *time.Time
 | 
						||
 | 
						||
	HostInfo      datatypes.JSON
 | 
						||
	Endpoints     datatypes.JSON
 | 
						||
	EnabledRoutes datatypes.JSON
 | 
						||
 | 
						||
	CreatedAt time.Time
 | 
						||
	UpdatedAt time.Time
 | 
						||
	DeletedAt *time.Time
 | 
						||
}
 | 
						||
 | 
						||
type (
 | 
						||
	Machines  []Machine
 | 
						||
	MachinesP []*Machine
 | 
						||
)
 | 
						||
 | 
						||
// For the time being this method is rather naive.
 | 
						||
func (machine Machine) isRegistered() bool {
 | 
						||
	return machine.Registered
 | 
						||
}
 | 
						||
 | 
						||
type MachineAddresses []netaddr.IP
 | 
						||
 | 
						||
func (ma MachineAddresses) ToStringSlice() []string {
 | 
						||
	strSlice := make([]string, 0, len(ma))
 | 
						||
	for _, addr := range ma {
 | 
						||
		strSlice = append(strSlice, addr.String())
 | 
						||
	}
 | 
						||
 | 
						||
	return strSlice
 | 
						||
}
 | 
						||
 | 
						||
func (ma *MachineAddresses) Scan(destination interface{}) error {
 | 
						||
	switch value := destination.(type) {
 | 
						||
	case string:
 | 
						||
		addresses := strings.Split(value, ",")
 | 
						||
		*ma = (*ma)[:0]
 | 
						||
		for _, addr := range addresses {
 | 
						||
			if len(addr) < 1 {
 | 
						||
				continue
 | 
						||
			}
 | 
						||
			parsed, err := netaddr.ParseIP(addr)
 | 
						||
			if err != nil {
 | 
						||
				return err
 | 
						||
			}
 | 
						||
			*ma = append(*ma, parsed)
 | 
						||
		}
 | 
						||
 | 
						||
		return nil
 | 
						||
 | 
						||
	default:
 | 
						||
		return fmt.Errorf("%w: unexpected data type %T", errMachineAddressesInvalid, destination)
 | 
						||
	}
 | 
						||
}
 | 
						||
 | 
						||
// Value return json value, implement driver.Valuer interface.
 | 
						||
func (ma MachineAddresses) Value() (driver.Value, error) {
 | 
						||
	addresses := strings.Join(ma.ToStringSlice(), ",")
 | 
						||
 | 
						||
	return addresses, nil
 | 
						||
}
 | 
						||
 | 
						||
// isExpired returns whether the machine registration has expired.
 | 
						||
func (machine Machine) isExpired() bool {
 | 
						||
	// If Expiry is not set, the client has not indicated that
 | 
						||
	// it wants an expiry time, it is therefor considered
 | 
						||
	// to mean "not expired"
 | 
						||
	if machine.Expiry.IsZero() {
 | 
						||
		return false
 | 
						||
	}
 | 
						||
 | 
						||
	return time.Now().UTC().After(*machine.Expiry)
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) ListAllMachines() ([]Machine, error) {
 | 
						||
	machines := []Machine{}
 | 
						||
	if err := h.db.Preload("AuthKey").
 | 
						||
		Preload("AuthKey.Namespace").
 | 
						||
		Preload("Namespace").
 | 
						||
		Where("registered").
 | 
						||
		Find(&machines).Error; err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	return machines, nil
 | 
						||
}
 | 
						||
 | 
						||
func containsAddresses(inputs []string, addrs []string) bool {
 | 
						||
	for _, addr := range addrs {
 | 
						||
		if containsString(inputs, addr) {
 | 
						||
			return true
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	return false
 | 
						||
}
 | 
						||
 | 
						||
// matchSourceAndDestinationWithRule.
 | 
						||
func matchSourceAndDestinationWithRule(
 | 
						||
	ruleSources []string,
 | 
						||
	ruleDestinations []string,
 | 
						||
	source []string,
 | 
						||
	destination []string,
 | 
						||
) bool {
 | 
						||
	return containsAddresses(ruleSources, source) &&
 | 
						||
		containsAddresses(ruleDestinations, destination)
 | 
						||
}
 | 
						||
 | 
						||
// getFilteredByACLPeerss should return the list of peers authorized to be accessed from machine.
 | 
						||
func getFilteredByACLPeers(
 | 
						||
	machines []Machine,
 | 
						||
	rules []tailcfg.FilterRule,
 | 
						||
	machine *Machine,
 | 
						||
) Machines {
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msg("Finding peers filtered by ACLs")
 | 
						||
 | 
						||
	peers := make(map[uint64]Machine)
 | 
						||
	// Aclfilter peers here. We are itering through machines in all namespaces and search through the computed aclRules
 | 
						||
	// for match between rule SrcIPs and DstPorts. If the rule is a match we allow the machine to be viewable.
 | 
						||
 | 
						||
	// FIXME: On official control plane if a rule allow user A to talk to user B but NO rule allows user B to talk to
 | 
						||
	// user A. The behaviour is the following
 | 
						||
	//
 | 
						||
	// On official tailscale control plane:
 | 
						||
	//   on first `tailscale status`` on node A we can see node B. The `tailscale status` command on node B doesn't show node A
 | 
						||
	//   We can successfully establish a communication from A to B. When it's done, if we run the `tailscale status` command
 | 
						||
	//   on node B again we can now see node A. It's not possible to establish a communication from node B to node A.
 | 
						||
	// On this implementation of the feature
 | 
						||
	//   on any `tailscale status` command on node A we can see node B. The `tailscale status` command on node B DOES show A.
 | 
						||
	//
 | 
						||
	// I couldn't find a way to not clutter the output of `tailscale status` with all nodes that we could be talking to.
 | 
						||
	// In order to do this we would need to be able to identify that node A want to talk to node B but that Node B doesn't know
 | 
						||
	// how to talk to node A and then add the peering resource.
 | 
						||
 | 
						||
	for _, peer := range machines {
 | 
						||
		if peer.ID == machine.ID {
 | 
						||
			continue
 | 
						||
		}
 | 
						||
		for _, rule := range rules {
 | 
						||
			var dst []string
 | 
						||
			for _, d := range rule.DstPorts {
 | 
						||
				dst = append(dst, d.IP)
 | 
						||
			}
 | 
						||
			if matchSourceAndDestinationWithRule(
 | 
						||
				rule.SrcIPs,
 | 
						||
				dst,
 | 
						||
				machine.IPAddresses.ToStringSlice(),
 | 
						||
				peer.IPAddresses.ToStringSlice(),
 | 
						||
			) || // match source and destination
 | 
						||
				matchSourceAndDestinationWithRule(
 | 
						||
					rule.SrcIPs,
 | 
						||
					dst,
 | 
						||
					machine.IPAddresses.ToStringSlice(),
 | 
						||
					[]string{"*"},
 | 
						||
				) || // match source and all destination
 | 
						||
				matchSourceAndDestinationWithRule(
 | 
						||
					rule.SrcIPs,
 | 
						||
					dst,
 | 
						||
					peer.IPAddresses.ToStringSlice(),
 | 
						||
					machine.IPAddresses.ToStringSlice(),
 | 
						||
				) { // match return path
 | 
						||
				peers[peer.ID] = peer
 | 
						||
			}
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	authorizedPeers := make([]Machine, 0, len(peers))
 | 
						||
	for _, m := range peers {
 | 
						||
		authorizedPeers = append(authorizedPeers, m)
 | 
						||
	}
 | 
						||
	sort.Slice(
 | 
						||
		authorizedPeers,
 | 
						||
		func(i, j int) bool { return authorizedPeers[i].ID < authorizedPeers[j].ID },
 | 
						||
	)
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msgf("Found some machines: %v", machines)
 | 
						||
 | 
						||
	return authorizedPeers
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) getDirectPeers(machine *Machine) (Machines, error) {
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msg("Finding direct peers")
 | 
						||
 | 
						||
	machines := Machines{}
 | 
						||
	if err := h.db.Preload("Namespace").Where("namespace_id = ? AND machine_key <> ? AND registered",
 | 
						||
		machine.NamespaceID, machine.MachineKey).Find(&machines).Error; err != nil {
 | 
						||
		log.Error().Err(err).Msg("Error accessing db")
 | 
						||
 | 
						||
		return Machines{}, err
 | 
						||
	}
 | 
						||
 | 
						||
	sort.Slice(machines, func(i, j int) bool { return machines[i].ID < machines[j].ID })
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msgf("Found direct machines: %s", machines.String())
 | 
						||
 | 
						||
	return machines, nil
 | 
						||
}
 | 
						||
 | 
						||
// getShared fetches machines that are shared to the `Namespace` of the machine we are getting peers for.
 | 
						||
func (h *Headscale) getShared(machine *Machine) (Machines, error) {
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msg("Finding shared peers")
 | 
						||
 | 
						||
	sharedMachines := []SharedMachine{}
 | 
						||
	if err := h.db.Preload("Namespace").Preload("Machine").Preload("Machine.Namespace").Where("namespace_id = ?",
 | 
						||
		machine.NamespaceID).Find(&sharedMachines).Error; err != nil {
 | 
						||
		return Machines{}, err
 | 
						||
	}
 | 
						||
 | 
						||
	peers := make(Machines, 0)
 | 
						||
	for _, sharedMachine := range sharedMachines {
 | 
						||
		peers = append(peers, sharedMachine.Machine)
 | 
						||
	}
 | 
						||
 | 
						||
	sort.Slice(peers, func(i, j int) bool { return peers[i].ID < peers[j].ID })
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msgf("Found shared peers: %s", peers.String())
 | 
						||
 | 
						||
	return peers, nil
 | 
						||
}
 | 
						||
 | 
						||
// getSharedTo fetches the machines of the namespaces this machine is shared in.
 | 
						||
func (h *Headscale) getSharedTo(machine *Machine) (Machines, error) {
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msg("Finding peers in namespaces this machine is shared with")
 | 
						||
 | 
						||
	sharedMachines := []SharedMachine{}
 | 
						||
	if err := h.db.Preload("Namespace").Preload("Machine").Preload("Machine.Namespace").Where("machine_id = ?",
 | 
						||
		machine.ID).Find(&sharedMachines).Error; err != nil {
 | 
						||
		return Machines{}, err
 | 
						||
	}
 | 
						||
 | 
						||
	peers := make(Machines, 0)
 | 
						||
	for _, sharedMachine := range sharedMachines {
 | 
						||
		namespaceMachines, err := h.ListMachinesInNamespace(
 | 
						||
			sharedMachine.Namespace.Name,
 | 
						||
		)
 | 
						||
		if err != nil {
 | 
						||
			return Machines{}, err
 | 
						||
		}
 | 
						||
		peers = append(peers, namespaceMachines...)
 | 
						||
	}
 | 
						||
 | 
						||
	sort.Slice(peers, func(i, j int) bool { return peers[i].ID < peers[j].ID })
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msgf("Found peers we are shared with: %s", peers.String())
 | 
						||
 | 
						||
	return peers, nil
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) getPeers(machine *Machine) (Machines, error) {
 | 
						||
	var peers Machines
 | 
						||
	var err error
 | 
						||
 | 
						||
	// If ACLs rules are defined, filter visible host list with the ACLs
 | 
						||
	// else use the classic namespace scope
 | 
						||
	if h.aclPolicy != nil {
 | 
						||
		var machines []Machine
 | 
						||
		machines, err = h.ListAllMachines()
 | 
						||
		if err != nil {
 | 
						||
			log.Error().Err(err).Msg("Error retrieving list of machines")
 | 
						||
 | 
						||
			return Machines{}, err
 | 
						||
		}
 | 
						||
		peers = getFilteredByACLPeers(machines, h.aclRules, machine)
 | 
						||
	} else {
 | 
						||
		direct, err := h.getDirectPeers(machine)
 | 
						||
		if err != nil {
 | 
						||
			log.Error().
 | 
						||
				Caller().
 | 
						||
				Err(err).
 | 
						||
				Msg("Cannot fetch peers")
 | 
						||
 | 
						||
			return Machines{}, err
 | 
						||
		}
 | 
						||
 | 
						||
		shared, err := h.getShared(machine)
 | 
						||
		if err != nil {
 | 
						||
			log.Error().
 | 
						||
				Caller().
 | 
						||
				Err(err).
 | 
						||
				Msg("Cannot fetch peers")
 | 
						||
 | 
						||
			return Machines{}, err
 | 
						||
		}
 | 
						||
 | 
						||
		sharedTo, err := h.getSharedTo(machine)
 | 
						||
		if err != nil {
 | 
						||
			log.Error().
 | 
						||
				Caller().
 | 
						||
				Err(err).
 | 
						||
				Msg("Cannot fetch peers")
 | 
						||
 | 
						||
			return Machines{}, err
 | 
						||
		}
 | 
						||
		peers = append(direct, shared...)
 | 
						||
		peers = append(peers, sharedTo...)
 | 
						||
	}
 | 
						||
 | 
						||
	sort.Slice(peers, func(i, j int) bool { return peers[i].ID < peers[j].ID })
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msgf("Found total peers: %s", peers.String())
 | 
						||
 | 
						||
	return peers, nil
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) getValidPeers(machine *Machine) (Machines, error) {
 | 
						||
	validPeers := make(Machines, 0)
 | 
						||
 | 
						||
	peers, err := h.getPeers(machine)
 | 
						||
	if err != nil {
 | 
						||
		return Machines{}, err
 | 
						||
	}
 | 
						||
 | 
						||
	for _, peer := range peers {
 | 
						||
		if peer.isRegistered() && !peer.isExpired() {
 | 
						||
			validPeers = append(validPeers, peer)
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	return validPeers, nil
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) ListMachines() ([]Machine, error) {
 | 
						||
	machines := []Machine{}
 | 
						||
	if err := h.db.Preload("AuthKey").Preload("AuthKey.Namespace").Preload("Namespace").Find(&machines).Error; err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	return machines, nil
 | 
						||
}
 | 
						||
 | 
						||
// GetMachine finds a Machine by name and namespace and returns the Machine struct.
 | 
						||
func (h *Headscale) GetMachine(namespace string, name string) (*Machine, error) {
 | 
						||
	machines, err := h.ListMachinesInNamespace(namespace)
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	for _, m := range machines {
 | 
						||
		if m.Name == name {
 | 
						||
			return &m, nil
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	return nil, errMachineNotFound
 | 
						||
}
 | 
						||
 | 
						||
// GetMachineByID finds a Machine by ID and returns the Machine struct.
 | 
						||
func (h *Headscale) GetMachineByID(id uint64) (*Machine, error) {
 | 
						||
	m := Machine{}
 | 
						||
	if result := h.db.Preload("Namespace").Find(&Machine{ID: id}).First(&m); result.Error != nil {
 | 
						||
		return nil, result.Error
 | 
						||
	}
 | 
						||
 | 
						||
	return &m, nil
 | 
						||
}
 | 
						||
 | 
						||
// GetMachineByMachineKey finds a Machine by ID and returns the Machine struct.
 | 
						||
func (h *Headscale) GetMachineByMachineKey(
 | 
						||
	machineKey key.MachinePublic,
 | 
						||
) (*Machine, error) {
 | 
						||
	m := Machine{}
 | 
						||
	if result := h.db.Preload("Namespace").First(&m, "machine_key = ?", MachinePublicKeyStripPrefix(machineKey)); result.Error != nil {
 | 
						||
		return nil, result.Error
 | 
						||
	}
 | 
						||
 | 
						||
	return &m, nil
 | 
						||
}
 | 
						||
 | 
						||
// UpdateMachine takes a Machine struct pointer (typically already loaded from database
 | 
						||
// and updates it with the latest data from the database.
 | 
						||
func (h *Headscale) UpdateMachine(machine *Machine) error {
 | 
						||
	if result := h.db.Find(machine).First(&machine); result.Error != nil {
 | 
						||
		return result.Error
 | 
						||
	}
 | 
						||
 | 
						||
	return nil
 | 
						||
}
 | 
						||
 | 
						||
// ExpireMachine takes a Machine struct and sets the expire field to now.
 | 
						||
func (h *Headscale) ExpireMachine(machine *Machine) {
 | 
						||
	now := time.Now()
 | 
						||
	machine.Expiry = &now
 | 
						||
 | 
						||
	h.setLastStateChangeToNow(machine.Namespace.Name)
 | 
						||
 | 
						||
	h.db.Save(machine)
 | 
						||
}
 | 
						||
 | 
						||
// RefreshMachine takes a Machine struct and sets the expire field to now.
 | 
						||
func (h *Headscale) RefreshMachine(machine *Machine, expiry time.Time) {
 | 
						||
	now := time.Now()
 | 
						||
 | 
						||
	machine.LastSuccessfulUpdate = &now
 | 
						||
	machine.Expiry = &expiry
 | 
						||
 | 
						||
	h.setLastStateChangeToNow(machine.Namespace.Name)
 | 
						||
 | 
						||
	h.db.Save(machine)
 | 
						||
}
 | 
						||
 | 
						||
// DeleteMachine softs deletes a Machine from the database.
 | 
						||
func (h *Headscale) DeleteMachine(machine *Machine) error {
 | 
						||
	err := h.RemoveSharedMachineFromAllNamespaces(machine)
 | 
						||
	if err != nil && errors.Is(err, errMachineNotShared) {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	machine.Registered = false
 | 
						||
	h.db.Save(&machine) // we mark it as unregistered, just in case
 | 
						||
	if err := h.db.Delete(&machine).Error; err != nil {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	return nil
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) TouchMachine(machine *Machine) error {
 | 
						||
	return h.db.Updates(Machine{
 | 
						||
		ID:                   machine.ID,
 | 
						||
		LastSeen:             machine.LastSeen,
 | 
						||
		LastSuccessfulUpdate: machine.LastSuccessfulUpdate,
 | 
						||
	}).Error
 | 
						||
}
 | 
						||
 | 
						||
// HardDeleteMachine hard deletes a Machine from the database.
 | 
						||
func (h *Headscale) HardDeleteMachine(machine *Machine) error {
 | 
						||
	err := h.RemoveSharedMachineFromAllNamespaces(machine)
 | 
						||
	if err != nil && errors.Is(err, errMachineNotShared) {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	if err := h.db.Unscoped().Delete(&machine).Error; err != nil {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	return nil
 | 
						||
}
 | 
						||
 | 
						||
// GetHostInfo returns a Hostinfo struct for the machine.
 | 
						||
func (machine *Machine) GetHostInfo() (*tailcfg.Hostinfo, error) {
 | 
						||
	hostinfo := tailcfg.Hostinfo{}
 | 
						||
	if len(machine.HostInfo) != 0 {
 | 
						||
		hi, err := machine.HostInfo.MarshalJSON()
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
		err = json.Unmarshal(hi, &hostinfo)
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	return &hostinfo, nil
 | 
						||
}
 | 
						||
 | 
						||
func (h *Headscale) isOutdated(machine *Machine) bool {
 | 
						||
	if err := h.UpdateMachine(machine); err != nil {
 | 
						||
		// It does not seem meaningful to propagate this error as the end result
 | 
						||
		// will have to be that the machine has to be considered outdated.
 | 
						||
		return true
 | 
						||
	}
 | 
						||
 | 
						||
	sharedMachines, _ := h.getShared(machine)
 | 
						||
 | 
						||
	namespaceSet := set.New(set.ThreadSafe)
 | 
						||
	namespaceSet.Add(machine.Namespace.Name)
 | 
						||
 | 
						||
	// Check if any of our shared namespaces has updates that we have
 | 
						||
	// not propagated.
 | 
						||
	for _, sharedMachine := range sharedMachines {
 | 
						||
		namespaceSet.Add(sharedMachine.Namespace.Name)
 | 
						||
	}
 | 
						||
 | 
						||
	namespaces := make([]string, namespaceSet.Size())
 | 
						||
	for index, namespace := range namespaceSet.List() {
 | 
						||
		if name, ok := namespace.(string); ok {
 | 
						||
			namespaces[index] = name
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	lastChange := h.getLastStateChange(namespaces...)
 | 
						||
	lastUpdate := machine.CreatedAt
 | 
						||
	if machine.LastSuccessfulUpdate != nil {
 | 
						||
		lastUpdate = *machine.LastSuccessfulUpdate
 | 
						||
	}
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Time("last_successful_update", lastChange).
 | 
						||
		Time("last_state_change", lastUpdate).
 | 
						||
		Msgf("Checking if %s is missing updates", machine.Name)
 | 
						||
 | 
						||
	return lastUpdate.Before(lastChange)
 | 
						||
}
 | 
						||
 | 
						||
func (machine Machine) String() string {
 | 
						||
	return machine.Name
 | 
						||
}
 | 
						||
 | 
						||
func (machines Machines) String() string {
 | 
						||
	temp := make([]string, len(machines))
 | 
						||
 | 
						||
	for index, machine := range machines {
 | 
						||
		temp[index] = machine.Name
 | 
						||
	}
 | 
						||
 | 
						||
	return fmt.Sprintf("[ %s ](%d)", strings.Join(temp, ", "), len(temp))
 | 
						||
}
 | 
						||
 | 
						||
// TODO(kradalby): Remove when we have generics...
 | 
						||
func (machines MachinesP) String() string {
 | 
						||
	temp := make([]string, len(machines))
 | 
						||
 | 
						||
	for index, machine := range machines {
 | 
						||
		temp[index] = machine.Name
 | 
						||
	}
 | 
						||
 | 
						||
	return fmt.Sprintf("[ %s ](%d)", strings.Join(temp, ", "), len(temp))
 | 
						||
}
 | 
						||
 | 
						||
func (machines Machines) toNodes(
 | 
						||
	baseDomain string,
 | 
						||
	dnsConfig *tailcfg.DNSConfig,
 | 
						||
	includeRoutes bool,
 | 
						||
) ([]*tailcfg.Node, error) {
 | 
						||
	nodes := make([]*tailcfg.Node, len(machines))
 | 
						||
 | 
						||
	for index, machine := range machines {
 | 
						||
		node, err := machine.toNode(baseDomain, dnsConfig, includeRoutes)
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
 | 
						||
		nodes[index] = node
 | 
						||
	}
 | 
						||
 | 
						||
	return nodes, nil
 | 
						||
}
 | 
						||
 | 
						||
// toNode converts a Machine into a Tailscale Node. includeRoutes is false for shared nodes
 | 
						||
// as per the expected behaviour in the official SaaS.
 | 
						||
func (machine Machine) toNode(
 | 
						||
	baseDomain string,
 | 
						||
	dnsConfig *tailcfg.DNSConfig,
 | 
						||
	includeRoutes bool,
 | 
						||
) (*tailcfg.Node, error) {
 | 
						||
	var nodeKey key.NodePublic
 | 
						||
	err := nodeKey.UnmarshalText([]byte(NodePublicKeyEnsurePrefix(machine.NodeKey)))
 | 
						||
	if err != nil {
 | 
						||
		log.Trace().
 | 
						||
			Caller().
 | 
						||
			Str("node_key", machine.NodeKey).
 | 
						||
			Msgf("Failed to parse node public key from hex")
 | 
						||
 | 
						||
		return nil, fmt.Errorf("failed to parse node public key: %w", err)
 | 
						||
	}
 | 
						||
 | 
						||
	var machineKey key.MachinePublic
 | 
						||
	err = machineKey.UnmarshalText(
 | 
						||
		[]byte(MachinePublicKeyEnsurePrefix(machine.MachineKey)),
 | 
						||
	)
 | 
						||
	if err != nil {
 | 
						||
		return nil, fmt.Errorf("failed to parse machine public key: %w", err)
 | 
						||
	}
 | 
						||
 | 
						||
	var discoKey key.DiscoPublic
 | 
						||
	if machine.DiscoKey != "" {
 | 
						||
		err := discoKey.UnmarshalText(
 | 
						||
			[]byte(DiscoPublicKeyEnsurePrefix(machine.DiscoKey)),
 | 
						||
		)
 | 
						||
		if err != nil {
 | 
						||
			return nil, fmt.Errorf("failed to parse disco public key: %w", err)
 | 
						||
		}
 | 
						||
	} else {
 | 
						||
		discoKey = key.DiscoPublic{}
 | 
						||
	}
 | 
						||
 | 
						||
	addrs := []netaddr.IPPrefix{}
 | 
						||
	for _, machineAddress := range machine.IPAddresses {
 | 
						||
		ip := netaddr.IPPrefixFrom(machineAddress, machineAddress.BitLen())
 | 
						||
		addrs = append(addrs, ip)
 | 
						||
	}
 | 
						||
 | 
						||
	allowedIPs := append(
 | 
						||
		[]netaddr.IPPrefix{},
 | 
						||
		addrs...) // we append the node own IP, as it is required by the clients
 | 
						||
 | 
						||
	if includeRoutes {
 | 
						||
		routesStr := []string{}
 | 
						||
		if len(machine.EnabledRoutes) != 0 {
 | 
						||
			allwIps, err := machine.EnabledRoutes.MarshalJSON()
 | 
						||
			if err != nil {
 | 
						||
				return nil, err
 | 
						||
			}
 | 
						||
			err = json.Unmarshal(allwIps, &routesStr)
 | 
						||
			if err != nil {
 | 
						||
				return nil, err
 | 
						||
			}
 | 
						||
		}
 | 
						||
 | 
						||
		for _, routeStr := range routesStr {
 | 
						||
			ip, err := netaddr.ParseIPPrefix(routeStr)
 | 
						||
			if err != nil {
 | 
						||
				return nil, err
 | 
						||
			}
 | 
						||
			allowedIPs = append(allowedIPs, ip)
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	endpoints := []string{}
 | 
						||
	if len(machine.Endpoints) != 0 {
 | 
						||
		be, err := machine.Endpoints.MarshalJSON()
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
		err = json.Unmarshal(be, &endpoints)
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	hostinfo := tailcfg.Hostinfo{}
 | 
						||
	if len(machine.HostInfo) != 0 {
 | 
						||
		hi, err := machine.HostInfo.MarshalJSON()
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
		err = json.Unmarshal(hi, &hostinfo)
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	var derp string
 | 
						||
	if hostinfo.NetInfo != nil {
 | 
						||
		derp = fmt.Sprintf("127.3.3.40:%d", hostinfo.NetInfo.PreferredDERP)
 | 
						||
	} else {
 | 
						||
		derp = "127.3.3.40:0" // Zero means disconnected or unknown.
 | 
						||
	}
 | 
						||
 | 
						||
	var keyExpiry time.Time
 | 
						||
	if machine.Expiry != nil {
 | 
						||
		keyExpiry = *machine.Expiry
 | 
						||
	} else {
 | 
						||
		keyExpiry = time.Time{}
 | 
						||
	}
 | 
						||
 | 
						||
	var hostname string
 | 
						||
	if dnsConfig != nil && dnsConfig.Proxied { // MagicDNS
 | 
						||
		hostname = fmt.Sprintf(
 | 
						||
			"%s.%s.%s",
 | 
						||
			machine.Name,
 | 
						||
			strings.ReplaceAll(
 | 
						||
				machine.Namespace.Name,
 | 
						||
				"@",
 | 
						||
				".",
 | 
						||
			), // Replace @ with . for valid domain for machine
 | 
						||
			baseDomain,
 | 
						||
		)
 | 
						||
	} else {
 | 
						||
		hostname = machine.Name
 | 
						||
	}
 | 
						||
 | 
						||
	node := tailcfg.Node{
 | 
						||
		ID: tailcfg.NodeID(machine.ID), // this is the actual ID
 | 
						||
		StableID: tailcfg.StableNodeID(
 | 
						||
			strconv.FormatUint(machine.ID, Base10),
 | 
						||
		), // in headscale, unlike tailcontrol server, IDs are permanent
 | 
						||
		Name:       hostname,
 | 
						||
		User:       tailcfg.UserID(machine.NamespaceID),
 | 
						||
		Key:        nodeKey,
 | 
						||
		KeyExpiry:  keyExpiry,
 | 
						||
		Machine:    machineKey,
 | 
						||
		DiscoKey:   discoKey,
 | 
						||
		Addresses:  addrs,
 | 
						||
		AllowedIPs: allowedIPs,
 | 
						||
		Endpoints:  endpoints,
 | 
						||
		DERP:       derp,
 | 
						||
 | 
						||
		Hostinfo: hostinfo,
 | 
						||
		Created:  machine.CreatedAt,
 | 
						||
		LastSeen: machine.LastSeen,
 | 
						||
 | 
						||
		KeepAlive:         true,
 | 
						||
		MachineAuthorized: machine.Registered,
 | 
						||
		Capabilities:      []string{tailcfg.CapabilityFileSharing},
 | 
						||
	}
 | 
						||
 | 
						||
	return &node, nil
 | 
						||
}
 | 
						||
 | 
						||
func (machine *Machine) toProto() *v1.Machine {
 | 
						||
	machineProto := &v1.Machine{
 | 
						||
		Id:         machine.ID,
 | 
						||
		MachineKey: machine.MachineKey,
 | 
						||
 | 
						||
		NodeKey:     machine.NodeKey,
 | 
						||
		DiscoKey:    machine.DiscoKey,
 | 
						||
		IpAddresses: machine.IPAddresses.ToStringSlice(),
 | 
						||
		Name:        machine.Name,
 | 
						||
		Namespace:   machine.Namespace.toProto(),
 | 
						||
 | 
						||
		Registered: machine.Registered,
 | 
						||
 | 
						||
		// TODO(kradalby): Implement register method enum converter
 | 
						||
		// RegisterMethod: ,
 | 
						||
 | 
						||
		CreatedAt: timestamppb.New(machine.CreatedAt),
 | 
						||
	}
 | 
						||
 | 
						||
	if machine.AuthKey != nil {
 | 
						||
		machineProto.PreAuthKey = machine.AuthKey.toProto()
 | 
						||
	}
 | 
						||
 | 
						||
	if machine.LastSeen != nil {
 | 
						||
		machineProto.LastSeen = timestamppb.New(*machine.LastSeen)
 | 
						||
	}
 | 
						||
 | 
						||
	if machine.LastSuccessfulUpdate != nil {
 | 
						||
		machineProto.LastSuccessfulUpdate = timestamppb.New(
 | 
						||
			*machine.LastSuccessfulUpdate,
 | 
						||
		)
 | 
						||
	}
 | 
						||
 | 
						||
	if machine.Expiry != nil {
 | 
						||
		machineProto.Expiry = timestamppb.New(*machine.Expiry)
 | 
						||
	}
 | 
						||
 | 
						||
	return machineProto
 | 
						||
}
 | 
						||
 | 
						||
// RegisterMachine is executed from the CLI to register a new Machine using its MachineKey.
 | 
						||
func (h *Headscale) RegisterMachine(
 | 
						||
	machineKeyStr string,
 | 
						||
	namespaceName string,
 | 
						||
) (*Machine, error) {
 | 
						||
	namespace, err := h.GetNamespace(namespaceName)
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	var machineKey key.MachinePublic
 | 
						||
	err = machineKey.UnmarshalText([]byte(MachinePublicKeyEnsurePrefix(machineKeyStr)))
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine_key_str", machineKeyStr).
 | 
						||
		Str("machine_key", machineKey.String()).
 | 
						||
		Msg("Registering machine")
 | 
						||
 | 
						||
	machine, err := h.GetMachineByMachineKey(machineKey)
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	// TODO(kradalby): Currently, if it fails to find a requested expiry, non will be set
 | 
						||
	// This means that if a user is to slow with register a machine, it will possibly not
 | 
						||
	// have the correct expiry.
 | 
						||
	requestedTime := time.Time{}
 | 
						||
	if requestedTimeIf, found := h.requestedExpiryCache.Get(machineKey.String()); found {
 | 
						||
		log.Trace().
 | 
						||
			Caller().
 | 
						||
			Str("machine", machine.Name).
 | 
						||
			Msg("Expiry time found in cache, assigning to node")
 | 
						||
		if reqTime, ok := requestedTimeIf.(time.Time); ok {
 | 
						||
			requestedTime = reqTime
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	if machine.isRegistered() {
 | 
						||
		log.Trace().
 | 
						||
			Caller().
 | 
						||
			Str("machine", machine.Name).
 | 
						||
			Msg("machine already registered, reauthenticating")
 | 
						||
 | 
						||
		h.RefreshMachine(machine, requestedTime)
 | 
						||
 | 
						||
		return machine, nil
 | 
						||
	}
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Msg("Attempting to register machine")
 | 
						||
 | 
						||
	if machine.isRegistered() {
 | 
						||
		err := errMachineAlreadyRegistered
 | 
						||
		log.Error().
 | 
						||
			Caller().
 | 
						||
			Err(err).
 | 
						||
			Str("machine", machine.Name).
 | 
						||
			Msg("Attempting to register machine")
 | 
						||
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	ips, err := h.getAvailableIPs()
 | 
						||
	if err != nil {
 | 
						||
		log.Error().
 | 
						||
			Caller().
 | 
						||
			Err(err).
 | 
						||
			Str("machine", machine.Name).
 | 
						||
			Msg("Could not find IP for the new machine")
 | 
						||
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Str("ip", strings.Join(ips.ToStringSlice(), ",")).
 | 
						||
		Msg("Found IP for host")
 | 
						||
 | 
						||
	machine.IPAddresses = ips
 | 
						||
	machine.NamespaceID = namespace.ID
 | 
						||
	machine.Registered = true
 | 
						||
	machine.RegisterMethod = RegisterMethodCLI
 | 
						||
	machine.Expiry = &requestedTime
 | 
						||
	h.db.Save(&machine)
 | 
						||
 | 
						||
	log.Trace().
 | 
						||
		Caller().
 | 
						||
		Str("machine", machine.Name).
 | 
						||
		Str("ip", strings.Join(ips.ToStringSlice(), ",")).
 | 
						||
		Msg("Machine registered with the database")
 | 
						||
 | 
						||
	return machine, nil
 | 
						||
}
 | 
						||
 | 
						||
func (machine *Machine) GetAdvertisedRoutes() ([]netaddr.IPPrefix, error) {
 | 
						||
	hostInfo, err := machine.GetHostInfo()
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	return hostInfo.RoutableIPs, nil
 | 
						||
}
 | 
						||
 | 
						||
func (machine *Machine) GetEnabledRoutes() ([]netaddr.IPPrefix, error) {
 | 
						||
	data, err := machine.EnabledRoutes.MarshalJSON()
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	routesStr := []string{}
 | 
						||
	err = json.Unmarshal(data, &routesStr)
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	routes := make([]netaddr.IPPrefix, len(routesStr))
 | 
						||
	for index, routeStr := range routesStr {
 | 
						||
		route, err := netaddr.ParseIPPrefix(routeStr)
 | 
						||
		if err != nil {
 | 
						||
			return nil, err
 | 
						||
		}
 | 
						||
		routes[index] = route
 | 
						||
	}
 | 
						||
 | 
						||
	return routes, nil
 | 
						||
}
 | 
						||
 | 
						||
func (machine *Machine) IsRoutesEnabled(routeStr string) bool {
 | 
						||
	route, err := netaddr.ParseIPPrefix(routeStr)
 | 
						||
	if err != nil {
 | 
						||
		return false
 | 
						||
	}
 | 
						||
 | 
						||
	enabledRoutes, err := machine.GetEnabledRoutes()
 | 
						||
	if err != nil {
 | 
						||
		return false
 | 
						||
	}
 | 
						||
 | 
						||
	for _, enabledRoute := range enabledRoutes {
 | 
						||
		if route == enabledRoute {
 | 
						||
			return true
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	return false
 | 
						||
}
 | 
						||
 | 
						||
// EnableNodeRoute enables new routes based on a list of new routes. It will _replace_ the
 | 
						||
// previous list of routes.
 | 
						||
func (h *Headscale) EnableRoutes(machine *Machine, routeStrs ...string) error {
 | 
						||
	newRoutes := make([]netaddr.IPPrefix, len(routeStrs))
 | 
						||
	for index, routeStr := range routeStrs {
 | 
						||
		route, err := netaddr.ParseIPPrefix(routeStr)
 | 
						||
		if err != nil {
 | 
						||
			return err
 | 
						||
		}
 | 
						||
 | 
						||
		newRoutes[index] = route
 | 
						||
	}
 | 
						||
 | 
						||
	availableRoutes, err := machine.GetAdvertisedRoutes()
 | 
						||
	if err != nil {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	for _, newRoute := range newRoutes {
 | 
						||
		if !containsIPPrefix(availableRoutes, newRoute) {
 | 
						||
			return fmt.Errorf(
 | 
						||
				"route (%s) is not available on node %s: %w",
 | 
						||
				machine.Name,
 | 
						||
				newRoute, errMachineRouteIsNotAvailable,
 | 
						||
			)
 | 
						||
		}
 | 
						||
	}
 | 
						||
 | 
						||
	routes, err := json.Marshal(newRoutes)
 | 
						||
	if err != nil {
 | 
						||
		return err
 | 
						||
	}
 | 
						||
 | 
						||
	machine.EnabledRoutes = datatypes.JSON(routes)
 | 
						||
	h.db.Save(&machine)
 | 
						||
 | 
						||
	return nil
 | 
						||
}
 | 
						||
 | 
						||
func (machine *Machine) RoutesToProto() (*v1.Routes, error) {
 | 
						||
	availableRoutes, err := machine.GetAdvertisedRoutes()
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	enabledRoutes, err := machine.GetEnabledRoutes()
 | 
						||
	if err != nil {
 | 
						||
		return nil, err
 | 
						||
	}
 | 
						||
 | 
						||
	return &v1.Routes{
 | 
						||
		AdvertisedRoutes: ipPrefixToString(availableRoutes),
 | 
						||
		EnabledRoutes:    ipPrefixToString(enabledRoutes),
 | 
						||
	}, nil
 | 
						||
}
 |