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.

427 lines
14 KiB

7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
new pubsub package comment out failing consensus tests for now rewrite rpc httpclient to use new pubsub package import pubsub as tmpubsub, query as tmquery make event IDs constants EventKey -> EventTypeKey rename EventsPubsub to PubSub mempool does not use pubsub rename eventsSub to pubsub new subscribe API fix channel size issues and consensus tests bugs refactor rpc client add missing discardFromChan method add mutex rename pubsub to eventBus remove IsRunning from WSRPCConnection interface (not needed) add a comment in broadcastNewRoundStepsAndVotes rename registerEventCallbacks to broadcastNewRoundStepsAndVotes See https://dave.cheney.net/2014/03/19/channel-axioms stop eventBuses after reactor tests remove unnecessary Unsubscribe return subscribe helper function move discardFromChan to where it is used subscribe now returns an err this gives us ability to refuse to subscribe if pubsub is at its max capacity. use context for control overflow cache queries handle err when subscribing in replay_test rename testClientID to testSubscriber extract var set channel buffer capacity to 1 in replay_file fix byzantine_test unsubscribe from single event, not all events refactor httpclient to return events to appropriate channels return failing testReplayCrashBeforeWriteVote test fix TestValidatorSetChanges refactor code a bit fix testReplayCrashBeforeWriteVote add comment fix TestValidatorSetChanges fixes from Bucky's review update comment [ci skip] test TxEventBuffer update changelog fix TestValidatorSetChanges (2nd attempt) only do wg.Done when no errors benchmark event bus create pubsub server inside NewEventBus only expose config params (later if needed) set buffer capacity to 0 so we are not testing cache new tx event format: key = "Tx" plus a tag {"tx.hash": XYZ} This should allow to subscribe to all transactions! or a specific one using a query: "tm.events.type = Tx and tx.hash = '013ABF99434...'" use TimeoutCommit instead of afterPublishEventNewBlockTimeout TimeoutCommit is the time a node waits after committing a block, before it goes into the next height. So it will finish everything from the last block, but then wait a bit. The idea is this gives it time to hear more votes from other validators, to strengthen the commit it includes in the next block. But it also gives it time to hear about new transactions. waitForBlockWithUpdatedVals rewrite WAL crash tests Task: test that we can recover from any WAL crash. Solution: the old tests were relying on event hub being run in the same thread (we were injecting the private validator's last signature). when considering a rewrite, we considered two possible solutions: write a "fuzzy" testing system where WAL is crashing upon receiving a new message, or inject failures and trigger them in tests using something like https://github.com/coreos/gofail. remove sleep no cs.Lock around wal.Save test different cases (empty block, non-empty block, ...) comments add comments test 4 cases: empty block, non-empty block, non-empty block with smaller part size, many blocks fixes as per Bucky's last review reset subscriptions on UnsubscribeAll use a simple counter to track message for which we panicked also, set a smaller part size for all test cases
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
7 years ago
  1. package consensus
  2. import (
  3. "bytes"
  4. "fmt"
  5. "hash/crc32"
  6. "io"
  7. "reflect"
  8. //"strconv"
  9. //"strings"
  10. "time"
  11. abci "github.com/tendermint/abci/types"
  12. //auto "github.com/tendermint/tmlibs/autofile"
  13. cmn "github.com/tendermint/tmlibs/common"
  14. dbm "github.com/tendermint/tmlibs/db"
  15. "github.com/tendermint/tmlibs/log"
  16. "github.com/tendermint/tendermint/proxy"
  17. sm "github.com/tendermint/tendermint/state"
  18. "github.com/tendermint/tendermint/types"
  19. "github.com/tendermint/tendermint/version"
  20. )
  21. var crc32c = crc32.MakeTable(crc32.Castagnoli)
  22. // Functionality to replay blocks and messages on recovery from a crash.
  23. // There are two general failure scenarios: failure during consensus, and failure while applying the block.
  24. // The former is handled by the WAL, the latter by the proxyApp Handshake on restart,
  25. // which ultimately hands off the work to the WAL.
  26. //-----------------------------------------
  27. // recover from failure during consensus
  28. // by replaying messages from the WAL
  29. // Unmarshal and apply a single message to the consensus state
  30. // as if it were received in receiveRoutine
  31. // Lines that start with "#" are ignored.
  32. // NOTE: receiveRoutine should not be running
  33. func (cs *ConsensusState) readReplayMessage(msg *TimedWALMessage, newStepCh chan interface{}) error {
  34. // skip meta messages
  35. if _, ok := msg.Msg.(EndHeightMessage); ok {
  36. return nil
  37. }
  38. // for logging
  39. switch m := msg.Msg.(type) {
  40. case types.EventDataRoundState:
  41. cs.Logger.Info("Replay: New Step", "height", m.Height, "round", m.Round, "step", m.Step)
  42. // these are playback checks
  43. ticker := time.After(time.Second * 2)
  44. if newStepCh != nil {
  45. select {
  46. case mi := <-newStepCh:
  47. m2 := mi.(types.EventDataRoundState)
  48. if m.Height != m2.Height || m.Round != m2.Round || m.Step != m2.Step {
  49. return fmt.Errorf("RoundState mismatch. Got %v; Expected %v", m2, m)
  50. }
  51. case <-ticker:
  52. return fmt.Errorf("Failed to read off newStepCh")
  53. }
  54. }
  55. case msgInfo:
  56. peerID := m.PeerID
  57. if peerID == "" {
  58. peerID = "local"
  59. }
  60. switch msg := m.Msg.(type) {
  61. case *ProposalMessage:
  62. p := msg.Proposal
  63. cs.Logger.Info("Replay: Proposal", "height", p.Height, "round", p.Round, "header",
  64. p.BlockPartsHeader, "pol", p.POLRound, "peer", peerID)
  65. case *BlockPartMessage:
  66. cs.Logger.Info("Replay: BlockPart", "height", msg.Height, "round", msg.Round, "peer", peerID)
  67. case *VoteMessage:
  68. v := msg.Vote
  69. cs.Logger.Info("Replay: Vote", "height", v.Height, "round", v.Round, "type", v.Type,
  70. "blockID", v.BlockID, "peer", peerID)
  71. }
  72. cs.handleMsg(m)
  73. case timeoutInfo:
  74. cs.Logger.Info("Replay: Timeout", "height", m.Height, "round", m.Round, "step", m.Step, "dur", m.Duration)
  75. cs.handleTimeout(m, cs.RoundState)
  76. default:
  77. return fmt.Errorf("Replay: Unknown TimedWALMessage type: %v", reflect.TypeOf(msg.Msg))
  78. }
  79. return nil
  80. }
  81. // replay only those messages since the last block.
  82. // timeoutRoutine should run concurrently to read off tickChan
  83. func (cs *ConsensusState) catchupReplay(csHeight int64) error {
  84. // set replayMode
  85. cs.replayMode = true
  86. defer func() { cs.replayMode = false }()
  87. // Ensure that ENDHEIGHT for this height doesn't exist.
  88. // NOTE: This is just a sanity check. As far as we know things work fine
  89. // without it, and Handshake could reuse ConsensusState if it weren't for
  90. // this check (since we can crash after writing ENDHEIGHT).
  91. //
  92. // Ignore data corruption errors since this is a sanity check.
  93. gr, found, err := cs.wal.SearchForEndHeight(csHeight, &WALSearchOptions{IgnoreDataCorruptionErrors: true})
  94. if err != nil {
  95. return err
  96. }
  97. if gr != nil {
  98. if err := gr.Close(); err != nil {
  99. return err
  100. }
  101. }
  102. if found {
  103. return fmt.Errorf("WAL should not contain #ENDHEIGHT %d.", csHeight)
  104. }
  105. // Search for last height marker
  106. //
  107. // Ignore data corruption errors in previous heights because we only care about last height
  108. gr, found, err = cs.wal.SearchForEndHeight(csHeight-1, &WALSearchOptions{IgnoreDataCorruptionErrors: true})
  109. if err == io.EOF {
  110. cs.Logger.Error("Replay: wal.group.Search returned EOF", "#ENDHEIGHT", csHeight-1)
  111. } else if err != nil {
  112. return err
  113. }
  114. if !found {
  115. return fmt.Errorf("Cannot replay height %d. WAL does not contain #ENDHEIGHT for %d.", csHeight, csHeight-1)
  116. }
  117. defer gr.Close() // nolint: errcheck
  118. cs.Logger.Info("Catchup by replaying consensus messages", "height", csHeight)
  119. var msg *TimedWALMessage
  120. dec := WALDecoder{gr}
  121. for {
  122. msg, err = dec.Decode()
  123. if err == io.EOF {
  124. break
  125. } else if IsDataCorruptionError(err) {
  126. cs.Logger.Debug("data has been corrupted in last height of consensus WAL", "err", err, "height", csHeight)
  127. panic(fmt.Sprintf("data has been corrupted (%v) in last height %d of consensus WAL", err, csHeight))
  128. } else if err != nil {
  129. return err
  130. }
  131. // NOTE: since the priv key is set when the msgs are received
  132. // it will attempt to eg double sign but we can just ignore it
  133. // since the votes will be replayed and we'll get to the next step
  134. if err := cs.readReplayMessage(msg, nil); err != nil {
  135. return err
  136. }
  137. }
  138. cs.Logger.Info("Replay: Done")
  139. return nil
  140. }
  141. //--------------------------------------------------------------------------------
  142. // Parses marker lines of the form:
  143. // #ENDHEIGHT: 12345
  144. /*
  145. func makeHeightSearchFunc(height int64) auto.SearchFunc {
  146. return func(line string) (int, error) {
  147. line = strings.TrimRight(line, "\n")
  148. parts := strings.Split(line, " ")
  149. if len(parts) != 2 {
  150. return -1, errors.New("Line did not have 2 parts")
  151. }
  152. i, err := strconv.Atoi(parts[1])
  153. if err != nil {
  154. return -1, errors.New("Failed to parse INFO: " + err.Error())
  155. }
  156. if height < i {
  157. return 1, nil
  158. } else if height == i {
  159. return 0, nil
  160. } else {
  161. return -1, nil
  162. }
  163. }
  164. }*/
  165. //----------------------------------------------
  166. // Recover from failure during block processing
  167. // by handshaking with the app to figure out where
  168. // we were last and using the WAL to recover there
  169. type Handshaker struct {
  170. stateDB dbm.DB
  171. initialState sm.State
  172. store types.BlockStore
  173. logger log.Logger
  174. nBlocks int // number of blocks applied to the state
  175. }
  176. func NewHandshaker(stateDB dbm.DB, state sm.State, store types.BlockStore) *Handshaker {
  177. return &Handshaker{stateDB, state, store, log.NewNopLogger(), 0}
  178. }
  179. func (h *Handshaker) SetLogger(l log.Logger) {
  180. h.logger = l
  181. }
  182. func (h *Handshaker) NBlocks() int {
  183. return h.nBlocks
  184. }
  185. // TODO: retry the handshake/replay if it fails ?
  186. func (h *Handshaker) Handshake(proxyApp proxy.AppConns) error {
  187. // handshake is done via info request on the query conn
  188. res, err := proxyApp.Query().InfoSync(abci.RequestInfo{version.Version})
  189. if err != nil {
  190. return fmt.Errorf("Error calling Info: %v", err)
  191. }
  192. blockHeight := int64(res.LastBlockHeight)
  193. if blockHeight < 0 {
  194. return fmt.Errorf("Got a negative last block height (%d) from the app", blockHeight)
  195. }
  196. appHash := res.LastBlockAppHash
  197. h.logger.Info("ABCI Handshake", "appHeight", blockHeight, "appHash", fmt.Sprintf("%X", appHash))
  198. // TODO: check version
  199. // replay blocks up to the latest in the blockstore
  200. _, err = h.ReplayBlocks(h.initialState, appHash, blockHeight, proxyApp)
  201. if err != nil {
  202. return fmt.Errorf("Error on replay: %v", err)
  203. }
  204. h.logger.Info("Completed ABCI Handshake - Tendermint and App are synced", "appHeight", blockHeight, "appHash", fmt.Sprintf("%X", appHash))
  205. // TODO: (on restart) replay mempool
  206. return nil
  207. }
  208. // Replay all blocks since appBlockHeight and ensure the result matches the current state.
  209. // Returns the final AppHash or an error
  210. func (h *Handshaker) ReplayBlocks(state sm.State, appHash []byte, appBlockHeight int64, proxyApp proxy.AppConns) ([]byte, error) {
  211. storeBlockHeight := h.store.Height()
  212. stateBlockHeight := state.LastBlockHeight
  213. h.logger.Info("ABCI Replay Blocks", "appHeight", appBlockHeight, "storeHeight", storeBlockHeight, "stateHeight", stateBlockHeight)
  214. // If appBlockHeight == 0 it means that we are at genesis and hence should send InitChain
  215. if appBlockHeight == 0 {
  216. validators := types.TM2PB.Validators(state.Validators)
  217. if _, err := proxyApp.Consensus().InitChainSync(abci.RequestInitChain{validators}); err != nil {
  218. return nil, err
  219. }
  220. }
  221. // First handle edge cases and constraints on the storeBlockHeight
  222. if storeBlockHeight == 0 {
  223. return appHash, checkAppHash(state, appHash)
  224. } else if storeBlockHeight < appBlockHeight {
  225. // the app should never be ahead of the store (but this is under app's control)
  226. return appHash, sm.ErrAppBlockHeightTooHigh{storeBlockHeight, appBlockHeight}
  227. } else if storeBlockHeight < stateBlockHeight {
  228. // the state should never be ahead of the store (this is under tendermint's control)
  229. cmn.PanicSanity(cmn.Fmt("StateBlockHeight (%d) > StoreBlockHeight (%d)", stateBlockHeight, storeBlockHeight))
  230. } else if storeBlockHeight > stateBlockHeight+1 {
  231. // store should be at most one ahead of the state (this is under tendermint's control)
  232. cmn.PanicSanity(cmn.Fmt("StoreBlockHeight (%d) > StateBlockHeight + 1 (%d)", storeBlockHeight, stateBlockHeight+1))
  233. }
  234. var err error
  235. // Now either store is equal to state, or one ahead.
  236. // For each, consider all cases of where the app could be, given app <= store
  237. if storeBlockHeight == stateBlockHeight {
  238. // Tendermint ran Commit and saved the state.
  239. // Either the app is asking for replay, or we're all synced up.
  240. if appBlockHeight < storeBlockHeight {
  241. // the app is behind, so replay blocks, but no need to go through WAL (state is already synced to store)
  242. return h.replayBlocks(state, proxyApp, appBlockHeight, storeBlockHeight, false)
  243. } else if appBlockHeight == storeBlockHeight {
  244. // We're good!
  245. return appHash, checkAppHash(state, appHash)
  246. }
  247. } else if storeBlockHeight == stateBlockHeight+1 {
  248. // We saved the block in the store but haven't updated the state,
  249. // so we'll need to replay a block using the WAL.
  250. if appBlockHeight < stateBlockHeight {
  251. // the app is further behind than it should be, so replay blocks
  252. // but leave the last block to go through the WAL
  253. return h.replayBlocks(state, proxyApp, appBlockHeight, storeBlockHeight, true)
  254. } else if appBlockHeight == stateBlockHeight {
  255. // We haven't run Commit (both the state and app are one block behind),
  256. // so replayBlock with the real app.
  257. // NOTE: We could instead use the cs.WAL on cs.Start,
  258. // but we'd have to allow the WAL to replay a block that wrote it's ENDHEIGHT
  259. h.logger.Info("Replay last block using real app")
  260. state, err = h.replayBlock(state, storeBlockHeight, proxyApp.Consensus())
  261. return state.AppHash, err
  262. } else if appBlockHeight == storeBlockHeight {
  263. // We ran Commit, but didn't save the state, so replayBlock with mock app
  264. abciResponses, err := sm.LoadABCIResponses(h.stateDB, storeBlockHeight)
  265. if err != nil {
  266. return nil, err
  267. }
  268. mockApp := newMockProxyApp(appHash, abciResponses)
  269. h.logger.Info("Replay last block using mock app")
  270. state, err = h.replayBlock(state, storeBlockHeight, mockApp)
  271. return state.AppHash, err
  272. }
  273. }
  274. cmn.PanicSanity("Should never happen")
  275. return nil, nil
  276. }
  277. func (h *Handshaker) replayBlocks(state sm.State, proxyApp proxy.AppConns, appBlockHeight, storeBlockHeight int64, mutateState bool) ([]byte, error) {
  278. // App is further behind than it should be, so we need to replay blocks.
  279. // We replay all blocks from appBlockHeight+1.
  280. //
  281. // Note that we don't have an old version of the state,
  282. // so we by-pass state validation/mutation using sm.ExecCommitBlock.
  283. // This also means we won't be saving validator sets if they change during this period.
  284. // TODO: Load the historical information to fix this and just use state.ApplyBlock
  285. //
  286. // If mutateState == true, the final block is replayed with h.replayBlock()
  287. var appHash []byte
  288. var err error
  289. finalBlock := storeBlockHeight
  290. if mutateState {
  291. finalBlock -= 1
  292. }
  293. for i := appBlockHeight + 1; i <= finalBlock; i++ {
  294. h.logger.Info("Applying block", "height", i)
  295. block := h.store.LoadBlock(i)
  296. appHash, err = sm.ExecCommitBlock(proxyApp.Consensus(), block, h.logger)
  297. if err != nil {
  298. return nil, err
  299. }
  300. h.nBlocks += 1
  301. }
  302. if mutateState {
  303. // sync the final block
  304. state, err = h.replayBlock(state, storeBlockHeight, proxyApp.Consensus())
  305. if err != nil {
  306. return nil, err
  307. }
  308. appHash = state.AppHash
  309. }
  310. return appHash, checkAppHash(state, appHash)
  311. }
  312. // ApplyBlock on the proxyApp with the last block.
  313. func (h *Handshaker) replayBlock(state sm.State, height int64, proxyApp proxy.AppConnConsensus) (sm.State, error) {
  314. block := h.store.LoadBlock(height)
  315. meta := h.store.LoadBlockMeta(height)
  316. blockExec := sm.NewBlockExecutor(h.stateDB, h.logger, proxyApp, types.MockMempool{}, types.MockEvidencePool{})
  317. var err error
  318. state, err = blockExec.ApplyBlock(state, meta.BlockID, block)
  319. if err != nil {
  320. return sm.State{}, err
  321. }
  322. h.nBlocks += 1
  323. return state, nil
  324. }
  325. func checkAppHash(state sm.State, appHash []byte) error {
  326. if !bytes.Equal(state.AppHash, appHash) {
  327. panic(fmt.Errorf("Tendermint state.AppHash does not match AppHash after replay. Got %X, expected %X", appHash, state.AppHash).Error())
  328. }
  329. return nil
  330. }
  331. //--------------------------------------------------------------------------------
  332. // mockProxyApp uses ABCIResponses to give the right results
  333. // Useful because we don't want to call Commit() twice for the same block on the real app.
  334. func newMockProxyApp(appHash []byte, abciResponses *sm.ABCIResponses) proxy.AppConnConsensus {
  335. clientCreator := proxy.NewLocalClientCreator(&mockProxyApp{
  336. appHash: appHash,
  337. abciResponses: abciResponses,
  338. })
  339. cli, _ := clientCreator.NewABCIClient()
  340. err := cli.Start()
  341. if err != nil {
  342. panic(err)
  343. }
  344. return proxy.NewAppConnConsensus(cli)
  345. }
  346. type mockProxyApp struct {
  347. abci.BaseApplication
  348. appHash []byte
  349. txCount int
  350. abciResponses *sm.ABCIResponses
  351. }
  352. func (mock *mockProxyApp) DeliverTx(tx []byte) abci.ResponseDeliverTx {
  353. r := mock.abciResponses.DeliverTx[mock.txCount]
  354. mock.txCount += 1
  355. return *r
  356. }
  357. func (mock *mockProxyApp) EndBlock(req abci.RequestEndBlock) abci.ResponseEndBlock {
  358. mock.txCount = 0
  359. return *mock.abciResponses.EndBlock
  360. }
  361. func (mock *mockProxyApp) Commit() abci.ResponseCommit {
  362. return abci.ResponseCommit{Data: mock.appHash}
  363. }