mirror of https://github.com/ethereum/go-ethereum
parent
8cf9ed0ea5
commit
f38052c499
@ -1,275 +0,0 @@ |
|||||||
package p2p |
|
||||||
|
|
||||||
import ( |
|
||||||
"bytes" |
|
||||||
// "fmt"
|
|
||||||
"net" |
|
||||||
"time" |
|
||||||
|
|
||||||
"github.com/ethereum/go-ethereum/ethutil" |
|
||||||
) |
|
||||||
|
|
||||||
type Connection struct { |
|
||||||
conn net.Conn |
|
||||||
// conn NetworkConnection
|
|
||||||
timeout time.Duration |
|
||||||
in chan []byte |
|
||||||
out chan []byte |
|
||||||
err chan *PeerError |
|
||||||
closingIn chan chan bool |
|
||||||
closingOut chan chan bool |
|
||||||
} |
|
||||||
|
|
||||||
// const readBufferLength = 2 //for testing
|
|
||||||
|
|
||||||
const readBufferLength = 1440 |
|
||||||
const partialsQueueSize = 10 |
|
||||||
const maxPendingQueueSize = 1 |
|
||||||
const defaultTimeout = 500 |
|
||||||
|
|
||||||
var magicToken = []byte{34, 64, 8, 145} |
|
||||||
|
|
||||||
func (self *Connection) Open() { |
|
||||||
go self.startRead() |
|
||||||
go self.startWrite() |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) Close() { |
|
||||||
self.closeIn() |
|
||||||
self.closeOut() |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) closeIn() { |
|
||||||
errc := make(chan bool) |
|
||||||
self.closingIn <- errc |
|
||||||
<-errc |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) closeOut() { |
|
||||||
errc := make(chan bool) |
|
||||||
self.closingOut <- errc |
|
||||||
<-errc |
|
||||||
} |
|
||||||
|
|
||||||
func NewConnection(conn net.Conn, errchan chan *PeerError) *Connection { |
|
||||||
return &Connection{ |
|
||||||
conn: conn, |
|
||||||
timeout: defaultTimeout, |
|
||||||
in: make(chan []byte), |
|
||||||
out: make(chan []byte), |
|
||||||
err: errchan, |
|
||||||
closingIn: make(chan chan bool, 1), |
|
||||||
closingOut: make(chan chan bool, 1), |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) Read() <-chan []byte { |
|
||||||
return self.in |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) Write() chan<- []byte { |
|
||||||
return self.out |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) Error() <-chan *PeerError { |
|
||||||
return self.err |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) startRead() { |
|
||||||
payloads := make(chan []byte) |
|
||||||
done := make(chan *PeerError) |
|
||||||
pending := [][]byte{} |
|
||||||
var head []byte |
|
||||||
var wait time.Duration // initally 0 (no delay)
|
|
||||||
read := time.After(wait * time.Millisecond) |
|
||||||
|
|
||||||
for { |
|
||||||
// if pending empty, nil channel blocks
|
|
||||||
var in chan []byte |
|
||||||
if len(pending) > 0 { |
|
||||||
in = self.in // enable send case
|
|
||||||
head = pending[0] |
|
||||||
} else { |
|
||||||
in = nil |
|
||||||
} |
|
||||||
|
|
||||||
select { |
|
||||||
case <-read: |
|
||||||
go self.read(payloads, done) |
|
||||||
case err := <-done: |
|
||||||
if err == nil { // no error but nothing to read
|
|
||||||
if len(pending) < maxPendingQueueSize { |
|
||||||
wait = 100 |
|
||||||
} else if wait == 0 { |
|
||||||
wait = 100 |
|
||||||
} else { |
|
||||||
wait = 2 * wait |
|
||||||
} |
|
||||||
} else { |
|
||||||
self.err <- err // report error
|
|
||||||
wait = 100 |
|
||||||
} |
|
||||||
read = time.After(wait * time.Millisecond) |
|
||||||
case payload := <-payloads: |
|
||||||
pending = append(pending, payload) |
|
||||||
if len(pending) < maxPendingQueueSize { |
|
||||||
wait = 0 |
|
||||||
} else { |
|
||||||
wait = 100 |
|
||||||
} |
|
||||||
read = time.After(wait * time.Millisecond) |
|
||||||
case in <- head: |
|
||||||
pending = pending[1:] |
|
||||||
case errc := <-self.closingIn: |
|
||||||
errc <- true |
|
||||||
close(self.in) |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) startWrite() { |
|
||||||
pending := [][]byte{} |
|
||||||
done := make(chan *PeerError) |
|
||||||
writing := false |
|
||||||
for { |
|
||||||
if len(pending) > 0 && !writing { |
|
||||||
writing = true |
|
||||||
go self.write(pending[0], done) |
|
||||||
} |
|
||||||
select { |
|
||||||
case payload := <-self.out: |
|
||||||
pending = append(pending, payload) |
|
||||||
case err := <-done: |
|
||||||
if err == nil { |
|
||||||
pending = pending[1:] |
|
||||||
writing = false |
|
||||||
} else { |
|
||||||
self.err <- err // report error
|
|
||||||
} |
|
||||||
case errc := <-self.closingOut: |
|
||||||
errc <- true |
|
||||||
close(self.out) |
|
||||||
return |
|
||||||
} |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func pack(payload []byte) (packet []byte) { |
|
||||||
length := ethutil.NumberToBytes(uint32(len(payload)), 32) |
|
||||||
// return error if too long?
|
|
||||||
// Write magic token and payload length (first 8 bytes)
|
|
||||||
packet = append(magicToken, length...) |
|
||||||
packet = append(packet, payload...) |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func avoidPanic(done chan *PeerError) { |
|
||||||
if rec := recover(); rec != nil { |
|
||||||
err := NewPeerError(MiscError, " %v", rec) |
|
||||||
logger.Debugln(err) |
|
||||||
done <- err |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) write(payload []byte, done chan *PeerError) { |
|
||||||
defer avoidPanic(done) |
|
||||||
var err *PeerError |
|
||||||
_, ok := self.conn.Write(pack(payload)) |
|
||||||
if ok != nil { |
|
||||||
err = NewPeerError(WriteError, " %v", ok) |
|
||||||
logger.Debugln(err) |
|
||||||
} |
|
||||||
done <- err |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) read(payloads chan []byte, done chan *PeerError) { |
|
||||||
//defer avoidPanic(done)
|
|
||||||
|
|
||||||
partials := make(chan []byte, partialsQueueSize) |
|
||||||
errc := make(chan *PeerError) |
|
||||||
go self.readPartials(partials, errc) |
|
||||||
|
|
||||||
packet := []byte{} |
|
||||||
length := 8 |
|
||||||
start := true |
|
||||||
var err *PeerError |
|
||||||
out: |
|
||||||
for { |
|
||||||
// appends partials read via connection until packet is
|
|
||||||
// - either parseable (>=8bytes)
|
|
||||||
// - or complete (payload fully consumed)
|
|
||||||
for len(packet) < length { |
|
||||||
partial, ok := <-partials |
|
||||||
if !ok { // partials channel is closed
|
|
||||||
err = <-errc |
|
||||||
if err == nil && len(packet) > 0 { |
|
||||||
if start { |
|
||||||
err = NewPeerError(PacketTooShort, "%v", packet) |
|
||||||
} else { |
|
||||||
err = NewPeerError(PayloadTooShort, "%d < %d", len(packet), length) |
|
||||||
} |
|
||||||
} |
|
||||||
break out |
|
||||||
} |
|
||||||
packet = append(packet, partial...) |
|
||||||
} |
|
||||||
if start { |
|
||||||
// at least 8 bytes read, can validate packet
|
|
||||||
if bytes.Compare(magicToken, packet[:4]) != 0 { |
|
||||||
err = NewPeerError(MagicTokenMismatch, " received %v", packet[:4]) |
|
||||||
break |
|
||||||
} |
|
||||||
length = int(ethutil.BytesToNumber(packet[4:8])) |
|
||||||
packet = packet[8:] |
|
||||||
|
|
||||||
if length > 0 { |
|
||||||
start = false // now consuming payload
|
|
||||||
} else { //penalize peer but read on
|
|
||||||
self.err <- NewPeerError(EmptyPayload, "") |
|
||||||
length = 8 |
|
||||||
} |
|
||||||
} else { |
|
||||||
// packet complete (payload fully consumed)
|
|
||||||
payloads <- packet[:length] |
|
||||||
packet = packet[length:] // resclice packet
|
|
||||||
start = true |
|
||||||
length = 8 |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
// this stops partials read via the connection, should we?
|
|
||||||
//if err != nil {
|
|
||||||
// select {
|
|
||||||
// case errc <- err
|
|
||||||
// default:
|
|
||||||
//}
|
|
||||||
done <- err |
|
||||||
} |
|
||||||
|
|
||||||
func (self *Connection) readPartials(partials chan []byte, errc chan *PeerError) { |
|
||||||
defer close(partials) |
|
||||||
for { |
|
||||||
// Give buffering some time
|
|
||||||
self.conn.SetReadDeadline(time.Now().Add(self.timeout * time.Millisecond)) |
|
||||||
buffer := make([]byte, readBufferLength) |
|
||||||
// read partial from connection
|
|
||||||
bytesRead, err := self.conn.Read(buffer) |
|
||||||
if err == nil || err.Error() == "EOF" { |
|
||||||
if bytesRead > 0 { |
|
||||||
partials <- buffer[:bytesRead] |
|
||||||
} |
|
||||||
if err != nil && err.Error() == "EOF" { |
|
||||||
break |
|
||||||
} |
|
||||||
} else { |
|
||||||
// unexpected error, report to errc
|
|
||||||
err := NewPeerError(ReadError, " %v", err) |
|
||||||
logger.Debugln(err) |
|
||||||
errc <- err |
|
||||||
return // will close partials channel
|
|
||||||
} |
|
||||||
} |
|
||||||
close(errc) |
|
||||||
} |
|
@ -1,222 +0,0 @@ |
|||||||
package p2p |
|
||||||
|
|
||||||
import ( |
|
||||||
"bytes" |
|
||||||
"fmt" |
|
||||||
"io" |
|
||||||
"net" |
|
||||||
"testing" |
|
||||||
"time" |
|
||||||
) |
|
||||||
|
|
||||||
type TestNetworkConnection struct { |
|
||||||
in chan []byte |
|
||||||
current []byte |
|
||||||
Out [][]byte |
|
||||||
addr net.Addr |
|
||||||
} |
|
||||||
|
|
||||||
func NewTestNetworkConnection(addr net.Addr) *TestNetworkConnection { |
|
||||||
return &TestNetworkConnection{ |
|
||||||
in: make(chan []byte), |
|
||||||
current: []byte{}, |
|
||||||
Out: [][]byte{}, |
|
||||||
addr: addr, |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) In(latency time.Duration, packets ...[]byte) { |
|
||||||
time.Sleep(latency) |
|
||||||
for _, s := range packets { |
|
||||||
self.in <- s |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) Read(buff []byte) (n int, err error) { |
|
||||||
if len(self.current) == 0 { |
|
||||||
select { |
|
||||||
case self.current = <-self.in: |
|
||||||
default: |
|
||||||
return 0, io.EOF |
|
||||||
} |
|
||||||
} |
|
||||||
length := len(self.current) |
|
||||||
if length > len(buff) { |
|
||||||
copy(buff[:], self.current[:len(buff)]) |
|
||||||
self.current = self.current[len(buff):] |
|
||||||
return len(buff), nil |
|
||||||
} else { |
|
||||||
copy(buff[:length], self.current[:]) |
|
||||||
self.current = []byte{} |
|
||||||
return length, io.EOF |
|
||||||
} |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) Write(buff []byte) (n int, err error) { |
|
||||||
self.Out = append(self.Out, buff) |
|
||||||
fmt.Printf("net write %v\n%v\n", len(self.Out), buff) |
|
||||||
return len(buff), nil |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) Close() (err error) { |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) LocalAddr() (addr net.Addr) { |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) RemoteAddr() (addr net.Addr) { |
|
||||||
return self.addr |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) SetDeadline(t time.Time) (err error) { |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) SetReadDeadline(t time.Time) (err error) { |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func (self *TestNetworkConnection) SetWriteDeadline(t time.Time) (err error) { |
|
||||||
return |
|
||||||
} |
|
||||||
|
|
||||||
func setupConnection() (*Connection, *TestNetworkConnection) { |
|
||||||
addr := &TestAddr{"test:30303"} |
|
||||||
net := NewTestNetworkConnection(addr) |
|
||||||
conn := NewConnection(net, NewPeerErrorChannel()) |
|
||||||
conn.Open() |
|
||||||
return conn, net |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingNilPacket(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{}) |
|
||||||
// time.Sleep(10 * time.Millisecond)
|
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
t.Errorf("read %v", packet) |
|
||||||
case err := <-conn.Error(): |
|
||||||
t.Errorf("incorrect error %v", err) |
|
||||||
default: |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingShortPacket(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{0}) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
t.Errorf("read %v", packet) |
|
||||||
case err := <-conn.Error(): |
|
||||||
if err.Code != PacketTooShort { |
|
||||||
t.Errorf("incorrect error %v, expected %v", err.Code, PacketTooShort) |
|
||||||
} |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingInvalidPacket(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{1, 0, 0, 0, 0, 0, 0, 0}) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
t.Errorf("read %v", packet) |
|
||||||
case err := <-conn.Error(): |
|
||||||
if err.Code != MagicTokenMismatch { |
|
||||||
t.Errorf("incorrect error %v, expected %v", err.Code, MagicTokenMismatch) |
|
||||||
} |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingInvalidPayload(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{34, 64, 8, 145, 0, 0, 0, 2, 0}) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
t.Errorf("read %v", packet) |
|
||||||
case err := <-conn.Error(): |
|
||||||
if err.Code != PayloadTooShort { |
|
||||||
t.Errorf("incorrect error %v, expected %v", err.Code, PayloadTooShort) |
|
||||||
} |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingEmptyPayload(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{34, 64, 8, 145, 0, 0, 0, 0}) |
|
||||||
time.Sleep(10 * time.Millisecond) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
t.Errorf("read %v", packet) |
|
||||||
default: |
|
||||||
} |
|
||||||
select { |
|
||||||
case err := <-conn.Error(): |
|
||||||
code := err.Code |
|
||||||
if code != EmptyPayload { |
|
||||||
t.Errorf("incorrect error, expected EmptyPayload, got %v", code) |
|
||||||
} |
|
||||||
default: |
|
||||||
t.Errorf("no error, expected EmptyPayload") |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingCompletePacket(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{34, 64, 8, 145, 0, 0, 0, 1, 1}) |
|
||||||
time.Sleep(10 * time.Millisecond) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
if bytes.Compare(packet, []byte{1}) != 0 { |
|
||||||
t.Errorf("incorrect payload read") |
|
||||||
} |
|
||||||
case err := <-conn.Error(): |
|
||||||
t.Errorf("incorrect error %v", err) |
|
||||||
default: |
|
||||||
t.Errorf("nothing read") |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestReadingTwoCompletePackets(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
go net.In(0, []byte{34, 64, 8, 145, 0, 0, 0, 1, 0, 34, 64, 8, 145, 0, 0, 0, 1, 1}) |
|
||||||
|
|
||||||
for i := 0; i < 2; i++ { |
|
||||||
time.Sleep(10 * time.Millisecond) |
|
||||||
select { |
|
||||||
case packet := <-conn.Read(): |
|
||||||
if bytes.Compare(packet, []byte{byte(i)}) != 0 { |
|
||||||
t.Errorf("incorrect payload read") |
|
||||||
} |
|
||||||
case err := <-conn.Error(): |
|
||||||
t.Errorf("incorrect error %v", err) |
|
||||||
default: |
|
||||||
t.Errorf("nothing read") |
|
||||||
} |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
func TestWriting(t *testing.T) { |
|
||||||
conn, net := setupConnection() |
|
||||||
conn.Write() <- []byte{0} |
|
||||||
time.Sleep(10 * time.Millisecond) |
|
||||||
if len(net.Out) == 0 { |
|
||||||
t.Errorf("no output") |
|
||||||
} else { |
|
||||||
out := net.Out[0] |
|
||||||
if bytes.Compare(out, []byte{34, 64, 8, 145, 0, 0, 0, 1, 0}) != 0 { |
|
||||||
t.Errorf("incorrect packet %v", out) |
|
||||||
} |
|
||||||
} |
|
||||||
conn.Close() |
|
||||||
} |
|
||||||
|
|
||||||
// hello packet with client id ABC: 0x22 40 08 91 00 00 00 08 84 00 00 00 43414243
|
|
@ -1,75 +1,174 @@ |
|||||||
package p2p |
package p2p |
||||||
|
|
||||||
import ( |
import ( |
||||||
// "fmt"
|
"bytes" |
||||||
|
"encoding/binary" |
||||||
|
"fmt" |
||||||
|
"io" |
||||||
|
"io/ioutil" |
||||||
|
"math/big" |
||||||
|
|
||||||
"github.com/ethereum/go-ethereum/ethutil" |
"github.com/ethereum/go-ethereum/ethutil" |
||||||
) |
) |
||||||
|
|
||||||
type MsgCode uint8 |
type MsgCode uint64 |
||||||
|
|
||||||
|
// Msg defines the structure of a p2p message.
|
||||||
|
//
|
||||||
|
// Note that a Msg can only be sent once since the Payload reader is
|
||||||
|
// consumed during sending. It is not possible to create a Msg and
|
||||||
|
// send it any number of times. If you want to reuse an encoded
|
||||||
|
// structure, encode the payload into a byte array and create a
|
||||||
|
// separate Msg with a bytes.Reader as Payload for each send.
|
||||||
type Msg struct { |
type Msg struct { |
||||||
code MsgCode // this is the raw code as per adaptive msg code scheme
|
Code MsgCode |
||||||
data *ethutil.Value |
Size uint32 // size of the paylod
|
||||||
encoded []byte |
Payload io.Reader |
||||||
} |
} |
||||||
|
|
||||||
func (self *Msg) Code() MsgCode { |
// NewMsg creates an RLP-encoded message with the given code.
|
||||||
return self.code |
func NewMsg(code MsgCode, params ...interface{}) Msg { |
||||||
|
buf := new(bytes.Buffer) |
||||||
|
for _, p := range params { |
||||||
|
buf.Write(ethutil.Encode(p)) |
||||||
|
} |
||||||
|
return Msg{Code: code, Size: uint32(buf.Len()), Payload: buf} |
||||||
} |
} |
||||||
|
|
||||||
func (self *Msg) Data() *ethutil.Value { |
func encodePayload(params ...interface{}) []byte { |
||||||
return self.data |
buf := new(bytes.Buffer) |
||||||
|
for _, p := range params { |
||||||
|
buf.Write(ethutil.Encode(p)) |
||||||
|
} |
||||||
|
return buf.Bytes() |
||||||
} |
} |
||||||
|
|
||||||
func NewMsg(code MsgCode, params ...interface{}) (msg *Msg, err error) { |
// Data returns the decoded RLP payload items in a message.
|
||||||
|
func (msg Msg) Data() (*ethutil.Value, error) { |
||||||
// // data := [][]interface{}{}
|
// TODO: avoid copying when we have a better RLP decoder
|
||||||
// data := []interface{}{}
|
buf := new(bytes.Buffer) |
||||||
// for _, value := range params {
|
var s []interface{} |
||||||
// if encodable, ok := value.(ethutil.RlpEncodeDecode); ok {
|
if _, err := buf.ReadFrom(msg.Payload); err != nil { |
||||||
// data = append(data, encodable.RlpValue())
|
return nil, err |
||||||
// } else if raw, ok := value.([]interface{}); ok {
|
} |
||||||
// data = append(data, raw)
|
for buf.Len() > 0 { |
||||||
// } else {
|
s = append(s, ethutil.DecodeWithReader(buf)) |
||||||
// // data = append(data, interface{}(raw))
|
} |
||||||
// err = fmt.Errorf("Unable to encode object of type %T", value)
|
return ethutil.NewValue(s), nil |
||||||
// return
|
} |
||||||
// }
|
|
||||||
// }
|
// Discard reads any remaining payload data into a black hole.
|
||||||
return &Msg{ |
func (msg Msg) Discard() error { |
||||||
code: code, |
_, err := io.Copy(ioutil.Discard, msg.Payload) |
||||||
data: ethutil.NewValue(interface{}(params)), |
return err |
||||||
}, nil |
} |
||||||
|
|
||||||
|
var magicToken = []byte{34, 64, 8, 145} |
||||||
|
|
||||||
|
func writeMsg(w io.Writer, msg Msg) error { |
||||||
|
// TODO: handle case when Size + len(code) + len(listhdr) overflows uint32
|
||||||
|
code := ethutil.Encode(uint32(msg.Code)) |
||||||
|
listhdr := makeListHeader(msg.Size + uint32(len(code))) |
||||||
|
payloadLen := uint32(len(listhdr)) + uint32(len(code)) + msg.Size |
||||||
|
|
||||||
|
start := make([]byte, 8) |
||||||
|
copy(start, magicToken) |
||||||
|
binary.BigEndian.PutUint32(start[4:], payloadLen) |
||||||
|
|
||||||
|
for _, b := range [][]byte{start, listhdr, code} { |
||||||
|
if _, err := w.Write(b); err != nil { |
||||||
|
return err |
||||||
|
} |
||||||
|
} |
||||||
|
_, err := io.CopyN(w, msg.Payload, int64(msg.Size)) |
||||||
|
return err |
||||||
} |
} |
||||||
|
|
||||||
func NewMsgFromBytes(encoded []byte) (msg *Msg, err error) { |
func makeListHeader(length uint32) []byte { |
||||||
value := ethutil.NewValueFromBytes(encoded) |
if length < 56 { |
||||||
// Type of message
|
return []byte{byte(length + 0xc0)} |
||||||
code := value.Get(0).Uint() |
|
||||||
// Actual data
|
|
||||||
data := value.SliceFrom(1) |
|
||||||
|
|
||||||
msg = &Msg{ |
|
||||||
code: MsgCode(code), |
|
||||||
data: data, |
|
||||||
// data: ethutil.NewValue(data),
|
|
||||||
encoded: encoded, |
|
||||||
} |
} |
||||||
return |
enc := big.NewInt(int64(length)).Bytes() |
||||||
|
lenb := byte(len(enc)) + 0xf7 |
||||||
|
return append([]byte{lenb}, enc...) |
||||||
} |
} |
||||||
|
|
||||||
func (self *Msg) Decode(offset MsgCode) { |
type byteReader interface { |
||||||
self.code = self.code - offset |
io.Reader |
||||||
|
io.ByteReader |
||||||
} |
} |
||||||
|
|
||||||
// encode takes an offset argument to implement adaptive message coding
|
// readMsg reads a message header.
|
||||||
// the encoded message is memoized to make msgs relayed to several peers more efficient
|
func readMsg(r byteReader) (msg Msg, err error) { |
||||||
func (self *Msg) Encode(offset MsgCode) (res []byte) { |
// read magic and payload size
|
||||||
if len(self.encoded) == 0 { |
start := make([]byte, 8) |
||||||
res = ethutil.NewValue(append([]interface{}{byte(self.code + offset)}, self.data.Slice()...)).Encode() |
if _, err = io.ReadFull(r, start); err != nil { |
||||||
self.encoded = res |
return msg, NewPeerError(ReadError, "%v", err) |
||||||
|
} |
||||||
|
if !bytes.HasPrefix(start, magicToken) { |
||||||
|
return msg, NewPeerError(MagicTokenMismatch, "got %x, want %x", start[:4], magicToken) |
||||||
|
} |
||||||
|
size := binary.BigEndian.Uint32(start[4:]) |
||||||
|
|
||||||
|
// decode start of RLP message to get the message code
|
||||||
|
_, hdrlen, err := readListHeader(r) |
||||||
|
if err != nil { |
||||||
|
return msg, err |
||||||
|
} |
||||||
|
code, codelen, err := readMsgCode(r) |
||||||
|
if err != nil { |
||||||
|
return msg, err |
||||||
|
} |
||||||
|
|
||||||
|
rlpsize := size - hdrlen - codelen |
||||||
|
return Msg{ |
||||||
|
Code: code, |
||||||
|
Size: rlpsize, |
||||||
|
Payload: io.LimitReader(r, int64(rlpsize)), |
||||||
|
}, nil |
||||||
|
} |
||||||
|
|
||||||
|
// readListHeader reads an RLP list header from r.
|
||||||
|
func readListHeader(r byteReader) (len uint64, hdrlen uint32, err error) { |
||||||
|
b, err := r.ReadByte() |
||||||
|
if err != nil { |
||||||
|
return 0, 0, err |
||||||
|
} |
||||||
|
if b < 0xC0 { |
||||||
|
return 0, 0, fmt.Errorf("expected list start byte >= 0xC0, got %x", b) |
||||||
|
} else if b < 0xF7 { |
||||||
|
len = uint64(b - 0xc0) |
||||||
|
hdrlen = 1 |
||||||
} else { |
} else { |
||||||
res = self.encoded |
lenlen := b - 0xF7 |
||||||
|
lenbuf := make([]byte, 8) |
||||||
|
if _, err := io.ReadFull(r, lenbuf[8-lenlen:]); err != nil { |
||||||
|
return 0, 0, err |
||||||
|
} |
||||||
|
len = binary.BigEndian.Uint64(lenbuf) |
||||||
|
hdrlen = 1 + uint32(lenlen) |
||||||
|
} |
||||||
|
return len, hdrlen, nil |
||||||
|
} |
||||||
|
|
||||||
|
// readUint reads an RLP-encoded unsigned integer from r.
|
||||||
|
func readMsgCode(r byteReader) (code MsgCode, codelen uint32, err error) { |
||||||
|
b, err := r.ReadByte() |
||||||
|
if err != nil { |
||||||
|
return 0, 0, err |
||||||
|
} |
||||||
|
if b < 0x80 { |
||||||
|
return MsgCode(b), 1, nil |
||||||
|
} else if b < 0x89 { // max length for uint64 is 8 bytes
|
||||||
|
codelen = uint32(b - 0x80) |
||||||
|
if codelen == 0 { |
||||||
|
return 0, 1, nil |
||||||
|
} |
||||||
|
buf := make([]byte, 8) |
||||||
|
if _, err := io.ReadFull(r, buf[8-codelen:]); err != nil { |
||||||
|
return 0, 0, err |
||||||
|
} |
||||||
|
return MsgCode(binary.BigEndian.Uint64(buf)), codelen, nil |
||||||
} |
} |
||||||
return |
return 0, 0, fmt.Errorf("bad RLP type for message code: %x", b) |
||||||
} |
} |
||||||
|
@ -1,38 +1,67 @@ |
|||||||
package p2p |
package p2p |
||||||
|
|
||||||
import ( |
import ( |
||||||
|
"bytes" |
||||||
|
"io/ioutil" |
||||||
"testing" |
"testing" |
||||||
|
|
||||||
|
"github.com/ethereum/go-ethereum/ethutil" |
||||||
) |
) |
||||||
|
|
||||||
func TestNewMsg(t *testing.T) { |
func TestNewMsg(t *testing.T) { |
||||||
msg, _ := NewMsg(3, 1, "000") |
msg := NewMsg(3, 1, "000") |
||||||
if msg.Code() != 3 { |
if msg.Code != 3 { |
||||||
t.Errorf("incorrect code %v", msg.Code()) |
t.Errorf("incorrect code %d, want %d", msg.Code) |
||||||
} |
} |
||||||
data0 := msg.Data().Get(0).Uint() |
if msg.Size != 5 { |
||||||
data1 := string(msg.Data().Get(1).Bytes()) |
t.Errorf("incorrect size %d, want %d", msg.Size, 5) |
||||||
if data0 != 1 { |
|
||||||
t.Errorf("incorrect data %v", data0) |
|
||||||
} |
} |
||||||
if data1 != "000" { |
pl, _ := ioutil.ReadAll(msg.Payload) |
||||||
t.Errorf("incorrect data %v", data1) |
expect := []byte{0x01, 0x83, 0x30, 0x30, 0x30} |
||||||
|
if !bytes.Equal(pl, expect) { |
||||||
|
t.Errorf("incorrect payload content, got %x, want %x", pl, expect) |
||||||
} |
} |
||||||
} |
} |
||||||
|
|
||||||
func TestEncodeDecodeMsg(t *testing.T) { |
func TestEncodeDecodeMsg(t *testing.T) { |
||||||
msg, _ := NewMsg(3, 1, "000") |
msg := NewMsg(3, 1, "000") |
||||||
encoded := msg.Encode(3) |
buf := new(bytes.Buffer) |
||||||
msg, _ = NewMsgFromBytes(encoded) |
if err := writeMsg(buf, msg); err != nil { |
||||||
msg.Decode(3) |
t.Fatalf("encodeMsg error: %v", err) |
||||||
if msg.Code() != 3 { |
} |
||||||
t.Errorf("incorrect code %v", msg.Code()) |
|
||||||
} |
t.Logf("encoded: %x", buf.Bytes()) |
||||||
data0 := msg.Data().Get(0).Uint() |
|
||||||
data1 := msg.Data().Get(1).Str() |
decmsg, err := readMsg(buf) |
||||||
if data0 != 1 { |
if err != nil { |
||||||
t.Errorf("incorrect data %v", data0) |
t.Fatalf("readMsg error: %v", err) |
||||||
} |
} |
||||||
if data1 != "000" { |
if decmsg.Code != 3 { |
||||||
t.Errorf("incorrect data %v", data1) |
t.Errorf("incorrect code %d, want %d", decmsg.Code, 3) |
||||||
|
} |
||||||
|
if decmsg.Size != 5 { |
||||||
|
t.Errorf("incorrect size %d, want %d", decmsg.Size, 5) |
||||||
|
} |
||||||
|
data, err := decmsg.Data() |
||||||
|
if err != nil { |
||||||
|
t.Fatalf("first payload item decode error: %v", err) |
||||||
|
} |
||||||
|
if v := data.Get(0).Uint(); v != 1 { |
||||||
|
t.Errorf("incorrect data[0]: got %v, expected %d", v, 1) |
||||||
|
} |
||||||
|
if v := data.Get(1).Str(); v != "000" { |
||||||
|
t.Errorf("incorrect data[1]: got %q, expected %q", v, "000") |
||||||
|
} |
||||||
|
} |
||||||
|
|
||||||
|
func TestDecodeRealMsg(t *testing.T) { |
||||||
|
data := ethutil.Hex2Bytes("2240089100000080f87e8002b5457468657265756d282b2b292f5065657220536572766572204f6e652f76302e372e382f52656c656173652f4c696e75782f672b2bc082765fb84086dd80b7aefd6a6d2e3b93f4f300a86bfb6ef7bdc97cb03f793db6bb") |
||||||
|
msg, err := readMsg(bytes.NewReader(data)) |
||||||
|
if err != nil { |
||||||
|
t.Fatalf("unexpected error: %v", err) |
||||||
|
} |
||||||
|
|
||||||
|
if msg.Code != 0 { |
||||||
|
t.Errorf("incorrect code %d, want %d", msg.Code, 0) |
||||||
} |
} |
||||||
} |
} |
||||||
|
@ -1,220 +1,221 @@ |
|||||||
package p2p |
package p2p |
||||||
|
|
||||||
import ( |
import ( |
||||||
|
"bufio" |
||||||
|
"bytes" |
||||||
"fmt" |
"fmt" |
||||||
|
"io" |
||||||
|
"io/ioutil" |
||||||
|
"net" |
||||||
"sync" |
"sync" |
||||||
"time" |
"time" |
||||||
) |
) |
||||||
|
|
||||||
const ( |
type Handlers map[string]func() Protocol |
||||||
handlerTimeout = 1000 |
|
||||||
) |
|
||||||
|
|
||||||
type Handlers map[string](func(p *Peer) Protocol) |
type proto struct { |
||||||
|
in chan Msg |
||||||
type Messenger struct { |
maxcode, offset MsgCode |
||||||
conn *Connection |
messenger *messenger |
||||||
peer *Peer |
|
||||||
handlers Handlers |
|
||||||
protocolLock sync.RWMutex |
|
||||||
protocols []Protocol |
|
||||||
offsets []MsgCode // offsets for adaptive message idss
|
|
||||||
protocolTable map[string]int |
|
||||||
quit chan chan bool |
|
||||||
err chan *PeerError |
|
||||||
pulse chan bool |
|
||||||
} |
|
||||||
|
|
||||||
func NewMessenger(peer *Peer, conn *Connection, errchan chan *PeerError, handlers Handlers) *Messenger { |
|
||||||
baseProtocol := NewBaseProtocol(peer) |
|
||||||
return &Messenger{ |
|
||||||
conn: conn, |
|
||||||
peer: peer, |
|
||||||
offsets: []MsgCode{baseProtocol.Offset()}, |
|
||||||
handlers: handlers, |
|
||||||
protocols: []Protocol{baseProtocol}, |
|
||||||
protocolTable: make(map[string]int), |
|
||||||
err: errchan, |
|
||||||
pulse: make(chan bool, 1), |
|
||||||
quit: make(chan chan bool, 1), |
|
||||||
} |
|
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) Start() { |
func (rw *proto) WriteMsg(msg Msg) error { |
||||||
self.conn.Open() |
if msg.Code >= rw.maxcode { |
||||||
go self.messenger() |
return NewPeerError(InvalidMsgCode, "not handled") |
||||||
self.protocolLock.RLock() |
} |
||||||
defer self.protocolLock.RUnlock() |
return rw.messenger.writeMsg(msg) |
||||||
self.protocols[0].Start() |
|
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) Stop() { |
func (rw *proto) ReadMsg() (Msg, error) { |
||||||
// close pulse to stop ping pong monitoring
|
msg, ok := <-rw.in |
||||||
close(self.pulse) |
if !ok { |
||||||
self.protocolLock.RLock() |
return msg, io.EOF |
||||||
defer self.protocolLock.RUnlock() |
|
||||||
for _, protocol := range self.protocols { |
|
||||||
protocol.Stop() // could be parallel
|
|
||||||
} |
} |
||||||
q := make(chan bool) |
return msg, nil |
||||||
self.quit <- q |
|
||||||
<-q |
|
||||||
self.conn.Close() |
|
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) messenger() { |
// eofSignal is used to 'lend' the network connection
|
||||||
in := self.conn.Read() |
// to a protocol. when the protocol's read loop has read the
|
||||||
for { |
// whole payload, the done channel is closed.
|
||||||
select { |
type eofSignal struct { |
||||||
case payload, ok := <-in: |
wrapped io.Reader |
||||||
//dispatches message to the protocol asynchronously
|
eof chan struct{} |
||||||
if ok { |
|
||||||
go self.handle(payload) |
|
||||||
} else { |
|
||||||
return |
|
||||||
} |
|
||||||
case q := <-self.quit: |
|
||||||
q <- true |
|
||||||
return |
|
||||||
} |
|
||||||
} |
|
||||||
} |
} |
||||||
|
|
||||||
// handles each message by dispatching to the appropriate protocol
|
func (r *eofSignal) Read(buf []byte) (int, error) { |
||||||
// using adaptive message codes
|
n, err := r.wrapped.Read(buf) |
||||||
// this function is started as a separate go routine for each message
|
|
||||||
// it waits for the protocol response
|
|
||||||
// then encodes and sends outgoing messages to the connection's write channel
|
|
||||||
func (self *Messenger) handle(payload []byte) { |
|
||||||
// send ping to heartbeat channel signalling time of last message
|
|
||||||
// select {
|
|
||||||
// case self.pulse <- true:
|
|
||||||
// default:
|
|
||||||
// }
|
|
||||||
self.pulse <- true |
|
||||||
// initialise message from payload
|
|
||||||
msg, err := NewMsgFromBytes(payload) |
|
||||||
if err != nil { |
if err != nil { |
||||||
self.err <- NewPeerError(MiscError, " %v", err) |
close(r.eof) // tell messenger that msg has been consumed
|
||||||
return |
|
||||||
} |
} |
||||||
// retrieves protocol based on message Code
|
return n, err |
||||||
protocol, offset, peerErr := self.getProtocol(msg.Code()) |
} |
||||||
if err != nil { |
|
||||||
self.err <- peerErr |
// messenger represents a message-oriented peer connection.
|
||||||
return |
// It keeps track of the set of protocols understood
|
||||||
|
// by the remote peer.
|
||||||
|
type messenger struct { |
||||||
|
peer *Peer |
||||||
|
handlers Handlers |
||||||
|
|
||||||
|
// the mutex protects the connection
|
||||||
|
// so only one protocol can write at a time.
|
||||||
|
writeMu sync.Mutex |
||||||
|
conn net.Conn |
||||||
|
bufconn *bufio.ReadWriter |
||||||
|
|
||||||
|
protocolLock sync.RWMutex |
||||||
|
protocols map[string]*proto |
||||||
|
offsets map[MsgCode]*proto |
||||||
|
protoWG sync.WaitGroup |
||||||
|
|
||||||
|
err chan error |
||||||
|
pulse chan bool |
||||||
|
} |
||||||
|
|
||||||
|
func newMessenger(peer *Peer, conn net.Conn, errchan chan error, handlers Handlers) *messenger { |
||||||
|
return &messenger{ |
||||||
|
conn: conn, |
||||||
|
bufconn: bufio.NewReadWriter(bufio.NewReader(conn), bufio.NewWriter(conn)), |
||||||
|
peer: peer, |
||||||
|
handlers: handlers, |
||||||
|
protocols: make(map[string]*proto), |
||||||
|
err: errchan, |
||||||
|
pulse: make(chan bool, 1), |
||||||
} |
} |
||||||
// reset message code based on adaptive offset
|
} |
||||||
msg.Decode(offset) |
|
||||||
// dispatches
|
func (m *messenger) Start() { |
||||||
response := make(chan *Msg) |
m.protocols[""] = m.startProto(0, "", &baseProtocol{}) |
||||||
go protocol.HandleIn(msg, response) |
go m.readLoop() |
||||||
// protocol reponse timeout to prevent leaks
|
} |
||||||
timer := time.After(handlerTimeout * time.Millisecond) |
|
||||||
|
func (m *messenger) Stop() { |
||||||
|
m.conn.Close() |
||||||
|
m.protoWG.Wait() |
||||||
|
} |
||||||
|
|
||||||
|
const ( |
||||||
|
// maximum amount of time allowed for reading a message
|
||||||
|
msgReadTimeout = 5 * time.Second |
||||||
|
|
||||||
|
// messages smaller than this many bytes will be read at
|
||||||
|
// once before passing them to a protocol.
|
||||||
|
wholePayloadSize = 64 * 1024 |
||||||
|
) |
||||||
|
|
||||||
|
func (m *messenger) readLoop() { |
||||||
|
defer m.closeProtocols() |
||||||
for { |
for { |
||||||
select { |
m.conn.SetReadDeadline(time.Now().Add(msgReadTimeout)) |
||||||
case outgoing, ok := <-response: |
msg, err := readMsg(m.bufconn) |
||||||
// we check if response channel is not closed
|
if err != nil { |
||||||
if ok { |
m.err <- err |
||||||
self.conn.Write() <- outgoing.Encode(offset) |
return |
||||||
} else { |
} |
||||||
|
// send ping to heartbeat channel signalling time of last message
|
||||||
|
m.pulse <- true |
||||||
|
proto, err := m.getProto(msg.Code) |
||||||
|
if err != nil { |
||||||
|
m.err <- err |
||||||
|
return |
||||||
|
} |
||||||
|
msg.Code -= proto.offset |
||||||
|
if msg.Size <= wholePayloadSize { |
||||||
|
// optimization: msg is small enough, read all
|
||||||
|
// of it and move on to the next message
|
||||||
|
buf, err := ioutil.ReadAll(msg.Payload) |
||||||
|
if err != nil { |
||||||
|
m.err <- err |
||||||
return |
return |
||||||
} |
} |
||||||
case <-timer: |
msg.Payload = bytes.NewReader(buf) |
||||||
return |
proto.in <- msg |
||||||
|
} else { |
||||||
|
pr := &eofSignal{msg.Payload, make(chan struct{})} |
||||||
|
msg.Payload = pr |
||||||
|
proto.in <- msg |
||||||
|
<-pr.eof |
||||||
} |
} |
||||||
} |
} |
||||||
} |
} |
||||||
|
|
||||||
// negotiated protocols
|
func (m *messenger) closeProtocols() { |
||||||
// stores offsets needed for adaptive message id scheme
|
m.protocolLock.RLock() |
||||||
|
for _, p := range m.protocols { |
||||||
// based on offsets set at handshake
|
close(p.in) |
||||||
// get the right protocol to handle the message
|
|
||||||
func (self *Messenger) getProtocol(code MsgCode) (Protocol, MsgCode, *PeerError) { |
|
||||||
self.protocolLock.RLock() |
|
||||||
defer self.protocolLock.RUnlock() |
|
||||||
base := MsgCode(0) |
|
||||||
for index, offset := range self.offsets { |
|
||||||
if code < offset { |
|
||||||
return self.protocols[index], base, nil |
|
||||||
} |
|
||||||
base = offset |
|
||||||
} |
} |
||||||
return nil, MsgCode(0), NewPeerError(InvalidMsgCode, " %v", code) |
m.protocolLock.RUnlock() |
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) PingPong(timeout time.Duration, gracePeriod time.Duration, pingCallback func(), timeoutCallback func()) { |
func (m *messenger) startProto(offset MsgCode, name string, impl Protocol) *proto { |
||||||
fmt.Printf("pingpong keepalive started at %v", time.Now()) |
proto := &proto{ |
||||||
|
in: make(chan Msg), |
||||||
|
offset: offset, |
||||||
|
maxcode: impl.Offset(), |
||||||
|
messenger: m, |
||||||
|
} |
||||||
|
m.protoWG.Add(1) |
||||||
|
go func() { |
||||||
|
if err := impl.Start(m.peer, proto); err != nil && err != io.EOF { |
||||||
|
logger.Errorf("protocol %q error: %v\n", name, err) |
||||||
|
m.err <- err |
||||||
|
} |
||||||
|
m.protoWG.Done() |
||||||
|
}() |
||||||
|
return proto |
||||||
|
} |
||||||
|
|
||||||
timer := time.After(timeout) |
// getProto finds the protocol responsible for handling
|
||||||
pinged := false |
// the given message code.
|
||||||
for { |
func (m *messenger) getProto(code MsgCode) (*proto, error) { |
||||||
select { |
m.protocolLock.RLock() |
||||||
case _, ok := <-self.pulse: |
defer m.protocolLock.RUnlock() |
||||||
if ok { |
for _, proto := range m.protocols { |
||||||
pinged = false |
if code >= proto.offset && code < proto.offset+proto.maxcode { |
||||||
timer = time.After(timeout) |
return proto, nil |
||||||
} else { |
|
||||||
// pulse is closed, stop monitoring
|
|
||||||
return |
|
||||||
} |
|
||||||
case <-timer: |
|
||||||
if pinged { |
|
||||||
fmt.Printf("timeout at %v", time.Now()) |
|
||||||
timeoutCallback() |
|
||||||
return |
|
||||||
} else { |
|
||||||
fmt.Printf("pinged at %v", time.Now()) |
|
||||||
pingCallback() |
|
||||||
timer = time.After(gracePeriod) |
|
||||||
pinged = true |
|
||||||
} |
|
||||||
} |
} |
||||||
} |
} |
||||||
|
return nil, NewPeerError(InvalidMsgCode, "%d", code) |
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) AddProtocols(protocols []string) { |
// setProtocols starts all subprotocols shared with the
|
||||||
self.protocolLock.Lock() |
// remote peer. the protocols must be sorted alphabetically.
|
||||||
defer self.protocolLock.Unlock() |
func (m *messenger) setRemoteProtocols(protocols []string) { |
||||||
i := len(self.offsets) |
m.protocolLock.Lock() |
||||||
offset := self.offsets[i-1] |
defer m.protocolLock.Unlock() |
||||||
|
offset := baseProtocolOffset |
||||||
for _, name := range protocols { |
for _, name := range protocols { |
||||||
protocolFunc, ok := self.handlers[name] |
protocolFunc, ok := m.handlers[name] |
||||||
if ok { |
if !ok { |
||||||
protocol := protocolFunc(self.peer) |
continue // not handled
|
||||||
self.protocolTable[name] = i |
|
||||||
i++ |
|
||||||
offset += protocol.Offset() |
|
||||||
fmt.Println("offset ", name, offset) |
|
||||||
|
|
||||||
self.offsets = append(self.offsets, offset) |
|
||||||
self.protocols = append(self.protocols, protocol) |
|
||||||
protocol.Start() |
|
||||||
} else { |
|
||||||
fmt.Println("no ", name) |
|
||||||
// protocol not handled
|
|
||||||
} |
} |
||||||
|
inst := protocolFunc() |
||||||
|
m.protocols[name] = m.startProto(offset, name, inst) |
||||||
|
offset += inst.Offset() |
||||||
} |
} |
||||||
} |
} |
||||||
|
|
||||||
func (self *Messenger) Write(protocol string, msg *Msg) error { |
// writeProtoMsg sends the given message on behalf of the given named protocol.
|
||||||
self.protocolLock.RLock() |
func (m *messenger) writeProtoMsg(protoName string, msg Msg) error { |
||||||
defer self.protocolLock.RUnlock() |
m.protocolLock.RLock() |
||||||
i := 0 |
proto, ok := m.protocols[protoName] |
||||||
offset := MsgCode(0) |
m.protocolLock.RUnlock() |
||||||
if len(protocol) > 0 { |
if !ok { |
||||||
var ok bool |
return fmt.Errorf("protocol %s not handled by peer", protoName) |
||||||
i, ok = self.protocolTable[protocol] |
|
||||||
if !ok { |
|
||||||
return fmt.Errorf("protocol %v not handled by peer", protocol) |
|
||||||
} |
|
||||||
offset = self.offsets[i-1] |
|
||||||
} |
} |
||||||
handler := self.protocols[i] |
if msg.Code >= proto.maxcode { |
||||||
// checking if protocol status/caps allows the message to be sent out
|
return NewPeerError(InvalidMsgCode, "code %x is out of range for protocol %q", msg.Code, protoName) |
||||||
if handler.HandleOut(msg) { |
} |
||||||
self.conn.Write() <- msg.Encode(offset) |
msg.Code += proto.offset |
||||||
|
return m.writeMsg(msg) |
||||||
|
} |
||||||
|
|
||||||
|
// writeMsg writes a message to the connection.
|
||||||
|
func (m *messenger) writeMsg(msg Msg) error { |
||||||
|
m.writeMu.Lock() |
||||||
|
defer m.writeMu.Unlock() |
||||||
|
if err := writeMsg(m.bufconn, msg); err != nil { |
||||||
|
return err |
||||||
} |
} |
||||||
return nil |
return m.bufconn.Flush() |
||||||
} |
} |
||||||
|
@ -1,147 +1,157 @@ |
|||||||
package p2p |
package p2p |
||||||
|
|
||||||
import ( |
import ( |
||||||
// "fmt"
|
"bufio" |
||||||
"bytes" |
"fmt" |
||||||
|
"io" |
||||||
|
"log" |
||||||
|
"net" |
||||||
|
"os" |
||||||
|
"reflect" |
||||||
"testing" |
"testing" |
||||||
"time" |
"time" |
||||||
|
|
||||||
"github.com/ethereum/go-ethereum/ethutil" |
"github.com/ethereum/go-ethereum/ethutil" |
||||||
) |
) |
||||||
|
|
||||||
func setupMessenger(handlers Handlers) (*TestNetworkConnection, chan *PeerError, *Messenger) { |
func init() { |
||||||
errchan := NewPeerErrorChannel() |
ethlog.AddLogSystem(ethlog.NewStdLogSystem(os.Stdout, log.LstdFlags, ethlog.DebugLevel)) |
||||||
addr := &TestAddr{"test:30303"} |
|
||||||
net := NewTestNetworkConnection(addr) |
|
||||||
conn := NewConnection(net, errchan) |
|
||||||
mess := NewMessenger(nil, conn, errchan, handlers) |
|
||||||
mess.Start() |
|
||||||
return net, errchan, mess |
|
||||||
} |
} |
||||||
|
|
||||||
type TestProtocol struct { |
func setupMessenger(handlers Handlers) (net.Conn, *Peer, *messenger) { |
||||||
Msgs []*Msg |
conn1, conn2 := net.Pipe() |
||||||
|
id := NewSimpleClientIdentity("test", "0", "0", "public key") |
||||||
|
server := New(nil, conn1.LocalAddr(), id, handlers, 10, NewBlacklist()) |
||||||
|
peer := server.addPeer(conn1, conn1.RemoteAddr(), true, 0) |
||||||
|
return conn2, peer, peer.messenger |
||||||
} |
} |
||||||
|
|
||||||
func (self *TestProtocol) Start() { |
func performTestHandshake(r *bufio.Reader, w io.Writer) error { |
||||||
} |
// read remote handshake
|
||||||
|
msg, err := readMsg(r) |
||||||
func (self *TestProtocol) Stop() { |
if err != nil { |
||||||
} |
return fmt.Errorf("read error: %v", err) |
||||||
|
} |
||||||
func (self *TestProtocol) Offset() MsgCode { |
if msg.Code != handshakeMsg { |
||||||
return MsgCode(5) |
return fmt.Errorf("first message should be handshake, got %x", msg.Code) |
||||||
|
} |
||||||
|
if err := msg.Discard(); err != nil { |
||||||
|
return err |
||||||
|
} |
||||||
|
// send empty handshake
|
||||||
|
pubkey := make([]byte, 64) |
||||||
|
msg = NewMsg(handshakeMsg, p2pVersion, "testid", nil, 9999, pubkey) |
||||||
|
return writeMsg(w, msg) |
||||||
} |
} |
||||||
|
|
||||||
func (self *TestProtocol) HandleIn(msg *Msg, response chan *Msg) { |
type testMsg struct { |
||||||
self.Msgs = append(self.Msgs, msg) |
code MsgCode |
||||||
close(response) |
data *ethutil.Value |
||||||
} |
} |
||||||
|
|
||||||
func (self *TestProtocol) HandleOut(msg *Msg) bool { |
type testProto struct { |
||||||
if msg.Code() > 3 { |
recv chan testMsg |
||||||
return false |
|
||||||
} else { |
|
||||||
return true |
|
||||||
} |
|
||||||
} |
} |
||||||
|
|
||||||
func (self *TestProtocol) Name() string { |
func (*testProto) Offset() MsgCode { return 5 } |
||||||
return "a" |
|
||||||
} |
|
||||||
|
|
||||||
func Packet(offset MsgCode, code MsgCode, params ...interface{}) []byte { |
func (tp *testProto) Start(peer *Peer, rw MsgReadWriter) error { |
||||||
msg, _ := NewMsg(code, params...) |
return MsgLoop(rw, 1024, func(code MsgCode, data *ethutil.Value) error { |
||||||
encoded := msg.Encode(offset) |
logger.Debugf("testprotocol got msg: %d\n", code) |
||||||
packet := []byte{34, 64, 8, 145} |
tp.recv <- testMsg{code, data} |
||||||
packet = append(packet, ethutil.NumberToBytes(uint32(len(encoded)), 32)...) |
return nil |
||||||
return append(packet, encoded...) |
}) |
||||||
} |
} |
||||||
|
|
||||||
func TestRead(t *testing.T) { |
func TestRead(t *testing.T) { |
||||||
handlers := make(Handlers) |
testProtocol := &testProto{make(chan testMsg)} |
||||||
testProtocol := &TestProtocol{Msgs: []*Msg{}} |
handlers := Handlers{"a": func() Protocol { return testProtocol }} |
||||||
handlers["a"] = func(p *Peer) Protocol { return testProtocol } |
net, peer, mess := setupMessenger(handlers) |
||||||
net, _, mess := setupMessenger(handlers) |
bufr := bufio.NewReader(net) |
||||||
mess.AddProtocols([]string{"a"}) |
defer peer.Stop() |
||||||
defer mess.Stop() |
if err := performTestHandshake(bufr, net); err != nil { |
||||||
wait := 1 * time.Millisecond |
t.Fatalf("handshake failed: %v", err) |
||||||
packet := Packet(16, 1, uint32(1), "000") |
} |
||||||
go net.In(0, packet) |
|
||||||
time.Sleep(wait) |
mess.setRemoteProtocols([]string{"a"}) |
||||||
if len(testProtocol.Msgs) != 1 { |
writeMsg(net, NewMsg(17, uint32(1), "000")) |
||||||
t.Errorf("msg not relayed to correct protocol") |
select { |
||||||
} else { |
case msg := <-testProtocol.recv: |
||||||
if testProtocol.Msgs[0].Code() != 1 { |
if msg.code != 1 { |
||||||
t.Errorf("incorrect msg code relayed to protocol") |
t.Errorf("incorrect msg code %d relayed to protocol", msg.code) |
||||||
|
} |
||||||
|
expdata := []interface{}{1, []byte{0x30, 0x30, 0x30}} |
||||||
|
if !reflect.DeepEqual(msg.data.Slice(), expdata) { |
||||||
|
t.Errorf("incorrect msg data %#v", msg.data.Slice()) |
||||||
} |
} |
||||||
|
case <-time.After(2 * time.Second): |
||||||
|
t.Errorf("receive timeout") |
||||||
} |
} |
||||||
} |
} |
||||||
|
|
||||||
func TestWrite(t *testing.T) { |
func TestWriteProtoMsg(t *testing.T) { |
||||||
handlers := make(Handlers) |
handlers := make(Handlers) |
||||||
testProtocol := &TestProtocol{Msgs: []*Msg{}} |
testProtocol := &testProto{recv: make(chan testMsg, 1)} |
||||||
handlers["a"] = func(p *Peer) Protocol { return testProtocol } |
handlers["a"] = func() Protocol { return testProtocol } |
||||||
net, _, mess := setupMessenger(handlers) |
net, peer, mess := setupMessenger(handlers) |
||||||
mess.AddProtocols([]string{"a"}) |
defer peer.Stop() |
||||||
defer mess.Stop() |
bufr := bufio.NewReader(net) |
||||||
wait := 1 * time.Millisecond |
if err := performTestHandshake(bufr, net); err != nil { |
||||||
msg, _ := NewMsg(3, uint32(1), "000") |
t.Fatalf("handshake failed: %v", err) |
||||||
err := mess.Write("b", msg) |
|
||||||
if err == nil { |
|
||||||
t.Errorf("expect error for unknown protocol") |
|
||||||
} |
} |
||||||
err = mess.Write("a", msg) |
mess.setRemoteProtocols([]string{"a"}) |
||||||
if err != nil { |
|
||||||
t.Errorf("expect no error for known protocol: %v", err) |
// test write errors
|
||||||
} else { |
if err := mess.writeProtoMsg("b", NewMsg(3)); err == nil { |
||||||
time.Sleep(wait) |
t.Errorf("expected error for unknown protocol, got nil") |
||||||
if len(net.Out) != 1 { |
} |
||||||
t.Errorf("msg not written") |
if err := mess.writeProtoMsg("a", NewMsg(8)); err == nil { |
||||||
|
t.Errorf("expected error for out-of-range msg code, got nil") |
||||||
|
} else if perr, ok := err.(*PeerError); !ok || perr.Code != InvalidMsgCode { |
||||||
|
t.Errorf("wrong error for out-of-range msg code, got %#v") |
||||||
|
} |
||||||
|
|
||||||
|
// test succcessful write
|
||||||
|
read, readerr := make(chan Msg), make(chan error) |
||||||
|
go func() { |
||||||
|
if msg, err := readMsg(bufr); err != nil { |
||||||
|
readerr <- err |
||||||
} else { |
} else { |
||||||
out := net.Out[0] |
read <- msg |
||||||
packet := Packet(16, 3, uint32(1), "000") |
} |
||||||
if bytes.Compare(out, packet) != 0 { |
}() |
||||||
t.Errorf("incorrect packet %v", out) |
if err := mess.writeProtoMsg("a", NewMsg(3)); err != nil { |
||||||
} |
t.Errorf("expect no error for known protocol: %v", err) |
||||||
|
} |
||||||
|
select { |
||||||
|
case msg := <-read: |
||||||
|
if msg.Code != 19 { |
||||||
|
t.Errorf("wrong code, got %d, expected %d", msg.Code, 19) |
||||||
} |
} |
||||||
|
msg.Discard() |
||||||
|
case err := <-readerr: |
||||||
|
t.Errorf("read error: %v", err) |
||||||
} |
} |
||||||
} |
} |
||||||
|
|
||||||
func TestPulse(t *testing.T) { |
func TestPulse(t *testing.T) { |
||||||
net, _, mess := setupMessenger(make(Handlers)) |
net, peer, _ := setupMessenger(nil) |
||||||
defer mess.Stop() |
defer peer.Stop() |
||||||
ping := false |
bufr := bufio.NewReader(net) |
||||||
timeout := false |
if err := performTestHandshake(bufr, net); err != nil { |
||||||
pingTimeout := 10 * time.Millisecond |
t.Fatalf("handshake failed: %v", err) |
||||||
gracePeriod := 200 * time.Millisecond |
|
||||||
go mess.PingPong(pingTimeout, gracePeriod, func() { ping = true }, func() { timeout = true }) |
|
||||||
net.In(0, Packet(0, 1)) |
|
||||||
if ping { |
|
||||||
t.Errorf("ping sent too early") |
|
||||||
} |
|
||||||
time.Sleep(pingTimeout + 100*time.Millisecond) |
|
||||||
if !ping { |
|
||||||
t.Errorf("no ping sent after timeout") |
|
||||||
} |
|
||||||
if timeout { |
|
||||||
t.Errorf("timeout too early") |
|
||||||
} |
} |
||||||
ping = false |
|
||||||
net.In(0, Packet(0, 1)) |
before := time.Now() |
||||||
time.Sleep(pingTimeout + 100*time.Millisecond) |
msg, err := readMsg(bufr) |
||||||
if !ping { |
if err != nil { |
||||||
t.Errorf("no ping sent after timeout") |
t.Fatalf("read error: %v", err) |
||||||
} |
|
||||||
if timeout { |
|
||||||
t.Errorf("timeout too early") |
|
||||||
} |
} |
||||||
ping = false |
after := time.Now() |
||||||
time.Sleep(gracePeriod) |
if msg.Code != pingMsg { |
||||||
if ping { |
t.Errorf("expected ping message, got %x", msg.Code) |
||||||
t.Errorf("ping called twice") |
|
||||||
} |
} |
||||||
if !timeout { |
if d := after.Sub(before); d < pingTimeout { |
||||||
t.Errorf("no timeout after grace period") |
t.Errorf("ping sent too early after %v, expected at least %v", d, pingTimeout) |
||||||
} |
} |
||||||
} |
} |
||||||
|
@ -1,96 +1,90 @@ |
|||||||
package p2p |
package p2p |
||||||
|
|
||||||
import ( |
// "net"
|
||||||
"bytes" |
|
||||||
"fmt" |
|
||||||
// "net"
|
|
||||||
"testing" |
|
||||||
"time" |
|
||||||
) |
|
||||||
|
|
||||||
func TestPeer(t *testing.T) { |
// func TestPeer(t *testing.T) {
|
||||||
handlers := make(Handlers) |
// handlers := make(Handlers)
|
||||||
testProtocol := &TestProtocol{Msgs: []*Msg{}} |
// testProtocol := &TestProtocol{recv: make(chan testMsg)}
|
||||||
handlers["aaa"] = func(p *Peer) Protocol { return testProtocol } |
// handlers["aaa"] = func(p *Peer) Protocol { return testProtocol }
|
||||||
handlers["ccc"] = func(p *Peer) Protocol { return testProtocol } |
// handlers["ccc"] = func(p *Peer) Protocol { return testProtocol }
|
||||||
addr := &TestAddr{"test:30"} |
// addr := &TestAddr{"test:30"}
|
||||||
conn := NewTestNetworkConnection(addr) |
// conn := NewTestNetworkConnection(addr)
|
||||||
_, server := SetupTestServer(handlers) |
// _, server := SetupTestServer(handlers)
|
||||||
server.Handshake() |
// server.Handshake()
|
||||||
peer := NewPeer(conn, addr, true, server) |
// peer := NewPeer(conn, addr, true, server)
|
||||||
// peer.Messenger().AddProtocols([]string{"aaa", "ccc"})
|
// // peer.Messenger().AddProtocols([]string{"aaa", "ccc"})
|
||||||
peer.Start() |
// peer.Start()
|
||||||
defer peer.Stop() |
// defer peer.Stop()
|
||||||
time.Sleep(2 * time.Millisecond) |
// time.Sleep(2 * time.Millisecond)
|
||||||
if len(conn.Out) != 1 { |
// if len(conn.Out) != 1 {
|
||||||
t.Errorf("handshake not sent") |
// t.Errorf("handshake not sent")
|
||||||
} else { |
// } else {
|
||||||
out := conn.Out[0] |
// out := conn.Out[0]
|
||||||
packet := Packet(0, HandshakeMsg, P2PVersion, []byte(peer.server.identity.String()), []interface{}{peer.server.protocols}, peer.server.port, peer.server.identity.Pubkey()[1:]) |
// packet := Packet(0, HandshakeMsg, P2PVersion, []byte(peer.server.identity.String()), []interface{}{peer.server.protocols}, peer.server.port, peer.server.identity.Pubkey()[1:])
|
||||||
if bytes.Compare(out, packet) != 0 { |
// if bytes.Compare(out, packet) != 0 {
|
||||||
t.Errorf("incorrect handshake packet %v != %v", out, packet) |
// t.Errorf("incorrect handshake packet %v != %v", out, packet)
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
|
|
||||||
packet := Packet(0, HandshakeMsg, P2PVersion, []byte("peer"), []interface{}{"bbb", "aaa", "ccc"}, 30, []byte("0000000000000000000000000000000000000000000000000000000000000000")) |
// packet := Packet(0, HandshakeMsg, P2PVersion, []byte("peer"), []interface{}{"bbb", "aaa", "ccc"}, 30, []byte("0000000000000000000000000000000000000000000000000000000000000000"))
|
||||||
conn.In(0, packet) |
// conn.In(0, packet)
|
||||||
time.Sleep(10 * time.Millisecond) |
// time.Sleep(10 * time.Millisecond)
|
||||||
|
|
||||||
pro, _ := peer.Messenger().protocols[0].(*BaseProtocol) |
// pro, _ := peer.Messenger().protocols[0].(*BaseProtocol)
|
||||||
if pro.state != handshakeReceived { |
// if pro.state != handshakeReceived {
|
||||||
t.Errorf("handshake not received") |
// t.Errorf("handshake not received")
|
||||||
} |
// }
|
||||||
if peer.Port != 30 { |
// if peer.Port != 30 {
|
||||||
t.Errorf("port incorrectly set") |
// t.Errorf("port incorrectly set")
|
||||||
} |
// }
|
||||||
if peer.Id != "peer" { |
// if peer.Id != "peer" {
|
||||||
t.Errorf("id incorrectly set") |
// t.Errorf("id incorrectly set")
|
||||||
} |
// }
|
||||||
if string(peer.Pubkey) != "0000000000000000000000000000000000000000000000000000000000000000" { |
// if string(peer.Pubkey) != "0000000000000000000000000000000000000000000000000000000000000000" {
|
||||||
t.Errorf("pubkey incorrectly set") |
// t.Errorf("pubkey incorrectly set")
|
||||||
} |
// }
|
||||||
fmt.Println(peer.Caps) |
// fmt.Println(peer.Caps)
|
||||||
if len(peer.Caps) != 3 || peer.Caps[0] != "aaa" || peer.Caps[1] != "bbb" || peer.Caps[2] != "ccc" { |
// if len(peer.Caps) != 3 || peer.Caps[0] != "aaa" || peer.Caps[1] != "bbb" || peer.Caps[2] != "ccc" {
|
||||||
t.Errorf("protocols incorrectly set") |
// t.Errorf("protocols incorrectly set")
|
||||||
} |
// }
|
||||||
|
|
||||||
msg, _ := NewMsg(3) |
// msg := NewMsg(3)
|
||||||
err := peer.Write("aaa", msg) |
// err := peer.Write("aaa", msg)
|
||||||
if err != nil { |
// if err != nil {
|
||||||
t.Errorf("expect no error for known protocol: %v", err) |
// t.Errorf("expect no error for known protocol: %v", err)
|
||||||
} else { |
// } else {
|
||||||
time.Sleep(1 * time.Millisecond) |
// time.Sleep(1 * time.Millisecond)
|
||||||
if len(conn.Out) != 2 { |
// if len(conn.Out) != 2 {
|
||||||
t.Errorf("msg not written") |
// t.Errorf("msg not written")
|
||||||
} else { |
// } else {
|
||||||
out := conn.Out[1] |
// out := conn.Out[1]
|
||||||
packet := Packet(16, 3) |
// packet := Packet(16, 3)
|
||||||
if bytes.Compare(out, packet) != 0 { |
// if bytes.Compare(out, packet) != 0 {
|
||||||
t.Errorf("incorrect packet %v != %v", out, packet) |
// t.Errorf("incorrect packet %v != %v", out, packet)
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
|
|
||||||
msg, _ = NewMsg(2) |
// msg = NewMsg(2)
|
||||||
err = peer.Write("ccc", msg) |
// err = peer.Write("ccc", msg)
|
||||||
if err != nil { |
// if err != nil {
|
||||||
t.Errorf("expect no error for known protocol: %v", err) |
// t.Errorf("expect no error for known protocol: %v", err)
|
||||||
} else { |
// } else {
|
||||||
time.Sleep(1 * time.Millisecond) |
// time.Sleep(1 * time.Millisecond)
|
||||||
if len(conn.Out) != 3 { |
// if len(conn.Out) != 3 {
|
||||||
t.Errorf("msg not written") |
// t.Errorf("msg not written")
|
||||||
} else { |
// } else {
|
||||||
out := conn.Out[2] |
// out := conn.Out[2]
|
||||||
packet := Packet(21, 2) |
// packet := Packet(21, 2)
|
||||||
if bytes.Compare(out, packet) != 0 { |
// if bytes.Compare(out, packet) != 0 {
|
||||||
t.Errorf("incorrect packet %v != %v", out, packet) |
// t.Errorf("incorrect packet %v != %v", out, packet)
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
|
|
||||||
err = peer.Write("bbb", msg) |
// err = peer.Write("bbb", msg)
|
||||||
time.Sleep(1 * time.Millisecond) |
// time.Sleep(1 * time.Millisecond)
|
||||||
if err == nil { |
// if err == nil {
|
||||||
t.Errorf("expect error for unknown protocol") |
// t.Errorf("expect error for unknown protocol")
|
||||||
} |
// }
|
||||||
} |
// }
|
||||||
|
Loading…
Reference in new issue