router

package
v0.10.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 21, 2015 License: Apache-2.0 Imports: 25 Imported by: 0

Documentation

Overview

Let peer names be MACs...

MACs need to be unique across our network, or bad things will happen anyway. So they make pretty good candidates for peer names. And doing so is pretty efficient both computationally and network overhead wise.

Note that we do not mandate *what* MAC should be used as the peer name. In particular it doesn't actually have to be the MAC of, say, the network interface the peer is sniffing on.

Index

Constants

View Source
const (
	InitialInterval = 5 * time.Second
	MaxInterval     = 10 * time.Minute
)
View Source
const (
	EthernetOverhead    = 14
	UDPOverhead         = 28 // 20 bytes for IPv4, 8 bytes for UDP
	Port                = 6783
	HTTPPort            = Port + 1
	DefaultPMTU         = 65535
	MaxUDPPacketSize    = 65536
	ChannelSize         = 16
	UDPNonceSendAt      = 8192
	FragTestSize        = 60001
	PMTUDiscoverySize   = 60000
	TCPHeartbeat        = 30 * time.Second
	FastHeartbeat       = 500 * time.Millisecond
	SlowHeartbeat       = 10 * time.Second
	FragTestInterval    = 5 * time.Minute
	PMTUVerifyAttempts  = 8
	PMTUVerifyTimeout   = 10 * time.Millisecond // gets doubled with every attempt
	MaxDuration         = time.Duration(math.MaxInt64)
	MaxMissedHeartbeats = 3
	HeartbeatTimeout    = MaxMissedHeartbeats * SlowHeartbeat
)
View Source
const (
	PeerNameFlavour = "mac"
	NameSize        = 6
	UnknownPeerName = PeerName(0)
)
View Source
const (
	Protocol        = "weave"
	ProtocolVersion = 15
)
View Source
const GossipInterval = 30 * time.Second

Variables

View Source
var (
	FragTest      = make([]byte, FragTestSize)
	PMTUDiscovery = make([]byte, PMTUDiscoverySize)
)

Functions

func Concat

func Concat(elems ...[]byte) []byte

func DecodeNonce

func DecodeNonce(msg []byte) (bool, *[24]byte)

func DecryptPrefixNonce

func DecryptPrefixNonce(ciphertxt []byte, secret *[32]byte) ([]byte, bool)

func EncodeNonce

func EncodeNonce(df bool) (*[24]byte, []byte, error)

func EncryptPrefixNonce

func EncryptPrefixNonce(plaintxt []byte, nonce *[24]byte, secret *[32]byte) []byte

func FormSessionKey

func FormSessionKey(remotePublicKey, localPrivateKey *[32]byte, secretKey []byte) *[32]byte

func GenerateKeyPair

func GenerateKeyPair() (publicKey, privateKey *[32]byte, err error)

func GenerateRandomNonce

func GenerateRandomNonce() ([24]byte, error)

func GobEncode added in v0.9.0

func GobEncode(items ...interface{}) []byte

func PosixError

func PosixError(err error) error

func SetNonceLow15Bits

func SetNonceLow15Bits(nonce *[24]byte, offset uint16)

Types

type Connection

type Connection interface {
	Local() *Peer
	Remote() *Peer
	RemoteTCPAddr() string
	Outbound() bool
	Established() bool
	BreakTie(Connection) ConnectionTieBreak
	Shutdown(error)
	Log(args ...interface{})
}

type ConnectionAction added in v0.10.0

type ConnectionAction func() error

type ConnectionMaker

type ConnectionMaker struct {
	// contains filtered or unexported fields
}

func NewConnectionMaker added in v0.9.0

func NewConnectionMaker(ourself *LocalPeer, peers *Peers, port int) *ConnectionMaker

func (*ConnectionMaker) ConnectionTerminated

func (cm *ConnectionMaker) ConnectionTerminated(address string, err error)

func (*ConnectionMaker) ForgetConnection added in v0.10.0

func (cm *ConnectionMaker) ForgetConnection(peer string)

func (*ConnectionMaker) InitiateConnection

func (cm *ConnectionMaker) InitiateConnection(peer string) error

func (*ConnectionMaker) Refresh

func (cm *ConnectionMaker) Refresh()

func (*ConnectionMaker) Start added in v0.9.0

func (cm *ConnectionMaker) Start()

func (*ConnectionMaker) String

func (cm *ConnectionMaker) String() string

type ConnectionMakerAction added in v0.10.0

type ConnectionMakerAction func() bool

type ConnectionSet added in v0.10.0

type ConnectionSet map[Connection]struct{}

type ConnectionTieBreak added in v0.9.0

type ConnectionTieBreak int
const (
	TieBreakWon ConnectionTieBreak = iota
	TieBreakLost
	TieBreakTied
)

type Decryptor

type Decryptor interface {
	IterateFrames([]byte, FrameConsumer) error
	ReceiveNonce([]byte)
	Shutdown()
}

type EncryptedTCPMessage

type EncryptedTCPMessage struct {
	Number int
	Body   []byte
}

type EncryptedTCPReceiver

type EncryptedTCPReceiver struct {
	// contains filtered or unexported fields
}

func NewEncryptedTCPReceiver

func NewEncryptedTCPReceiver(conn *LocalConnection) *EncryptedTCPReceiver

func (*EncryptedTCPReceiver) Decode

func (receiver *EncryptedTCPReceiver) Decode(msg []byte) ([]byte, error)

type EncryptedTCPSender

type EncryptedTCPSender struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func NewEncryptedTCPSender

func NewEncryptedTCPSender(encoder *gob.Encoder, conn *LocalConnection) *EncryptedTCPSender

func (*EncryptedTCPSender) Send

func (sender *EncryptedTCPSender) Send(msg []byte) error

type Encryptor

type Encryptor interface {
	FrameOverhead() int
	PacketOverhead() int
	IsEmpty() bool
	Bytes() []byte
	AppendFrame(src []byte, dst []byte, frame []byte)
	TotalLen() int
}

type EthernetDecoder

type EthernetDecoder struct {
	// contains filtered or unexported fields
}

func NewEthernetDecoder

func NewEthernetDecoder() *EthernetDecoder

func (*EthernetDecoder) DecodeLayers

func (dec *EthernetDecoder) DecodeLayers(data []byte) error

func (*EthernetDecoder) DropFrame

func (dec *EthernetDecoder) DropFrame() bool

func (*EthernetDecoder) IsSpecial added in v0.9.0

func (dec *EthernetDecoder) IsSpecial() bool

type FieldValidator added in v0.10.0

type FieldValidator struct {
	// contains filtered or unexported fields
}

func NewFieldValidator added in v0.10.0

func NewFieldValidator(fields map[string]string) *FieldValidator

func (*FieldValidator) CheckEqual added in v0.10.0

func (fv *FieldValidator) CheckEqual(fieldName, expectedValue string) error

func (*FieldValidator) Err added in v0.10.0

func (fv *FieldValidator) Err() error

func (*FieldValidator) Value added in v0.10.0

func (fv *FieldValidator) Value(fieldName string) (string, error)

type ForwardedFrame

type ForwardedFrame struct {
	// contains filtered or unexported fields
}

type Forwarder

type Forwarder struct {
	// contains filtered or unexported fields
}

func NewForwarder

func NewForwarder(conn *LocalConnection, enc Encryptor, udpSender UDPSender, pmtu int) *Forwarder

func (*Forwarder) Forward added in v0.10.0

func (fwd *Forwarder) Forward(frame *ForwardedFrame)

func (*Forwarder) Shutdown added in v0.10.0

func (fwd *Forwarder) Shutdown()

func (*Forwarder) Start added in v0.9.0

func (fwd *Forwarder) Start()

type ForwarderDF added in v0.10.0

type ForwarderDF struct {
	Forwarder
	// contains filtered or unexported fields
}

func NewForwarderDF added in v0.10.0

func NewForwarderDF(conn *LocalConnection, enc Encryptor, udpSender UDPSender, pmtu int) *ForwarderDF

func (*ForwarderDF) PMTUVerified added in v0.10.0

func (fwd *ForwarderDF) PMTUVerified(pmtu int)

func (*ForwarderDF) Start added in v0.10.0

func (fwd *ForwarderDF) Start()

type FrameConsumer

type FrameConsumer func(conn *LocalConnection, src []byte, dst []byte, frame []byte)

type FrameTooBigError

type FrameTooBigError struct {
	EPMTU int // effective pmtu, i.e. what we tell packet senders
}

func (FrameTooBigError) Error

func (ftbe FrameTooBigError) Error() string

type Gossip added in v0.9.0

type Gossip interface {
	// specific message from one peer to another
	// intermediate peers relay it using unicast topology.
	GossipUnicast(dstPeerName PeerName, msg []byte) error
	// send gossip to every peer, relayed using broadcast topology.
	GossipBroadcast(update GossipData) error
}

type GossipChannel added in v0.9.0

type GossipChannel struct {
	sync.Mutex
	// contains filtered or unexported fields
}

func (*GossipChannel) GossipBroadcast added in v0.9.0

func (c *GossipChannel) GossipBroadcast(update GossipData) error

func (*GossipChannel) GossipUnicast added in v0.9.0

func (c *GossipChannel) GossipUnicast(dstPeerName PeerName, msg []byte) error

func (*GossipChannel) Send added in v0.10.0

func (c *GossipChannel) Send(srcName PeerName, data GossipData)

func (*GossipChannel) SendDown added in v0.10.0

func (c *GossipChannel) SendDown(conn Connection, data GossipData)

type GossipData added in v0.10.0

type GossipData interface {
	Encode() []byte
	Merge(GossipData)
}

type GossipSender added in v0.10.0

type GossipSender struct {
	// contains filtered or unexported fields
}

Accumulates GossipData that needs to be sent to one destination, and sends it when possible.

func NewGossipSender added in v0.10.0

func NewGossipSender(send func(GossipData)) *GossipSender

func (*GossipSender) Send added in v0.10.0

func (sender *GossipSender) Send(data GossipData)

func (*GossipSender) Start added in v0.10.0

func (sender *GossipSender) Start()

func (*GossipSender) Stop added in v0.10.0

func (sender *GossipSender) Stop()

type Gossiper added in v0.9.0

type Gossiper interface {
	OnGossipUnicast(sender PeerName, msg []byte) error
	// merge received data into state and return a representation of
	// the received data, for further propagation
	OnGossipBroadcast(update []byte) (GossipData, error)
	// return state of everything we know; gets called periodically
	Gossip() GossipData
	// merge received data into state and return "everything new I've
	// just learnt", or nil if nothing in the received data was new
	OnGossip(update []byte) (GossipData, error)
}

type ListOfPeers

type ListOfPeers []*Peer

func (ListOfPeers) Len

func (lop ListOfPeers) Len() int

func (ListOfPeers) Less

func (lop ListOfPeers) Less(i, j int) bool

func (ListOfPeers) Swap

func (lop ListOfPeers) Swap(i, j int)

type LocalConnection

type LocalConnection struct {
	sync.RWMutex
	RemoteConnection
	TCPConn *net.TCPConn

	SessionKey *[32]byte

	Decryptor Decryptor
	Router    *Router
	// contains filtered or unexported fields
}

func NewLocalConnection

func NewLocalConnection(connRemote *RemoteConnection, tcpConn *net.TCPConn, udpAddr *net.UDPAddr, router *Router) *LocalConnection

func (*LocalConnection) BreakTie added in v0.9.0

func (conn *LocalConnection) BreakTie(dupConn Connection) ConnectionTieBreak

func (*LocalConnection) Established

func (conn *LocalConnection) Established() bool

func (*LocalConnection) Forward

func (conn *LocalConnection) Forward(df bool, frame *ForwardedFrame, dec *EthernetDecoder) error

Called from peer.Relay[Broadcast] which is itself invoked from router (both UDP listener process and sniffer process). Also called from connection's heartbeat process, and from the connection's TCP receiver process.

func (*LocalConnection) ReceivedHeartbeat added in v0.9.0

func (conn *LocalConnection) ReceivedHeartbeat(remoteUDPAddr *net.UDPAddr, connUID uint64)

Async

Heartbeating serves two purposes: a) keeping NAT paths alive, and b) updating a remote peer's knowledge of our address, in the event it changes (e.g. because NAT paths expired).

func (*LocalConnection) RemoteUDPAddr

func (conn *LocalConnection) RemoteUDPAddr() *net.UDPAddr

Read by the forwarder processes when in the UDP senders

func (*LocalConnection) SendProtocolMsg added in v0.9.0

func (conn *LocalConnection) SendProtocolMsg(m ProtocolMsg)

Send directly, not via the Actor. If it goes via the Actor we can get a deadlock where LocalConnection is blocked talking to LocalPeer and LocalPeer is blocked trying send a ProtocolMsg via LocalConnection, and the channels are full in both directions so nothing can proceed.

func (*LocalConnection) SetEstablished

func (conn *LocalConnection) SetEstablished()

Async

func (*LocalConnection) Shutdown

func (conn *LocalConnection) Shutdown(err error)

Async

func (*LocalConnection) Start added in v0.9.0

func (conn *LocalConnection) Start(acceptNewPeer bool)

Async. Does not return anything. If the connection is successful, it will end up in the local peer's connections map.

type LocalPeer

type LocalPeer struct {
	*Peer
	// contains filtered or unexported fields
}

func NewLocalPeer added in v0.9.0

func NewLocalPeer(name PeerName, nickName string, router *Router) *LocalPeer

func (*LocalPeer) AddConnection

func (peer *LocalPeer) AddConnection(conn *LocalConnection) error

Sync.

func (*LocalPeer) Broadcast

func (peer *LocalPeer) Broadcast(df bool, frame []byte, dec *EthernetDecoder)

func (*LocalPeer) ConnectionEstablished

func (peer *LocalPeer) ConnectionEstablished(conn *LocalConnection)

Async.

func (*LocalPeer) ConnectionsTo added in v0.10.0

func (peer *LocalPeer) ConnectionsTo(names []PeerName) []Connection

func (*LocalPeer) CreateConnection

func (peer *LocalPeer) CreateConnection(peerAddr string, acceptNewPeer bool) error

func (*LocalPeer) DeleteConnection

func (peer *LocalPeer) DeleteConnection(conn *LocalConnection)

Sync.

func (*LocalPeer) Forward

func (peer *LocalPeer) Forward(dstPeer *Peer, df bool, frame []byte, dec *EthernetDecoder) error

func (*LocalPeer) Relay

func (peer *LocalPeer) Relay(srcPeer, dstPeer *Peer, df bool, frame []byte, dec *EthernetDecoder) error

func (*LocalPeer) RelayBroadcast

func (peer *LocalPeer) RelayBroadcast(srcPeer *Peer, df bool, frame []byte, dec *EthernetDecoder)

func (*LocalPeer) Start added in v0.9.0

func (peer *LocalPeer) Start()

type LocalPeerAction added in v0.10.0

type LocalPeerAction func()

type LogFrameFunc added in v0.10.0

type LogFrameFunc func(string, []byte, *layers.Ethernet)

type MacCache

type MacCache struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func NewMacCache

func NewMacCache(maxAge time.Duration, onExpiry func(net.HardwareAddr, *Peer)) *MacCache

func (*MacCache) Delete

func (cache *MacCache) Delete(peer *Peer) bool

func (*MacCache) Enter

func (cache *MacCache) Enter(mac net.HardwareAddr, peer *Peer) bool

func (*MacCache) Lookup

func (cache *MacCache) Lookup(mac net.HardwareAddr) (*Peer, bool)

func (*MacCache) MarshalJSON added in v0.10.0

func (cache *MacCache) MarshalJSON() ([]byte, error)

func (*MacCache) Start added in v0.9.0

func (cache *MacCache) Start()

func (*MacCache) String

func (cache *MacCache) String() string

type MacCacheEntry

type MacCacheEntry struct {
	// contains filtered or unexported fields
}

type MsgTooBigError

type MsgTooBigError struct {
	PMTU int // actual pmtu, i.e. what the kernel told us
}

func (MsgTooBigError) Error

func (mtbe MsgTooBigError) Error() string

type NaClDecryptor

type NaClDecryptor struct {
	NonDecryptor
	// contains filtered or unexported fields
}

func NewNaClDecryptor

func NewNaClDecryptor(conn *LocalConnection) *NaClDecryptor

func (*NaClDecryptor) IterateFrames

func (nd *NaClDecryptor) IterateFrames(packet []byte, consumer FrameConsumer) error

func (*NaClDecryptor) ReceiveNonce

func (nd *NaClDecryptor) ReceiveNonce(msg []byte)

func (*NaClDecryptor) Shutdown

func (nd *NaClDecryptor) Shutdown()

type NaClDecryptorInstance

type NaClDecryptorInstance struct {
	// contains filtered or unexported fields
}

type NaClEncryptor

type NaClEncryptor struct {
	NonEncryptor
	// contains filtered or unexported fields
}

func NewNaClEncryptor

func NewNaClEncryptor(prefix []byte, conn *LocalConnection, df bool) *NaClEncryptor

func (*NaClEncryptor) Bytes

func (ne *NaClEncryptor) Bytes() []byte

func (*NaClEncryptor) PacketOverhead

func (ne *NaClEncryptor) PacketOverhead() int

func (*NaClEncryptor) TotalLen

func (ne *NaClEncryptor) TotalLen() int

type NameCollisionError

type NameCollisionError struct {
	Name PeerName
}

func (NameCollisionError) Error

func (nce NameCollisionError) Error() string

type NonDecryptor

type NonDecryptor struct {
	// contains filtered or unexported fields
}

func NewNonDecryptor

func NewNonDecryptor(conn *LocalConnection) *NonDecryptor

func (*NonDecryptor) IterateFrames

func (nd *NonDecryptor) IterateFrames(packet []byte, consumer FrameConsumer) error

func (*NonDecryptor) ReceiveNonce

func (nd *NonDecryptor) ReceiveNonce(msg []byte)

func (*NonDecryptor) Shutdown

func (nd *NonDecryptor) Shutdown()

type NonEncryptor

type NonEncryptor struct {
	// contains filtered or unexported fields
}

func NewNonEncryptor

func NewNonEncryptor(prefix []byte) *NonEncryptor

func (*NonEncryptor) AppendFrame

func (ne *NonEncryptor) AppendFrame(src []byte, dst []byte, frame []byte)

func (*NonEncryptor) Bytes

func (ne *NonEncryptor) Bytes() []byte

func (*NonEncryptor) FrameOverhead

func (ne *NonEncryptor) FrameOverhead() int

func (*NonEncryptor) IsEmpty

func (ne *NonEncryptor) IsEmpty() bool

func (*NonEncryptor) PacketOverhead

func (ne *NonEncryptor) PacketOverhead() int

func (*NonEncryptor) TotalLen

func (ne *NonEncryptor) TotalLen() int

type PacketDecodingError

type PacketDecodingError struct {
	Desc string
}

func (PacketDecodingError) Error

func (pde PacketDecodingError) Error() string

type PacketSink

type PacketSink interface {
	WritePacket([]byte) error
}

func NewPcapO

func NewPcapO(ifName string) (po PacketSink, err error)

type PacketSource

type PacketSource interface {
	ReadPacket() ([]byte, error)
}

type PacketSourceSink

type PacketSourceSink interface {
	PacketSource
	PacketSink
}

func NewPcapIO

func NewPcapIO(ifName string, bufSz int) (PacketSourceSink, error)

type PcapIO

type PcapIO struct {
	// contains filtered or unexported fields
}

func (*PcapIO) ReadPacket

func (pi *PcapIO) ReadPacket() (data []byte, err error)

func (*PcapIO) WritePacket

func (po *PcapIO) WritePacket(data []byte) error

type Peer

type Peer struct {
	sync.RWMutex
	Name     PeerName
	NameByte []byte
	NickName string
	UID      uint64
	// contains filtered or unexported fields
}

func NewPeer

func NewPeer(name PeerName, nickName string, uid uint64, version uint64) *Peer

func (*Peer) ConnectionCount

func (peer *Peer) ConnectionCount() int

func (*Peer) ConnectionTo

func (peer *Peer) ConnectionTo(name PeerName) (Connection, bool)

func (*Peer) Connections added in v0.10.0

func (peer *Peer) Connections() ConnectionSet

func (*Peer) DecrementLocalRefCount

func (peer *Peer) DecrementLocalRefCount()

func (*Peer) FullName added in v0.10.0

func (peer *Peer) FullName() string

func (*Peer) IncrementLocalRefCount

func (peer *Peer) IncrementLocalRefCount()

func (*Peer) IsLocallyReferenced

func (peer *Peer) IsLocallyReferenced() bool

func (*Peer) MarshalJSON added in v0.10.0

func (peer *Peer) MarshalJSON() ([]byte, error)

func (*Peer) Routes

func (peer *Peer) Routes(stopAt *Peer, establishedAndSymmetric bool) (bool, map[PeerName]PeerName)

Calculate the routing table from this peer to all peers reachable from it, returning a "next hop" map of PeerNameX -> PeerNameY, which says "in order to send a message to X, the peer should send the message to its neighbour Y".

Because currently we do not have weightings on the connections between peers, there is no need to use a minimum spanning tree algorithm. Instead we employ the simpler and cheaper breadth-first widening. The computation is deterministic, which ensures that when it is performed on the same data by different peers, they get the same result. This is important since otherwise we risk message loss or routing cycles.

When the 'establishedAndSymmetric' flag is set, only connections that are marked as 'established' and are symmetric (i.e. where both sides indicate they have a connection to the other) are considered.

When a non-nil stopAt peer is supplied, the widening stops when it reaches that peer. The boolean return indicates whether that has happened.

We acquire read locks on peers as we encounter them during the traversal. This prevents the connectivity graph from changing underneath us in ways that would invalidate the result. Thus the answer returned may be out of date, but never inconsistent.

func (*Peer) SetVersionAndConnections

func (peer *Peer) SetVersionAndConnections(version uint64, connections map[PeerName]Connection)

func (*Peer) String

func (peer *Peer) String() string

func (*Peer) Version

func (peer *Peer) Version() uint64

type PeerName

type PeerName uint64

PeerName is used as a map key. Since net.HardwareAddr isn't suitable for that - it's a slice, and slices can't be map keys - we convert that to/from uint64.

func PeerNameFromBin

func PeerNameFromBin(nameByte []byte) PeerName

func PeerNameFromString

func PeerNameFromString(nameStr string) (PeerName, error)

func PeerNameFromUserInput

func PeerNameFromUserInput(userInput string) (PeerName, error)

func (PeerName) Bin

func (name PeerName) Bin() []byte

func (PeerName) MarshalJSON added in v0.10.0

func (name PeerName) MarshalJSON() ([]byte, error)

func (PeerName) String

func (name PeerName) String() string

type PeerNameSet added in v0.10.0

type PeerNameSet map[PeerName]struct{}

type Peers

type Peers struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func NewPeers

func NewPeers(ourself *Peer, onGC func(*Peer)) *Peers

func (*Peers) ApplyUpdate

func (peers *Peers) ApplyUpdate(update []byte) (PeerNameSet, PeerNameSet, error)

Merge an incoming update with our own topology.

We add peers hitherto unknown to us, and update peers for which the update contains a more recent version than known to us. The return value is a) a representation of the received update, and b) an "improved" update containing just these new/updated elements.

func (*Peers) EncodePeers added in v0.10.0

func (peers *Peers) EncodePeers(names PeerNameSet) []byte

func (*Peers) Fetch

func (peers *Peers) Fetch(name PeerName) (*Peer, bool)

func (*Peers) FetchWithDefault

func (peers *Peers) FetchWithDefault(peer *Peer) *Peer

func (*Peers) ForEach

func (peers *Peers) ForEach(fun func(*Peer))

func (*Peers) GarbageCollect

func (peers *Peers) GarbageCollect() []*Peer

func (*Peers) MarshalJSON added in v0.10.0

func (peers *Peers) MarshalJSON() ([]byte, error)

func (*Peers) Names added in v0.10.0

func (peers *Peers) Names() PeerNameSet

func (*Peers) String

func (peers *Peers) String() string

type ProtocolMsg added in v0.9.0

type ProtocolMsg struct {
	// contains filtered or unexported fields
}

type ProtocolSender added in v0.9.0

type ProtocolSender interface {
	SendProtocolMsg(m ProtocolMsg)
}

type ProtocolTag added in v0.9.0

type ProtocolTag byte
const (
	ProtocolHeartbeat ProtocolTag = iota
	ProtocolConnectionEstablished
	ProtocolFragmentationReceived
	ProtocolStartFragmentationTest
	ProtocolNonce
	ProtocolPMTUVerified
	ProtocolGossip
	ProtocolGossipUnicast
	ProtocolGossipBroadcast
)

type RawUDPSender

type RawUDPSender struct {
	// contains filtered or unexported fields
}

func NewRawUDPSender

func NewRawUDPSender(conn *LocalConnection) (*RawUDPSender, error)

func (*RawUDPSender) Send

func (sender *RawUDPSender) Send(msg []byte) error

func (*RawUDPSender) Shutdown

func (sender *RawUDPSender) Shutdown() error

type RemoteConnection

type RemoteConnection struct {
	// contains filtered or unexported fields
}

func NewRemoteConnection

func NewRemoteConnection(from, to *Peer, tcpAddr string, outbound bool, established bool) *RemoteConnection

func (*RemoteConnection) BreakTie added in v0.9.0

func (*RemoteConnection) Established

func (conn *RemoteConnection) Established() bool

func (*RemoteConnection) Local

func (conn *RemoteConnection) Local() *Peer

func (*RemoteConnection) Log added in v0.10.0

func (conn *RemoteConnection) Log(args ...interface{})

func (*RemoteConnection) MarshalJSON added in v0.10.0

func (conn *RemoteConnection) MarshalJSON() ([]byte, error)

func (*RemoteConnection) Outbound added in v0.10.0

func (conn *RemoteConnection) Outbound() bool

func (*RemoteConnection) Remote

func (conn *RemoteConnection) Remote() *Peer

func (*RemoteConnection) RemoteTCPAddr

func (conn *RemoteConnection) RemoteTCPAddr() string

func (*RemoteConnection) Shutdown

func (conn *RemoteConnection) Shutdown(error)

func (*RemoteConnection) String

func (conn *RemoteConnection) String() string

type Router

type Router struct {
	RouterConfig
	Ourself         *LocalPeer
	Macs            *MacCache
	Peers           *Peers
	Routes          *Routes
	ConnectionMaker *ConnectionMaker
	GossipChannels  map[uint32]*GossipChannel
	TopologyGossip  Gossip
	UDPListener     *net.UDPConn
}

func NewRouter

func NewRouter(config RouterConfig, name PeerName, nickName string) *Router

func (*Router) GenerateStatusJSON added in v0.10.0

func (router *Router) GenerateStatusJSON(version, encryption string) ([]byte, error)

func (*Router) Gossip added in v0.9.0

func (router *Router) Gossip() GossipData

func (*Router) NewGossip added in v0.9.0

func (router *Router) NewGossip(channelName string, g Gossiper) Gossip

func (*Router) OnGossip added in v0.9.0

func (router *Router) OnGossip(update []byte) (GossipData, error)

func (*Router) OnGossipBroadcast added in v0.9.0

func (router *Router) OnGossipBroadcast(update []byte) (GossipData, error)

func (*Router) OnGossipUnicast added in v0.9.0

func (router *Router) OnGossipUnicast(sender PeerName, msg []byte) error

func (*Router) SendAllGossip added in v0.9.0

func (router *Router) SendAllGossip()

func (*Router) SendAllGossipDown added in v0.9.0

func (router *Router) SendAllGossipDown(conn Connection)

func (*Router) Start

func (router *Router) Start()

func (*Router) Status

func (router *Router) Status() string

func (*Router) UsingPassword

func (router *Router) UsingPassword() bool

type RouterConfig added in v0.10.0

type RouterConfig struct {
	Port      int
	Iface     *net.Interface
	Password  []byte
	ConnLimit int
	BufSz     int
	LogFrame  LogFrameFunc
}

type Routes

type Routes struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func NewRoutes added in v0.9.0

func NewRoutes(ourself *Peer, peers *Peers) *Routes

func (*Routes) Broadcast

func (routes *Routes) Broadcast(name PeerName) []PeerName

func (*Routes) BroadcastAll added in v0.10.0

func (routes *Routes) BroadcastAll(name PeerName) []PeerName

func (*Routes) EnsureRecalculated added in v0.10.0

func (routes *Routes) EnsureRecalculated()

Wait for any preceding Recalculate requests to be processed.

func (*Routes) MarshalJSON added in v0.10.0

func (routes *Routes) MarshalJSON() ([]byte, error)

func (*Routes) PeerNames added in v0.10.0

func (routes *Routes) PeerNames() PeerNameSet

func (*Routes) RandomNeighbours added in v0.10.0

func (routes *Routes) RandomNeighbours(except PeerName) PeerNameSet

Choose min(log2(n_peers), n_neighbouring_peers) neighbours, with a random distribution that is topology-sensitive, favouring neighbours at the end of "bottleneck links". We determine the latter based on the unicast routing table. If a neighbour appears as the value more frequently than others - meaning that we reach a higher proportion of peers via that neighbour than other neighbours - then it is chosen with a higher probability.

Note that we choose log2(n_peers) *neighbours*, not peers. Consequently, on sparsely connected peers this function returns a higher proportion of neighbours than elsewhere. In extremis, on peers with fewer than log2(n_peers) neighbours, all neighbours are returned.

func (*Routes) Recalculate

func (routes *Routes) Recalculate()

Request recalculation of the routing table. This is async but can effectively be made synchronous with a subsequent call to EnsureRecalculated.

func (*Routes) Start added in v0.9.0

func (routes *Routes) Start()

func (*Routes) String

func (routes *Routes) String() string

func (*Routes) Unicast

func (routes *Routes) Unicast(name PeerName) (PeerName, bool)

func (*Routes) UnicastAll added in v0.10.0

func (routes *Routes) UnicastAll(name PeerName) (PeerName, bool)

type SimpleTCPReceiver

type SimpleTCPReceiver struct {
}

func NewSimpleTCPReceiver

func NewSimpleTCPReceiver() *SimpleTCPReceiver

func (*SimpleTCPReceiver) Decode

func (receiver *SimpleTCPReceiver) Decode(msg []byte) ([]byte, error)

type SimpleTCPSender

type SimpleTCPSender struct {
	// contains filtered or unexported fields
}

func NewSimpleTCPSender

func NewSimpleTCPSender(encoder *gob.Encoder) *SimpleTCPSender

func (*SimpleTCPSender) Send

func (sender *SimpleTCPSender) Send(msg []byte) error

type SimpleUDPSender

type SimpleUDPSender struct {
	// contains filtered or unexported fields
}

func NewSimpleUDPSender

func NewSimpleUDPSender(conn *LocalConnection) *SimpleUDPSender

func (*SimpleUDPSender) Send

func (sender *SimpleUDPSender) Send(msg []byte) error

func (*SimpleUDPSender) Shutdown

func (sender *SimpleUDPSender) Shutdown() error

type TCPReceiver

type TCPReceiver interface {
	Decode([]byte) ([]byte, error)
}

type TCPSender

type TCPSender interface {
	Send([]byte) error
}

type Target

type Target struct {
	// contains filtered or unexported fields
}

Information about an address where we may find a peer

type TopologyGossipData added in v0.10.0

type TopologyGossipData struct {
	// contains filtered or unexported fields
}

func NewTopologyGossipData added in v0.10.0

func NewTopologyGossipData(peers *Peers, update ...*Peer) *TopologyGossipData

func (*TopologyGossipData) Encode added in v0.10.0

func (d *TopologyGossipData) Encode() []byte

func (*TopologyGossipData) Merge added in v0.10.0

func (d *TopologyGossipData) Merge(other GossipData)

type UDPSender

type UDPSender interface {
	Send([]byte) error
	Shutdown() error
}

type UnknownPeerError added in v0.9.0

type UnknownPeerError struct {
	Name PeerName
}

func (UnknownPeerError) Error added in v0.9.0

func (upe UnknownPeerError) Error() string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL