server.go 19 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672
  1. // Copyright 2014 The go-ethereum Authors
  2. // This file is part of the go-ethereum library.
  3. //
  4. // The go-ethereum library is free software: you can redistribute it and/or modify
  5. // it under the terms of the GNU Lesser General Public License as published by
  6. // the Free Software Foundation, either version 3 of the License, or
  7. // (at your option) any later version.
  8. //
  9. // The go-ethereum library is distributed in the hope that it will be useful,
  10. // but WITHOUT ANY WARRANTY; without even the implied warranty of
  11. // MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
  12. // GNU Lesser General Public License for more details.
  13. //
  14. // You should have received a copy of the GNU Lesser General Public License
  15. // along with the go-ethereum library. If not, see <http://www.gnu.org/licenses/>.
  16. // Package p2p implements the Ethereum p2p network protocols.
  17. package p2p
  18. import (
  19. "crypto/ecdsa"
  20. "errors"
  21. "fmt"
  22. "net"
  23. "sync"
  24. "time"
  25. "github.com/ethereum/go-ethereum/logger"
  26. "github.com/ethereum/go-ethereum/logger/glog"
  27. "github.com/ethereum/go-ethereum/p2p/discover"
  28. "github.com/ethereum/go-ethereum/p2p/nat"
  29. )
  30. const (
  31. defaultDialTimeout = 15 * time.Second
  32. refreshPeersInterval = 30 * time.Second
  33. staticPeerCheckInterval = 15 * time.Second
  34. // Maximum number of concurrently handshaking inbound connections.
  35. maxAcceptConns = 50
  36. // Maximum number of concurrently dialing outbound connections.
  37. maxActiveDialTasks = 16
  38. // Maximum time allowed for reading a complete message.
  39. // This is effectively the amount of time a connection can be idle.
  40. frameReadTimeout = 30 * time.Second
  41. // Maximum amount of time allowed for writing a complete message.
  42. frameWriteTimeout = 20 * time.Second
  43. )
  44. var errServerStopped = errors.New("server stopped")
  45. var srvjslog = logger.NewJsonLogger()
  46. // Server manages all peer connections.
  47. //
  48. // The fields of Server are used as configuration parameters.
  49. // You should set them before starting the Server. Fields may not be
  50. // modified while the server is running.
  51. type Server struct {
  52. // This field must be set to a valid secp256k1 private key.
  53. PrivateKey *ecdsa.PrivateKey
  54. // MaxPeers is the maximum number of peers that can be
  55. // connected. It must be greater than zero.
  56. MaxPeers int
  57. // MaxPendingPeers is the maximum number of peers that can be pending in the
  58. // handshake phase, counted separately for inbound and outbound connections.
  59. // Zero defaults to preset values.
  60. MaxPendingPeers int
  61. // Discovery specifies whether the peer discovery mechanism should be started
  62. // or not. Disabling is usually useful for protocol debugging (manual topology).
  63. Discovery bool
  64. // Name sets the node name of this server.
  65. // Use common.MakeName to create a name that follows existing conventions.
  66. Name string
  67. // Bootstrap nodes are used to establish connectivity
  68. // with the rest of the network.
  69. BootstrapNodes []*discover.Node
  70. // Static nodes are used as pre-configured connections which are always
  71. // maintained and re-connected on disconnects.
  72. StaticNodes []*discover.Node
  73. // Trusted nodes are used as pre-configured connections which are always
  74. // allowed to connect, even above the peer limit.
  75. TrustedNodes []*discover.Node
  76. // NodeDatabase is the path to the database containing the previously seen
  77. // live nodes in the network.
  78. NodeDatabase string
  79. // Protocols should contain the protocols supported
  80. // by the server. Matching protocols are launched for
  81. // each peer.
  82. Protocols []Protocol
  83. // If ListenAddr is set to a non-nil address, the server
  84. // will listen for incoming connections.
  85. //
  86. // If the port is zero, the operating system will pick a port. The
  87. // ListenAddr field will be updated with the actual address when
  88. // the server is started.
  89. ListenAddr string
  90. // If set to a non-nil value, the given NAT port mapper
  91. // is used to make the listening port available to the
  92. // Internet.
  93. NAT nat.Interface
  94. // If Dialer is set to a non-nil value, the given Dialer
  95. // is used to dial outbound peer connections.
  96. Dialer *net.Dialer
  97. // If NoDial is true, the server will not dial any peers.
  98. NoDial bool
  99. // Hooks for testing. These are useful because we can inhibit
  100. // the whole protocol stack.
  101. newTransport func(net.Conn) transport
  102. newPeerHook func(*Peer)
  103. lock sync.Mutex // protects running
  104. running bool
  105. ntab discoverTable
  106. listener net.Listener
  107. ourHandshake *protoHandshake
  108. lastLookup time.Time
  109. // These are for Peers, PeerCount (and nothing else).
  110. peerOp chan peerOpFunc
  111. peerOpDone chan struct{}
  112. quit chan struct{}
  113. addstatic chan *discover.Node
  114. posthandshake chan *conn
  115. addpeer chan *conn
  116. delpeer chan *Peer
  117. loopWG sync.WaitGroup // loop, listenLoop
  118. }
  119. type peerOpFunc func(map[discover.NodeID]*Peer)
  120. type connFlag int
  121. const (
  122. dynDialedConn connFlag = 1 << iota
  123. staticDialedConn
  124. inboundConn
  125. trustedConn
  126. )
  127. // conn wraps a network connection with information gathered
  128. // during the two handshakes.
  129. type conn struct {
  130. fd net.Conn
  131. transport
  132. flags connFlag
  133. cont chan error // The run loop uses cont to signal errors to setupConn.
  134. id discover.NodeID // valid after the encryption handshake
  135. caps []Cap // valid after the protocol handshake
  136. name string // valid after the protocol handshake
  137. }
  138. type transport interface {
  139. // The two handshakes.
  140. doEncHandshake(prv *ecdsa.PrivateKey, dialDest *discover.Node) (discover.NodeID, error)
  141. doProtoHandshake(our *protoHandshake) (*protoHandshake, error)
  142. // The MsgReadWriter can only be used after the encryption
  143. // handshake has completed. The code uses conn.id to track this
  144. // by setting it to a non-nil value after the encryption handshake.
  145. MsgReadWriter
  146. // transports must provide Close because we use MsgPipe in some of
  147. // the tests. Closing the actual network connection doesn't do
  148. // anything in those tests because NsgPipe doesn't use it.
  149. close(err error)
  150. }
  151. func (c *conn) String() string {
  152. s := c.flags.String() + " conn"
  153. if (c.id != discover.NodeID{}) {
  154. s += fmt.Sprintf(" %x", c.id[:8])
  155. }
  156. s += " " + c.fd.RemoteAddr().String()
  157. return s
  158. }
  159. func (f connFlag) String() string {
  160. s := ""
  161. if f&trustedConn != 0 {
  162. s += " trusted"
  163. }
  164. if f&dynDialedConn != 0 {
  165. s += " dyn dial"
  166. }
  167. if f&staticDialedConn != 0 {
  168. s += " static dial"
  169. }
  170. if f&inboundConn != 0 {
  171. s += " inbound"
  172. }
  173. if s != "" {
  174. s = s[1:]
  175. }
  176. return s
  177. }
  178. func (c *conn) is(f connFlag) bool {
  179. return c.flags&f != 0
  180. }
  181. // Peers returns all connected peers.
  182. func (srv *Server) Peers() []*Peer {
  183. var ps []*Peer
  184. select {
  185. // Note: We'd love to put this function into a variable but
  186. // that seems to cause a weird compiler error in some
  187. // environments.
  188. case srv.peerOp <- func(peers map[discover.NodeID]*Peer) {
  189. for _, p := range peers {
  190. ps = append(ps, p)
  191. }
  192. }:
  193. <-srv.peerOpDone
  194. case <-srv.quit:
  195. }
  196. return ps
  197. }
  198. // PeerCount returns the number of connected peers.
  199. func (srv *Server) PeerCount() int {
  200. var count int
  201. select {
  202. case srv.peerOp <- func(ps map[discover.NodeID]*Peer) { count = len(ps) }:
  203. <-srv.peerOpDone
  204. case <-srv.quit:
  205. }
  206. return count
  207. }
  208. // AddPeer connects to the given node and maintains the connection until the
  209. // server is shut down. If the connection fails for any reason, the server will
  210. // attempt to reconnect the peer.
  211. func (srv *Server) AddPeer(node *discover.Node) {
  212. select {
  213. case srv.addstatic <- node:
  214. case <-srv.quit:
  215. }
  216. }
  217. // Self returns the local node's endpoint information.
  218. func (srv *Server) Self() *discover.Node {
  219. srv.lock.Lock()
  220. defer srv.lock.Unlock()
  221. // If the server's not running, return an empty node
  222. if !srv.running {
  223. return &discover.Node{IP: net.ParseIP("0.0.0.0")}
  224. }
  225. // If the node is running but discovery is off, manually assemble the node infos
  226. if srv.ntab == nil {
  227. // Inbound connections disabled, use zero address
  228. if srv.listener == nil {
  229. return &discover.Node{IP: net.ParseIP("0.0.0.0"), ID: discover.PubkeyID(&srv.PrivateKey.PublicKey)}
  230. }
  231. // Otherwise inject the listener address too
  232. addr := srv.listener.Addr().(*net.TCPAddr)
  233. return &discover.Node{
  234. ID: discover.PubkeyID(&srv.PrivateKey.PublicKey),
  235. IP: addr.IP,
  236. TCP: uint16(addr.Port),
  237. }
  238. }
  239. // Otherwise return the live node infos
  240. return srv.ntab.Self()
  241. }
  242. // Stop terminates the server and all active peer connections.
  243. // It blocks until all active connections have been closed.
  244. func (srv *Server) Stop() {
  245. srv.lock.Lock()
  246. defer srv.lock.Unlock()
  247. if !srv.running {
  248. return
  249. }
  250. srv.running = false
  251. if srv.listener != nil {
  252. // this unblocks listener Accept
  253. srv.listener.Close()
  254. }
  255. close(srv.quit)
  256. srv.loopWG.Wait()
  257. }
  258. // Start starts running the server.
  259. // Servers can not be re-used after stopping.
  260. func (srv *Server) Start() (err error) {
  261. srv.lock.Lock()
  262. defer srv.lock.Unlock()
  263. if srv.running {
  264. return errors.New("server already running")
  265. }
  266. srv.running = true
  267. glog.V(logger.Info).Infoln("Starting Server")
  268. // static fields
  269. if srv.PrivateKey == nil {
  270. return fmt.Errorf("Server.PrivateKey must be set to a non-nil key")
  271. }
  272. if srv.newTransport == nil {
  273. srv.newTransport = newRLPX
  274. }
  275. if srv.Dialer == nil {
  276. srv.Dialer = &net.Dialer{Timeout: defaultDialTimeout}
  277. }
  278. srv.quit = make(chan struct{})
  279. srv.addpeer = make(chan *conn)
  280. srv.delpeer = make(chan *Peer)
  281. srv.posthandshake = make(chan *conn)
  282. srv.addstatic = make(chan *discover.Node)
  283. srv.peerOp = make(chan peerOpFunc)
  284. srv.peerOpDone = make(chan struct{})
  285. // node table
  286. if srv.Discovery {
  287. ntab, err := discover.ListenUDP(srv.PrivateKey, srv.ListenAddr, srv.NAT, srv.NodeDatabase)
  288. if err != nil {
  289. return err
  290. }
  291. srv.ntab = ntab
  292. }
  293. dynPeers := srv.MaxPeers / 2
  294. if !srv.Discovery {
  295. dynPeers = 0
  296. }
  297. dialer := newDialState(srv.StaticNodes, srv.ntab, dynPeers)
  298. // handshake
  299. srv.ourHandshake = &protoHandshake{Version: baseProtocolVersion, Name: srv.Name, ID: discover.PubkeyID(&srv.PrivateKey.PublicKey)}
  300. for _, p := range srv.Protocols {
  301. srv.ourHandshake.Caps = append(srv.ourHandshake.Caps, p.cap())
  302. }
  303. // listen/dial
  304. if srv.ListenAddr != "" {
  305. if err := srv.startListening(); err != nil {
  306. return err
  307. }
  308. }
  309. if srv.NoDial && srv.ListenAddr == "" {
  310. glog.V(logger.Warn).Infoln("I will be kind-of useless, neither dialing nor listening.")
  311. }
  312. srv.loopWG.Add(1)
  313. go srv.run(dialer)
  314. srv.running = true
  315. return nil
  316. }
  317. func (srv *Server) startListening() error {
  318. // Launch the TCP listener.
  319. listener, err := net.Listen("tcp", srv.ListenAddr)
  320. if err != nil {
  321. return err
  322. }
  323. laddr := listener.Addr().(*net.TCPAddr)
  324. srv.ListenAddr = laddr.String()
  325. srv.listener = listener
  326. srv.loopWG.Add(1)
  327. go srv.listenLoop()
  328. // Map the TCP listening port if NAT is configured.
  329. if !laddr.IP.IsLoopback() && srv.NAT != nil {
  330. srv.loopWG.Add(1)
  331. go func() {
  332. nat.Map(srv.NAT, srv.quit, "tcp", laddr.Port, laddr.Port, "ethereum p2p")
  333. srv.loopWG.Done()
  334. }()
  335. }
  336. return nil
  337. }
  338. type dialer interface {
  339. newTasks(running int, peers map[discover.NodeID]*Peer, now time.Time) []task
  340. taskDone(task, time.Time)
  341. addStatic(*discover.Node)
  342. }
  343. func (srv *Server) run(dialstate dialer) {
  344. defer srv.loopWG.Done()
  345. var (
  346. peers = make(map[discover.NodeID]*Peer)
  347. trusted = make(map[discover.NodeID]bool, len(srv.TrustedNodes))
  348. tasks []task
  349. pendingTasks []task
  350. taskdone = make(chan task, maxActiveDialTasks)
  351. )
  352. // Put trusted nodes into a map to speed up checks.
  353. // Trusted peers are loaded on startup and cannot be
  354. // modified while the server is running.
  355. for _, n := range srv.TrustedNodes {
  356. trusted[n.ID] = true
  357. }
  358. // Some task list helpers.
  359. delTask := func(t task) {
  360. for i := range tasks {
  361. if tasks[i] == t {
  362. tasks = append(tasks[:i], tasks[i+1:]...)
  363. break
  364. }
  365. }
  366. }
  367. scheduleTasks := func(new []task) {
  368. pt := append(pendingTasks, new...)
  369. start := maxActiveDialTasks - len(tasks)
  370. if len(pt) < start {
  371. start = len(pt)
  372. }
  373. if start > 0 {
  374. tasks = append(tasks, pt[:start]...)
  375. for _, t := range pt[:start] {
  376. t := t
  377. glog.V(logger.Detail).Infoln("new task:", t)
  378. go func() { t.Do(srv); taskdone <- t }()
  379. }
  380. copy(pt, pt[start:])
  381. pendingTasks = pt[:len(pt)-start]
  382. }
  383. }
  384. running:
  385. for {
  386. // Query the dialer for new tasks and launch them.
  387. now := time.Now()
  388. nt := dialstate.newTasks(len(pendingTasks)+len(tasks), peers, now)
  389. scheduleTasks(nt)
  390. select {
  391. case <-srv.quit:
  392. // The server was stopped. Run the cleanup logic.
  393. glog.V(logger.Detail).Infoln("<-quit: spinning down")
  394. break running
  395. case n := <-srv.addstatic:
  396. // This channel is used by AddPeer to add to the
  397. // ephemeral static peer list. Add it to the dialer,
  398. // it will keep the node connected.
  399. glog.V(logger.Detail).Infoln("<-addstatic:", n)
  400. dialstate.addStatic(n)
  401. case op := <-srv.peerOp:
  402. // This channel is used by Peers and PeerCount.
  403. op(peers)
  404. srv.peerOpDone <- struct{}{}
  405. case t := <-taskdone:
  406. // A task got done. Tell dialstate about it so it
  407. // can update its state and remove it from the active
  408. // tasks list.
  409. glog.V(logger.Detail).Infoln("<-taskdone:", t)
  410. dialstate.taskDone(t, now)
  411. delTask(t)
  412. case c := <-srv.posthandshake:
  413. // A connection has passed the encryption handshake so
  414. // the remote identity is known (but hasn't been verified yet).
  415. if trusted[c.id] {
  416. // Ensure that the trusted flag is set before checking against MaxPeers.
  417. c.flags |= trustedConn
  418. }
  419. glog.V(logger.Detail).Infoln("<-posthandshake:", c)
  420. // TODO: track in-progress inbound node IDs (pre-Peer) to avoid dialing them.
  421. c.cont <- srv.encHandshakeChecks(peers, c)
  422. case c := <-srv.addpeer:
  423. // At this point the connection is past the protocol handshake.
  424. // Its capabilities are known and the remote identity is verified.
  425. glog.V(logger.Detail).Infoln("<-addpeer:", c)
  426. err := srv.protoHandshakeChecks(peers, c)
  427. if err != nil {
  428. glog.V(logger.Detail).Infof("Not adding %v as peer: %v", c, err)
  429. } else {
  430. // The handshakes are done and it passed all checks.
  431. p := newPeer(c, srv.Protocols)
  432. peers[c.id] = p
  433. go srv.runPeer(p)
  434. }
  435. // The dialer logic relies on the assumption that
  436. // dial tasks complete after the peer has been added or
  437. // discarded. Unblock the task last.
  438. c.cont <- err
  439. case p := <-srv.delpeer:
  440. // A peer disconnected.
  441. glog.V(logger.Detail).Infoln("<-delpeer:", p)
  442. delete(peers, p.ID())
  443. }
  444. }
  445. // Terminate discovery. If there is a running lookup it will terminate soon.
  446. if srv.ntab != nil {
  447. srv.ntab.Close()
  448. }
  449. // Disconnect all peers.
  450. for _, p := range peers {
  451. p.Disconnect(DiscQuitting)
  452. }
  453. // Wait for peers to shut down. Pending connections and tasks are
  454. // not handled here and will terminate soon-ish because srv.quit
  455. // is closed.
  456. glog.V(logger.Detail).Infof("ignoring %d pending tasks at spindown", len(tasks))
  457. for len(peers) > 0 {
  458. p := <-srv.delpeer
  459. glog.V(logger.Detail).Infoln("<-delpeer (spindown):", p)
  460. delete(peers, p.ID())
  461. }
  462. }
  463. func (srv *Server) protoHandshakeChecks(peers map[discover.NodeID]*Peer, c *conn) error {
  464. // Drop connections with no matching protocols.
  465. if len(srv.Protocols) > 0 && countMatchingProtocols(srv.Protocols, c.caps) == 0 {
  466. return DiscUselessPeer
  467. }
  468. // Repeat the encryption handshake checks because the
  469. // peer set might have changed between the handshakes.
  470. return srv.encHandshakeChecks(peers, c)
  471. }
  472. func (srv *Server) encHandshakeChecks(peers map[discover.NodeID]*Peer, c *conn) error {
  473. switch {
  474. case !c.is(trustedConn|staticDialedConn) && len(peers) >= srv.MaxPeers:
  475. return DiscTooManyPeers
  476. case peers[c.id] != nil:
  477. return DiscAlreadyConnected
  478. case c.id == srv.Self().ID:
  479. return DiscSelf
  480. default:
  481. return nil
  482. }
  483. }
  484. // listenLoop runs in its own goroutine and accepts
  485. // inbound connections.
  486. func (srv *Server) listenLoop() {
  487. defer srv.loopWG.Done()
  488. glog.V(logger.Info).Infoln("Listening on", srv.listener.Addr())
  489. // This channel acts as a semaphore limiting
  490. // active inbound connections that are lingering pre-handshake.
  491. // If all slots are taken, no further connections are accepted.
  492. tokens := maxAcceptConns
  493. if srv.MaxPendingPeers > 0 {
  494. tokens = srv.MaxPendingPeers
  495. }
  496. slots := make(chan struct{}, tokens)
  497. for i := 0; i < tokens; i++ {
  498. slots <- struct{}{}
  499. }
  500. for {
  501. <-slots
  502. fd, err := srv.listener.Accept()
  503. if err != nil {
  504. return
  505. }
  506. mfd := newMeteredConn(fd, true)
  507. glog.V(logger.Debug).Infof("Accepted conn %v\n", mfd.RemoteAddr())
  508. go func() {
  509. srv.setupConn(mfd, inboundConn, nil)
  510. slots <- struct{}{}
  511. }()
  512. }
  513. }
  514. // setupConn runs the handshakes and attempts to add the connection
  515. // as a peer. It returns when the connection has been added as a peer
  516. // or the handshakes have failed.
  517. func (srv *Server) setupConn(fd net.Conn, flags connFlag, dialDest *discover.Node) {
  518. // Prevent leftover pending conns from entering the handshake.
  519. srv.lock.Lock()
  520. running := srv.running
  521. srv.lock.Unlock()
  522. c := &conn{fd: fd, transport: srv.newTransport(fd), flags: flags, cont: make(chan error)}
  523. if !running {
  524. c.close(errServerStopped)
  525. return
  526. }
  527. // Run the encryption handshake.
  528. var err error
  529. if c.id, err = c.doEncHandshake(srv.PrivateKey, dialDest); err != nil {
  530. glog.V(logger.Debug).Infof("%v faild enc handshake: %v", c, err)
  531. c.close(err)
  532. return
  533. }
  534. // For dialed connections, check that the remote public key matches.
  535. if dialDest != nil && c.id != dialDest.ID {
  536. c.close(DiscUnexpectedIdentity)
  537. glog.V(logger.Debug).Infof("%v dialed identity mismatch, want %x", c, dialDest.ID[:8])
  538. return
  539. }
  540. if err := srv.checkpoint(c, srv.posthandshake); err != nil {
  541. glog.V(logger.Debug).Infof("%v failed checkpoint posthandshake: %v", c, err)
  542. c.close(err)
  543. return
  544. }
  545. // Run the protocol handshake
  546. phs, err := c.doProtoHandshake(srv.ourHandshake)
  547. if err != nil {
  548. glog.V(logger.Debug).Infof("%v failed proto handshake: %v", c, err)
  549. c.close(err)
  550. return
  551. }
  552. if phs.ID != c.id {
  553. glog.V(logger.Debug).Infof("%v wrong proto handshake identity: %x", c, phs.ID[:8])
  554. c.close(DiscUnexpectedIdentity)
  555. return
  556. }
  557. c.caps, c.name = phs.Caps, phs.Name
  558. if err := srv.checkpoint(c, srv.addpeer); err != nil {
  559. glog.V(logger.Debug).Infof("%v failed checkpoint addpeer: %v", c, err)
  560. c.close(err)
  561. return
  562. }
  563. // If the checks completed successfully, runPeer has now been
  564. // launched by run.
  565. }
  566. // checkpoint sends the conn to run, which performs the
  567. // post-handshake checks for the stage (posthandshake, addpeer).
  568. func (srv *Server) checkpoint(c *conn, stage chan<- *conn) error {
  569. select {
  570. case stage <- c:
  571. case <-srv.quit:
  572. return errServerStopped
  573. }
  574. select {
  575. case err := <-c.cont:
  576. return err
  577. case <-srv.quit:
  578. return errServerStopped
  579. }
  580. }
  581. // runPeer runs in its own goroutine for each peer.
  582. // it waits until the Peer logic returns and removes
  583. // the peer.
  584. func (srv *Server) runPeer(p *Peer) {
  585. glog.V(logger.Debug).Infof("Added %v\n", p)
  586. srvjslog.LogJson(&logger.P2PConnected{
  587. RemoteId: p.ID().String(),
  588. RemoteAddress: p.RemoteAddr().String(),
  589. RemoteVersionString: p.Name(),
  590. NumConnections: srv.PeerCount(),
  591. })
  592. if srv.newPeerHook != nil {
  593. srv.newPeerHook(p)
  594. }
  595. discreason := p.run()
  596. // Note: run waits for existing peers to be sent on srv.delpeer
  597. // before returning, so this send should not select on srv.quit.
  598. srv.delpeer <- p
  599. glog.V(logger.Debug).Infof("Removed %v (%v)\n", p, discreason)
  600. srvjslog.LogJson(&logger.P2PDisconnected{
  601. RemoteId: p.ID().String(),
  602. NumConnections: srv.PeerCount(),
  603. })
  604. }