OSDN Git Service

fix detach vote (#164)
[bytom/vapor.git] / protocol / bbft.go
index d0049b5..a0e133b 100644 (file)
@@ -4,12 +4,9 @@ import (
        "encoding/hex"
        "fmt"
 
-       "github.com/golang/groupcache/lru"
        log "github.com/sirupsen/logrus"
 
        "github.com/vapor/config"
-       "github.com/vapor/crypto/ed25519"
-       "github.com/vapor/crypto/ed25519/chainkd"
        "github.com/vapor/errors"
        "github.com/vapor/event"
        "github.com/vapor/protocol/bc"
@@ -25,244 +22,206 @@ var (
        errVotingOperationOverFlow = errors.New("voting operation result overflow")
        errDoubleSignBlock         = errors.New("the consensus is double sign in same height of different block")
        errInvalidSignature        = errors.New("the signature of block is invalid")
+       errSignForkChain           = errors.New("can not sign fork before the irreversible block")
 )
 
-type bbft struct {
-       consensusNodeManager *consensusNodeManager
-       orphanManage         *OrphanManage
-       signatureCache       *lru.Cache
-       eventDispatcher      *event.Dispatcher
+func signCacheKey(blockHash, pubkey string) string {
+       return fmt.Sprintf("%s:%s", blockHash, pubkey)
 }
 
-func newBbft(store Store, blockIndex *state.BlockIndex, orphanManage *OrphanManage, eventDispatcher *event.Dispatcher) *bbft {
-       return &bbft{
-               orphanManage:         orphanManage,
-               consensusNodeManager: newConsensusNodeManager(store, blockIndex),
-               signatureCache:       lru.New(maxSignatureCacheSize),
-               eventDispatcher:      eventDispatcher,
-       }
-}
-
-func (b *bbft) isIrreversible(block *types.Block) bool {
-       consensusNodes, err := b.consensusNodeManager.getConsensusNodesByVoteResult(&block.PreviousBlockHash)
+func (c *Chain) isIrreversible(blockNode *state.BlockNode) bool {
+       consensusNodes, err := c.consensusNodeManager.getConsensusNodes(&blockNode.Parent.Hash)
        if err != nil {
                return false
        }
 
-       signNum, err := b.validateSign(block)
-       if err != nil {
-               return false
+       signCount := 0
+       for i := 0; i < len(consensusNodes); i++ {
+               if ok, _ := blockNode.BlockWitness.Test(uint32(i)); ok {
+                       signCount++
+               }
        }
 
-       return signNum > (uint64(len(consensusNodes)) * 2 / 3)
+       return signCount > len(consensusNodes)*2/3
 }
 
 // NextLeaderTime returns the start time of the specified public key as the next leader node
-func (b *bbft) IsBlocker(prevBlockHash *bc.Hash, pubkey string, timeStamp uint64) (bool, error) {
-       return b.consensusNodeManager.isBlocker(prevBlockHash, pubkey, timeStamp)
-}
-
-func (b *bbft) ApplyBlock(voteResultMap map[uint64]*state.VoteResult, block *types.Block) (err error) {
-       return b.consensusNodeManager.applyBlock(voteResultMap, block)
-}
-
-func (b *bbft) DetachBlock(voteResultMap map[uint64]*state.VoteResult, block *types.Block) error {
-       return b.consensusNodeManager.detachBlock(voteResultMap, block)
+func (c *Chain) IsBlocker(prevBlockHash *bc.Hash, pubkey string, timeStamp uint64) (bool, error) {
+       return c.consensusNodeManager.isBlocker(prevBlockHash, pubkey, timeStamp)
 }
 
 // ProcessBlockSignature process the received block signature messages
 // return whether a block become irreversible, if so, the chain module must update status
-func (b *bbft) ProcessBlockSignature(signature []byte, xPub [64]byte, blockHeight uint64, blockHash *bc.Hash) (bool, error) {
-       block, err := b.consensusNodeManager.store.GetBlock(blockHash)
-       if err != nil {
-               // block is not exist, save the signature
-               key := fmt.Sprintf("%s:%s", blockHash.String(), hex.EncodeToString(xPub[:]))
-               b.signatureCache.Add(key, signature)
-               return false, err
+func (c *Chain) ProcessBlockSignature(signature, xPub []byte, blockHash *bc.Hash) error {
+       xpubStr := hex.EncodeToString(xPub[:])
+       blockNode := c.index.GetNode(blockHash)
+       // save the signature if the block is not exist
+       if blockNode == nil {
+               cacheKey := signCacheKey(blockHash.String(), xpubStr)
+               c.signatureCache.Add(cacheKey, signature)
+               return nil
        }
 
-       consensusNode, err := b.consensusNodeManager.getConsensusNode(&block.PreviousBlockHash, hex.EncodeToString(xPub[:]))
+       consensusNode, err := c.consensusNodeManager.getConsensusNode(&blockNode.Parent.Hash, xpubStr)
        if err != nil {
-               return false, err
-       }
-
-       if chainkd.XPub(xPub).Verify(blockHash.Bytes(), signature) {
-               return false, errInvalidSignature
-       }
-
-       isDoubleSign, err := b.checkDoubleSign(consensusNode.order, blockHeight, *blockHash)
-       if err != nil {
-               return false, err
-       }
-
-       if isDoubleSign {
-               log.WithFields(log.Fields{"module": logModule, "blockHash": blockHash.String(), "xPub": hex.EncodeToString(xPub[:])}).Warn("the consensus node double sign the same height of different block")
-               return false, errDoubleSignBlock
-       }
-
-       orphanBlock, ok := b.orphanManage.Get(blockHash)
-       if ok {
-               orphanBlock.Witness[consensusNode.order] = signature
-               return false, nil
+               return err
        }
 
-       if err := b.updateBlockSignature(block, consensusNode.order, signature); err != nil {
-               return false, err
+       if exist, _ := blockNode.BlockWitness.Test(uint32(consensusNode.Order)); exist {
+               return nil
        }
 
-       return b.isIrreversible(block), nil
-}
-
-// ValidateBlock verify whether the block is valid
-func (b *bbft) ValidateBlock(block *types.Block) error {
-       signNum, err := b.validateSign(block)
-       if err != nil {
+       c.cond.L.Lock()
+       defer c.cond.L.Unlock()
+       if err := c.checkNodeSign(blockNode.BlockHeader(), consensusNode, signature); err != nil {
                return err
        }
 
-       if signNum == 0 {
-               return errors.New("no valid signature")
+       if err := c.updateBlockSignature(blockNode, consensusNode.Order, signature); err != nil {
+               return err
        }
-       return nil
+       return c.eventDispatcher.Post(event.BlockSignatureEvent{BlockHash: *blockHash, Signature: signature, XPub: xPub})
 }
 
 // validateSign verify the signatures of block, and return the number of correct signature
 // if some signature is invalid, they will be reset to nil
 // if the block has not the signature of blocker, it will return error
-func (b *bbft) validateSign(block *types.Block) (uint64, error) {
-       var correctSignNum uint64
-       consensusNodeMap, err := b.consensusNodeManager.getConsensusNodesByVoteResult(&block.PreviousBlockHash)
+func (c *Chain) validateSign(block *types.Block) error {
+       consensusNodeMap, err := c.consensusNodeManager.getConsensusNodes(&block.PreviousBlockHash)
        if err != nil {
-               return 0, err
+               return err
        }
 
        hasBlockerSign := false
+       blockHash := block.Hash()
        for pubKey, node := range consensusNodeMap {
-               if len(block.Witness) <= int(node.order) {
+               if len(block.Witness) <= int(node.Order) {
                        continue
                }
 
-               blockHash := block.Hash()
-               if block.Witness[node.order] == nil {
-                       key := fmt.Sprintf("%s:%s", blockHash.String(), pubKey)
-                       signature, ok := b.signatureCache.Get(key)
-                       if ok {
-                               block.Witness[node.order] = signature.([]byte)
+               if block.Witness[node.Order] == nil {
+                       cachekey := signCacheKey(blockHash.String(), pubKey)
+                       if signature, ok := c.signatureCache.Get(cachekey); ok {
+                               block.Witness[node.Order] = signature.([]byte)
+                       } else {
+                               continue
                        }
                }
 
-               pubKeyBytes, err := hex.DecodeString(pubKey)
-               if err != nil {
-                       return 0, err
+               if err := c.checkNodeSign(&block.BlockHeader, node, block.Witness[node.Order]); err == errDoubleSignBlock {
+                       log.WithFields(log.Fields{"module": logModule, "blockHash": blockHash.String(), "pubKey": pubKey}).Warn("the consensus node double sign the same height of different block")
+                       block.Witness[node.Order] = nil
+                       continue
+               } else if err != nil {
+                       return err
                }
 
-               if ed25519.Verify(ed25519.PublicKey(pubKeyBytes[:32]), blockHash.Bytes(), block.Witness[node.order]) {
-                       isDoubleSign, err := b.checkDoubleSign(node.order, block.Height, block.Hash())
-                       if err != nil {
-                               return 0, err
-                       }
+               isBlocker, err := c.consensusNodeManager.isBlocker(&block.PreviousBlockHash, pubKey, block.Timestamp)
+               if err != nil {
+                       return err
+               }
 
-                       if isDoubleSign {
-                               log.WithFields(log.Fields{"module": logModule, "blockHash": blockHash.String(), "pubKey": pubKey}).Warn("the consensus node double sign the same height of different block")
-                               // Consensus node is signed twice with the same block height, discard the signature
-                               block.Witness[node.order] = nil
-                       } else {
-                               correctSignNum++
-                               isBlocker, err := b.consensusNodeManager.isBlocker(&block.PreviousBlockHash, pubKey, block.Timestamp)
-                               if err != nil {
-                                       return 0, err
-                               }
-                               if isBlocker {
-                                       hasBlockerSign = true
-                               }
-                       }
-               } else {
-                       // discard the invalid signature
-                       block.Witness[node.order] = nil
+               if isBlocker {
+                       hasBlockerSign = true
                }
+
        }
+
        if !hasBlockerSign {
-               return 0, errors.New("the block has no signature of the blocker")
+               return errors.New("the block has no signature of the blocker")
        }
-       return correctSignNum, nil
+       return nil
 }
 
-func (b *bbft) checkDoubleSign(nodeOrder, blockHeight uint64, blockHash bc.Hash) (bool, error) {
-       blockNodes := b.consensusNodeManager.blockIndex.NodesByHeight(blockHeight)
+func (c *Chain) checkNodeSign(bh *types.BlockHeader, consensusNode *state.ConsensusNode, signature []byte) error {
+       if !consensusNode.XPub.Verify(bh.Hash().Bytes(), signature) {
+               return errInvalidSignature
+       }
+
+       blockNodes := c.consensusNodeManager.blockIndex.NodesByHeight(bh.Height)
        for _, blockNode := range blockNodes {
-               if blockNode.Hash == blockHash {
+               if blockNode.Hash == bh.Hash() {
                        continue
                }
-               if ok, err := blockNode.BlockWitness.Test(uint32(nodeOrder)); err != nil && ok {
-                       block, err := b.consensusNodeManager.store.GetBlock(&blockHash)
-                       if err != nil {
-                               return false, err
-                       }
 
-                       // reset nil to discard signature
-                       if err := b.updateBlockSignature(block, nodeOrder, nil); err != nil {
-                               return false, err
-                       }
+               consensusNode, err := c.consensusNodeManager.getConsensusNode(&blockNode.Parent.Hash, consensusNode.XPub.String())
+               if err != nil && err != errNotFoundConsensusNode {
+                       return err
+               }
 
-                       return true, nil
+               if err == errNotFoundConsensusNode {
+                       continue
+               }
+
+               if ok, err := blockNode.BlockWitness.Test(uint32(consensusNode.Order)); err == nil && ok {
+                       return errDoubleSignBlock
                }
        }
-       return false, nil
+       return nil
 }
 
 // SignBlock signing the block if current node is consensus node
-func (b *bbft) SignBlock(block *types.Block) ([]byte, error) {
+func (c *Chain) SignBlock(block *types.Block) ([]byte, error) {
        xprv := config.CommonConfig.PrivateKey()
-       xpub := [64]byte(xprv.XPub())
-       node, err := b.consensusNodeManager.getConsensusNode(&block.PreviousBlockHash, hex.EncodeToString(xpub[:]))
-       if err != nil && err != errNotFoundConsensusNode {
-               return nil, err
-       }
-
-       if node == nil {
+       xpubStr := xprv.XPub().String()
+       node, err := c.consensusNodeManager.getConsensusNode(&block.PreviousBlockHash, xpubStr)
+       if err == errNotFoundConsensusNode {
                return nil, nil
+       } else if err != nil {
+               return nil, err
        }
 
-       blockNodes := b.consensusNodeManager.blockIndex.NodesByHeight(block.Height)
+       c.cond.L.Lock()
+       defer c.cond.L.Unlock()
+       //check double sign in same block height
+       blockNodes := c.consensusNodeManager.blockIndex.NodesByHeight(block.Height)
        for _, blockNode := range blockNodes {
                // Has already signed the same height block
-               if ok, err := blockNode.BlockWitness.Test(uint32(node.order)); err != nil && ok {
+               if ok, err := blockNode.BlockWitness.Test(uint32(node.Order)); err == nil && ok {
                        return nil, nil
                }
        }
 
-       signature := block.Witness[node.order]
+       for blockNode := c.index.GetNode(&block.PreviousBlockHash); !c.index.InMainchain(blockNode.Hash); blockNode = blockNode.Parent {
+               if blockNode.Height <= c.bestIrreversibleNode.Height {
+                       return nil, errSignForkChain
+               }
+       }
+
+       signature := block.Witness[node.Order]
        if len(signature) == 0 {
                signature = xprv.Sign(block.Hash().Bytes())
-               block.Witness[node.order] = signature
+               block.Witness[node.Order] = signature
        }
        return signature, nil
 }
 
-func (b *bbft) updateBlockSignature(block *types.Block, nodeOrder uint64, signature []byte) error {
-       blockHash := block.Hash()
-       blockNode := b.consensusNodeManager.blockIndex.GetNode(&blockHash)
+func (c *Chain) updateBlockSignature(blockNode *state.BlockNode, nodeOrder uint64, signature []byte) error {
+       if err := blockNode.BlockWitness.Set(uint32(nodeOrder)); err != nil {
+               return err
+       }
 
-       if len(signature) != 0 {
-               if err := blockNode.BlockWitness.Set(uint32(nodeOrder)); err != nil {
-                       return err
-               }
-       } else {
-               if err := blockNode.BlockWitness.Clean(uint32(nodeOrder)); err != nil {
-                       return err
-               }
+       block, err := c.store.GetBlock(&blockNode.Hash)
+       if err != nil {
+               return err
        }
 
        block.Witness[nodeOrder] = signature
-       txStatus, err := b.consensusNodeManager.store.GetTransactionStatus(&blockHash)
+       txStatus, err := c.store.GetTransactionStatus(&blockNode.Hash)
        if err != nil {
                return err
        }
 
-       return b.consensusNodeManager.store.SaveBlock(block, txStatus)
-}
+       if err := c.store.SaveBlock(block, txStatus); err != nil {
+               return err
+       }
 
-// SetBlockIndex set the block index field
-func (b *bbft) SetBlockIndex(blockIndex *state.BlockIndex) {
-       b.consensusNodeManager.blockIndex = blockIndex
+       if c.isIrreversible(blockNode) && blockNode.Height > c.bestIrreversibleNode.Height {
+               if err := c.store.SaveChainStatus(c.bestNode, blockNode, state.NewUtxoViewpoint(), []*state.VoteResult{}); err != nil {
+                       return err
+               }
+
+               c.bestIrreversibleNode = blockNode
+       }
+       return nil
 }