5
0
mirror of https://github.com/cwinfo/yggdrasil-go.git synced 2024-11-13 01:40:27 +00:00

use a session worker to try to avoid mutex hell. compiles, but incomplete and doesn't work yet

This commit is contained in:
Arceliar 2019-04-21 20:38:14 -05:00
parent 0b8f5b5dda
commit 5dada3952c
4 changed files with 191 additions and 151 deletions

View File

@ -4,7 +4,6 @@ import (
"errors" "errors"
"fmt" "fmt"
"sync" "sync"
"sync/atomic"
"time" "time"
"github.com/yggdrasil-network/yggdrasil-go/src/crypto" "github.com/yggdrasil-network/yggdrasil-go/src/crypto"
@ -15,10 +14,11 @@ type Conn struct {
core *Core core *Core
nodeID *crypto.NodeID nodeID *crypto.NodeID
nodeMask *crypto.NodeID nodeMask *crypto.NodeID
session *sessionInfo recv chan *wire_trafficPacket // Eventually gets attached to session.recv
mutex *sync.RWMutex mutex *sync.RWMutex
readDeadline time.Time session *sessionInfo
writeDeadline time.Time readDeadline time.Time // TODO timer
writeDeadline time.Time // TODO timer
expired bool expired bool
} }
@ -39,6 +39,7 @@ func (c *Conn) startSearch() {
if sinfo != nil { if sinfo != nil {
c.mutex.Lock() c.mutex.Lock()
c.session = sinfo c.session = sinfo
c.session.recv = c.recv
c.nodeID, c.nodeMask = sinfo.theirAddr.GetNodeIDandMask() c.nodeID, c.nodeMask = sinfo.theirAddr.GetNodeIDandMask()
c.mutex.Unlock() c.mutex.Unlock()
} }
@ -50,113 +51,124 @@ func (c *Conn) startSearch() {
} }
c.core.searches.continueSearch(sinfo) c.core.searches.continueSearch(sinfo)
} }
switch { c.mutex.RLock()
case c.session == nil || !c.session.init.Load().(bool): defer c.mutex.RUnlock()
if c.session == nil {
doSearch() doSearch()
case time.Since(c.session.time.Load().(time.Time)) > 6*time.Second: } else {
sTime := c.session.time.Load().(time.Time) sinfo := c.session // In case c.session is somehow changed meanwhile
pingTime := c.session.pingTime.Load().(time.Time) sinfo.worker <- func() {
if sTime.Before(pingTime) && time.Since(pingTime) > 6*time.Second { switch {
doSearch() case !sinfo.init:
} else { doSearch()
pingSend := c.session.pingSend.Load().(time.Time) case time.Since(sinfo.time) > 6*time.Second:
now := time.Now() if sinfo.time.Before(sinfo.pingTime) && time.Since(sinfo.pingTime) > 6*time.Second {
if !sTime.Before(pingTime) { // TODO double check that the above condition is correct
c.session.pingTime.Store(now) doSearch()
} } else {
if time.Since(pingSend) > time.Second { c.core.sessions.ping(sinfo)
c.session.pingSend.Store(now) }
c.core.sessions.sendPingPong(c.session, false) default: // Don't do anything, to keep traffic throttled
} }
} }
} }
} }
func (c *Conn) Read(b []byte) (int, error) { func (c *Conn) Read(b []byte) (int, error) {
c.mutex.RLock() err := func() error {
defer c.mutex.RUnlock() c.mutex.RLock()
if c.expired { defer c.mutex.RUnlock()
return 0, errors.New("session is closed") if c.expired {
} return errors.New("session is closed")
if c.session == nil { }
return 0, errors.New("searching for remote side") return nil
} }()
if init, ok := c.session.init.Load().(bool); !ok || (ok && !init) { if err != nil {
return 0, errors.New("waiting for remote side to accept " + c.String()) return 0, err
} }
select { select {
case p, ok := <-c.session.recv: // TODO...
case p, ok := <-c.recv:
if !ok { if !ok {
c.mutex.Lock()
c.expired = true c.expired = true
c.mutex.Unlock()
return 0, errors.New("session is closed") return 0, errors.New("session is closed")
} }
defer util.PutBytes(p.Payload) defer util.PutBytes(p.Payload)
err := func() error { c.mutex.RLock()
c.session.theirNonceMutex.Lock() sinfo := c.session
defer c.session.theirNonceMutex.Unlock() c.mutex.RUnlock()
if !c.session.nonceIsOK(&p.Nonce) { var err error
return errors.New("packet dropped due to invalid nonce") sinfo.doWorker(func() {
if !sinfo.nonceIsOK(&p.Nonce) {
err = errors.New("packet dropped due to invalid nonce")
return
} }
bs, isOK := crypto.BoxOpen(&c.session.sharedSesKey, p.Payload, &p.Nonce) bs, isOK := crypto.BoxOpen(&sinfo.sharedSesKey, p.Payload, &p.Nonce)
if !isOK { if !isOK {
util.PutBytes(bs) util.PutBytes(bs)
return errors.New("packet dropped due to decryption failure") err = errors.New("packet dropped due to decryption failure")
return
} }
copy(b, bs) copy(b, bs)
if len(bs) < len(b) { if len(bs) < len(b) {
b = b[:len(bs)] b = b[:len(bs)]
} }
c.session.updateNonce(&p.Nonce) sinfo.updateNonce(&p.Nonce)
c.session.time.Store(time.Now()) sinfo.time = time.Now()
return nil sinfo.bytesRecvd += uint64(len(b))
}() })
if err != nil { if err != nil {
return 0, err return 0, err
} }
atomic.AddUint64(&c.session.bytesRecvd, uint64(len(b)))
return len(b), nil return len(b), nil
case <-c.session.closed: //case <-c.recvTimeout:
c.expired = true //case <-c.session.closed:
return len(b), errors.New("session is closed") // c.expired = true
// return len(b), errors.New("session is closed")
} }
} }
func (c *Conn) Write(b []byte) (bytesWritten int, err error) { func (c *Conn) Write(b []byte) (bytesWritten int, err error) {
c.mutex.RLock() var sinfo *sessionInfo
defer c.mutex.RUnlock() err = func() error {
if c.expired { c.mutex.RLock()
return 0, errors.New("session is closed") defer c.mutex.RUnlock()
if c.expired {
return errors.New("session is closed")
}
sinfo = c.session
return nil
}()
if err != nil {
return 0, err
} }
if c.session == nil { if sinfo == nil {
c.core.router.doAdmin(func() { c.core.router.doAdmin(func() {
c.startSearch() c.startSearch()
}) })
return 0, errors.New("searching for remote side") return 0, errors.New("searching for remote side")
} }
defer util.PutBytes(b) //defer util.PutBytes(b)
if init, ok := c.session.init.Load().(bool); !ok || (ok && !init) { var packet []byte
return 0, errors.New("waiting for remote side to accept " + c.String()) sinfo.doWorker(func() {
} if !sinfo.init {
coords := c.session.coords err = errors.New("waiting for remote side to accept " + c.String())
c.session.myNonceMutex.Lock() return
payload, nonce := crypto.BoxSeal(&c.session.sharedSesKey, b, &c.session.myNonce) }
defer util.PutBytes(payload) payload, nonce := crypto.BoxSeal(&sinfo.sharedSesKey, b, &sinfo.myNonce)
p := wire_trafficPacket{ defer util.PutBytes(payload)
Coords: coords, p := wire_trafficPacket{
Handle: c.session.theirHandle, Coords: sinfo.coords,
Nonce: *nonce, Handle: sinfo.theirHandle,
Payload: payload, Nonce: *nonce,
} Payload: payload,
packet := p.encode() }
c.session.myNonceMutex.Unlock() packet = p.encode()
atomic.AddUint64(&c.session.bytesSent, uint64(len(b))) sinfo.bytesSent += uint64(len(b))
select { })
case c.session.send <- packet: sinfo.core.router.out(packet)
case <-c.session.closed:
c.expired = true
return len(b), errors.New("session is closed")
}
c.session.core.router.out(packet)
return len(b), nil return len(b), nil
} }

View File

@ -63,6 +63,7 @@ func (d *Dialer) DialByNodeIDandMask(nodeID, nodeMask *crypto.NodeID) (Conn, err
mutex: &sync.RWMutex{}, mutex: &sync.RWMutex{},
nodeID: nodeID, nodeID: nodeID,
nodeMask: nodeMask, nodeMask: nodeMask,
recv: make(chan *wire_trafficPacket, 32),
} }
conn.core.router.doAdmin(func() { conn.core.router.doAdmin(func() {
conn.startSearch() conn.startSearch()

View File

@ -23,7 +23,7 @@ package yggdrasil
// The router then runs some sanity checks before passing it to the adapter // The router then runs some sanity checks before passing it to the adapter
import ( import (
"bytes" //"bytes"
"time" "time"
"github.com/yggdrasil-network/yggdrasil-go/src/address" "github.com/yggdrasil-network/yggdrasil-go/src/address"
@ -42,12 +42,12 @@ type router struct {
out func([]byte) // packets we're sending to the network, link to peer's "in" out func([]byte) // packets we're sending to the network, link to peer's "in"
toRecv chan router_recvPacket // packets to handle via recvPacket() toRecv chan router_recvPacket // packets to handle via recvPacket()
recv chan<- []byte // place where the adapter pulls received packets from recv chan<- []byte // place where the adapter pulls received packets from
send <-chan []byte // place where the adapter puts outgoing packets //send <-chan []byte // place where the adapter puts outgoing packets
reject chan<- RejectedPacket // place where we send error packets back to adapter reject chan<- RejectedPacket // place where we send error packets back to adapter
reset chan struct{} // signal that coords changed (re-init sessions/dht) reset chan struct{} // signal that coords changed (re-init sessions/dht)
admin chan func() // pass a lambda for the admin socket to query stuff admin chan func() // pass a lambda for the admin socket to query stuff
cryptokey cryptokey cryptokey cryptokey
nodeinfo nodeinfo nodeinfo nodeinfo
} }
// Packet and session info, used to check that the packet matches a valid IP range or CKR prefix before sending to the adapter. // Packet and session info, used to check that the packet matches a valid IP range or CKR prefix before sending to the adapter.
@ -122,11 +122,11 @@ func (r *router) init(core *Core) {
}() }()
r.out = func(packet []byte) { out2 <- packet } r.out = func(packet []byte) { out2 <- packet }
r.toRecv = make(chan router_recvPacket, 32) r.toRecv = make(chan router_recvPacket, 32)
recv := make(chan []byte, 32) //recv := make(chan []byte, 32)
send := make(chan []byte, 32) //send := make(chan []byte, 32)
reject := make(chan RejectedPacket, 32) reject := make(chan RejectedPacket, 32)
r.recv = recv //r.recv = recv
r.send = send //r.send = send
r.reject = reject r.reject = reject
r.reset = make(chan struct{}, 1) r.reset = make(chan struct{}, 1)
r.admin = make(chan func(), 32) r.admin = make(chan func(), 32)
@ -157,8 +157,8 @@ func (r *router) mainLoop() {
r.recvPacket(rp.bs, rp.sinfo) r.recvPacket(rp.bs, rp.sinfo)
case p := <-r.in: case p := <-r.in:
r.handleIn(p) r.handleIn(p)
case p := <-r.send: //case p := <-r.send:
r.sendPacket(p) // r.sendPacket(p)
case info := <-r.core.dht.peers: case info := <-r.core.dht.peers:
r.core.dht.insertPeer(info) r.core.dht.insertPeer(info)
case <-r.reset: case <-r.reset:
@ -181,6 +181,7 @@ func (r *router) mainLoop() {
} }
} }
/*
// Checks a packet's to/from address to make sure it's in the allowed range. // Checks a packet's to/from address to make sure it's in the allowed range.
// If a session to the destination exists, gets the session and passes the packet to it. // If a session to the destination exists, gets the session and passes the packet to it.
// If no session exists, it triggers (or continues) a search. // If no session exists, it triggers (or continues) a search.
@ -353,6 +354,7 @@ func (r *router) sendPacket(bs []byte) {
sinfo.send <- bs sinfo.send <- bs
} }
} }
*/
// Called for incoming traffic by the session worker for that connection. // Called for incoming traffic by the session worker for that connection.
// Checks that the IP address is correct (matches the session) and passes the packet to the adapter. // Checks that the IP address is correct (matches the session) and passes the packet to the adapter.
@ -429,7 +431,11 @@ func (r *router) handleTraffic(packet []byte) {
if !isIn { if !isIn {
return return
} }
sinfo.recv <- &p select {
case sinfo.recv <- &p: // FIXME ideally this should be FIFO
default:
util.PutBytes(p.Payload)
}
} }
// Handles protocol traffic by decrypting it, checking its type, and passing it to the appropriate handler for that traffic type. // Handles protocol traffic by decrypting it, checking its type, and passing it to the appropriate handler for that traffic type.

View File

@ -18,38 +18,50 @@ import (
// All the information we know about an active session. // All the information we know about an active session.
// This includes coords, permanent and ephemeral keys, handles and nonces, various sorts of timing information for timeout and maintenance, and some metadata for the admin API. // This includes coords, permanent and ephemeral keys, handles and nonces, various sorts of timing information for timeout and maintenance, and some metadata for the admin API.
type sessionInfo struct { type sessionInfo struct {
core *Core // core *Core //
reconfigure chan chan error // reconfigure chan chan error //
theirAddr address.Address // theirAddr address.Address //
theirSubnet address.Subnet // theirSubnet address.Subnet //
theirPermPub crypto.BoxPubKey // theirPermPub crypto.BoxPubKey //
theirSesPub crypto.BoxPubKey // theirSesPub crypto.BoxPubKey //
mySesPub crypto.BoxPubKey // mySesPub crypto.BoxPubKey //
mySesPriv crypto.BoxPrivKey // mySesPriv crypto.BoxPrivKey //
sharedSesKey crypto.BoxSharedKey // derived from session keys sharedSesKey crypto.BoxSharedKey // derived from session keys
theirHandle crypto.Handle // theirHandle crypto.Handle //
myHandle crypto.Handle // myHandle crypto.Handle //
theirNonce crypto.BoxNonce // theirNonce crypto.BoxNonce //
theirNonceMask uint64 // theirNonceMask uint64 //
theirNonceMutex sync.Mutex // protects the above myNonce crypto.BoxNonce //
myNonce crypto.BoxNonce // theirMTU uint16 //
myNonceMutex sync.Mutex // protects the above myMTU uint16 //
theirMTU uint16 // wasMTUFixed bool // Was the MTU fixed by a receive error?
myMTU uint16 // time time.Time // Time we last received a packet
wasMTUFixed bool // Was the MTU fixed by a receive error? mtuTime time.Time // time myMTU was last changed
time atomic.Value // time.Time // Time we last received a packet pingTime time.Time // time the first ping was sent since the last received packet
mtuTime atomic.Value // time.Time // time myMTU was last changed pingSend time.Time // time the last ping was sent
pingTime atomic.Value // time.Time // time the first ping was sent since the last received packet coords []byte // coords of destination
pingSend atomic.Value // time.Time // time the last ping was sent packet []byte // a buffered packet, sent immediately on ping/pong
coords []byte // coords of destination init bool // Reset if coords change
packet []byte // a buffered packet, sent immediately on ping/pong tstamp int64 // ATOMIC - tstamp from their last session ping, replay attack mitigation
init atomic.Value // bool // Reset if coords change bytesSent uint64 // Bytes of real traffic sent in this session
send chan []byte // bytesRecvd uint64 // Bytes of real traffic received in this session
recv chan *wire_trafficPacket // worker chan func() // Channel to send work to the session worker
closed chan interface{} // recv chan *wire_trafficPacket // Received packets go here, picked up by the associated Conn
tstamp int64 // ATOMIC - tstamp from their last session ping, replay attack mitigation }
bytesSent uint64 // Bytes of real traffic sent in this session
bytesRecvd uint64 // Bytes of real traffic received in this session func (sinfo *sessionInfo) doWorker(f func()) {
done := make(chan struct{})
sinfo.worker <- func() {
f()
close(done)
}
<-done
}
func (sinfo *sessionInfo) workerMain() {
for f := range sinfo.worker {
f()
}
} }
// Represents a session ping/pong packet, andincludes information like public keys, a session handle, coords, a timestamp to prevent replays, and the tun/tap MTU. // Represents a session ping/pong packet, andincludes information like public keys, a session handle, coords, a timestamp to prevent replays, and the tun/tap MTU.
@ -89,16 +101,19 @@ func (s *sessionInfo) update(p *sessionPing) bool {
// allocate enough space for additional coords // allocate enough space for additional coords
s.coords = append(make([]byte, 0, len(p.Coords)+11), p.Coords...) s.coords = append(make([]byte, 0, len(p.Coords)+11), p.Coords...)
} }
now := time.Now() s.time = time.Now()
s.time.Store(now) s.tstamp = p.Tstamp
atomic.StoreInt64(&s.tstamp, p.Tstamp) s.init = true
s.init.Store(true)
return true return true
} }
// Returns true if the session has been idle for longer than the allowed timeout. // Returns true if the session has been idle for longer than the allowed timeout.
func (s *sessionInfo) timedout() bool { func (s *sessionInfo) timedout() bool {
return time.Since(s.time.Load().(time.Time)) > time.Minute var timedout bool
s.doWorker(func() {
timedout = time.Since(s.time) > time.Minute
})
return timedout
} }
// Struct of all active sessions. // Struct of all active sessions.
@ -282,10 +297,10 @@ func (ss *sessions) createSession(theirPermKey *crypto.BoxPubKey) *sessionInfo {
sinfo.theirMTU = 1280 sinfo.theirMTU = 1280
sinfo.myMTU = 1280 sinfo.myMTU = 1280
now := time.Now() now := time.Now()
sinfo.time.Store(now) sinfo.time = now
sinfo.mtuTime.Store(now) sinfo.mtuTime = now
sinfo.pingTime.Store(now) sinfo.pingTime = now
sinfo.pingSend.Store(now) sinfo.pingSend = now
higher := false higher := false
for idx := range ss.core.boxPub { for idx := range ss.core.boxPub {
if ss.core.boxPub[idx] > sinfo.theirPermPub[idx] { if ss.core.boxPub[idx] > sinfo.theirPermPub[idx] {
@ -305,14 +320,13 @@ func (ss *sessions) createSession(theirPermKey *crypto.BoxPubKey) *sessionInfo {
sinfo.myHandle = *crypto.NewHandle() sinfo.myHandle = *crypto.NewHandle()
sinfo.theirAddr = *address.AddrForNodeID(crypto.GetNodeID(&sinfo.theirPermPub)) sinfo.theirAddr = *address.AddrForNodeID(crypto.GetNodeID(&sinfo.theirPermPub))
sinfo.theirSubnet = *address.SubnetForNodeID(crypto.GetNodeID(&sinfo.theirPermPub)) sinfo.theirSubnet = *address.SubnetForNodeID(crypto.GetNodeID(&sinfo.theirPermPub))
sinfo.send = make(chan []byte, 32) sinfo.worker = make(chan func(), 1)
sinfo.recv = make(chan *wire_trafficPacket, 32)
sinfo.closed = make(chan interface{})
ss.sinfos[sinfo.myHandle] = &sinfo ss.sinfos[sinfo.myHandle] = &sinfo
ss.byMySes[sinfo.mySesPub] = &sinfo.myHandle ss.byMySes[sinfo.mySesPub] = &sinfo.myHandle
ss.byTheirPerm[sinfo.theirPermPub] = &sinfo.myHandle ss.byTheirPerm[sinfo.theirPermPub] = &sinfo.myHandle
ss.addrToPerm[sinfo.theirAddr] = &sinfo.theirPermPub ss.addrToPerm[sinfo.theirAddr] = &sinfo.theirPermPub
ss.subnetToPerm[sinfo.theirSubnet] = &sinfo.theirPermPub ss.subnetToPerm[sinfo.theirSubnet] = &sinfo.theirPermPub
go sinfo.workerMain()
return &sinfo return &sinfo
} }
@ -366,14 +380,12 @@ func (ss *sessions) cleanup() {
// Closes a session, removing it from sessions maps and killing the worker goroutine. // Closes a session, removing it from sessions maps and killing the worker goroutine.
func (sinfo *sessionInfo) close() { func (sinfo *sessionInfo) close() {
close(sinfo.closed)
delete(sinfo.core.sessions.sinfos, sinfo.myHandle) delete(sinfo.core.sessions.sinfos, sinfo.myHandle)
delete(sinfo.core.sessions.byMySes, sinfo.mySesPub) delete(sinfo.core.sessions.byMySes, sinfo.mySesPub)
delete(sinfo.core.sessions.byTheirPerm, sinfo.theirPermPub) delete(sinfo.core.sessions.byTheirPerm, sinfo.theirPermPub)
delete(sinfo.core.sessions.addrToPerm, sinfo.theirAddr) delete(sinfo.core.sessions.addrToPerm, sinfo.theirAddr)
delete(sinfo.core.sessions.subnetToPerm, sinfo.theirSubnet) delete(sinfo.core.sessions.subnetToPerm, sinfo.theirSubnet)
close(sinfo.send) close(sinfo.worker)
close(sinfo.recv)
} }
// Returns a session ping appropriate for the given session info. // Returns a session ping appropriate for the given session info.
@ -436,7 +448,7 @@ func (ss *sessions) sendPingPong(sinfo *sessionInfo, isPong bool) {
packet := p.encode() packet := p.encode()
ss.core.router.out(packet) ss.core.router.out(packet)
if !isPong { if !isPong {
sinfo.pingSend.Store(time.Now()) sinfo.pingSend = time.Now()
} }
} }
@ -468,29 +480,36 @@ func (ss *sessions) handlePing(ping *sessionPing) {
mutex: &sync.RWMutex{}, mutex: &sync.RWMutex{},
nodeID: crypto.GetNodeID(&sinfo.theirPermPub), nodeID: crypto.GetNodeID(&sinfo.theirPermPub),
nodeMask: &crypto.NodeID{}, nodeMask: &crypto.NodeID{},
recv: make(chan *wire_trafficPacket, 32),
} }
for i := range conn.nodeMask { for i := range conn.nodeMask {
conn.nodeMask[i] = 0xFF conn.nodeMask[i] = 0xFF
} }
sinfo.recv = conn.recv
ss.listener.conn <- conn ss.listener.conn <- conn
} else { } else {
ss.core.log.Debugln("Received new session but there is no listener, ignoring") ss.core.log.Debugln("Received new session but there is no listener, ignoring")
} }
ss.listenerMutex.Unlock() ss.listenerMutex.Unlock()
} }
// Update the session sinfo.doWorker(func() {
if !sinfo.update(ping) { /*panic("Should not happen in testing")*/ // Update the session
return if !sinfo.update(ping) { /*panic("Should not happen in testing")*/
} return
if !ping.IsPong { }
ss.sendPingPong(sinfo, true) if !ping.IsPong {
} ss.sendPingPong(sinfo, true)
if sinfo.packet != nil { }
// send if sinfo.packet != nil {
var bs []byte /* FIXME this needs to live in the net.Conn or something, needs work in Write
bs, sinfo.packet = sinfo.packet, nil // send
ss.core.router.sendPacket(bs) var bs []byte
} bs, sinfo.packet = sinfo.packet, nil
ss.core.router.sendPacket(bs) // FIXME this needs to live in the net.Conn or something, needs work in Write
*/
sinfo.packet = nil
}
})
} }
// Get the MTU of the session. // Get the MTU of the session.
@ -536,6 +555,8 @@ func (sinfo *sessionInfo) updateNonce(theirNonce *crypto.BoxNonce) {
// Called after coord changes, so attemtps to use a session will trigger a new ping and notify the remote end of the coord change. // Called after coord changes, so attemtps to use a session will trigger a new ping and notify the remote end of the coord change.
func (ss *sessions) resetInits() { func (ss *sessions) resetInits() {
for _, sinfo := range ss.sinfos { for _, sinfo := range ss.sinfos {
sinfo.init.Store(false) sinfo.doWorker(func() {
sinfo.init = false
})
} }
} }