broadcast shares in serial
[p2pool.git] / p2pool / p2p.py
index f562b9c..871a2d9 100644 (file)
@@ -1,42 +1,38 @@
 from __future__ import division
 
+import math
 import random
 import time
 
-from twisted.internet import defer, error, protocol, reactor
+from twisted.internet import defer, protocol, reactor
 from twisted.python import log
 
 import p2pool
 from p2pool import data as p2pool_data
-from p2pool.bitcoin import p2p as bitcoin_p2p
 from p2pool.bitcoin import data as bitcoin_data
-from p2pool.util import deferral, pack
+from p2pool.util import deferral, p2protocol, pack
 
-class Protocol(bitcoin_p2p.BaseProtocol):
-    version = 2
-    sub_version = p2pool.__version__
-    
+class PeerMisbehavingError(Exception):
+    pass
+
+class Protocol(p2protocol.Protocol):
     def __init__(self, node, incoming):
+        p2protocol.Protocol.__init__(self, node.net.PREFIX, 1000000)
         self.node = node
         self.incoming = incoming
         
-        self._prefix = self.node.net.PREFIX
-    
-    max_payload_length = 1000000
-    use_checksum = True
-    
-    other_version = None
-    connected2 = False
+        self.other_version = None
+        self.connected2 = False
     
     def connectionMade(self):
-        bitcoin_p2p.BaseProtocol.connectionMade(self)
+        p2protocol.Protocol.connectionMade(self)
         
         self.factory.proto_made_connection(self)
         
         self.addr = self.transport.getPeer().host, self.transport.getPeer().port
         
         self.send_version(
-            version=self.version,
+            version=4,
             services=0,
             addr_to=dict(
                 services=0,
@@ -49,47 +45,39 @@ class Protocol(bitcoin_p2p.BaseProtocol):
                 port=self.transport.getHost().port,
             ),
             nonce=self.node.nonce,
-            sub_version=self.sub_version,
+            sub_version=p2pool.__version__,
             mode=1,
             best_share_hash=self.node.best_share_hash_func(),
         )
         
-        reactor.callLater(10, self._connect_timeout)
-        self.timeout_delayed = reactor.callLater(100, self._timeout)
+        self.timeout_delayed = reactor.callLater(10, self._connect_timeout)
     
     def _connect_timeout(self):
-        if not self.connected2 and self.transport.connected:
-            print 'Handshake timed out, disconnecting from %s:%i' % self.addr
-            self.transport.loseConnection()
+        self.timeout_delayed = None
+        print 'Handshake timed out, disconnecting from %s:%i' % self.addr
+        self.transport.loseConnection()
     
     def packetReceived(self, command, payload2):
-        if command != 'version' and not self.connected2:
-            self.transport.loseConnection()
+        try:
+            if command != 'version' and not self.connected2:
+                raise PeerMisbehavingError('first message was not version message')
+            p2protocol.Protocol.packetReceived(self, command, payload2)
+        except PeerMisbehavingError, e:
             return
-        
-        if not self.timeout_delayed.called:
-            self.timeout_delayed.cancel()
-            self.timeout_delayed = reactor.callLater(100, self._timeout)
-        
-        bitcoin_p2p.BaseProtocol.packetReceived(self, command, payload2)
+            print 'Peer %s:%i misbehaving, will drop and ban. Reason:' % self.addr, e.message
+            self.badPeerHappened()
     
-    def _timeout(self):
-        if self.transport.connected:
-            print 'Connection timed out, disconnecting from %s:%i' % self.addr
-            self.transport.loseConnection()
-    
-    @defer.inlineCallbacks
-    def _think(self):
-        while self.connected2:
-            self.send_ping()
-            yield deferral.sleep(random.expovariate(1/100))
+    def badPeerHappened(self):
+        return
+        if p2pool.DEBUG:
+            print "Bad peer banned:", self.addr
+        self.transport.loseConnection()
+        self.node.bans[self.transport.getPeer().host] = time.time() + 60*60
     
-    @defer.inlineCallbacks
-    def _think2(self):
-        while self.connected2:
-            self.send_addrme(port=self.node.port)
-            #print 'sending addrme'
-            yield deferral.sleep(random.expovariate(1/(100*len(self.node.peers) + 1)))
+    def _timeout(self):
+        self.timeout_delayed = None
+        print 'Connection timed out, disconnecting from %s:%i' % self.addr
+        self.transport.loseConnection()
     
     message_version = pack.ComposedType([
         ('version', pack.IntType(32)),
@@ -102,29 +90,45 @@ class Protocol(bitcoin_p2p.BaseProtocol):
         ('best_share_hash', pack.PossiblyNoneType(0, pack.IntType(256))),
     ])
     def handle_version(self, version, services, addr_to, addr_from, nonce, sub_version, mode, best_share_hash):
-        if self.other_version is not None or version < 2:
-            self.transport.loseConnection()
-            return
+        if self.other_version is not None:
+            raise PeerMisbehavingError('more than one version message')
+        if version < 4:
+            raise PeerMisbehavingError('peer too old')
         
         self.other_version = version
         self.other_sub_version = sub_version[:512]
         self.other_services = services
         
         if nonce == self.node.nonce:
-            #print 'Detected connection to self, disconnecting from %s:%i' % self.addr
-            self.transport.loseConnection()
-            return
+            raise PeerMisbehavingError('was connected to self')
         if nonce in self.node.peers:
-            #print 'Detected duplicate connection, disconnecting from %s:%i' % self.addr
+            if p2pool.DEBUG:
+                print 'Detected duplicate connection, disconnecting from %s:%i' % self.addr
             self.transport.loseConnection()
             return
         
         self.nonce = nonce
         self.connected2 = True
+        
+        self.timeout_delayed.cancel()
+        self.timeout_delayed = reactor.callLater(100, self._timeout)
+        
+        old_dataReceived = self.dataReceived
+        def new_dataReceived(data):
+            if self.timeout_delayed is not None:
+                self.timeout_delayed.reset(100)
+            old_dataReceived(data)
+        self.dataReceived = new_dataReceived
+        
         self.factory.proto_connected(self)
         
-        self._think()
-        self._think2()
+        self._stop_thread = deferral.run_repeatedly(lambda: [
+            self.send_ping(),
+        random.expovariate(1/100)][-1])
+        
+        self._stop_thread2 = deferral.run_repeatedly(lambda: [
+            self.send_addrme(port=self.node.port),
+        random.expovariate(1/(100*len(self.node.peers) + 1))][-1])
         
         if best_share_hash is not None:
             self.node.handle_share_hashes([best_share_hash], self)
@@ -176,7 +180,7 @@ class Protocol(bitcoin_p2p.BaseProtocol):
             count = 100
         self.send_addrs(addrs=[
             dict(
-                timestamp=self.node.addr_store[host, port][2],
+                timestamp=int(self.node.addr_store[host, port][2]),
                 address=dict(
                     services=self.node.addr_store[host, port][0],
                     address=host,
@@ -192,81 +196,117 @@ class Protocol(bitcoin_p2p.BaseProtocol):
         ('stops', pack.ListType(pack.IntType(256))),
     ])
     def handle_getshares(self, hashes, parents, stops):
-        self.node.handle_get_shares(hashes, parents, stops, self)
+        self.sendShares(self.node.handle_get_shares(hashes, parents, stops, self))
     
     message_shares = pack.ComposedType([
         ('shares', pack.ListType(p2pool_data.share_type)),
     ])
     def handle_shares(self, shares):
-        res = []
-        for share in shares:
-            share_obj = p2pool_data.Share.from_share(share, self.node.net)
-            share_obj.peer = self
-            res.append(share_obj)
-        self.node.handle_shares(res, self)
-    
-    def sendShares(self, shares, full=False):
+        self.node.handle_shares([p2pool_data.load_share(share, self.node.net, self) for share in shares if share['type'] not in [6, 7]], self)
+    
+    def sendShares(self, shares):
         def att(f, **kwargs):
             try:
-                f(**kwargs)
-            except bitcoin_p2p.TooLong:
+                return f(**kwargs)
+            except p2protocol.TooLong:
                 att(f, **dict((k, v[:len(v)//2]) for k, v in kwargs.iteritems()))
-                att(f, **dict((k, v[len(v)//2:]) for k, v in kwargs.iteritems()))
+                return att(f, **dict((k, v[len(v)//2:]) for k, v in kwargs.iteritems()))
         if shares:
-            att(self.send_shares, shares=[share.as_share() for share in shares])
+            return att(self.send_shares, shares=[share.as_share() for share in shares])
+        else:
+            return defer.succeed(None)
+    
+    
+    message_sharereq = pack.ComposedType([
+        ('id', pack.IntType(256)),
+        ('hashes', pack.ListType(pack.IntType(256))),
+        ('parents', pack.VarIntType()),
+        ('stops', pack.ListType(pack.IntType(256))),
+    ])
+    def handle_sharereq(self, id, hashes, parents, stops):
+        shares = self.node.handle_get_shares(hashes, parents, stops, self)
+        try:
+            self.send_sharereply(id=id, result='good', shares=[share.as_share() for share in shares])
+        except p2protocol.TooLong:
+            self.send_sharereply(id=id, result='too long', shares=[])
+    
+    message_sharereply = pack.ComposedType([
+        ('id', pack.IntType(256)),
+        ('result', pack.EnumType(pack.VarIntType(), {0: 'good', 1: 'too long', 2: 'unk2', 3: 'unk3', 4: 'unk4', 5: 'unk5', 6: 'unk6'})),
+        ('shares', pack.ListType(p2pool_data.share_type)),
+    ])
+    def handle_sharereply(self, id, result, shares):
+        self.node.handle_share_reply(id, result, shares, self)
+    
+    message_bestblock = pack.ComposedType([
+        ('header', bitcoin_data.block_header_type),
+    ])
+    def handle_bestblock(self, header):
+        self.node.handle_bestblock(header, self)
     
     def connectionLost(self, reason):
+        if self.timeout_delayed is not None:
+            self.timeout_delayed.cancel()
         if self.connected2:
-            self.factory.proto_disconnected(self)
+            self.factory.proto_disconnected(self, reason)
+            self._stop_thread()
+            self._stop_thread2()
             self.connected2 = False
-        self.factory.proto_lost_connection(self)
+        self.factory.proto_lost_connection(self, reason)
+        if p2pool.DEBUG:
+            print "Peer connection lost:", self.addr, reason
 
 class ServerFactory(protocol.ServerFactory):
     def __init__(self, node, max_conns):
         self.node = node
         self.max_conns = max_conns
         
-        self.conns = set()
+        self.conns = {}
         self.running = False
     
     def buildProtocol(self, addr):
-        if len(self.conns) >= self.max_conns:
+        if sum(self.conns.itervalues()) >= self.max_conns or self.conns.get(self._host_to_ident(addr.host), 0) >= 3:
+            return None
+        if addr.host in self.node.bans and self.node.bans[addr.host] > time.time():
             return None
         p = Protocol(self.node, True)
         p.factory = self
+        if p2pool.DEBUG:
+            print "Got peer connection from:", addr
         return p
     
+    def _host_to_ident(self, host):
+        a, b, c, d = host.split('.')
+        return a, b
+    
     def proto_made_connection(self, proto):
-        self.conns.add(proto)
-    def proto_lost_connection(self, proto):
-        self.conns.remove(proto)
+        ident = self._host_to_ident(proto.transport.getPeer().host)
+        self.conns[ident] = self.conns.get(ident, 0) + 1
+    def proto_lost_connection(self, proto, reason):
+        ident = self._host_to_ident(proto.transport.getPeer().host)
+        self.conns[ident] -= 1
+        if not self.conns[ident]:
+            del self.conns[ident]
     
     def proto_connected(self, proto):
         self.node.got_conn(proto)
-    def proto_disconnected(self, proto):
-        self.node.lost_conn(proto)
+    def proto_disconnected(self, proto, reason):
+        self.node.lost_conn(proto, reason)
     
     def start(self):
         assert not self.running
         self.running = True
         
         def attempt_listen():
-            if not self.running:
-                return
-            try:
+            if self.running:
                 self.listen_port = reactor.listenTCP(self.node.port, self)
-            except error.CannotListenError, e:
-                if e.socketError.errno != 98:
-                    raise
-                print 'P2P port busy, retrying listening in 3 seconds.'
-                reactor.callLater(3, attempt_listen)
-        attempt_listen()
+        deferral.retry('Error binding to P2P port:', traceback=False)(attempt_listen)()
     
     def stop(self):
         assert self.running
         self.running = False
         
-        self.listen_port.stopListening()
+        return self.listen_port.stopListening()
 
 class ClientFactory(protocol.ClientFactory):
     def __init__(self, node, desired_conns, max_attempts):
@@ -274,66 +314,68 @@ class ClientFactory(protocol.ClientFactory):
         self.desired_conns = desired_conns
         self.max_attempts = max_attempts
         
-        self.attempts = {}
+        self.attempts = set()
         self.conns = set()
         self.running = False
     
+    def _host_to_ident(self, host):
+        a, b, c, d = host.split('.')
+        return a, b
+    
     def buildProtocol(self, addr):
         p = Protocol(self.node, False)
         p.factory = self
         return p
     
     def startedConnecting(self, connector):
-        host, port = connector.getDestination().host, connector.getDestination().port
-        if (host, port) in self.attempts:
-            raise ValueError('already have attempt')
-        self.attempts[host, port] = connector
+        ident = self._host_to_ident(connector.getDestination().host)
+        if ident in self.attempts:
+            raise AssertionError('already have attempt')
+        self.attempts.add(ident)
     
     def clientConnectionFailed(self, connector, reason):
-        self.clientConnectionLost(connector, reason)
+        self.attempts.remove(self._host_to_ident(connector.getDestination().host))
     
     def clientConnectionLost(self, connector, reason):
-        host, port = connector.getDestination().host, connector.getDestination().port
-        if (host, port) not in self.attempts:
-            raise ValueError('''don't have attempt''')
-        if connector is not self.attempts[host, port]:
-            raise ValueError('wrong connector')
-        del self.attempts[host, port]
+        self.attempts.remove(self._host_to_ident(connector.getDestination().host))
     
     def proto_made_connection(self, proto):
         pass
-    def proto_lost_connection(self, proto):
+    def proto_lost_connection(self, proto, reason):
         pass
     
     def proto_connected(self, proto):
         self.conns.add(proto)
         self.node.got_conn(proto)
-    def proto_disconnected(self, proto):
+    def proto_disconnected(self, proto, reason):
         self.conns.remove(proto)
-        self.node.lost_conn(proto)
+        self.node.lost_conn(proto, reason)
     
     def start(self):
         assert not self.running
         self.running = True
-        self._think()
+        self._stop_thinking = deferral.run_repeatedly(self._think)
     def stop(self):
         assert self.running
         self.running = False
+        self._stop_thinking()
     
-    @defer.inlineCallbacks
     def _think(self):
-        while self.running:
-            try:
-                if len(self.conns) < self.desired_conns and len(self.attempts) < self.max_attempts and self.node.addr_store:
-                    (host, port), = self.node.get_good_peers(1)
-                    
-                    if (host, port) not in self.attempts:
-                        #print 'Trying to connect to', host, port
-                        reactor.connectTCP(host, port, self, timeout=5)
-            except:
-                log.err()
-            
-            yield deferral.sleep(random.expovariate(1/1))
+        try:
+            if len(self.conns) < self.desired_conns and len(self.attempts) < self.max_attempts and self.node.addr_store:
+                (host, port), = self.node.get_good_peers(1)
+                
+                if self._host_to_ident(host) in self.attempts:
+                    pass
+                elif host in self.node.bans and self.node.bans[host] > time.time():
+                    pass
+                else:
+                    #print 'Trying to connect to', host, port
+                    reactor.connectTCP(host, port, self, timeout=5)
+        except:
+            log.err()
+        
+        return random.expovariate(1/1)
 
 class SingleClientFactory(protocol.ReconnectingClientFactory):
     def __init__(self, node):
@@ -346,14 +388,14 @@ class SingleClientFactory(protocol.ReconnectingClientFactory):
     
     def proto_made_connection(self, proto):
         pass
-    def proto_lost_connection(self, proto):
+    def proto_lost_connection(self, proto, reason):
         pass
     
     def proto_connected(self, proto):
         self.resetDelay()
         self.node.got_conn(proto)
-    def proto_disconnected(self, proto):
-        self.node.lost_conn(proto)
+    def proto_disconnected(self, proto, reason):
+        self.node.lost_conn(proto, reason)
 
 class Node(object):
     def __init__(self, best_share_hash_func, port, net, addr_store={}, connect_addrs=set(), desired_outgoing_conns=10, max_outgoing_attempts=30, max_incoming_conns=50, preferred_storage=1000):
@@ -366,6 +408,7 @@ class Node(object):
         
         self.nonce = random.randrange(2**64)
         self.peers = {}
+        self.bans = {} # address -> end_time
         self.clientfactory = ClientFactory(self, desired_outgoing_conns, max_outgoing_attempts)
         self.serverfactory = ServerFactory(self, max_incoming_conns)
         self.running = False
@@ -380,29 +423,30 @@ class Node(object):
         
         self.running = True
         
-        self._think2()
+        self._stop_thinking = deferral.run_repeatedly(self._think)
     
-    @defer.inlineCallbacks
-    def _think2(self):
-        while self.running:
-            try:
-                if len(self.addr_store) < self.preferred_storage and self.peers:
-                    random.choice(self.peers.values()).send_getaddrs(count=8)
-            except:
-                log.err()
-            
-            yield deferral.sleep(random.expovariate(1/20))
+    def _think(self):
+        try:
+            if len(self.addr_store) < self.preferred_storage and self.peers:
+                random.choice(self.peers.values()).send_getaddrs(count=8)
+        except:
+            log.err()
+        
+        return random.expovariate(1/20)
     
+    @defer.inlineCallbacks
     def stop(self):
         if not self.running:
             raise ValueError('already stopped')
         
         self.running = False
         
-        self.clientfactory.stop()
-        self.serverfactory.stop()
+        self._stop_thinking()
+        yield self.clientfactory.stop()
+        yield self.serverfactory.stop()
         for singleclientconnector in self.singleclientconnectors:
-            singleclientconnector.factory.stopTrying() # XXX will this disconnect a current connection?
+            yield singleclientconnector.factory.stopTrying()
+            yield singleclientconnector.disconnect()
         del self.singleclientconnectors
     
     def got_conn(self, conn):
@@ -412,14 +456,14 @@ class Node(object):
         
         print '%s connection to peer %s:%i established. p2pool version: %i %r' % ('Incoming' if conn.incoming else 'Outgoing', conn.addr[0], conn.addr[1], conn.other_version, conn.other_sub_version)
     
-    def lost_conn(self, conn):
+    def lost_conn(self, conn, reason):
         if conn.nonce not in self.peers:
             raise ValueError('''don't have peer''')
         if conn is not self.peers[conn.nonce]:
             raise ValueError('wrong conn')
         del self.peers[conn.nonce]
         
-        print 'Lost peer %s:%i' % (conn.addr[0], conn.addr[1])
+        print 'Lost peer %s:%i - %s' % (conn.addr[0], conn.addr[1], reason.getErrorMessage())
     
     
     def got_addr(self, (host, port), services, timestamp):
@@ -438,17 +482,14 @@ class Node(object):
     def handle_get_shares(self, hashes, parents, stops, peer):
         print 'handle_get_shares', (hashes, parents, stops, peer)
     
+    def handle_share_reply(self, id, result, shares, peer):
+        raise PeerMisbehavingError('sent share reply without being sent a request')
+    
+    def handle_bestblock(self, header, peer):
+        print 'handle_bestblock', header
+    
     def get_good_peers(self, max_count):
         t = time.time()
-        return [x[0] for x in sorted(self.addr_store.iteritems(), key=lambda (k, (services, first_seen, last_seen)): -(last_seen - first_seen)/max(3600, t - last_seen)*random.expovariate(1))][:max_count]
-
-if __name__ == '__main__':
-    p = random.randrange(2**15, 2**16)
-    for i in xrange(5):
-        p2 = random.randrange(2**15, 2**16)
-        print p, p2
-        n = Node(p2, True, {addrdb_key.pack(dict(address='127.0.0.1', port=p)): addrdb_value.pack(dict(services=0, first_seen=int(time.time())-10, last_seen=int(time.time())))})
-        n.start()
-        p = p2
-    
-    reactor.run()
+        return [x[0] for x in sorted(self.addr_store.iteritems(), key=lambda (k, (services, first_seen, last_seen)):
+            -math.log(max(3600, last_seen - first_seen))/math.log(max(3600, t - last_seen))*random.expovariate(1)
+        )][:max_count]