OSDN Git Service

Fix mining (#113)
[bytom/vapor.git] / protocol / consensus_node_manager.go
index d116eb0..675b680 100644 (file)
@@ -2,28 +2,30 @@ package protocol
 
 import (
        "encoding/hex"
-       "fmt"
        "sort"
-       "sync"
-       "time"
 
+       "github.com/vapor/config"
        "github.com/vapor/errors"
+       "github.com/vapor/math/checked"
+       "github.com/vapor/protocol/bc"
+       "github.com/vapor/protocol/bc/types"
        "github.com/vapor/protocol/state"
 )
 
 const (
-       numOfConsensusNode = 21
-       roundVoteBlockNums = 1000
-
-       // product one block per 500 milliseconds
-       blockTimeInterval = 500
-       blockNumEachNode  = 3
+       NumOfConsensusNode = 21
+       RoundVoteBlockNums = 1000
+       MinVoteNum         = 5000000
+
+       // BlockTimeInterval indicate product one block per 500 milliseconds
+       BlockTimeInterval = 500
+       // BlockNumEachNode indicate product three blocks per node in succession
+       BlockNumEachNode = 3
 )
 
 var (
-       errHasNoChanceProductBlock  = errors.New("the node has no chance to product a block in this round of voting")
-       errNotFoundConsensusNode    = errors.New("can not found consensus node")
-       errVoteResultIsNotfinalized = errors.New("vote result is not finalized")
+       errNotFoundConsensusNode = errors.New("can not found consensus node")
+       errNotFoundBlockNode     = errors.New("can not find block node")
 )
 
 type consensusNode struct {
@@ -39,156 +41,119 @@ func (c consensusNodeSlice) Less(i, j int) bool { return c[i].voteNum > c[j].vot
 func (c consensusNodeSlice) Swap(i, j int)      { c[i], c[j] = c[j], c[i] }
 
 type consensusNodeManager struct {
-       consensusNodeMap     map[string]*consensusNode
-       effectiveStartHeight uint64
-       store                Store
-       blockIndex           *state.BlockIndex
-       sync.RWMutex
+       store      Store
+       blockIndex *state.BlockIndex
 }
 
 func newConsensusNodeManager(store Store, blockIndex *state.BlockIndex) *consensusNodeManager {
        return &consensusNodeManager{
-               consensusNodeMap:     make(map[string]*consensusNode),
-               effectiveStartHeight: 1,
-               store:                store,
-               blockIndex:           blockIndex,
+               store:      store,
+               blockIndex: blockIndex,
        }
 }
 
-func (c *consensusNodeManager) getConsensusNode(height uint64, pubkey string) (*consensusNode, error) {
-       defer c.RUnlock()
-       c.RLock()
-       if height >= c.effectiveStartHeight+roundVoteBlockNums {
-               return nil, errors.New("the vote has not been completed for the specified block height ")
-       }
-
-       var err error
-       consensusNodeMap := c.consensusNodeMap
-       // query history vote result
-       if height < c.effectiveStartHeight {
-               consensusNodeMap, err = c.getConsensusNodesByVoteResult(height)
-               if err != nil {
-                       return nil, err
-               }
+func (c *consensusNodeManager) getConsensusNode(prevBlockHash *bc.Hash, pubkey string) (*consensusNode, error) {
+       consensusNodeMap, err := c.getConsensusNodesByVoteResult(prevBlockHash)
+       if err != nil {
+               return nil, err
        }
 
        node, exist := consensusNodeMap[pubkey]
        if !exist {
-               return node, errNotFoundConsensusNode
+               return nil, errNotFoundConsensusNode
        }
        return node, nil
 }
 
-func (c *consensusNodeManager) isBlocker(height uint64, blockTimestamp uint64, pubkey string) (bool, error) {
-       prevVoteRoundLastBlock := c.blockIndex.NodeByHeight(height - 1)
-       startTimestamp := prevVoteRoundLastBlock.Timestamp + blockTimeInterval
-
-       consensusNodeMap, err := c.getConsensusNodesByVoteResult(height)
-       if err != nil {
+func (c *consensusNodeManager) isBlocker(prevBlockHash *bc.Hash, pubKey string, timeStamp uint64) (bool, error) {
+       consensusNode, err := c.getConsensusNode(prevBlockHash, pubKey)
+       if err != nil && err != errNotFoundConsensusNode {
                return false, err
        }
 
-       blockerNode, exist := consensusNodeMap[pubkey]
-       if !exist {
+       if consensusNode == nil {
                return false, nil
        }
 
-       begin := getLastBlockTimeInTimeRange(startTimestamp, blockTimestamp, blockerNode.order)
-       end := begin + blockNumEachNode*blockTimeInterval
-       return blockTimestamp >= begin && blockTimestamp < end, nil
-}
-
-func (c *consensusNodeManager) nextLeaderTime(pubkey []byte, bestBlockTimestamp, bestBlockHeight uint64) (*time.Time, error) {
-       defer c.RUnlock()
-       c.RLock()
-
-       startHeight := c.effectiveStartHeight
-       prevRoundLastBlock := c.blockIndex.NodeByHeight(startHeight - 1)
-       startTime := prevRoundLastBlock.Timestamp + blockTimeInterval
-       endTime := bestBlockTimestamp + (roundVoteBlockNums-bestBlockHeight%roundVoteBlockNums)*blockTimeInterval
-
-       consensusNode, exist := c.consensusNodeMap[hex.EncodeToString(pubkey)]
-       if !exist {
-               return nil, fmt.Errorf("pubkey:%s is not consensus node", hex.EncodeToString(pubkey))
-       }
-
-       nextLeaderTime, err := nextLeaderTimeHelper(startTime, endTime, uint64(time.Now().UnixNano()/1e6), consensusNode.order)
+       prevVoteRoundLastBlock, err := c.getPrevRoundVoteLastBlock(prevBlockHash)
        if err != nil {
-               return nil, err
+               return false, err
        }
 
-       return nextLeaderTime, nil
+       startTimestamp := prevVoteRoundLastBlock.Timestamp + BlockTimeInterval
+       begin := getLastBlockTimeInTimeRange(startTimestamp, timeStamp, consensusNode.order)
+       end := begin + BlockNumEachNode*BlockTimeInterval
+       return timeStamp >= begin && timeStamp < end, nil
 }
 
-func nextLeaderTimeHelper(startTime, endTime, now, nodeOrder uint64) (*time.Time, error) {
-       nextLeaderTimestamp := getLastBlockTimeInTimeRange(startTime, now, nodeOrder)
-       roundBlockTime := uint64(blockNumEachNode * numOfConsensusNode * blockTimeInterval)
+func getLastBlockTimeInTimeRange(startTimestamp, endTimestamp, order uint64) uint64 {
+       // One round of product block time for all consensus nodes
+       roundBlockTime := uint64(BlockNumEachNode * NumOfConsensusNode * BlockTimeInterval)
+       // The start time of the last round of product block
+       lastRoundStartTime := startTimestamp + (endTimestamp-startTimestamp)/roundBlockTime*roundBlockTime
+       // The time of product block of the consensus in last round
+       return lastRoundStartTime + order*(BlockNumEachNode*BlockTimeInterval)
+}
 
-       if int64(now-nextLeaderTimestamp) >= blockNumEachNode*blockTimeInterval {
-               nextLeaderTimestamp += roundBlockTime
-               if nextLeaderTimestamp >= endTime {
-                       return nil, errHasNoChanceProductBlock
-               }
+func (c *consensusNodeManager) getPrevRoundVoteLastBlock(prevBlockHash *bc.Hash) (*state.BlockNode, error) {
+       prevBlockNode := c.blockIndex.GetNode(prevBlockHash)
+       if prevBlockNode == nil {
+               return nil, errNotFoundBlockNode
        }
 
-       nextLeaderTime := time.Unix(int64(nextLeaderTimestamp)/1000, (int64(nextLeaderTimestamp)%1000)*1e6)
-       return &nextLeaderTime, nil
-}
-
-// updateConsensusNodes used to update consensus node after each round of voting
-func (c *consensusNodeManager) updateConsensusNodes(bestBlockHeight uint64) error {
-       defer c.Unlock()
-       c.Lock()
+       blockHeight := prevBlockNode.Height + 1
 
-       consensusNodeMap, err := c.getConsensusNodesByVoteResult(bestBlockHeight)
-       if err != nil && err != errVoteResultIsNotfinalized {
-               return err
+       prevVoteRoundLastBlockHeight := blockHeight/RoundVoteBlockNums*RoundVoteBlockNums - 1
+       // first round
+       if blockHeight/RoundVoteBlockNums == 0 {
+               prevVoteRoundLastBlockHeight = 0
        }
 
-       if err == errVoteResultIsNotfinalized {
-               return nil
+       lastBlockNode := prevBlockNode.GetParent(prevVoteRoundLastBlockHeight)
+       if lastBlockNode == nil {
+               return nil, errNotFoundBlockNode
        }
-
-       c.consensusNodeMap = consensusNodeMap
-       c.effectiveStartHeight = bestBlockHeight / roundVoteBlockNums * roundVoteBlockNums
-       return nil
+       return lastBlockNode, nil
 }
 
-func getLastBlockTimeInTimeRange(startTimestamp, endTimestamp, order uint64) uint64 {
-       // One round of product block time for all consensus nodes
-       roundBlockTime := uint64(blockNumEachNode * numOfConsensusNode * blockTimeInterval)
-       // The start time of the last round of product block
-       lastRoundStartTime := startTimestamp + (endTimestamp-startTimestamp)/roundBlockTime*roundBlockTime
-       // The time of product block of the consensus in last round
-       return lastRoundStartTime + order*(blockNumEachNode*blockTimeInterval)
-}
-
-func (c *consensusNodeManager) getConsensusNodesByVoteResult(blockHeight uint64) (map[string]*consensusNode, error) {
-       defer c.RUnlock()
-       c.RLock()
-       if blockHeight >= c.effectiveStartHeight+roundVoteBlockNums {
-               return nil, errors.New("the given block height is greater than current vote start height")
+func (c *consensusNodeManager) getConsensusNodesByVoteResult(prevBlockHash *bc.Hash) (map[string]*consensusNode, error) {
+       prevBlockNode := c.blockIndex.GetNode(prevBlockHash)
+       if prevBlockNode == nil {
+               return nil, errNotFoundBlockNode
        }
 
-       if blockHeight >= c.effectiveStartHeight {
-               return c.consensusNodeMap, nil
+       seq := (prevBlockNode.Height + 1) / RoundVoteBlockNums
+       voteResult, err := c.store.GetVoteResult(seq)
+       if err != nil {
+               // TODO find previous round vote
+               voteResult = &state.VoteResult{
+                       Seq:       seq,
+                       NumOfVote: make(map[string]uint64),
+                       Finalized: false,
+               }
        }
 
-       voteResult, err := c.store.GetVoteResult(blockHeight / roundVoteBlockNums)
+       lastBlockNode, err := c.getPrevRoundVoteLastBlock(prevBlockHash)
        if err != nil {
                return nil, err
        }
 
-       if !voteResult.Finalized {
-               return nil, errVoteResultIsNotfinalized
+       if err := c.reorganizeVoteResult(voteResult, lastBlockNode); err != nil {
+               return nil, err
+       }
+
+       if len(voteResult.NumOfVote) == 0 {
+               return initConsensusNodes(), nil
        }
 
        var nodes []*consensusNode
        for pubkey, voteNum := range voteResult.NumOfVote {
-               nodes = append(nodes, &consensusNode{
-                       pubkey:  pubkey,
-                       voteNum: voteNum,
-               })
+               if voteNum >= MinVoteNum {
+                       nodes = append(nodes, &consensusNode{
+                               pubkey:  pubkey,
+                               voteNum: voteNum,
+                       })
+               }
        }
        // In principle, there is no need to sort all voting nodes.
        // if there is a performance problem, consider the optimization later.
@@ -196,10 +161,213 @@ func (c *consensusNodeManager) getConsensusNodesByVoteResult(blockHeight uint64)
        sort.Sort(consensusNodeSlice(nodes))
 
        result := make(map[string]*consensusNode)
-       for i := 0; i < numOfConsensusNode; i++ {
+       for i := 0; i < len(nodes) && i < NumOfConsensusNode; i++ {
                node := nodes[i]
                node.order = uint64(i)
                result[node.pubkey] = node
        }
        return result, nil
 }
+
+func (c *consensusNodeManager) reorganizeVoteResult(voteResult *state.VoteResult, forkChainNode *state.BlockNode) error {
+       genesisBlockHash := config.GenesisBlock().Hash()
+       mainChainNode := c.blockIndex.GetNode(&genesisBlockHash)
+
+       emptyHash := bc.Hash{}
+       if voteResult.LastBlockHash != emptyHash {
+               mainChainNode = c.blockIndex.GetNode(&voteResult.LastBlockHash)
+               if mainChainNode == nil {
+                       return errNotFoundBlockNode
+               }
+       }
+
+       var attachNodes []*state.BlockNode
+       var detachNodes []*state.BlockNode
+
+       for forkChainNode != nil && mainChainNode != nil && forkChainNode.Hash != mainChainNode.Hash {
+               if forkChainNode.Height == mainChainNode.Height {
+                       detachNodes = append(detachNodes, mainChainNode)
+                       mainChainNode = mainChainNode.Parent
+               }
+               attachNodes = append([]*state.BlockNode{forkChainNode}, attachNodes...)
+               forkChainNode = forkChainNode.Parent
+       }
+
+       for _, node := range detachNodes {
+               block, err := c.store.GetBlock(&node.Hash)
+               if err != nil {
+                       return err
+               }
+
+               if err := c.detachBlock(map[uint64]*state.VoteResult{voteResult.Seq: voteResult}, block); err != nil {
+                       return err
+               }
+       }
+
+       for _, node := range attachNodes {
+               block, err := c.store.GetBlock(&node.Hash)
+               if err != nil {
+                       return err
+               }
+
+               if err := c.applyBlock(map[uint64]*state.VoteResult{voteResult.Seq: voteResult}, block); err != nil {
+                       return err
+               }
+       }
+       return nil
+}
+
+func (c *consensusNodeManager) applyBlock(voteResultMap map[uint64]*state.VoteResult, block *types.Block) (err error) {
+       voteResult, err := c.getVoteResult(voteResultMap, block.Height)
+       if err != nil {
+               return err
+       }
+
+       emptyHash := bc.Hash{}
+       if voteResult.LastBlockHash != emptyHash && voteResult.LastBlockHash != block.PreviousBlockHash {
+               return errors.New("bbft append block error, the block parent hash is not equals last block hash of vote result")
+       }
+
+       for _, tx := range block.Transactions {
+               for _, input := range tx.Inputs {
+                       unVoteInput, ok := input.TypedInput.(*types.UnvoteInput)
+                       if !ok {
+                               continue
+                       }
+
+                       pubkey := hex.EncodeToString(unVoteInput.Vote)
+                       voteResult.NumOfVote[pubkey], ok = checked.SubUint64(voteResult.NumOfVote[pubkey], unVoteInput.Amount)
+                       if !ok {
+                               return errVotingOperationOverFlow
+                       }
+               }
+               for _, output := range tx.Outputs {
+                       voteOutput, ok := output.TypedOutput.(*types.VoteTxOutput)
+                       if !ok {
+                               continue
+                       }
+
+                       pubkey := hex.EncodeToString(voteOutput.Vote)
+                       voteResult.NumOfVote[pubkey], ok = checked.AddUint64(voteResult.NumOfVote[pubkey], voteOutput.Amount)
+                       if !ok {
+                               return errVotingOperationOverFlow
+                       }
+               }
+       }
+
+       voteResult.Finalized = (block.Height+1)%RoundVoteBlockNums == 0
+       return nil
+}
+
+func (c *consensusNodeManager) getVoteResult(voteResultMap map[uint64]*state.VoteResult, blockHeight uint64) (*state.VoteResult, error) {
+       var err error
+       // This round of voting prepares for the next round
+       seq := blockHeight/RoundVoteBlockNums + 1
+       voteResult := voteResultMap[seq]
+       if blockHeight == 0 {
+               voteResult = &state.VoteResult{
+                       Seq:       seq,
+                       NumOfVote: make(map[string]uint64),
+                       Finalized: false,
+               }
+       }
+
+       if voteResult == nil {
+               prevVoteResult := voteResultMap[seq-1]
+               if prevVoteResult != nil {
+                       voteResult = &state.VoteResult{
+                               Seq:       seq,
+                               NumOfVote: prevVoteResult.NumOfVote,
+                               Finalized: false,
+                       }
+               }
+       }
+
+       if voteResult == nil {
+               voteResult, err = c.store.GetVoteResult(seq)
+               if err != nil && err != ErrNotFoundVoteResult {
+                       return nil, err
+               }
+       }
+
+       if voteResult == nil {
+               voteResult, err = c.store.GetVoteResult(seq - 1)
+               if err != nil && err != ErrNotFoundVoteResult {
+                       return nil, err
+               }
+
+               if voteResult != nil {
+                       // previous round voting must have finalized
+                       if !voteResult.Finalized {
+                               return nil, errors.New("previous round voting has not finalized")
+                       }
+
+                       voteResult.Seq = seq
+                       voteResult.Finalized = false
+                       voteResult.LastBlockHash = bc.Hash{}
+               }
+       }
+
+       if voteResult == nil {
+               return nil, errors.New("fail to get vote result")
+       }
+
+       voteResultMap[seq] = voteResult
+       return voteResult, nil
+}
+
+func (c *consensusNodeManager) detachBlock(voteResultMap map[uint64]*state.VoteResult, block *types.Block) error {
+       voteSeq := block.Height / RoundVoteBlockNums
+       voteResult := voteResultMap[voteSeq]
+
+       if voteResult == nil {
+               voteResult, err := c.store.GetVoteResult(voteSeq)
+               if err != nil {
+                       return err
+               }
+               voteResultMap[voteSeq] = voteResult
+       }
+
+       if voteResult.LastBlockHash != block.Hash() {
+               return errors.New("bbft detach block error, the block hash is not equals last block hash of vote result")
+       }
+
+       for _, tx := range block.Transactions {
+               for _, input := range tx.Inputs {
+                       unVoteInput, ok := input.TypedInput.(*types.UnvoteInput)
+                       if !ok {
+                               continue
+                       }
+
+                       pubkey := hex.EncodeToString(unVoteInput.Vote)
+                       voteResult.NumOfVote[pubkey], ok = checked.AddUint64(voteResult.NumOfVote[pubkey], unVoteInput.Amount)
+                       if !ok {
+                               return errVotingOperationOverFlow
+                       }
+               }
+               for _, output := range tx.Outputs {
+                       voteOutput, ok := output.TypedOutput.(*types.VoteTxOutput)
+                       if !ok {
+                               continue
+                       }
+
+                       pubkey := hex.EncodeToString(voteOutput.Vote)
+                       voteResult.NumOfVote[pubkey], ok = checked.SubUint64(voteResult.NumOfVote[pubkey], voteOutput.Amount)
+                       if !ok {
+                               return errVotingOperationOverFlow
+                       }
+               }
+       }
+
+       voteResult.Finalized = false
+       return nil
+}
+
+func initConsensusNodes() map[string]*consensusNode {
+       voteResult := map[string]*consensusNode{}
+       for i, pubkey := range config.CommonConfig.Federation.Xpubs {
+               pubkeyStr := pubkey.String()
+               voteResult[pubkeyStr] = &consensusNode{pubkey: pubkeyStr, voteNum: 0, order: uint64(i)}
+       }
+       return voteResult
+}