aboutsummaryrefslogblamecommitdiffstats
path: root/dex/app.go
blob: d28f5f4908c0a8ca7b0bc37388bbb512e4b6b61e (plain) (tree)
1
2
3
4
5
6
7
8
9

                                                    
  
                                                                        



                                                                               
                                                                         




                                                                           
                                                      




                                  
             


                  
 

                                                                          

                                                  
                                                


                                                      
                                               
                                               



                                                                        







                                     
                             
 

                                                 
                                                


                    
                             

 





                               

                                                                                          
                          








                                                                
         

 
                                                            

                                 
                                   






                                                                                           

 
                                           

                                 


                                                      
                                            



                                               

 




                                                                                          
                                                                               
                                                                                             

                                              

                                 
                                                            
                                                                                             
                                                         
                                                                                                                                                               



                                                                                   









                                                                          

         




                                         
                                                                   
                                                                                       

                                                                                                                                    
                                     

           
                                          
                                                                          
                                                               


                                
                                                          
                                                                                               



                                                                 

                                                       
                                                                                                                  
                           

                                                                                           
                        


                                                            
                                        










                                                                                                                               







                                                                                                                                                     

                                     
 
                                                                      






                                                                                                       
                                                

                         




                                                   





                      

                                                                                                   
                                     

                                                                
                                                          

                                                                 
                                                                             
                                                                 


                                                                

         
                                                           


                                                        





                                 

                                                 
              


                                                  
                                                                                     

                         
                                   
                                                                

                                                             
                                                   

         
                                                    



                                                               

                                                                                  

                 
 
                       
                                                                             
                                                 

         

                                                    
 
                                       
                                                            
                                                                                                   
                                                               

                                                                                                       
                                                         


                 




                                                                 
 




                                                            


                                           
                                                           

                                                             
                                                   





                                                                               
                                                   






                                                                                             
                                                                         
                                                           



                                                       
                                                                                                                        
                           







                                                                                                       
                                                           





                                                         
                                                               
                                                                                                     



                                                                                                           



                                                 

                                                                                  
                                    



                                                                                               
                                                           


                                                                                                 


                                                                                         
                                                           

                                                                        

                                                                                         
                                                           

                 
                                                              
                                                   
                                                                            
                                                           
                 



                                                                                               
                                                           

                 


                                                      
                                 

 
                                                                        



                                                                                                                                      
 
                                                                         
                         
                                                    
         
 
                                           
                                                            
                       
                                                                    
                          
         
 



                                                   

         
                                                 
                                                                  
                                                                              

                                                                                          
                                          
                                                 

                                              

                                  
                                                                               
                       
                                                       
                          
         
                                                          
 
                                                                         
                                                             




                                                                           

                                                   
 
                                              
 



                                                                                              
 







                                                                                               

                                                                                                        

                                                              




                                                                   

                                     
 
                                                                     



                                                                           



                                                   
                                 

                                         

                                         
                                                       
         
 
 

                                               





                                                 








                                                  
// Copyright 2018 The dexon-consensus Authors
// This file is part of the dexon-consensus library.
//
// The dexon-consensus library is free software: you can redistribute it
// and/or modify it under the terms of the GNU Lesser General Public License as
// published by the Free Software Foundation, either version 3 of the License,
// or (at your option) any later version.
//
// The dexon-consensus library is distributed in the hope that it will be
// useful, but WITHOUT ANY WARRANTY; without even the implied warranty of
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the GNU Lesser
// General Public License for more details.
//
// You should have received a copy of the GNU Lesser General Public License
// along with the dexon-consensus library. If not, see
// <http://www.gnu.org/licenses/>.

package dex

import (
    "fmt"
    "math/big"
    "sync"
    "time"

    coreCommon "github.com/dexon-foundation/dexon-consensus/common"
    coreTypes "github.com/dexon-foundation/dexon-consensus/core/types"

    "github.com/dexon-foundation/dexon/common"
    "github.com/dexon-foundation/dexon/core"
    "github.com/dexon-foundation/dexon/core/types"
    "github.com/dexon-foundation/dexon/core/vm"
    "github.com/dexon-foundation/dexon/ethdb"
    "github.com/dexon-foundation/dexon/log"
    "github.com/dexon-foundation/dexon/rlp"
)

// DexconApp implementes the DEXON consensus core application interface.
type DexconApp struct {
    txPool     *core.TxPool
    blockchain *core.BlockChain
    gov        *DexconGovernance
    chainDB    ethdb.Database
    config     *Config
    vmConfig   vm.Config

    notifyChan map[uint64]*notify
    notifyMu   sync.Mutex

    chainLocksInitMu sync.Mutex
    chainLocks       map[uint32]*sync.RWMutex
    chainLatestRoot  map[uint32]*common.Hash
}

type notify struct {
    results []chan uint64
}

type witnessData struct {
    Root        common.Hash
    TxHash      common.Hash
    ReceiptHash common.Hash
}

func NewDexconApp(txPool *core.TxPool, blockchain *core.BlockChain, gov *DexconGovernance,
    chainDB ethdb.Database, config *Config, vmConfig vm.Config) *DexconApp {
    return &DexconApp{
        txPool:          txPool,
        blockchain:      blockchain,
        gov:             gov,
        chainDB:         chainDB,
        config:          config,
        vmConfig:        vmConfig,
        notifyChan:      make(map[uint64]*notify),
        chainLocks:      make(map[uint32]*sync.RWMutex),
        chainLatestRoot: make(map[uint32]*common.Hash),
    }
}

func (d *DexconApp) addNotify(height uint64) <-chan uint64 {
    d.notifyMu.Lock()
    defer d.notifyMu.Unlock()
    result := make(chan uint64)
    if n, exist := d.notifyChan[height]; exist {
        n.results = append(n.results, result)
    } else {
        d.notifyChan[height] = &notify{}
        d.notifyChan[height].results = append(d.notifyChan[height].results, result)
    }
    return result
}

func (d *DexconApp) notify(height uint64) {
    d.notifyMu.Lock()
    defer d.notifyMu.Unlock()
    for h, n := range d.notifyChan {
        if height >= h {
            for _, ch := range n.results {
                ch <- height
            }
            delete(d.notifyChan, h)
        }
    }
}

func (d *DexconApp) checkChain(address common.Address, chainSize, chainID *big.Int) bool {
    addrModChainSize := new(big.Int)
    return addrModChainSize.Mod(address.Big(), chainSize).Cmp(chainID) == 0
}

// PreparePayload is called when consensus core is preparing payload for block.
func (d *DexconApp) PreparePayload(position coreTypes.Position) (payload []byte, err error) {
    d.chainRLock(position.ChainID)
    defer d.chainRUnlock(position.ChainID)

    if position.Height != 0 {
        // check if chain block height is sequential
        chainLastHeight := d.blockchain.GetChainLastConfirmedHeight(position.ChainID)
        if chainLastHeight != position.Height-1 {
            log.Error("Check confirmed block height fail", "chain", position.ChainID, "height", position.Height-1, "cache height", chainLastHeight)
            return nil, fmt.Errorf("check confirmed block height fail")
        }
    }

    root := d.getChainLatestRoot(position.ChainID)
    if root == nil {
        currentRoot := d.blockchain.CurrentBlock().Root()
        root = &currentRoot
    }
    // set state to the chain latest height
    latestState, err := d.blockchain.StateAt(*root)
    if err != nil {
        log.Error("Get pending state", "error", err)
        return nil, fmt.Errorf("get pending state error: %v", err)
    }

    txsMap, err := d.txPool.Pending()
    if err != nil {
        return
    }

    chainID := new(big.Int).SetUint64(uint64(position.ChainID))
    chainNums := new(big.Int).SetUint64(uint64(d.gov.GetNumChains(position.Round)))
    blockGasLimit := new(big.Int).SetUint64(core.CalcGasLimit(d.blockchain.CurrentBlock(), d.config.GasFloor, d.config.GasCeil))
    blockGasUsed := new(big.Int)
    var allTxs types.Transactions

addressMap:
    for address, txs := range txsMap {
        // every address's transactions will appear in fixed chain
        if !d.checkChain(address, chainNums, chainID) {
            continue
        }

        balance := latestState.GetBalance(address)
        cost, exist := d.blockchain.GetCostInConfirmedBlocks(position.ChainID, address)
        if exist {
            balance = new(big.Int).Sub(balance, cost)
        }

        var expectNonce uint64
        // get last nonce from confirmed blocks
        lastConfirmedNonce, exist := d.blockchain.GetLastNonceInConfirmedBlocks(position.ChainID, address)
        if !exist {
            // get expect nonce from latest state when confirmed block is empty
            expectNonce = latestState.GetNonce(address)
        } else {
            expectNonce = lastConfirmedNonce + 1
        }

        for _, tx := range txs {
            if expectNonce == tx.Nonce() {
                expectNonce++
            } else if expectNonce < tx.Nonce() {
                // break to do next address
                break
            } else if expectNonce > tx.Nonce() {
                // continue to find next available
                log.Debug("Nonce check error and continue next tx", "expect", expectNonce, "nonce", tx.Nonce())
                continue
            }

            maxGasUsed := new(big.Int).Mul(new(big.Int).SetUint64(tx.Gas()), tx.GasPrice())
            intrinsicGas, err := core.IntrinsicGas(tx.Data(), tx.To() == nil, true)
            if err != nil {
                log.Error("Calculate intrinsic gas fail", "err", err)
                return nil, fmt.Errorf("calculate intrinsic gas error: %v", err)
            }
            if big.NewInt(int64(intrinsicGas)).Cmp(maxGasUsed) > 0 {
                log.Warn("Intrinsic gas is larger than (gas limit * gas price)", "intrinsic", intrinsicGas, "maxGasUsed", maxGasUsed)
                break
            }

            balance = new(big.Int).Sub(balance, tx.Cost())
            if balance.Cmp(big.NewInt(0)) < 0 {
                log.Error("Tx fail", "reason", "not enough balance")
                break
            }

            blockGasUsed = new(big.Int).Add(blockGasUsed, new(big.Int).SetUint64(tx.Gas()))
            if blockGasLimit.Cmp(blockGasUsed) < 0 {
                break addressMap
            }

            allTxs = append(allTxs, tx)
        }
    }
    payload, err = rlp.EncodeToBytes(&allTxs)
    if err != nil {
        return
    }

    return
}

// PrepareWitness will return the witness data no lower than consensusHeight.
func (d *DexconApp) PrepareWitness(consensusHeight uint64) (witness coreTypes.Witness, err error) {
    var witnessBlock *types.Block
    lastPendingHeight := d.blockchain.GetLastPendingHeight()
    if lastPendingHeight == 0 && consensusHeight == 0 {
        witnessBlock = d.blockchain.CurrentBlock()
    } else if lastPendingHeight >= consensusHeight {
        witnessBlock = d.blockchain.GetLastPendingBlock()
    } else if h := <-d.addNotify(consensusHeight); h >= consensusHeight {
        witnessBlock = d.blockchain.GetLastPendingBlock()
    } else {
        log.Error("need pending block")
        return witness, fmt.Errorf("need pending block")
    }

    witnessData, err := rlp.EncodeToBytes(&witnessData{
        Root:        witnessBlock.Root(),
        TxHash:      witnessBlock.TxHash(),
        ReceiptHash: witnessBlock.ReceiptHash(),
    })
    if err != nil {
        return
    }

    return coreTypes.Witness{
        Height: witnessBlock.NumberU64(),
        Data:   witnessData,
    }, nil
}

// VerifyBlock verifies if the payloads are valid.
func (d *DexconApp) VerifyBlock(block *coreTypes.Block) coreTypes.BlockVerifyStatus {
    const retries = 6

    var witnessData witnessData
    err := rlp.DecodeBytes(block.Witness.Data, &witnessData)
    if err != nil {
        log.Error("Witness rlp decode", "error", err)
        return coreTypes.VerifyInvalidBlock
    }

    for i := 0; i < retries && err != nil; i++ {
        // check witness root exist
        err = nil
        _, err = d.blockchain.StateAt(witnessData.Root)
        if err != nil {
            log.Debug("Sleep 0.5 seconds and try again", "error", err)
            time.Sleep(500 * time.Millisecond)
        }
    }

    if err != nil {
        log.Error("Expected witness root not in stateDB", "err", err)
        return coreTypes.VerifyRetryLater
    }

    d.chainRLock(block.Position.ChainID)
    defer d.chainRUnlock(block.Position.ChainID)

    if block.Position.Height != 0 {
        // check if chain block height is sequential
        chainLastHeight := d.blockchain.GetChainLastConfirmedHeight(block.Position.ChainID)
        if chainLastHeight != block.Position.Height-1 {
            log.Error("Check confirmed block height fail", "chain", block.Position.ChainID,
                "height", block.Position.Height-1, "cache height", chainLastHeight)
            return coreTypes.VerifyRetryLater
        }
    }

    root := d.getChainLatestRoot(block.Position.ChainID)
    if root == nil {
        currentRoot := d.blockchain.CurrentBlock().Root()
        root = &currentRoot
    }

    // set state to the chain latest height
    latestState, err := d.blockchain.StateAt(*root)
    if err != nil {
        log.Error("Get pending state", "error", err)
        return coreTypes.VerifyInvalidBlock
    }

    var transactions types.Transactions
    err = rlp.DecodeBytes(block.Payload, &transactions)
    if err != nil {
        log.Error("Payload rlp decode", "error", err)
        return coreTypes.VerifyInvalidBlock
    }

    // check if nonce is sequential and return first nonce of every address
    addresses, err := d.validateNonce(transactions)
    if err != nil {
        log.Error("Get address nonce", "error", err)
        return coreTypes.VerifyInvalidBlock
    }

    // check all address nonce
    chainID := big.NewInt(int64(block.Position.ChainID))
    chainNums := new(big.Int).SetUint64(uint64(d.gov.GetNumChains(block.Position.Round)))
    for address, firstNonce := range addresses {
        if !d.checkChain(address, chainNums, chainID) {
            log.Error("Check chain fail", "address", address)
            return coreTypes.VerifyInvalidBlock
        }

        var expectNonce uint64
        // get last nonce from confirmed blocks
        lastConfirmedNonce, exist := d.blockchain.GetLastNonceInConfirmedBlocks(block.Position.ChainID, address)
        if !exist {
            // get expect nonce from latest state when confirmed block is empty
            expectNonce = latestState.GetNonce(address)
        } else {
            expectNonce = lastConfirmedNonce + 1
        }

        if expectNonce != firstNonce {
            log.Error("Nonce check error", "expect", expectNonce, "firstNonce", firstNonce)
            return coreTypes.VerifyInvalidBlock
        }
    }

    // get balance from state
    addressesBalance := map[common.Address]*big.Int{}
    for address := range addresses {
        // replay confirmed block tx to correct balance
        cost, exist := d.blockchain.GetCostInConfirmedBlocks(block.Position.ChainID, address)
        if exist {
            addressesBalance[address] = new(big.Int).Sub(latestState.GetBalance(address), cost)
        } else {
            addressesBalance[address] = latestState.GetBalance(address)
        }
    }

    // validate tx to check available balance
    blockGasLimit := new(big.Int).SetUint64(core.CalcGasLimit(
        d.blockchain.CurrentBlock(), d.config.GasFloor, d.config.GasCeil))
    blockGasUsed := new(big.Int)
    for _, tx := range transactions {
        msg, err := tx.AsMessage(types.MakeSigner(d.blockchain.Config(), new(big.Int)))
        if err != nil {
            log.Error("Tx to message", "error", err)
            return coreTypes.VerifyInvalidBlock
        }
        balance, _ := addressesBalance[msg.From()]
        maxGasUsed := new(big.Int).Mul(new(big.Int).SetUint64(msg.Gas()), msg.GasPrice())
        intrinsicGas, err := core.IntrinsicGas(msg.Data(), msg.To() == nil, true)
        if err != nil {
            log.Error("Calculate intrinsic gas fail", "err", err)
            return coreTypes.VerifyInvalidBlock
        }
        if big.NewInt(int64(intrinsicGas)).Cmp(maxGasUsed) > 0 {
            log.Error("Intrinsic gas is larger than (gas limit * gas price)",
                "intrinsic", intrinsicGas, "maxGasUsed", maxGasUsed)
            return coreTypes.VerifyInvalidBlock
        }

        balance = new(big.Int).Sub(balance, tx.Cost())
        if balance.Cmp(big.NewInt(0)) < 0 {
            log.Error("Tx fail", "reason", "not enough balance")
            return coreTypes.VerifyInvalidBlock
        }

        blockGasUsed = new(big.Int).Add(blockGasUsed, new(big.Int).SetUint64(tx.Gas()))
        if blockGasLimit.Cmp(blockGasUsed) < 0 {
            log.Error("Reach block gas limit", "limit", blockGasLimit)
            return coreTypes.VerifyInvalidBlock
        }

        addressesBalance[msg.From()] = balance
    }

    return coreTypes.VerifyOK
}

// BlockDelivered is called when a block is add to the compaction chain.
func (d *DexconApp) BlockDelivered(blockHash coreCommon.Hash, blockPosition coreTypes.Position, result coreTypes.FinalizationResult) {
    chainID := blockPosition.ChainID
    d.chainLock(chainID)
    defer d.chainUnlock(chainID)

    block := d.blockchain.GetConfirmedBlockByHash(chainID, blockHash)
    if block == nil {
        panic("Can not get confirmed block")
    }

    var transactions types.Transactions
    err := rlp.DecodeBytes(block.Payload, &transactions)
    if err != nil {
        log.Error("Payload rlp decode failed", "error", err)
        panic(err)
    }

    block.Payload = nil
    dexconMeta, err := rlp.EncodeToBytes(block)
    if err != nil {
        panic(err)
    }

    newBlock := types.NewBlock(&types.Header{
        Number:     new(big.Int).SetUint64(result.Height),
        Time:       big.NewInt(result.Timestamp.UnixNano() / 1000000),
        Coinbase:   common.BytesToAddress(block.ProposerID.Bytes()),
        GasLimit:   d.gov.DexconConfiguration(block.Position.Round).BlockGasLimit,
        Difficulty: big.NewInt(1),
        Round:      block.Position.Round,
        DexconMeta: dexconMeta,
        Randomness: result.Randomness,
    }, transactions, nil, nil)

    root, err := d.blockchain.ProcessPendingBlock(newBlock, &block.Witness)
    if err != nil {
        log.Error("Insert chain", "error", err)
        panic(err)
    }
    d.setChainLatestRoot(block.Position.ChainID, root)

    log.Info("Insert pending block success", "height", result.Height)
    d.blockchain.RemoveConfirmedBlock(chainID, blockHash)
    d.notify(result.Height)
}

// BlockConfirmed is called when a block is confirmed and added to lattice.
func (d *DexconApp) BlockConfirmed(block coreTypes.Block) {
    d.chainLock(block.Position.ChainID)
    defer d.chainUnlock(block.Position.ChainID)

    d.blockchain.AddConfirmedBlock(&block)
}

func (d *DexconApp) validateNonce(txs types.Transactions) (map[common.Address]uint64, error) {
    addressFirstNonce := map[common.Address]uint64{}
    addressNonce := map[common.Address]uint64{}

    for _, tx := range txs {
        msg, err := tx.AsMessage(types.MakeSigner(d.blockchain.Config(), new(big.Int)))
        if err != nil {
            return nil, err
        }

        if _, exist := addressFirstNonce[msg.From()]; exist {
            if addressNonce[msg.From()]+1 != msg.Nonce() {
                return nil, fmt.Errorf("address nonce check error: expect %v actual %v",
                    addressNonce[msg.From()]+1, msg.Nonce())
            }
            addressNonce[msg.From()] = msg.Nonce()
        } else {
            addressNonce[msg.From()] = msg.Nonce()
            addressFirstNonce[msg.From()] = msg.Nonce()
        }
    }
    return addressFirstNonce, nil
}

func (d *DexconApp) getChainLatestRoot(chainID uint32) *common.Hash {
    return d.chainLatestRoot[chainID]
}

func (d *DexconApp) setChainLatestRoot(chainID uint32, root *common.Hash) {
    d.chainLatestRoot[chainID] = root
}

func (d *DexconApp) chainLockInit(chainID uint32) {
    d.chainLocksInitMu.Lock()
    defer d.chainLocksInitMu.Unlock()

    _, exist := d.chainLocks[chainID]
    if !exist {
        d.chainLocks[chainID] = &sync.RWMutex{}
    }
}

func (d *DexconApp) chainLock(chainID uint32) {
    d.chainLockInit(chainID)
    d.chainLocks[chainID].Lock()
}

func (d *DexconApp) chainUnlock(chainID uint32) {
    d.chainLocks[chainID].Unlock()
}

func (d *DexconApp) chainRLock(chainID uint32) {
    d.chainLockInit(chainID)
    d.chainLocks[chainID].RLock()
}

func (d *DexconApp) chainRUnlock(chainID uint32) {
    d.chainLocks[chainID].RUnlock()
}