yggdrasil-go/src/yggdrasil/tcp.go

465 lines
13 KiB
Go
Raw Normal View History

2017-12-29 07:16:20 +03:00
package yggdrasil
// This sends packets to peers using TCP as a transport
// It's generally better tested than the UDP implementation
// Using it regularly is insane, but I find TCP easier to test/debug with it
// Updating and optimizing the UDP version is a higher priority
// TODO:
// Something needs to make sure we're getting *valid* packets
// Could be used to DoS (connect, give someone else's keys, spew garbage)
// I guess the "peer" part should watch for link packets, disconnect?
// TCP connections start with a metadata exchange.
// It involves exchanging version numbers and crypto keys
// See version.go for version metadata format
2018-06-13 01:50:08 +03:00
import (
2019-01-13 21:08:41 +03:00
"context"
2018-06-13 01:50:08 +03:00
"fmt"
2018-06-21 18:39:43 +03:00
"math/rand"
2018-06-13 01:50:08 +03:00
"net"
"sync"
"sync/atomic"
"time"
"golang.org/x/net/proxy"
"github.com/yggdrasil-network/yggdrasil-go/src/address"
"github.com/yggdrasil-network/yggdrasil-go/src/crypto"
"github.com/yggdrasil-network/yggdrasil-go/src/util"
2018-06-13 01:50:08 +03:00
)
2017-12-29 07:16:20 +03:00
const default_timeout = 6 * time.Second
const tcp_ping_interval = (default_timeout * 2 / 3)
2017-12-29 07:16:20 +03:00
// The TCP listener and information about active TCP connections, to avoid duplication.
2017-12-29 07:16:20 +03:00
type tcpInterface struct {
core *Core
2018-12-30 18:21:09 +03:00
reconfigure chan chan error
serv net.Listener
stop chan bool
timeout time.Duration
addr string
mutex sync.Mutex // Protecting the below
calls map[string]struct{}
conns map[tcpInfo](chan struct{})
stream stream
2017-12-29 07:16:20 +03:00
}
// This is used as the key to a map that tracks existing connections, to prevent multiple connections to the same keys and local/remote address pair from occuring.
// Different address combinations are allowed, so multi-homing is still technically possible (but not necessarily advisable).
2018-02-18 05:44:23 +03:00
type tcpInfo struct {
box crypto.BoxPubKey
sig crypto.SigPubKey
localAddr string
2018-04-20 15:41:09 +03:00
remoteAddr string
2017-12-29 07:16:20 +03:00
}
// Wrapper function to set additional options for specific connection types.
func (iface *tcpInterface) setExtraOptions(c net.Conn) {
switch sock := c.(type) {
case *net.TCPConn:
sock.SetNoDelay(true)
// TODO something for socks5
default:
}
}
// Returns the address of the listener.
2018-05-28 00:13:37 +03:00
func (iface *tcpInterface) getAddr() *net.TCPAddr {
return iface.serv.Addr().(*net.TCPAddr)
}
// Attempts to initiate a connection to the provided address.
func (iface *tcpInterface) connect(addr string, intf string) {
iface.call(addr, nil, intf)
2018-05-28 00:13:37 +03:00
}
// Attempst to initiate a connection to the provided address, viathe provided socks proxy address.
2018-05-28 00:13:37 +03:00
func (iface *tcpInterface) connectSOCKS(socksaddr, peeraddr string) {
iface.call(peeraddr, &socksaddr, "")
2018-05-28 00:13:37 +03:00
}
// Initializes the struct.
2018-12-29 22:14:26 +03:00
func (iface *tcpInterface) init(core *Core) (err error) {
2018-01-05 01:37:51 +03:00
iface.core = core
iface.stop = make(chan bool, 1)
2018-12-30 18:21:09 +03:00
iface.reconfigure = make(chan chan error, 1)
go func() {
for {
2019-01-15 11:51:19 +03:00
e := <-iface.reconfigure
iface.core.configMutex.RLock()
updated := iface.core.config.Listen != iface.core.configOld.Listen
iface.core.configMutex.RUnlock()
if updated {
iface.stop <- true
2019-01-15 11:51:19 +03:00
iface.serv.Close()
e <- iface.listen()
} else {
e <- nil
2018-12-30 18:21:09 +03:00
}
}
}()
return iface.listen()
}
func (iface *tcpInterface) listen() error {
var err error
2018-12-29 22:53:31 +03:00
iface.core.configMutex.RLock()
iface.addr = iface.core.config.Listen
iface.timeout = time.Duration(iface.core.config.ReadTimeout) * time.Millisecond
2018-12-29 22:53:31 +03:00
iface.core.configMutex.RUnlock()
2018-12-30 18:21:09 +03:00
if iface.timeout >= 0 && iface.timeout < default_timeout {
iface.timeout = default_timeout
}
2019-01-13 21:08:41 +03:00
ctx := context.Background()
lc := net.ListenConfig{
Control: iface.tcpContext,
}
iface.serv, err = lc.Listen(ctx, "tcp", iface.addr)
2018-04-19 17:30:40 +03:00
if err == nil {
2019-01-16 16:20:12 +03:00
iface.mutex.Lock()
2018-04-19 17:30:40 +03:00
iface.calls = make(map[string]struct{})
iface.conns = make(map[tcpInfo](chan struct{}))
2019-01-16 16:20:12 +03:00
iface.mutex.Unlock()
2018-04-19 17:30:40 +03:00
go iface.listener()
2018-12-30 18:21:09 +03:00
return nil
2018-01-05 01:37:51 +03:00
}
2018-05-28 00:13:37 +03:00
return err
2017-12-29 07:16:20 +03:00
}
// Runs the listener, which spawns off goroutines for incoming connections.
2017-12-29 07:16:20 +03:00
func (iface *tcpInterface) listener() {
2018-01-05 01:37:51 +03:00
defer iface.serv.Close()
iface.core.log.Println("Listening for TCP on:", iface.serv.Addr().String())
2018-01-05 01:37:51 +03:00
for {
2018-04-19 17:30:40 +03:00
sock, err := iface.serv.Accept()
if err != nil {
iface.core.log.Println("Failed to accept connection:", err)
return
}
2018-12-30 18:21:09 +03:00
select {
case <-iface.stop:
2018-12-30 18:21:09 +03:00
iface.core.log.Println("Stopping listener")
return
default:
if err != nil {
panic(err)
}
go iface.handler(sock, true)
2018-01-05 01:37:51 +03:00
}
}
2017-12-29 07:16:20 +03:00
}
// Checks if we already have a connection to this node
func (iface *tcpInterface) isAlreadyConnected(info tcpInfo) bool {
iface.mutex.Lock()
defer iface.mutex.Unlock()
_, isIn := iface.conns[info]
return isIn
}
// Checks if we already are calling this address
func (iface *tcpInterface) isAlreadyCalling(saddr string) bool {
iface.mutex.Lock()
defer iface.mutex.Unlock()
_, isIn := iface.calls[saddr]
return isIn
}
// Checks if a connection already exists.
// If not, it adds it to the list of active outgoing calls (to block future attempts) and dials the address.
// If the dial is successful, it launches the handler.
// When finished, it removes the outgoing call, so reconnection attempts can be made later.
// This all happens in a separate goroutine that it spawns.
func (iface *tcpInterface) call(saddr string, socksaddr *string, sintf string) {
2018-01-05 01:37:51 +03:00
go func() {
callname := saddr
if sintf != "" {
callname = fmt.Sprintf("%s/%s", saddr, sintf)
}
if iface.isAlreadyCalling(saddr) {
2018-06-14 17:11:34 +03:00
return
}
2019-01-16 16:20:12 +03:00
iface.mutex.Lock()
iface.calls[callname] = struct{}{}
2019-01-16 16:20:12 +03:00
iface.mutex.Unlock()
defer func() {
// Block new calls for a little while, to mitigate livelock scenarios
time.Sleep(default_timeout)
time.Sleep(time.Duration(rand.Intn(1000)) * time.Millisecond)
iface.mutex.Lock()
delete(iface.calls, callname)
iface.mutex.Unlock()
}()
2018-06-14 17:11:34 +03:00
var conn net.Conn
var err error
if socksaddr != nil {
2018-09-25 21:46:06 +03:00
if sintf != "" {
return
}
var dialer proxy.Dialer
dialer, err = proxy.SOCKS5("tcp", *socksaddr, nil, proxy.Direct)
if err != nil {
return
}
2018-06-14 17:11:34 +03:00
conn, err = dialer.Dial("tcp", saddr)
if err != nil {
return
}
conn = &wrappedConn{
c: conn,
raddr: &wrappedAddr{
network: "tcp",
addr: saddr,
},
}
} else {
2019-01-13 21:08:41 +03:00
dialer := net.Dialer{
Control: iface.tcpContext,
}
if sintf != "" {
ief, err := net.InterfaceByName(sintf)
if err != nil {
return
}
if ief.Flags&net.FlagUp == 0 {
return
}
addrs, err := ief.Addrs()
if err == nil {
dst, err := net.ResolveTCPAddr("tcp", saddr)
if err != nil {
return
2018-09-25 21:46:06 +03:00
}
for addrindex, addr := range addrs {
src, _, err := net.ParseCIDR(addr.String())
if err != nil {
continue
}
2019-01-18 02:06:59 +03:00
if src.Equal(dst.IP) {
continue
}
if !src.IsGlobalUnicast() && !src.IsLinkLocalUnicast() {
continue
}
bothglobal := src.IsGlobalUnicast() == dst.IP.IsGlobalUnicast()
bothlinklocal := src.IsLinkLocalUnicast() == dst.IP.IsLinkLocalUnicast()
if !bothglobal && !bothlinklocal {
continue
}
if (src.To4() != nil) != (dst.IP.To4() != nil) {
continue
}
if bothglobal || bothlinklocal || addrindex == len(addrs)-1 {
dialer.LocalAddr = &net.TCPAddr{
IP: src,
Port: 0,
Zone: sintf,
}
2019-01-18 02:06:59 +03:00
break
}
}
if dialer.LocalAddr == nil {
return
}
}
}
conn, err = dialer.Dial("tcp", saddr)
2018-01-05 01:37:51 +03:00
if err != nil {
return
}
}
2018-06-14 17:11:34 +03:00
iface.handler(conn, false)
2018-01-05 01:37:51 +03:00
}()
2017-12-29 07:16:20 +03:00
}
// This exchanges/checks connection metadata, sets up the peer struct, sets up the writer goroutine, and then runs the reader within the current goroutine.
// It defers a bunch of cleanup stuff to tear down all of these things when the reader exists (e.g. due to a closed connection or a timeout).
func (iface *tcpInterface) handler(sock net.Conn, incoming bool) {
2018-01-05 01:37:51 +03:00
defer sock.Close()
iface.setExtraOptions(sock)
2018-01-05 01:37:51 +03:00
// Get our keys
myLinkPub, myLinkPriv := crypto.NewBoxKeys() // ephemeral link keys
meta := version_getBaseMetadata()
meta.box = iface.core.boxPub
meta.sig = iface.core.sigPub
meta.link = *myLinkPub
metaBytes := meta.encode()
_, err := sock.Write(metaBytes)
2018-01-05 01:37:51 +03:00
if err != nil {
return
}
if iface.timeout > 0 {
sock.SetReadDeadline(time.Now().Add(iface.timeout))
}
2018-06-10 02:38:30 +03:00
_, err = sock.Read(metaBytes)
2018-01-05 01:37:51 +03:00
if err != nil {
return
}
meta = version_metadata{} // Reset to zero value
2018-06-10 02:38:30 +03:00
if !meta.decode(metaBytes) || !meta.check() {
// Failed to decode and check the metadata
// If it's a version mismatch issue, then print an error message
base := version_getBaseMetadata()
if meta.meta == base.meta {
if meta.ver > base.ver {
iface.core.log.Println("Failed to connect to node:", sock.RemoteAddr().String(), "version:", meta.ver)
} else if meta.ver == base.ver && meta.minorVer > base.minorVer {
iface.core.log.Println("Failed to connect to node:", sock.RemoteAddr().String(), "version:", fmt.Sprintf("%d.%d", meta.ver, meta.minorVer))
}
}
2018-06-10 02:38:30 +03:00
// TODO? Block forever to prevent future connection attempts? suppress future messages about the same node?
2018-01-05 01:37:51 +03:00
return
}
remoteAddr, _, e1 := net.SplitHostPort(sock.RemoteAddr().String())
localAddr, _, e2 := net.SplitHostPort(sock.LocalAddr().String())
if e1 != nil || e2 != nil {
return
}
info := tcpInfo{ // used as a map key, so don't include ephemeral link key
box: meta.box,
sig: meta.sig,
localAddr: localAddr,
remoteAddr: remoteAddr,
}
if iface.isAlreadyConnected(info) {
return
}
2018-01-05 01:37:51 +03:00
// Quit the parent call if this is a connection to ourself
equiv := func(k1, k2 []byte) bool {
for idx := range k1 {
if k1[idx] != k2[idx] {
return false
}
}
return true
}
if equiv(meta.box[:], iface.core.boxPub[:]) {
2018-01-05 01:37:51 +03:00
return
2018-06-13 01:50:08 +03:00
}
if equiv(meta.sig[:], iface.core.sigPub[:]) {
2018-01-05 01:37:51 +03:00
return
}
// Check if we're authorized to connect to this key / IP
if incoming && !iface.core.peers.isAllowedEncryptionPublicKey(&meta.box) {
// Allow unauthorized peers if they're link-local
raddrStr, _, _ := net.SplitHostPort(sock.RemoteAddr().String())
raddr := net.ParseIP(raddrStr)
if !raddr.IsLinkLocalUnicast() {
return
}
}
2018-02-18 05:44:23 +03:00
// Check if we already have a connection to this node, close and block if yes
iface.mutex.Lock()
/*if blockChan, isIn := iface.conns[info]; isIn {
2018-02-18 05:44:23 +03:00
iface.mutex.Unlock()
sock.Close()
<-blockChan
return
}*/
2018-02-18 05:44:23 +03:00
blockChan := make(chan struct{})
iface.conns[info] = blockChan
iface.mutex.Unlock()
defer func() {
iface.mutex.Lock()
delete(iface.conns, info)
iface.mutex.Unlock()
close(blockChan)
}()
2018-01-05 01:37:51 +03:00
// Note that multiple connections to the same node are allowed
// E.g. over different interfaces
p := iface.core.peers.newPeer(&meta.box, &meta.sig, crypto.GetSharedKey(myLinkPriv, &meta.link), sock.RemoteAddr().String())
p.linkOut = make(chan []byte, 1)
out := make(chan []byte, 1)
2018-01-05 01:37:51 +03:00
defer close(out)
go func() {
// This goroutine waits for outgoing packets, link protocol traffic, or sends idle keep-alive traffic
send := func(msg []byte) {
msgLen := wire_encode_uint64(uint64(len(msg)))
buf := net.Buffers{streamMsg[:], msgLen, msg}
buf.WriteTo(sock)
atomic.AddUint64(&p.bytesSent, uint64(len(streamMsg)+len(msgLen)+len(msg)))
util.PutBytes(msg)
}
timerInterval := tcp_ping_interval
2018-06-08 00:49:51 +03:00
timer := time.NewTimer(timerInterval)
defer timer.Stop()
for {
select {
case msg := <-p.linkOut:
// Always send outgoing link traffic first, if needed
send(msg)
continue
default:
}
// Otherwise wait reset the timer and wait for something to do
2018-06-08 00:49:51 +03:00
timer.Stop()
select {
case <-timer.C:
default:
}
timer.Reset(timerInterval)
select {
2018-06-08 00:49:51 +03:00
case _ = <-timer.C:
send(nil) // TCP keep-alive traffic
case msg := <-p.linkOut:
send(msg)
case msg, ok := <-out:
if !ok {
return
}
send(msg) // Block until the socket write has finished
// Now inform the switch that we're ready for more traffic
p.core.switchTable.idleIn <- p.port
2018-01-05 01:37:51 +03:00
}
}
}()
p.core.switchTable.idleIn <- p.port // Start in the idle state
2018-01-05 01:37:51 +03:00
p.out = func(msg []byte) {
defer func() { recover() }()
out <- msg
2018-01-05 01:37:51 +03:00
}
p.close = func() { sock.Close() }
go p.linkLoop()
2018-01-05 01:37:51 +03:00
defer func() {
// Put all of our cleanup here...
p.core.peers.removePeer(p.port)
2018-01-05 01:37:51 +03:00
}()
us, _, _ := net.SplitHostPort(sock.LocalAddr().String())
2018-04-20 15:41:09 +03:00
them, _, _ := net.SplitHostPort(sock.RemoteAddr().String())
themNodeID := crypto.GetNodeID(&meta.box)
themAddr := address.AddrForNodeID(themNodeID)
2018-01-05 01:37:51 +03:00
themAddrString := net.IP(themAddr[:]).String()
themString := fmt.Sprintf("%s@%s", themAddrString, them)
2018-12-30 18:21:09 +03:00
iface.core.log.Printf("Connected: %s, source: %s", themString, us)
iface.stream.init(p.handlePacket)
bs := make([]byte, 2*streamMsgSize)
var n int
2018-01-05 01:37:51 +03:00
for {
if iface.timeout > 0 {
sock.SetReadDeadline(time.Now().Add(iface.timeout))
}
n, err = sock.Read(bs)
if err != nil {
break
2018-01-05 01:37:51 +03:00
}
if n > 0 {
iface.stream.handleInput(bs[:n])
2018-01-05 01:37:51 +03:00
}
}
if err == nil {
iface.core.log.Printf("Disconnected: %s, source: %s", themString, us)
} else {
iface.core.log.Printf("Disconnected: %s, source: %s, error: %s", themString, us, err)
2018-01-05 01:37:51 +03:00
}
return
2017-12-29 07:16:20 +03:00
}