You can not select more than 25 topics Topics must start with a letter or number, can include dashes ('-') and can be up to 35 characters long.

361 lines
10 KiB

9 years ago
8 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
8 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
7 years ago
9 years ago
9 years ago
8 years ago
7 years ago
8 years ago
9 years ago
7 years ago
9 years ago
9 years ago
9 years ago
9 years ago
prevent nil addr Error: ``` Error: runtime error: invalid memoryaddress or nil pointer dereference\nStack: goroutine 549 [running]:\nruntime/debug.Stack(0x0, 0x0, 0x0)\n\t/usr/local/go/src/runtime/debug/stack.go:24 +0x80\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*MConnection)._recover(0xc821723b00)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/connection.go:173 +0x53\npanic(0xbe1500, 0xc820012080)\n\t/usr/local/go/src/runtime/panic.go:443 +0x4e9\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*NetAddress).Valid(0x0, 0x0)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/netaddress.go:125 +0x1c\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*NetAddress).Routable(0x0, 0xc8217bb740)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/netaddress.go:117 +0x25\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*AddrBook).addAddress(0xc820108380, 0x0, 0xc821739590)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/addrbook.go:524 +0x45\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*AddrBook).AddAddress(0xc820108380, 0x0, 0xc821739590)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/addrbook.go:160 +0x286\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*PEXReactor).Receive(0xc82000be60, 0xc820149f00, 0xc8218163f0, 0xc82184e000, 0x5b, 0x1000)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/pex_reactor.go:109 +0x457\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.newPeer.func1(0xc82011d500, 0xc82184e000, 0x5b, 0x1000)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/peer.go:58 +0x202\ngithub.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*MConnection).recvRoutine(0xc821723b00)\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/connection.go:439 +0x1177\ncreated by github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p.(*MConnection).OnStart\n\t/go/src/github.com/tendermint/tendermint/vendor/github.com/tendermint/go-p2p/connection.go:138 +0x1a1\n ```
8 years ago
9 years ago
8 years ago
9 years ago
7 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
8 years ago
9 years ago
8 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
9 years ago
  1. package p2p
  2. import (
  3. "bytes"
  4. "fmt"
  5. "math/rand"
  6. "reflect"
  7. "time"
  8. wire "github.com/tendermint/go-wire"
  9. cmn "github.com/tendermint/tmlibs/common"
  10. )
  11. const (
  12. // PexChannel is a channel for PEX messages
  13. PexChannel = byte(0x00)
  14. // period to ensure peers connected
  15. defaultEnsurePeersPeriod = 30 * time.Second
  16. minNumOutboundPeers = 10
  17. maxPexMessageSize = 1048576 // 1MB
  18. // maximum pex messages one peer can send to us during `msgCountByPeerFlushInterval`
  19. defaultMaxMsgCountByPeer = 1000
  20. msgCountByPeerFlushInterval = 1 * time.Hour
  21. )
  22. // PEXReactor handles PEX (peer exchange) and ensures that an
  23. // adequate number of peers are connected to the switch.
  24. //
  25. // It uses `AddrBook` (address book) to store `NetAddress`es of the peers.
  26. //
  27. // ## Preventing abuse
  28. //
  29. // For now, it just limits the number of messages from one peer to
  30. // `defaultMaxMsgCountByPeer` messages per `msgCountByPeerFlushInterval` (1000
  31. // msg/hour).
  32. //
  33. // NOTE [2017-01-17]:
  34. // Limiting is fine for now. Maybe down the road we want to keep track of the
  35. // quality of peer messages so if peerA keeps telling us about peers we can't
  36. // connect to then maybe we should care less about peerA. But I don't think
  37. // that kind of complexity is priority right now.
  38. type PEXReactor struct {
  39. BaseReactor
  40. book *AddrBook
  41. config *PEXReactorConfig
  42. ensurePeersPeriod time.Duration
  43. // tracks message count by peer, so we can prevent abuse
  44. msgCountByPeer *cmn.CMap
  45. maxMsgCountByPeer uint16
  46. }
  47. // PEXReactorConfig holds reactor specific configuration data.
  48. type PEXReactorConfig struct {
  49. // Seeds is a list of addresses reactor may use if it can't connect to peers
  50. // in the addrbook.
  51. Seeds []string
  52. }
  53. // NewPEXReactor creates new PEX reactor.
  54. func NewPEXReactor(b *AddrBook, config *PEXReactorConfig) *PEXReactor {
  55. r := &PEXReactor{
  56. book: b,
  57. config: config,
  58. ensurePeersPeriod: defaultEnsurePeersPeriod,
  59. msgCountByPeer: cmn.NewCMap(),
  60. maxMsgCountByPeer: defaultMaxMsgCountByPeer,
  61. }
  62. r.BaseReactor = *NewBaseReactor("PEXReactor", r)
  63. return r
  64. }
  65. // OnStart implements BaseService
  66. func (r *PEXReactor) OnStart() error {
  67. if err := r.BaseReactor.OnStart(); err != nil {
  68. return err
  69. }
  70. err := r.book.Start()
  71. if err != nil && err != cmn.ErrAlreadyStarted {
  72. return err
  73. }
  74. go r.ensurePeersRoutine()
  75. go r.flushMsgCountByPeer()
  76. return nil
  77. }
  78. // OnStop implements BaseService
  79. func (r *PEXReactor) OnStop() {
  80. r.BaseReactor.OnStop()
  81. r.book.Stop()
  82. }
  83. // GetChannels implements Reactor
  84. func (r *PEXReactor) GetChannels() []*ChannelDescriptor {
  85. return []*ChannelDescriptor{
  86. {
  87. ID: PexChannel,
  88. Priority: 1,
  89. SendQueueCapacity: 10,
  90. },
  91. }
  92. }
  93. // AddPeer implements Reactor by adding peer to the address book (if inbound)
  94. // or by requesting more addresses (if outbound).
  95. func (r *PEXReactor) AddPeer(p Peer) {
  96. if p.IsOutbound() {
  97. // For outbound peers, the address is already in the books.
  98. // Either it was added in DialPeersAsync or when we
  99. // received the peer's address in r.Receive
  100. if r.book.NeedMoreAddrs() {
  101. r.RequestPEX(p)
  102. }
  103. } else {
  104. // For inbound connections, the peer is its own source,
  105. // and its NodeInfo has already been validated
  106. addr := p.NodeInfo().NetAddress()
  107. r.book.AddAddress(addr, addr)
  108. }
  109. }
  110. // RemovePeer implements Reactor.
  111. func (r *PEXReactor) RemovePeer(p Peer, reason interface{}) {
  112. // If we aren't keeping track of local temp data for each peer here, then we
  113. // don't have to do anything.
  114. }
  115. // Receive implements Reactor by handling incoming PEX messages.
  116. func (r *PEXReactor) Receive(chID byte, src Peer, msgBytes []byte) {
  117. srcAddr := src.NodeInfo().NetAddress()
  118. r.IncrementMsgCountForPeer(srcAddr.ID)
  119. if r.ReachedMaxMsgCountForPeer(srcAddr.ID) {
  120. r.Logger.Error("Maximum number of messages reached for peer", "peer", srcAddr)
  121. // TODO remove src from peers?
  122. return
  123. }
  124. _, msg, err := DecodeMessage(msgBytes)
  125. if err != nil {
  126. r.Logger.Error("Error decoding message", "err", err)
  127. return
  128. }
  129. r.Logger.Debug("Received message", "src", src, "chId", chID, "msg", msg)
  130. switch msg := msg.(type) {
  131. case *pexRequestMessage:
  132. // src requested some peers.
  133. // NOTE: we might send an empty selection
  134. r.SendAddrs(src, r.book.GetSelection())
  135. case *pexAddrsMessage:
  136. // We received some peer addresses from src.
  137. // TODO: (We don't want to get spammed with bad peers)
  138. for _, netAddr := range msg.Addrs {
  139. if netAddr != nil {
  140. r.book.AddAddress(netAddr, srcAddr)
  141. }
  142. }
  143. default:
  144. r.Logger.Error(fmt.Sprintf("Unknown message type %v", reflect.TypeOf(msg)))
  145. }
  146. }
  147. // RequestPEX asks peer for more addresses.
  148. func (r *PEXReactor) RequestPEX(p Peer) {
  149. p.Send(PexChannel, struct{ PexMessage }{&pexRequestMessage{}})
  150. }
  151. // SendAddrs sends addrs to the peer.
  152. func (r *PEXReactor) SendAddrs(p Peer, netAddrs []*NetAddress) {
  153. p.Send(PexChannel, struct{ PexMessage }{&pexAddrsMessage{Addrs: netAddrs}})
  154. }
  155. // SetEnsurePeersPeriod sets period to ensure peers connected.
  156. func (r *PEXReactor) SetEnsurePeersPeriod(d time.Duration) {
  157. r.ensurePeersPeriod = d
  158. }
  159. // SetMaxMsgCountByPeer sets maximum messages one peer can send to us during 'msgCountByPeerFlushInterval'.
  160. func (r *PEXReactor) SetMaxMsgCountByPeer(v uint16) {
  161. r.maxMsgCountByPeer = v
  162. }
  163. // ReachedMaxMsgCountForPeer returns true if we received too many
  164. // messages from peer with address `addr`.
  165. // NOTE: assumes the value in the CMap is non-nil
  166. func (r *PEXReactor) ReachedMaxMsgCountForPeer(peerID ID) bool {
  167. return r.msgCountByPeer.Get(string(peerID)).(uint16) >= r.maxMsgCountByPeer
  168. }
  169. // Increment or initialize the msg count for the peer in the CMap
  170. func (r *PEXReactor) IncrementMsgCountForPeer(peerID ID) {
  171. var count uint16
  172. countI := r.msgCountByPeer.Get(string(peerID))
  173. if countI != nil {
  174. count = countI.(uint16)
  175. }
  176. count++
  177. r.msgCountByPeer.Set(string(peerID), count)
  178. }
  179. // Ensures that sufficient peers are connected. (continuous)
  180. func (r *PEXReactor) ensurePeersRoutine() {
  181. // Randomize when routine starts
  182. ensurePeersPeriodMs := r.ensurePeersPeriod.Nanoseconds() / 1e6
  183. time.Sleep(time.Duration(rand.Int63n(ensurePeersPeriodMs)) * time.Millisecond)
  184. // fire once immediately.
  185. r.ensurePeers()
  186. // fire periodically
  187. ticker := time.NewTicker(r.ensurePeersPeriod)
  188. for {
  189. select {
  190. case <-ticker.C:
  191. r.ensurePeers()
  192. case <-r.Quit:
  193. ticker.Stop()
  194. return
  195. }
  196. }
  197. }
  198. // ensurePeers ensures that sufficient peers are connected. (once)
  199. //
  200. // Old bucket / New bucket are arbitrary categories to denote whether an
  201. // address is vetted or not, and this needs to be determined over time via a
  202. // heuristic that we haven't perfected yet, or, perhaps is manually edited by
  203. // the node operator. It should not be used to compute what addresses are
  204. // already connected or not.
  205. //
  206. // TODO Basically, we need to work harder on our good-peer/bad-peer marking.
  207. // What we're currently doing in terms of marking good/bad peers is just a
  208. // placeholder. It should not be the case that an address becomes old/vetted
  209. // upon a single successful connection.
  210. func (r *PEXReactor) ensurePeers() {
  211. numOutPeers, numInPeers, numDialing := r.Switch.NumPeers()
  212. numToDial := minNumOutboundPeers - (numOutPeers + numDialing)
  213. r.Logger.Info("Ensure peers", "numOutPeers", numOutPeers, "numDialing", numDialing, "numToDial", numToDial)
  214. if numToDial <= 0 {
  215. return
  216. }
  217. // bias to prefer more vetted peers when we have fewer connections.
  218. // not perfect, but somewhate ensures that we prioritize connecting to more-vetted
  219. // NOTE: range here is [10, 90]. Too high ?
  220. newBias := cmn.MinInt(numOutPeers, 8)*10 + 10
  221. toDial := make(map[ID]*NetAddress)
  222. // Try maxAttempts times to pick numToDial addresses to dial
  223. maxAttempts := numToDial * 3
  224. for i := 0; i < maxAttempts && len(toDial) < numToDial; i++ {
  225. try := r.book.PickAddress(newBias)
  226. if try == nil {
  227. continue
  228. }
  229. if _, selected := toDial[try.ID]; selected {
  230. continue
  231. }
  232. if dialling := r.Switch.IsDialing(try.ID); dialling {
  233. continue
  234. }
  235. if connected := r.Switch.Peers().Has(try.ID); connected {
  236. continue
  237. }
  238. r.Logger.Info("Will dial address", "addr", try)
  239. toDial[try.ID] = try
  240. }
  241. // Dial picked addresses
  242. for _, item := range toDial {
  243. go func(picked *NetAddress) {
  244. _, err := r.Switch.DialPeerWithAddress(picked, false)
  245. if err != nil {
  246. r.book.MarkAttempt(picked)
  247. }
  248. }(item)
  249. }
  250. // If we need more addresses, pick a random peer and ask for more.
  251. if r.book.NeedMoreAddrs() {
  252. peers := r.Switch.Peers().List()
  253. peersCount := len(peers)
  254. if peersCount > 0 {
  255. peer := peers[rand.Int()%peersCount] // nolint: gas
  256. r.Logger.Info("We need more addresses. Sending pexRequest to random peer", "peer", peer)
  257. r.RequestPEX(peer)
  258. }
  259. }
  260. // If we are not connected to nor dialing anybody, fallback to dialing seeds.
  261. if numOutPeers+numInPeers+numDialing+len(toDial) == 0 {
  262. r.Logger.Info("No addresses to dial nor connected peers. Will dial seeds", "seeds", r.config.Seeds)
  263. r.Switch.DialPeersAsync(r.book, r.config.Seeds, false)
  264. }
  265. }
  266. func (r *PEXReactor) flushMsgCountByPeer() {
  267. ticker := time.NewTicker(msgCountByPeerFlushInterval)
  268. for {
  269. select {
  270. case <-ticker.C:
  271. r.msgCountByPeer.Clear()
  272. case <-r.Quit:
  273. ticker.Stop()
  274. return
  275. }
  276. }
  277. }
  278. //-----------------------------------------------------------------------------
  279. // Messages
  280. const (
  281. msgTypeRequest = byte(0x01)
  282. msgTypeAddrs = byte(0x02)
  283. )
  284. // PexMessage is a primary type for PEX messages. Underneath, it could contain
  285. // either pexRequestMessage, or pexAddrsMessage messages.
  286. type PexMessage interface{}
  287. var _ = wire.RegisterInterface(
  288. struct{ PexMessage }{},
  289. wire.ConcreteType{&pexRequestMessage{}, msgTypeRequest},
  290. wire.ConcreteType{&pexAddrsMessage{}, msgTypeAddrs},
  291. )
  292. // DecodeMessage implements interface registered above.
  293. func DecodeMessage(bz []byte) (msgType byte, msg PexMessage, err error) {
  294. msgType = bz[0]
  295. n := new(int)
  296. r := bytes.NewReader(bz)
  297. msg = wire.ReadBinary(struct{ PexMessage }{}, r, maxPexMessageSize, n, &err).(struct{ PexMessage }).PexMessage
  298. return
  299. }
  300. /*
  301. A pexRequestMessage requests additional peer addresses.
  302. */
  303. type pexRequestMessage struct {
  304. }
  305. func (m *pexRequestMessage) String() string {
  306. return "[pexRequest]"
  307. }
  308. /*
  309. A message with announced peer addresses.
  310. */
  311. type pexAddrsMessage struct {
  312. Addrs []*NetAddress
  313. }
  314. func (m *pexAddrsMessage) String() string {
  315. return fmt.Sprintf("[pexAddrs %v]", m.Addrs)
  316. }