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.

492 lines
16 KiB

7 years ago
6 years ago
6 years ago
6 years ago
6 years ago
8 years ago
8 years ago
8 years ago
8 years ago
6 years ago
6 years ago
6 years ago
6 years ago
8 years ago
8 years ago
6 years ago
8 years ago
8 years ago
8 years ago
7 years ago
7 years ago
6 years ago
6 years ago
6 years ago
6 years ago
8 years ago
6 years ago
6 years ago
6 years ago
6 years ago
8 years ago
6 years ago
6 years ago
8 years ago
7 years ago
8 years ago
8 years ago
8 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/tendermint/abci/types"
  12. //auto "github.com/tendermint/tendermint/libs/autofile"
  13. cmn "github.com/tendermint/tendermint/libs/common"
  14. dbm "github.com/tendermint/tendermint/libs/db"
  15. "github.com/tendermint/tendermint/libs/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:
  24. //
  25. // 1. failure during consensus
  26. // 2. failure while applying the block
  27. //
  28. // The former is handled by the WAL, the latter by the proxyApp Handshake on
  29. // restart, which ultimately hands off the work to the WAL.
  30. //-----------------------------------------
  31. // 1. Recover from failure during consensus
  32. // (by replaying messages from the WAL)
  33. //-----------------------------------------
  34. // Unmarshal and apply a single message to the consensus state as if it were
  35. // received in receiveRoutine. Lines that start with "#" are ignored.
  36. // NOTE: receiveRoutine should not be running.
  37. func (cs *ConsensusState) readReplayMessage(msg *TimedWALMessage, newStepCh chan interface{}) error {
  38. // Skip meta messages which exist for demarcating boundaries.
  39. if _, ok := msg.Msg.(EndHeightMessage); ok {
  40. return nil
  41. }
  42. // for logging
  43. switch m := msg.Msg.(type) {
  44. case types.EventDataRoundState:
  45. cs.Logger.Info("Replay: New Step", "height", m.Height, "round", m.Round, "step", m.Step)
  46. // these are playback checks
  47. ticker := time.After(time.Second * 2)
  48. if newStepCh != nil {
  49. select {
  50. case mi := <-newStepCh:
  51. m2 := mi.(types.EventDataRoundState)
  52. if m.Height != m2.Height || m.Round != m2.Round || m.Step != m2.Step {
  53. return fmt.Errorf("RoundState mismatch. Got %v; Expected %v", m2, m)
  54. }
  55. case <-ticker:
  56. return fmt.Errorf("Failed to read off newStepCh")
  57. }
  58. }
  59. case msgInfo:
  60. peerID := m.PeerID
  61. if peerID == "" {
  62. peerID = "local"
  63. }
  64. switch msg := m.Msg.(type) {
  65. case *ProposalMessage:
  66. p := msg.Proposal
  67. cs.Logger.Info("Replay: Proposal", "height", p.Height, "round", p.Round, "header",
  68. p.BlockID.PartsHeader, "pol", p.POLRound, "peer", peerID)
  69. case *BlockPartMessage:
  70. cs.Logger.Info("Replay: BlockPart", "height", msg.Height, "round", msg.Round, "peer", peerID)
  71. case *VoteMessage:
  72. v := msg.Vote
  73. cs.Logger.Info("Replay: Vote", "height", v.Height, "round", v.Round, "type", v.Type,
  74. "blockID", v.BlockID, "peer", peerID)
  75. }
  76. cs.handleMsg(m)
  77. case timeoutInfo:
  78. cs.Logger.Info("Replay: Timeout", "height", m.Height, "round", m.Round, "step", m.Step, "dur", m.Duration)
  79. cs.handleTimeout(m, cs.RoundState)
  80. default:
  81. return fmt.Errorf("Replay: Unknown TimedWALMessage type: %v", reflect.TypeOf(msg.Msg))
  82. }
  83. return nil
  84. }
  85. // Replay only those messages since the last block. `timeoutRoutine` should
  86. // run concurrently to read off tickChan.
  87. func (cs *ConsensusState) catchupReplay(csHeight int64) error {
  88. // Set replayMode to true so we don't log signing errors.
  89. cs.replayMode = true
  90. defer func() { cs.replayMode = false }()
  91. // Ensure that #ENDHEIGHT for this height doesn't exist.
  92. // NOTE: This is just a sanity check. As far as we know things work fine
  93. // without it, and Handshake could reuse ConsensusState if it weren't for
  94. // this check (since we can crash after writing #ENDHEIGHT).
  95. //
  96. // Ignore data corruption errors since this is a sanity check.
  97. gr, found, err := cs.wal.SearchForEndHeight(csHeight, &WALSearchOptions{IgnoreDataCorruptionErrors: true})
  98. if err != nil {
  99. return err
  100. }
  101. if gr != nil {
  102. if err := gr.Close(); err != nil {
  103. return err
  104. }
  105. }
  106. if found {
  107. return fmt.Errorf("WAL should not contain #ENDHEIGHT %d", csHeight)
  108. }
  109. // Search for last height marker.
  110. //
  111. // Ignore data corruption errors in previous heights because we only care about last height
  112. gr, found, err = cs.wal.SearchForEndHeight(csHeight-1, &WALSearchOptions{IgnoreDataCorruptionErrors: true})
  113. if err == io.EOF {
  114. cs.Logger.Error("Replay: wal.group.Search returned EOF", "#ENDHEIGHT", csHeight-1)
  115. } else if err != nil {
  116. return err
  117. }
  118. if !found {
  119. return fmt.Errorf("Cannot replay height %d. WAL does not contain #ENDHEIGHT for %d", csHeight, csHeight-1)
  120. }
  121. defer gr.Close() // nolint: errcheck
  122. cs.Logger.Info("Catchup by replaying consensus messages", "height", csHeight)
  123. var msg *TimedWALMessage
  124. dec := WALDecoder{gr}
  125. for {
  126. msg, err = dec.Decode()
  127. if err == io.EOF {
  128. break
  129. } else if IsDataCorruptionError(err) {
  130. cs.Logger.Debug("data has been corrupted in last height of consensus WAL", "err", err, "height", csHeight)
  131. panic(fmt.Sprintf("data has been corrupted (%v) in last height %d of consensus WAL", err, csHeight))
  132. } else if err != nil {
  133. return err
  134. }
  135. // NOTE: since the priv key is set when the msgs are received
  136. // it will attempt to eg double sign but we can just ignore it
  137. // since the votes will be replayed and we'll get to the next step
  138. if err := cs.readReplayMessage(msg, nil); err != nil {
  139. return err
  140. }
  141. }
  142. cs.Logger.Info("Replay: Done")
  143. return nil
  144. }
  145. //--------------------------------------------------------------------------------
  146. // Parses marker lines of the form:
  147. // #ENDHEIGHT: 12345
  148. /*
  149. func makeHeightSearchFunc(height int64) auto.SearchFunc {
  150. return func(line string) (int, error) {
  151. line = strings.TrimRight(line, "\n")
  152. parts := strings.Split(line, " ")
  153. if len(parts) != 2 {
  154. return -1, errors.New("Line did not have 2 parts")
  155. }
  156. i, err := strconv.Atoi(parts[1])
  157. if err != nil {
  158. return -1, errors.New("Failed to parse INFO: " + err.Error())
  159. }
  160. if height < i {
  161. return 1, nil
  162. } else if height == i {
  163. return 0, nil
  164. } else {
  165. return -1, nil
  166. }
  167. }
  168. }*/
  169. //---------------------------------------------------
  170. // 2. Recover from failure while applying the block.
  171. // (by handshaking with the app to figure out where
  172. // we were last, and using the WAL to recover there.)
  173. //---------------------------------------------------
  174. type Handshaker struct {
  175. stateDB dbm.DB
  176. initialState sm.State
  177. store sm.BlockStore
  178. genDoc *types.GenesisDoc
  179. logger log.Logger
  180. nBlocks int // number of blocks applied to the state
  181. }
  182. func NewHandshaker(stateDB dbm.DB, state sm.State,
  183. store sm.BlockStore, genDoc *types.GenesisDoc) *Handshaker {
  184. return &Handshaker{
  185. stateDB: stateDB,
  186. initialState: state,
  187. store: store,
  188. genDoc: genDoc,
  189. logger: log.NewNopLogger(),
  190. nBlocks: 0,
  191. }
  192. }
  193. func (h *Handshaker) SetLogger(l log.Logger) {
  194. h.logger = l
  195. }
  196. func (h *Handshaker) NBlocks() int {
  197. return h.nBlocks
  198. }
  199. // TODO: retry the handshake/replay if it fails ?
  200. func (h *Handshaker) Handshake(proxyApp proxy.AppConns) error {
  201. // Handshake is done via ABCI Info on the query conn.
  202. res, err := proxyApp.Query().InfoSync(proxy.RequestInfo)
  203. if err != nil {
  204. return fmt.Errorf("Error calling Info: %v", err)
  205. }
  206. blockHeight := int64(res.LastBlockHeight)
  207. if blockHeight < 0 {
  208. return fmt.Errorf("Got a negative last block height (%d) from the app", blockHeight)
  209. }
  210. appHash := res.LastBlockAppHash
  211. h.logger.Info("ABCI Handshake App Info",
  212. "height", blockHeight,
  213. "hash", fmt.Sprintf("%X", appHash),
  214. "software-version", res.Version,
  215. "protocol-version", res.AppVersion,
  216. )
  217. // Set AppVersion on the state.
  218. h.initialState.Version.Consensus.App = version.Protocol(res.AppVersion)
  219. sm.SaveState(h.stateDB, h.initialState)
  220. // Replay blocks up to the latest in the blockstore.
  221. _, err = h.ReplayBlocks(h.initialState, appHash, blockHeight, proxyApp)
  222. if err != nil {
  223. return fmt.Errorf("Error on replay: %v", err)
  224. }
  225. h.logger.Info("Completed ABCI Handshake - Tendermint and App are synced",
  226. "appHeight", blockHeight, "appHash", fmt.Sprintf("%X", appHash))
  227. // TODO: (on restart) replay mempool
  228. return nil
  229. }
  230. // Replay all blocks since appBlockHeight and ensure the result matches the current state.
  231. // Returns the final AppHash or an error.
  232. func (h *Handshaker) ReplayBlocks(
  233. state sm.State,
  234. appHash []byte,
  235. appBlockHeight int64,
  236. proxyApp proxy.AppConns,
  237. ) ([]byte, error) {
  238. storeBlockHeight := h.store.Height()
  239. stateBlockHeight := state.LastBlockHeight
  240. h.logger.Info("ABCI Replay Blocks", "appHeight", appBlockHeight, "storeHeight", storeBlockHeight, "stateHeight", stateBlockHeight)
  241. // If appBlockHeight == 0 it means that we are at genesis and hence should send InitChain.
  242. if appBlockHeight == 0 {
  243. validators := make([]*types.Validator, len(h.genDoc.Validators))
  244. for i, val := range h.genDoc.Validators {
  245. validators[i] = types.NewValidator(val.PubKey, val.Power)
  246. }
  247. validatorSet := types.NewValidatorSet(validators)
  248. nextVals := types.TM2PB.ValidatorUpdates(validatorSet)
  249. csParams := types.TM2PB.ConsensusParams(h.genDoc.ConsensusParams)
  250. req := abci.RequestInitChain{
  251. Time: h.genDoc.GenesisTime,
  252. ChainId: h.genDoc.ChainID,
  253. ConsensusParams: csParams,
  254. Validators: nextVals,
  255. AppStateBytes: h.genDoc.AppState,
  256. }
  257. res, err := proxyApp.Consensus().InitChainSync(req)
  258. if err != nil {
  259. return nil, err
  260. }
  261. if stateBlockHeight == 0 { //we only update state when we are in initial state
  262. // If the app returned validators or consensus params, update the state.
  263. if len(res.Validators) > 0 {
  264. vals, err := types.PB2TM.ValidatorUpdates(res.Validators)
  265. if err != nil {
  266. return nil, err
  267. }
  268. state.Validators = types.NewValidatorSet(vals)
  269. state.NextValidators = types.NewValidatorSet(vals)
  270. } else {
  271. // If validator set is not set in genesis and still empty after InitChain, exit.
  272. if len(h.genDoc.Validators) == 0 {
  273. return nil, fmt.Errorf("Validator set is nil in genesis and still empty after InitChain")
  274. }
  275. }
  276. if res.ConsensusParams != nil {
  277. state.ConsensusParams = types.PB2TM.ConsensusParams(res.ConsensusParams)
  278. }
  279. sm.SaveState(h.stateDB, state)
  280. }
  281. }
  282. // First handle edge cases and constraints on the storeBlockHeight.
  283. if storeBlockHeight == 0 {
  284. return appHash, checkAppHash(state, appHash)
  285. } else if storeBlockHeight < appBlockHeight {
  286. // the app should never be ahead of the store (but this is under app's control)
  287. return appHash, sm.ErrAppBlockHeightTooHigh{storeBlockHeight, appBlockHeight}
  288. } else if storeBlockHeight < stateBlockHeight {
  289. // the state should never be ahead of the store (this is under tendermint's control)
  290. cmn.PanicSanity(fmt.Sprintf("StateBlockHeight (%d) > StoreBlockHeight (%d)", stateBlockHeight, storeBlockHeight))
  291. } else if storeBlockHeight > stateBlockHeight+1 {
  292. // store should be at most one ahead of the state (this is under tendermint's control)
  293. cmn.PanicSanity(fmt.Sprintf("StoreBlockHeight (%d) > StateBlockHeight + 1 (%d)", storeBlockHeight, stateBlockHeight+1))
  294. }
  295. var err error
  296. // Now either store is equal to state, or one ahead.
  297. // For each, consider all cases of where the app could be, given app <= store
  298. if storeBlockHeight == stateBlockHeight {
  299. // Tendermint ran Commit and saved the state.
  300. // Either the app is asking for replay, or we're all synced up.
  301. if appBlockHeight < storeBlockHeight {
  302. // the app is behind, so replay blocks, but no need to go through WAL (state is already synced to store)
  303. return h.replayBlocks(state, proxyApp, appBlockHeight, storeBlockHeight, false)
  304. } else if appBlockHeight == storeBlockHeight {
  305. // We're good!
  306. return appHash, checkAppHash(state, appHash)
  307. }
  308. } else if storeBlockHeight == stateBlockHeight+1 {
  309. // We saved the block in the store but haven't updated the state,
  310. // so we'll need to replay a block using the WAL.
  311. if appBlockHeight < stateBlockHeight {
  312. // the app is further behind than it should be, so replay blocks
  313. // but leave the last block to go through the WAL
  314. return h.replayBlocks(state, proxyApp, appBlockHeight, storeBlockHeight, true)
  315. } else if appBlockHeight == stateBlockHeight {
  316. // We haven't run Commit (both the state and app are one block behind),
  317. // so replayBlock with the real app.
  318. // NOTE: We could instead use the cs.WAL on cs.Start,
  319. // but we'd have to allow the WAL to replay a block that wrote it's #ENDHEIGHT
  320. h.logger.Info("Replay last block using real app")
  321. state, err = h.replayBlock(state, storeBlockHeight, proxyApp.Consensus())
  322. return state.AppHash, err
  323. } else if appBlockHeight == storeBlockHeight {
  324. // We ran Commit, but didn't save the state, so replayBlock with mock app
  325. abciResponses, err := sm.LoadABCIResponses(h.stateDB, storeBlockHeight)
  326. if err != nil {
  327. return nil, err
  328. }
  329. mockApp := newMockProxyApp(appHash, abciResponses)
  330. h.logger.Info("Replay last block using mock app")
  331. state, err = h.replayBlock(state, storeBlockHeight, mockApp)
  332. return state.AppHash, err
  333. }
  334. }
  335. cmn.PanicSanity("Should never happen")
  336. return nil, nil
  337. }
  338. func (h *Handshaker) replayBlocks(state sm.State, proxyApp proxy.AppConns, appBlockHeight, storeBlockHeight int64, mutateState bool) ([]byte, error) {
  339. // App is further behind than it should be, so we need to replay blocks.
  340. // We replay all blocks from appBlockHeight+1.
  341. //
  342. // Note that we don't have an old version of the state,
  343. // so we by-pass state validation/mutation using sm.ExecCommitBlock.
  344. // This also means we won't be saving validator sets if they change during this period.
  345. // TODO: Load the historical information to fix this and just use state.ApplyBlock
  346. //
  347. // If mutateState == true, the final block is replayed with h.replayBlock()
  348. var appHash []byte
  349. var err error
  350. finalBlock := storeBlockHeight
  351. if mutateState {
  352. finalBlock--
  353. }
  354. for i := appBlockHeight + 1; i <= finalBlock; i++ {
  355. h.logger.Info("Applying block", "height", i)
  356. block := h.store.LoadBlock(i)
  357. appHash, err = sm.ExecCommitBlock(proxyApp.Consensus(), block, h.logger, state.LastValidators, h.stateDB)
  358. if err != nil {
  359. return nil, err
  360. }
  361. h.nBlocks++
  362. }
  363. if mutateState {
  364. // sync the final block
  365. state, err = h.replayBlock(state, storeBlockHeight, proxyApp.Consensus())
  366. if err != nil {
  367. return nil, err
  368. }
  369. appHash = state.AppHash
  370. }
  371. return appHash, checkAppHash(state, appHash)
  372. }
  373. // ApplyBlock on the proxyApp with the last block.
  374. func (h *Handshaker) replayBlock(state sm.State, height int64, proxyApp proxy.AppConnConsensus) (sm.State, error) {
  375. block := h.store.LoadBlock(height)
  376. meta := h.store.LoadBlockMeta(height)
  377. blockExec := sm.NewBlockExecutor(h.stateDB, h.logger, proxyApp, sm.MockMempool{}, sm.MockEvidencePool{})
  378. var err error
  379. state, err = blockExec.ApplyBlock(state, meta.BlockID, block)
  380. if err != nil {
  381. return sm.State{}, err
  382. }
  383. h.nBlocks++
  384. return state, nil
  385. }
  386. func checkAppHash(state sm.State, appHash []byte) error {
  387. if !bytes.Equal(state.AppHash, appHash) {
  388. panic(fmt.Errorf("Tendermint state.AppHash does not match AppHash after replay. Got %X, expected %X", appHash, state.AppHash).Error())
  389. }
  390. return nil
  391. }
  392. //--------------------------------------------------------------------------------
  393. // mockProxyApp uses ABCIResponses to give the right results
  394. // Useful because we don't want to call Commit() twice for the same block on the real app.
  395. func newMockProxyApp(appHash []byte, abciResponses *sm.ABCIResponses) proxy.AppConnConsensus {
  396. clientCreator := proxy.NewLocalClientCreator(&mockProxyApp{
  397. appHash: appHash,
  398. abciResponses: abciResponses,
  399. })
  400. cli, _ := clientCreator.NewABCIClient()
  401. err := cli.Start()
  402. if err != nil {
  403. panic(err)
  404. }
  405. return proxy.NewAppConnConsensus(cli)
  406. }
  407. type mockProxyApp struct {
  408. abci.BaseApplication
  409. appHash []byte
  410. txCount int
  411. abciResponses *sm.ABCIResponses
  412. }
  413. func (mock *mockProxyApp) DeliverTx(tx []byte) abci.ResponseDeliverTx {
  414. r := mock.abciResponses.DeliverTx[mock.txCount]
  415. mock.txCount++
  416. return *r
  417. }
  418. func (mock *mockProxyApp) EndBlock(req abci.RequestEndBlock) abci.ResponseEndBlock {
  419. mock.txCount = 0
  420. return *mock.abciResponses.EndBlock
  421. }
  422. func (mock *mockProxyApp) Commit() abci.ResponseCommit {
  423. return abci.ResponseCommit{Data: mock.appHash}
  424. }