2021-08-15 16:56:26 +02:00
|
|
|
package internal
|
2021-05-01 12:45:37 +02:00
|
|
|
|
|
|
|
import (
|
2021-09-07 18:36:46 +02:00
|
|
|
"context"
|
2021-05-01 12:45:37 +02:00
|
|
|
"fmt"
|
2022-06-23 17:04:53 +02:00
|
|
|
nbssh "github.com/netbirdio/netbird/client/ssh"
|
2022-07-02 12:02:17 +02:00
|
|
|
nbstatus "github.com/netbirdio/netbird/client/status"
|
2022-02-08 18:03:27 +01:00
|
|
|
"math/rand"
|
2022-02-16 20:00:21 +01:00
|
|
|
"net"
|
2022-06-23 17:04:53 +02:00
|
|
|
"runtime"
|
2022-02-08 18:03:27 +01:00
|
|
|
"strings"
|
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
2022-03-26 12:08:54 +01:00
|
|
|
"github.com/netbirdio/netbird/client/internal/peer"
|
|
|
|
"github.com/netbirdio/netbird/client/internal/proxy"
|
|
|
|
"github.com/netbirdio/netbird/iface"
|
|
|
|
mgm "github.com/netbirdio/netbird/management/client"
|
|
|
|
mgmProto "github.com/netbirdio/netbird/management/proto"
|
|
|
|
signal "github.com/netbirdio/netbird/signal/client"
|
|
|
|
sProto "github.com/netbirdio/netbird/signal/proto"
|
|
|
|
"github.com/netbirdio/netbird/util"
|
2021-11-06 15:00:13 +01:00
|
|
|
"github.com/pion/ice/v2"
|
2021-05-01 12:45:37 +02:00
|
|
|
log "github.com/sirupsen/logrus"
|
|
|
|
"golang.zx2c4.com/wireguard/wgctrl/wgtypes"
|
|
|
|
)
|
|
|
|
|
2022-01-01 14:03:03 +01:00
|
|
|
// PeerConnectionTimeoutMax is a timeout of an initial connection attempt to a remote peer.
|
2022-02-16 20:00:21 +01:00
|
|
|
// E.g. this peer will wait PeerConnectionTimeoutMax for the remote peer to respond,
|
|
|
|
// if not successful then it will retry the connection attempt.
|
2022-01-17 14:01:58 +01:00
|
|
|
// Todo pass timeout at EnginConfig
|
2022-02-16 20:00:21 +01:00
|
|
|
const (
|
|
|
|
PeerConnectionTimeoutMax = 45000 // ms
|
|
|
|
PeerConnectionTimeoutMin = 30000 // ms
|
|
|
|
)
|
2022-01-10 18:43:13 +01:00
|
|
|
|
2022-03-08 14:47:55 +01:00
|
|
|
var ErrResetConnection = fmt.Errorf("reset connection")
|
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// EngineConfig is a config for the Engine
|
|
|
|
type EngineConfig struct {
|
2022-01-17 14:01:58 +01:00
|
|
|
WgPort int
|
|
|
|
WgIfaceName string
|
2022-02-16 20:00:21 +01:00
|
|
|
|
2022-05-26 10:09:11 +02:00
|
|
|
// WgAddr is a Wireguard local address (Netbird Network IP)
|
2021-08-15 16:56:26 +02:00
|
|
|
WgAddr string
|
2022-02-16 20:00:21 +01:00
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// WgPrivateKey is a Wireguard private key of our peer (it MUST never leave the machine)
|
|
|
|
WgPrivateKey wgtypes.Key
|
2022-02-16 20:00:21 +01:00
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// IFaceBlackList is a list of network interfaces to ignore when discovering connection candidates (ICE related)
|
2022-06-05 14:43:13 +02:00
|
|
|
IFaceBlackList []string
|
2021-11-21 17:47:19 +01:00
|
|
|
|
|
|
|
PreSharedKey *wgtypes.Key
|
2022-02-16 20:00:21 +01:00
|
|
|
|
|
|
|
// UDPMuxPort default value 0 - the system will pick an available port
|
|
|
|
UDPMuxPort int
|
|
|
|
|
|
|
|
// UDPMuxSrflxPort default value 0 - the system will pick an available port
|
|
|
|
UDPMuxSrflxPort int
|
2022-06-23 17:04:53 +02:00
|
|
|
|
|
|
|
// SSHKey is a private SSH key in a PEM format
|
|
|
|
SSHKey []byte
|
2021-08-15 16:56:26 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Engine is a mechanism responsible for reacting on Signal and Management stream events and managing connections to the remote peers.
|
2021-05-01 12:45:37 +02:00
|
|
|
type Engine struct {
|
2021-08-15 16:56:26 +02:00
|
|
|
// signal is a Signal Service client
|
2022-01-18 16:44:58 +01:00
|
|
|
signal signal.Client
|
2021-08-15 16:56:26 +02:00
|
|
|
// mgmClient is a Management Service client
|
2022-01-18 16:44:58 +01:00
|
|
|
mgmClient mgm.Client
|
2022-01-10 18:43:13 +01:00
|
|
|
// peerConns is a map that holds all the peers that are known to this peer
|
|
|
|
peerConns map[string]*peer.Conn
|
2021-08-15 16:56:26 +02:00
|
|
|
|
|
|
|
// syncMsgMux is used to guarantee sequential Management Service message processing
|
|
|
|
syncMsgMux *sync.Mutex
|
|
|
|
|
|
|
|
config *EngineConfig
|
2021-09-03 17:47:40 +02:00
|
|
|
// STUNs is a list of STUN servers used by ICE
|
|
|
|
STUNs []*ice.URL
|
|
|
|
// TURNs is a list of STUN servers used by ICE
|
|
|
|
TURNs []*ice.URL
|
2021-09-07 18:36:46 +02:00
|
|
|
|
|
|
|
cancel context.CancelFunc
|
2021-10-17 22:15:38 +02:00
|
|
|
|
|
|
|
ctx context.Context
|
2022-01-17 14:01:58 +01:00
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
wgInterface *iface.WGIface
|
2022-01-18 16:44:58 +01:00
|
|
|
|
2022-02-16 20:00:21 +01:00
|
|
|
udpMux ice.UDPMux
|
|
|
|
udpMuxSrflx ice.UniversalUDPMux
|
|
|
|
udpMuxConn *net.UDPConn
|
|
|
|
udpMuxConnSrflx *net.UDPConn
|
|
|
|
|
2022-03-10 18:18:38 +01:00
|
|
|
// networkSerial is the latest CurrentSerial (state ID) of the network sent by the Management service
|
2022-01-18 16:44:58 +01:00
|
|
|
networkSerial uint64
|
2022-06-23 17:04:53 +02:00
|
|
|
|
|
|
|
sshServerFunc func(hostKeyPEM []byte, addr string) (nbssh.Server, error)
|
|
|
|
sshServer nbssh.Server
|
2022-07-02 12:02:17 +02:00
|
|
|
|
|
|
|
statusRecorder *nbstatus.Status
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2021-05-15 12:23:56 +02:00
|
|
|
// Peer is an instance of the Connection Peer
|
2021-05-01 12:45:37 +02:00
|
|
|
type Peer struct {
|
|
|
|
WgPubKey string
|
|
|
|
WgAllowedIps string
|
|
|
|
}
|
|
|
|
|
2021-05-15 12:23:56 +02:00
|
|
|
// NewEngine creates a new Connection Engine
|
2022-02-16 20:00:21 +01:00
|
|
|
func NewEngine(
|
2022-03-08 14:47:55 +01:00
|
|
|
ctx context.Context, cancel context.CancelFunc,
|
2022-07-02 12:02:17 +02:00
|
|
|
signalClient signal.Client, mgmClient mgm.Client,
|
|
|
|
config *EngineConfig, statusRecorder *nbstatus.Status,
|
2022-02-16 20:00:21 +01:00
|
|
|
) *Engine {
|
2021-05-01 12:45:37 +02:00
|
|
|
return &Engine{
|
2022-07-02 12:02:17 +02:00
|
|
|
ctx: ctx,
|
|
|
|
cancel: cancel,
|
|
|
|
signal: signalClient,
|
|
|
|
mgmClient: mgmClient,
|
|
|
|
peerConns: map[string]*peer.Conn{},
|
|
|
|
syncMsgMux: &sync.Mutex{},
|
|
|
|
config: config,
|
|
|
|
STUNs: []*ice.URL{},
|
|
|
|
TURNs: []*ice.URL{},
|
|
|
|
networkSerial: 0,
|
|
|
|
sshServerFunc: nbssh.DefaultSSHServer,
|
|
|
|
statusRecorder: statusRecorder,
|
2021-09-07 18:36:46 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (e *Engine) Stop() error {
|
2022-01-10 18:43:13 +01:00
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
|
|
|
|
2022-01-25 11:18:01 +01:00
|
|
|
err := e.removeAllPeers()
|
2021-10-17 22:15:38 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2022-03-13 15:16:16 +01:00
|
|
|
// very ugly but we want to remove peers from the WireGuard interface first before removing interface.
|
|
|
|
// Removing peers happens in the conn.CLose() asynchronously
|
|
|
|
time.Sleep(500 * time.Millisecond)
|
|
|
|
|
2022-05-26 10:09:11 +02:00
|
|
|
log.Debugf("removing Netbird interface %s", e.config.WgIfaceName)
|
2022-01-17 14:01:58 +01:00
|
|
|
if e.wgInterface.Interface != nil {
|
|
|
|
err = e.wgInterface.Close()
|
|
|
|
if err != nil {
|
2022-05-26 10:09:11 +02:00
|
|
|
log.Errorf("failed closing Netbird interface %s %v", e.config.WgIfaceName, err)
|
2022-01-17 14:01:58 +01:00
|
|
|
return err
|
|
|
|
}
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
2021-09-07 18:36:46 +02:00
|
|
|
|
2022-02-16 20:00:21 +01:00
|
|
|
if e.udpMux != nil {
|
|
|
|
if err := e.udpMux.Close(); err != nil {
|
|
|
|
log.Debugf("close udp mux: %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if e.udpMuxSrflx != nil {
|
|
|
|
if err := e.udpMuxSrflx.Close(); err != nil {
|
|
|
|
log.Debugf("close server reflexive udp mux: %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if e.udpMuxConn != nil {
|
|
|
|
if err := e.udpMuxConn.Close(); err != nil {
|
|
|
|
log.Debugf("close udp mux connection: %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if e.udpMuxConnSrflx != nil {
|
|
|
|
if err := e.udpMuxConnSrflx.Close(); err != nil {
|
|
|
|
log.Debugf("close server reflexive udp mux connection: %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-05-26 10:09:11 +02:00
|
|
|
log.Infof("stopped Netbird Engine")
|
2021-10-17 22:15:38 +02:00
|
|
|
|
2021-09-07 18:36:46 +02:00
|
|
|
return nil
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// Start creates a new Wireguard tunnel interface and listens to events from Signal and Management services
|
|
|
|
// Connections to remote peers are not established here.
|
|
|
|
// However, they will be established once an event with a list of peers to connect to will be received from Management Service
|
|
|
|
func (e *Engine) Start() error {
|
2022-01-10 18:43:13 +01:00
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
2021-08-15 16:56:26 +02:00
|
|
|
|
2022-01-17 14:01:58 +01:00
|
|
|
wgIfaceName := e.config.WgIfaceName
|
2021-08-15 16:56:26 +02:00
|
|
|
wgAddr := e.config.WgAddr
|
|
|
|
myPrivateKey := e.config.WgPrivateKey
|
2022-01-17 14:01:58 +01:00
|
|
|
var err error
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
e.wgInterface, err = iface.NewWGIFace(wgIfaceName, wgAddr, iface.DefaultMTU)
|
2022-01-17 14:01:58 +01:00
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed creating wireguard interface instance %s: [%s]", wgIfaceName, err.Error())
|
|
|
|
return err
|
|
|
|
}
|
2021-05-01 12:45:37 +02:00
|
|
|
|
2022-02-16 20:00:21 +01:00
|
|
|
e.udpMuxConn, err = net.ListenUDP("udp4", &net.UDPAddr{Port: e.config.UDPMuxPort})
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed listening on UDP port %d: [%s]", e.config.UDPMuxPort, err.Error())
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
e.udpMuxConnSrflx, err = net.ListenUDP("udp4", &net.UDPAddr{Port: e.config.UDPMuxSrflxPort})
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed listening on UDP port %d: [%s]", e.config.UDPMuxSrflxPort, err.Error())
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
e.udpMux = ice.NewUDPMuxDefault(ice.UDPMuxParams{UDPConn: e.udpMuxConn})
|
|
|
|
e.udpMuxSrflx = ice.NewUniversalUDPMuxDefault(ice.UniversalUDPMuxParams{UDPConn: e.udpMuxConnSrflx})
|
|
|
|
|
2022-01-17 14:01:58 +01:00
|
|
|
err = e.wgInterface.Create()
|
2021-05-01 12:45:37 +02:00
|
|
|
if err != nil {
|
2022-01-17 14:01:58 +01:00
|
|
|
log.Errorf("failed creating tunnel interface %s: [%s]", wgIfaceName, err.Error())
|
2021-05-01 12:45:37 +02:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2022-01-17 14:01:58 +01:00
|
|
|
err = e.wgInterface.Configure(myPrivateKey.String(), e.config.WgPort)
|
2021-05-01 12:45:37 +02:00
|
|
|
if err != nil {
|
2022-01-17 14:01:58 +01:00
|
|
|
log.Errorf("failed configuring Wireguard interface [%s]: %s", wgIfaceName, err.Error())
|
2021-05-01 12:45:37 +02:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
e.receiveSignalEvents()
|
|
|
|
e.receiveManagementEvents()
|
2021-05-01 12:45:37 +02:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
// modifyPeers updates peers that have been modified (e.g. IP address has been changed).
|
|
|
|
// It closes the existing connection, removes it from the peerConns map, and creates a new one.
|
|
|
|
func (e *Engine) modifyPeers(peersUpdate []*mgmProto.RemotePeerConfig) error {
|
|
|
|
|
|
|
|
// first, check if peers have been modified
|
|
|
|
var modified []*mgmProto.RemotePeerConfig
|
|
|
|
for _, p := range peersUpdate {
|
|
|
|
if peerConn, ok := e.peerConns[p.GetWgPubKey()]; ok {
|
|
|
|
if peerConn.GetConf().ProxyConfig.AllowedIps != strings.Join(p.AllowedIps, ",") {
|
|
|
|
modified = append(modified, p)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// second, close all modified connections and remove them from the state map
|
|
|
|
for _, p := range modified {
|
|
|
|
err := e.removePeer(p.GetWgPubKey())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
// third, add the peer connections again
|
|
|
|
for _, p := range modified {
|
|
|
|
err := e.addNewPeer(p)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// removePeers finds and removes peers that do not exist anymore in the network map received from the Management Service.
|
|
|
|
// It also removes peers that have been modified (e.g. change of IP address). They will be added again in addPeers method.
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) removePeers(peersUpdate []*mgmProto.RemotePeerConfig) error {
|
|
|
|
currentPeers := make([]string, 0, len(e.peerConns))
|
|
|
|
for p := range e.peerConns {
|
|
|
|
currentPeers = append(currentPeers, p)
|
|
|
|
}
|
|
|
|
|
|
|
|
newPeers := make([]string, 0, len(peersUpdate))
|
|
|
|
for _, p := range peersUpdate {
|
|
|
|
newPeers = append(newPeers, p.GetWgPubKey())
|
|
|
|
}
|
|
|
|
|
|
|
|
toRemove := util.SliceDiff(currentPeers, newPeers)
|
|
|
|
|
|
|
|
for _, p := range toRemove {
|
2022-01-10 18:43:13 +01:00
|
|
|
err := e.removePeer(p)
|
2021-08-15 16:56:26 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
log.Infof("removed peer %s", p)
|
2021-08-15 16:56:26 +02:00
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) removeAllPeers() error {
|
2021-10-17 22:15:38 +02:00
|
|
|
log.Debugf("removing all peer connections")
|
2022-01-10 18:43:13 +01:00
|
|
|
for p := range e.peerConns {
|
|
|
|
err := e.removePeer(p)
|
2021-10-17 22:15:38 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-06-23 17:04:53 +02:00
|
|
|
// removePeer closes an existing peer connection, removes a peer, and clears authorized key of the SSH server
|
2021-12-31 18:11:33 +01:00
|
|
|
func (e *Engine) removePeer(peerKey string) error {
|
2022-01-10 18:43:13 +01:00
|
|
|
log.Debugf("removing peer from engine %s", peerKey)
|
2022-06-23 17:04:53 +02:00
|
|
|
|
|
|
|
if e.sshServer != nil {
|
|
|
|
e.sshServer.RemoveAuthorizedKey(peerKey)
|
|
|
|
}
|
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
conn, exists := e.peerConns[peerKey]
|
|
|
|
if exists {
|
2022-07-02 12:02:17 +02:00
|
|
|
err := e.statusRecorder.RemovePeer(peerKey)
|
|
|
|
if err != nil {
|
|
|
|
log.Warn("received error when removing peer from status recorder: ", err)
|
|
|
|
}
|
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
delete(e.peerConns, peerKey)
|
2022-07-02 12:02:17 +02:00
|
|
|
err = conn.Close()
|
2022-01-21 13:52:19 +01:00
|
|
|
if err != nil {
|
|
|
|
switch err.(type) {
|
|
|
|
case *peer.ConnectionAlreadyClosedError:
|
|
|
|
return nil
|
|
|
|
default:
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
2021-07-19 15:02:11 +02:00
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// GetPeerConnectionStatus returns a connection Status or nil if peer connection wasn't found
|
2022-01-10 18:43:13 +01:00
|
|
|
func (e *Engine) GetPeerConnectionStatus(peerKey string) peer.ConnStatus {
|
|
|
|
conn, exists := e.peerConns[peerKey]
|
2021-07-19 15:02:11 +02:00
|
|
|
if exists && conn != nil {
|
2022-01-10 18:43:13 +01:00
|
|
|
return conn.Status()
|
2021-07-19 15:02:11 +02:00
|
|
|
}
|
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
return -1
|
2021-07-19 15:02:11 +02:00
|
|
|
}
|
2022-02-16 20:00:21 +01:00
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) GetPeers() []string {
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
|
|
|
|
|
|
|
peers := []string{}
|
|
|
|
for s := range e.peerConns {
|
|
|
|
peers = append(peers, s)
|
|
|
|
}
|
|
|
|
return peers
|
|
|
|
}
|
2021-07-19 15:02:11 +02:00
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
// GetConnectedPeers returns a connection Status or nil if peer connection wasn't found
|
|
|
|
func (e *Engine) GetConnectedPeers() []string {
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
2021-05-01 12:45:37 +02:00
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
peers := []string{}
|
|
|
|
for s, conn := range e.peerConns {
|
|
|
|
if conn.Status() == peer.StatusConnected {
|
|
|
|
peers = append(peers, s)
|
|
|
|
}
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
return peers
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func signalCandidate(candidate ice.Candidate, myKey wgtypes.Key, remoteKey wgtypes.Key, s signal.Client) error {
|
2021-05-01 12:45:37 +02:00
|
|
|
err := s.Send(&sProto.Message{
|
|
|
|
Key: myKey.PublicKey().String(),
|
|
|
|
RemoteKey: remoteKey.String(),
|
2021-05-01 18:29:59 +02:00
|
|
|
Body: &sProto.Body{
|
|
|
|
Type: sProto.Body_CANDIDATE,
|
|
|
|
Payload: candidate.Marshal(),
|
|
|
|
},
|
2021-05-01 12:45:37 +02:00
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed signaling candidate to the remote peer %s %s", remoteKey.String(), err)
|
2022-02-16 20:00:21 +01:00
|
|
|
// todo ??
|
2021-05-01 12:45:37 +02:00
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func signalAuth(uFrag string, pwd string, myKey wgtypes.Key, remoteKey wgtypes.Key, s signal.Client, isAnswer bool) error {
|
2021-05-01 18:29:59 +02:00
|
|
|
var t sProto.Body_Type
|
2021-05-01 12:45:37 +02:00
|
|
|
if isAnswer {
|
2021-05-01 18:29:59 +02:00
|
|
|
t = sProto.Body_ANSWER
|
2021-05-01 12:45:37 +02:00
|
|
|
} else {
|
2021-05-01 18:29:59 +02:00
|
|
|
t = sProto.Body_OFFER
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2021-05-01 18:29:59 +02:00
|
|
|
msg, err := signal.MarshalCredential(myKey, remoteKey, &signal.Credential{
|
2021-05-01 12:45:37 +02:00
|
|
|
UFrag: uFrag,
|
2022-02-16 20:00:21 +01:00
|
|
|
Pwd: pwd,
|
|
|
|
}, t)
|
2021-05-15 12:23:56 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-05-01 18:29:59 +02:00
|
|
|
err = s.Send(msg)
|
2021-05-01 12:45:37 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) handleSync(update *mgmProto.SyncResponse) error {
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
|
|
|
|
|
|
|
if update.GetWiretrusteeConfig() != nil {
|
|
|
|
err := e.updateTURNs(update.GetWiretrusteeConfig().GetTurns())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
err = e.updateSTUNs(update.GetWiretrusteeConfig().GetStuns())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2022-02-16 20:00:21 +01:00
|
|
|
// todo update signal
|
2022-01-18 16:44:58 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
if update.GetNetworkMap() != nil {
|
|
|
|
// only apply new changes and ignore old ones
|
|
|
|
err := e.updateNetworkMap(update.GetNetworkMap())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-06-23 17:04:53 +02:00
|
|
|
func (e *Engine) updateSSH(sshConf *mgmProto.SSHConfig) error {
|
|
|
|
if sshConf.GetSshEnabled() {
|
|
|
|
if runtime.GOOS == "windows" {
|
|
|
|
log.Warnf("running SSH server on Windows is not supported")
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
// start SSH server if it wasn't running
|
|
|
|
if e.sshServer == nil {
|
|
|
|
//nil sshServer means it has not yet been started
|
|
|
|
var err error
|
|
|
|
e.sshServer, err = e.sshServerFunc(e.config.SSHKey,
|
|
|
|
fmt.Sprintf("%s:%d", e.wgInterface.Address.IP.String(), nbssh.DefaultSSHPort))
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
go func() {
|
|
|
|
// blocking
|
|
|
|
err = e.sshServer.Start()
|
|
|
|
if err != nil {
|
|
|
|
// will throw error when we stop it even if it is a graceful stop
|
|
|
|
log.Debugf("stopped SSH server with error %v", err)
|
|
|
|
}
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
|
|
|
e.sshServer = nil
|
|
|
|
log.Infof("stopped SSH server")
|
|
|
|
}()
|
|
|
|
} else {
|
|
|
|
log.Debugf("SSH server is already running")
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
// Disable SSH server request, so stop it if it was running
|
|
|
|
if e.sshServer != nil {
|
|
|
|
err := e.sshServer.Stop()
|
|
|
|
if err != nil {
|
|
|
|
log.Warnf("failed to stop SSH server %v", err)
|
|
|
|
}
|
|
|
|
e.sshServer = nil
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
func (e *Engine) updateConfig(conf *mgmProto.PeerConfig) error {
|
|
|
|
if e.wgInterface.Address.String() != conf.Address {
|
|
|
|
oldAddr := e.wgInterface.Address.String()
|
|
|
|
log.Debugf("updating peer address from %s to %s", oldAddr, conf.Address)
|
|
|
|
err := e.wgInterface.UpdateAddr(conf.Address)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2022-06-23 17:04:53 +02:00
|
|
|
e.config.WgAddr = conf.Address
|
2022-06-04 19:41:01 +02:00
|
|
|
log.Infof("updated peer address from %s to %s", oldAddr, conf.Address)
|
|
|
|
}
|
|
|
|
|
2022-06-23 17:04:53 +02:00
|
|
|
if conf.GetSshConfig() != nil {
|
|
|
|
err := e.updateSSH(conf.GetSshConfig())
|
|
|
|
if err != nil {
|
|
|
|
log.Warnf("failed handling SSH server setup %v", e)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// receiveManagementEvents connects to the Management Service event stream to receive updates from the management service
|
|
|
|
// E.g. when a new peer has been registered and we are allowed to connect to it.
|
|
|
|
func (e *Engine) receiveManagementEvents() {
|
2021-09-07 18:36:46 +02:00
|
|
|
go func() {
|
|
|
|
err := e.mgmClient.Sync(func(update *mgmProto.SyncResponse) error {
|
2022-01-18 16:44:58 +01:00
|
|
|
return e.handleSync(update)
|
2021-09-07 18:36:46 +02:00
|
|
|
})
|
2021-09-03 17:47:40 +02:00
|
|
|
if err != nil {
|
2021-11-06 15:00:13 +01:00
|
|
|
// happens if management is unavailable for a long time.
|
|
|
|
// We want to cancel the operation of the whole client
|
2022-03-08 14:47:55 +01:00
|
|
|
_ = CtxGetState(e.ctx).Wrap(ErrResetConnection)
|
2021-09-07 18:36:46 +02:00
|
|
|
e.cancel()
|
|
|
|
return
|
2021-08-15 16:56:26 +02:00
|
|
|
}
|
2021-10-17 22:15:38 +02:00
|
|
|
log.Debugf("stopped receiving updates from Management Service")
|
2021-09-07 18:36:46 +02:00
|
|
|
}()
|
|
|
|
log.Debugf("connecting to Management Service updates stream")
|
2021-08-15 16:56:26 +02:00
|
|
|
}
|
|
|
|
|
2021-09-03 17:47:40 +02:00
|
|
|
func (e *Engine) updateSTUNs(stuns []*mgmProto.HostConfig) error {
|
|
|
|
if len(stuns) == 0 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
var newSTUNs []*ice.URL
|
|
|
|
log.Debugf("got STUNs update from Management Service, updating")
|
|
|
|
for _, stun := range stuns {
|
|
|
|
url, err := ice.ParseURL(stun.Uri)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
newSTUNs = append(newSTUNs, url)
|
|
|
|
}
|
|
|
|
e.STUNs = newSTUNs
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (e *Engine) updateTURNs(turns []*mgmProto.ProtectedHostConfig) error {
|
|
|
|
if len(turns) == 0 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
var newTURNs []*ice.URL
|
|
|
|
log.Debugf("got TURNs update from Management Service, updating")
|
|
|
|
for _, turn := range turns {
|
|
|
|
url, err := ice.ParseURL(turn.HostConfig.Uri)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
url.Username = turn.User
|
|
|
|
url.Password = turn.Password
|
|
|
|
newTURNs = append(newTURNs, url)
|
|
|
|
}
|
|
|
|
e.TURNs = newTURNs
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) updateNetworkMap(networkMap *mgmProto.NetworkMap) error {
|
2022-06-23 17:04:53 +02:00
|
|
|
|
|
|
|
// intentionally leave it before checking serial because for now it can happen that peer IP changed but serial didn't
|
|
|
|
if networkMap.GetPeerConfig() != nil {
|
|
|
|
err := e.updateConfig(networkMap.GetPeerConfig())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
serial := networkMap.GetSerial()
|
|
|
|
if e.networkSerial > serial {
|
|
|
|
log.Debugf("received outdated NetworkMap with serial %d, ignoring", serial)
|
|
|
|
return nil
|
2021-09-03 17:47:40 +02:00
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
log.Debugf("got peers update from Management Service, total peers to connect to = %d", len(networkMap.GetRemotePeers()))
|
|
|
|
|
|
|
|
// cleanup request, most likely our peer has been deleted
|
|
|
|
if networkMap.GetRemotePeersIsEmpty() {
|
|
|
|
err := e.removeAllPeers()
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
err := e.removePeers(networkMap.GetRemotePeers())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
err = e.modifyPeers(networkMap.GetRemotePeers())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
err = e.addNewPeers(networkMap.GetRemotePeers())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
2021-09-03 17:47:40 +02:00
|
|
|
}
|
2022-06-23 17:04:53 +02:00
|
|
|
|
|
|
|
// update SSHServer by adding remote peer SSH keys
|
|
|
|
if e.sshServer != nil {
|
|
|
|
for _, config := range networkMap.GetRemotePeers() {
|
|
|
|
if config.GetSshConfig() != nil && config.GetSshConfig().GetSshPubKey() != nil {
|
|
|
|
err := e.sshServer.AddAuthorizedKey(config.WgPubKey, string(config.GetSshConfig().GetSshPubKey()))
|
|
|
|
if err != nil {
|
|
|
|
log.Warnf("failed adding authroized key to SSH DefaultServer %v", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2021-09-03 17:47:40 +02:00
|
|
|
}
|
|
|
|
|
2022-01-18 16:44:58 +01:00
|
|
|
e.networkSerial = serial
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
// addNewPeers adds peers that were not know before but arrived from the Management service with the update
|
2022-01-18 16:44:58 +01:00
|
|
|
func (e *Engine) addNewPeers(peersUpdate []*mgmProto.RemotePeerConfig) error {
|
|
|
|
for _, p := range peersUpdate {
|
2022-06-04 19:41:01 +02:00
|
|
|
err := e.addNewPeer(p)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
// addNewPeer add peer if connection doesn't exist
|
|
|
|
func (e *Engine) addNewPeer(peerConfig *mgmProto.RemotePeerConfig) error {
|
|
|
|
peerKey := peerConfig.GetWgPubKey()
|
|
|
|
peerIPs := peerConfig.GetAllowedIps()
|
|
|
|
if _, ok := e.peerConns[peerKey]; !ok {
|
|
|
|
conn, err := e.createPeerConn(peerKey, strings.Join(peerIPs, ","))
|
|
|
|
if err != nil {
|
|
|
|
return err
|
2021-09-03 17:47:40 +02:00
|
|
|
}
|
2022-06-04 19:41:01 +02:00
|
|
|
e.peerConns[peerKey] = conn
|
2021-09-03 17:47:40 +02:00
|
|
|
|
2022-07-02 12:02:17 +02:00
|
|
|
err = e.statusRecorder.AddPeer(peerKey)
|
|
|
|
if err != nil {
|
|
|
|
log.Warnf("error adding peer %s to status recorder, got error: %v", peerKey, err)
|
|
|
|
}
|
|
|
|
|
2022-06-04 19:41:01 +02:00
|
|
|
go e.connWorker(conn, peerKey)
|
2021-09-03 17:47:40 +02:00
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
func (e Engine) connWorker(conn *peer.Conn, peerKey string) {
|
|
|
|
for {
|
|
|
|
|
|
|
|
// randomize starting time a bit
|
|
|
|
min := 500
|
|
|
|
max := 2000
|
|
|
|
time.Sleep(time.Duration(rand.Intn(max-min)+min) * time.Millisecond)
|
|
|
|
|
|
|
|
// if peer has been removed -> give up
|
|
|
|
if !e.peerExists(peerKey) {
|
2022-03-13 15:16:16 +01:00
|
|
|
log.Debugf("peer %s doesn't exist anymore, won't retry connection", peerKey)
|
2022-01-10 18:43:13 +01:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
if !e.signal.Ready() {
|
|
|
|
log.Infof("signal client isn't ready, skipping connection attempt %s", peerKey)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
err := conn.Open()
|
|
|
|
if err != nil {
|
|
|
|
log.Debugf("connection to peer %s failed: %v", peerKey, err)
|
2022-06-04 19:41:01 +02:00
|
|
|
switch err.(type) {
|
|
|
|
case *peer.ConnectionClosedError:
|
|
|
|
// conn has been forced to close, so we exit the loop
|
|
|
|
return
|
|
|
|
default:
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
func (e Engine) peerExists(peerKey string) bool {
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
|
|
|
_, ok := e.peerConns[peerKey]
|
|
|
|
return ok
|
|
|
|
}
|
|
|
|
|
|
|
|
func (e Engine) createPeerConn(pubKey string, allowedIPs string) (*peer.Conn, error) {
|
|
|
|
var stunTurn []*ice.URL
|
|
|
|
stunTurn = append(stunTurn, e.STUNs...)
|
|
|
|
stunTurn = append(stunTurn, e.TURNs...)
|
|
|
|
|
|
|
|
proxyConfig := proxy.Config{
|
|
|
|
RemoteKey: pubKey,
|
|
|
|
WgListenAddr: fmt.Sprintf("127.0.0.1:%d", e.config.WgPort),
|
2022-01-17 14:01:58 +01:00
|
|
|
WgInterface: e.wgInterface,
|
2022-01-10 18:43:13 +01:00
|
|
|
AllowedIps: allowedIPs,
|
|
|
|
PreSharedKey: e.config.PreSharedKey,
|
|
|
|
}
|
|
|
|
|
|
|
|
// randomize connection timeout
|
|
|
|
timeout := time.Duration(rand.Intn(PeerConnectionTimeoutMax-PeerConnectionTimeoutMin)+PeerConnectionTimeoutMin) * time.Millisecond
|
|
|
|
config := peer.ConnConfig{
|
|
|
|
Key: pubKey,
|
|
|
|
LocalKey: e.config.WgPrivateKey.PublicKey().String(),
|
|
|
|
StunTurn: stunTurn,
|
2022-06-05 14:43:13 +02:00
|
|
|
InterfaceBlackList: e.config.IFaceBlackList,
|
2022-01-10 18:43:13 +01:00
|
|
|
Timeout: timeout,
|
2022-02-16 20:00:21 +01:00
|
|
|
UDPMux: e.udpMux,
|
|
|
|
UDPMuxSrflx: e.udpMuxSrflx,
|
2022-01-10 18:43:13 +01:00
|
|
|
ProxyConfig: proxyConfig,
|
|
|
|
}
|
|
|
|
|
2022-07-02 12:02:17 +02:00
|
|
|
peerConn, err := peer.NewConn(config, e.statusRecorder)
|
2022-01-10 18:43:13 +01:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
wgPubKey, err := wgtypes.ParseKey(pubKey)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
signalOffer := func(uFrag string, pwd string) error {
|
|
|
|
return signalAuth(uFrag, pwd, e.config.WgPrivateKey, wgPubKey, e.signal, false)
|
|
|
|
}
|
|
|
|
|
|
|
|
signalCandidate := func(candidate ice.Candidate) error {
|
|
|
|
return signalCandidate(candidate, e.config.WgPrivateKey, wgPubKey, e.signal)
|
|
|
|
}
|
|
|
|
|
|
|
|
signalAnswer := func(uFrag string, pwd string) error {
|
|
|
|
return signalAuth(uFrag, pwd, e.config.WgPrivateKey, wgPubKey, e.signal, true)
|
|
|
|
}
|
|
|
|
|
|
|
|
peerConn.SetSignalCandidate(signalCandidate)
|
|
|
|
peerConn.SetSignalOffer(signalOffer)
|
|
|
|
peerConn.SetSignalAnswer(signalAnswer)
|
|
|
|
|
|
|
|
return peerConn, nil
|
|
|
|
}
|
|
|
|
|
2021-08-15 16:56:26 +02:00
|
|
|
// receiveSignalEvents connects to the Signal Service event stream to negotiate connection with remote peers
|
|
|
|
func (e *Engine) receiveSignalEvents() {
|
2021-11-06 15:00:13 +01:00
|
|
|
go func() {
|
|
|
|
// connect to a stream of messages coming from the signal server
|
|
|
|
err := e.signal.Receive(func(msg *sProto.Message) error {
|
|
|
|
e.syncMsgMux.Lock()
|
|
|
|
defer e.syncMsgMux.Unlock()
|
2021-05-01 12:45:37 +02:00
|
|
|
|
2022-01-10 18:43:13 +01:00
|
|
|
conn := e.peerConns[msg.Key]
|
2021-11-06 15:00:13 +01:00
|
|
|
if conn == nil {
|
|
|
|
return fmt.Errorf("wrongly addressed message %s", msg.Key)
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2021-11-06 15:00:13 +01:00
|
|
|
switch msg.GetBody().Type {
|
|
|
|
case sProto.Body_OFFER:
|
|
|
|
remoteCred, err := signal.UnMarshalCredential(msg)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
conn.OnRemoteOffer(peer.IceCredentials{
|
|
|
|
UFrag: remoteCred.UFrag,
|
|
|
|
Pwd: remoteCred.Pwd,
|
2021-11-06 15:00:13 +01:00
|
|
|
})
|
|
|
|
case sProto.Body_ANSWER:
|
|
|
|
remoteCred, err := signal.UnMarshalCredential(msg)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
conn.OnRemoteAnswer(peer.IceCredentials{
|
|
|
|
UFrag: remoteCred.UFrag,
|
|
|
|
Pwd: remoteCred.Pwd,
|
2021-11-06 15:00:13 +01:00
|
|
|
})
|
|
|
|
case sProto.Body_CANDIDATE:
|
|
|
|
candidate, err := ice.UnmarshalCandidate(msg.GetBody().Payload)
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("failed on parsing remote candidate %s -> %s", candidate, err)
|
|
|
|
return err
|
|
|
|
}
|
2022-01-10 18:43:13 +01:00
|
|
|
conn.OnRemoteCandidate(candidate)
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|
|
|
|
|
2021-11-06 15:00:13 +01:00
|
|
|
return nil
|
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
// happens if signal is unavailable for a long time.
|
|
|
|
// We want to cancel the operation of the whole client
|
2022-03-08 14:47:55 +01:00
|
|
|
_ = CtxGetState(e.ctx).Wrap(ErrResetConnection)
|
2021-11-06 15:00:13 +01:00
|
|
|
e.cancel()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}()
|
2021-05-01 12:45:37 +02:00
|
|
|
|
2021-11-06 15:00:13 +01:00
|
|
|
e.signal.WaitStreamConnected()
|
2021-05-01 12:45:37 +02:00
|
|
|
}
|