2015-08-26 06:03:18 +02:00
|
|
|
// Copyright (c) 2013-2016 The btcsuite developers
|
2013-07-18 16:49:28 +02:00
|
|
|
// Use of this source code is governed by an ISC
|
|
|
|
// license that can be found in the LICENSE file.
|
|
|
|
|
2015-01-30 21:54:30 +01:00
|
|
|
package blockchain
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
import (
|
|
|
|
"container/list"
|
|
|
|
"fmt"
|
|
|
|
"math/big"
|
|
|
|
"sort"
|
2013-08-20 18:13:39 +02:00
|
|
|
"sync"
|
2013-07-18 16:49:28 +02:00
|
|
|
"time"
|
2014-07-02 18:04:59 +02:00
|
|
|
|
2015-02-06 06:18:27 +01:00
|
|
|
"github.com/btcsuite/btcd/chaincfg"
|
2015-08-26 11:54:55 +02:00
|
|
|
"github.com/btcsuite/btcd/database"
|
2015-09-25 01:22:00 +02:00
|
|
|
"github.com/btcsuite/btcd/txscript"
|
2015-02-05 22:16:39 +01:00
|
|
|
"github.com/btcsuite/btcd/wire"
|
2015-01-15 17:23:47 +01:00
|
|
|
"github.com/btcsuite/btcutil"
|
2013-07-18 16:49:28 +02:00
|
|
|
)
|
|
|
|
|
2013-08-01 18:31:42 +02:00
|
|
|
const (
|
|
|
|
// maxOrphanBlocks is the maximum number of orphan blocks that can be
|
|
|
|
// queued.
|
|
|
|
maxOrphanBlocks = 100
|
|
|
|
|
|
|
|
// minMemoryNodes is the minimum number of consecutive nodes needed
|
|
|
|
// in memory in order to perform all necessary validation. It is used
|
|
|
|
// to determine when it's safe to prune nodes from memory without
|
|
|
|
// causing constant dynamic reloading.
|
2014-02-07 23:23:11 +01:00
|
|
|
minMemoryNodes = BlocksPerRetarget
|
2013-08-01 18:31:42 +02:00
|
|
|
)
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// blockNode represents a block within the block chain and is primarily used to
|
|
|
|
// aid in selecting the best chain to be the main chain. The main chain is
|
|
|
|
// stored into the block database.
|
|
|
|
type blockNode struct {
|
|
|
|
// parent is the parent block for this node.
|
|
|
|
parent *blockNode
|
|
|
|
|
|
|
|
// children contains the child nodes for this node. Typically there
|
|
|
|
// will only be one, but sometimes there can be more than one and that
|
|
|
|
// is when the best chain selection algorithm is used.
|
|
|
|
children []*blockNode
|
|
|
|
|
|
|
|
// hash is the double sha 256 of the block.
|
2015-02-05 22:16:39 +01:00
|
|
|
hash *wire.ShaHash
|
2013-07-18 16:49:28 +02:00
|
|
|
|
2013-08-01 18:31:42 +02:00
|
|
|
// parentHash is the double sha 256 of the parent block. This is kept
|
|
|
|
// here over simply relying on parent.hash directly since block nodes
|
|
|
|
// are sparse and the parent node might not be in memory when its hash
|
|
|
|
// is needed.
|
2015-02-05 22:16:39 +01:00
|
|
|
parentHash *wire.ShaHash
|
2013-08-01 18:31:42 +02:00
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// height is the position in the block chain.
|
2015-08-08 04:20:49 +02:00
|
|
|
height int32
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// workSum is the total amount of work in the chain up to and including
|
|
|
|
// this node.
|
2013-07-31 19:57:54 +02:00
|
|
|
workSum *big.Int
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// inMainChain denotes whether the block node is currently on the
|
|
|
|
// the main chain or not. This is used to help find the common
|
|
|
|
// ancestor when switching chains.
|
|
|
|
inMainChain bool
|
|
|
|
|
|
|
|
// Some fields from block headers to aid in best chain selection.
|
2014-06-29 22:11:13 +02:00
|
|
|
version int32
|
2013-07-18 16:49:28 +02:00
|
|
|
bits uint32
|
|
|
|
timestamp time.Time
|
|
|
|
}
|
|
|
|
|
2014-01-19 20:00:12 +01:00
|
|
|
// newBlockNode returns a new block node for the given block header. It is
|
|
|
|
// completely disconnected from the chain and the workSum value is just the work
|
|
|
|
// for the passed block. The work sum is updated accordingly when the node is
|
|
|
|
// inserted into a chain.
|
2015-08-08 04:20:49 +02:00
|
|
|
func newBlockNode(blockHeader *wire.BlockHeader, blockSha *wire.ShaHash, height int32) *blockNode {
|
2014-02-09 08:34:08 +01:00
|
|
|
// Make a copy of the hash so the node doesn't keep a reference to part
|
|
|
|
// of the full block/block header preventing it from being garbage
|
|
|
|
// collected.
|
|
|
|
prevHash := blockHeader.PrevBlock
|
2013-07-18 16:49:28 +02:00
|
|
|
node := blockNode{
|
2013-08-01 18:31:42 +02:00
|
|
|
hash: blockSha,
|
2014-02-09 08:34:08 +01:00
|
|
|
parentHash: &prevHash,
|
2014-02-07 23:23:11 +01:00
|
|
|
workSum: CalcWork(blockHeader.Bits),
|
2014-01-19 20:00:12 +01:00
|
|
|
height: height,
|
2013-08-01 18:31:42 +02:00
|
|
|
version: blockHeader.Version,
|
|
|
|
bits: blockHeader.Bits,
|
|
|
|
timestamp: blockHeader.Timestamp,
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
return &node
|
|
|
|
}
|
|
|
|
|
|
|
|
// orphanBlock represents a block that we don't yet have the parent for. It
|
|
|
|
// is a normal block plus an expiration time to prevent caching the orphan
|
|
|
|
// forever.
|
|
|
|
type orphanBlock struct {
|
|
|
|
block *btcutil.Block
|
|
|
|
expiration time.Time
|
|
|
|
}
|
|
|
|
|
|
|
|
// removeChildNode deletes node from the provided slice of child block
|
|
|
|
// nodes. It ensures the final pointer reference is set to nil to prevent
|
|
|
|
// potential memory leaks. The original slice is returned unmodified if node
|
|
|
|
// is invalid or not in the slice.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-07-18 16:49:28 +02:00
|
|
|
func removeChildNode(children []*blockNode, node *blockNode) []*blockNode {
|
|
|
|
if node == nil {
|
|
|
|
return children
|
|
|
|
}
|
2013-08-17 21:05:36 +02:00
|
|
|
|
|
|
|
// An indexing for loop is intentionally used over a range here as range
|
|
|
|
// does not reevaluate the slice on each iteration nor does it adjust
|
|
|
|
// the index for the modified slice.
|
|
|
|
for i := 0; i < len(children); i++ {
|
|
|
|
if children[i].hash.IsEqual(node.hash) {
|
2013-07-18 16:49:28 +02:00
|
|
|
copy(children[i:], children[i+1:])
|
|
|
|
children[len(children)-1] = nil
|
|
|
|
return children[:len(children)-1]
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return children
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// BestState houses information about the current best block and other info
|
|
|
|
// related to the state of the main chain as it exists from the point of view of
|
|
|
|
// the current best block.
|
|
|
|
//
|
|
|
|
// The BestSnapshot method can be used to obtain access to this information
|
|
|
|
// in a concurrent safe manner and the data will not be changed out from under
|
|
|
|
// the caller when chain state changes occur as the function name implies.
|
|
|
|
// However, the returned snapshot must be treated as immutable since it is
|
|
|
|
// shared by all callers.
|
|
|
|
type BestState struct {
|
|
|
|
Hash *wire.ShaHash // The hash of the block.
|
|
|
|
Height int32 // The height of the block.
|
|
|
|
Bits uint32 // The difficulty bits of the block.
|
|
|
|
BlockSize uint64 // The size of the block.
|
|
|
|
NumTxns uint64 // The number of txns in the block.
|
|
|
|
TotalTxns uint64 // The total number of txns in the chain.
|
|
|
|
}
|
|
|
|
|
|
|
|
// newBestState returns a new best stats instance for the given parameters.
|
|
|
|
func newBestState(node *blockNode, blockSize, numTxns, totalTxns uint64) *BestState {
|
|
|
|
return &BestState{
|
|
|
|
Hash: node.hash,
|
|
|
|
Height: node.height,
|
|
|
|
Bits: node.bits,
|
|
|
|
BlockSize: blockSize,
|
|
|
|
NumTxns: numTxns,
|
|
|
|
TotalTxns: totalTxns,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// BlockChain provides functions for working with the bitcoin block chain.
|
|
|
|
// It includes functionality such as rejecting duplicate blocks, ensuring blocks
|
|
|
|
// follow all rules, orphan handling, checkpoint handling, and best chain
|
|
|
|
// selection with reorganization.
|
|
|
|
type BlockChain struct {
|
2015-08-26 06:03:18 +02:00
|
|
|
// The following fields are set when the instance is created and can't
|
|
|
|
// be changed afterwards, so there is no need to protect them with a
|
|
|
|
// separate mutex.
|
2015-08-08 04:20:49 +02:00
|
|
|
checkpointsByHeight map[int32]*chaincfg.Checkpoint
|
2015-08-26 06:03:18 +02:00
|
|
|
db database.DB
|
|
|
|
chainParams *chaincfg.Params
|
2016-07-14 02:36:36 +02:00
|
|
|
timeSource MedianTimeSource
|
2014-05-26 17:27:50 +02:00
|
|
|
notifications NotificationCallback
|
2015-09-25 01:22:00 +02:00
|
|
|
sigCache *txscript.SigCache
|
2016-02-19 05:51:18 +01:00
|
|
|
indexManager IndexManager
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// chainLock protects concurrent access to the vast majority of the
|
|
|
|
// fields in this struct below this point.
|
|
|
|
chainLock sync.RWMutex
|
|
|
|
|
|
|
|
// These fields are configuration parameters that can be toggled at
|
|
|
|
// runtime. They are protected by the chain lock.
|
|
|
|
noVerify bool
|
|
|
|
noCheckpoints bool
|
|
|
|
|
|
|
|
// These fields are related to the memory block index. They are
|
|
|
|
// protected by the chain lock.
|
|
|
|
bestNode *blockNode
|
|
|
|
index map[wire.ShaHash]*blockNode
|
|
|
|
depNodes map[wire.ShaHash][]*blockNode
|
|
|
|
|
|
|
|
// These fields are related to handling of orphan blocks. They are
|
|
|
|
// protected by a combination of the chain lock and the orphan lock.
|
|
|
|
orphanLock sync.RWMutex
|
|
|
|
orphans map[wire.ShaHash]*orphanBlock
|
|
|
|
prevOrphans map[wire.ShaHash][]*orphanBlock
|
|
|
|
oldestOrphan *orphanBlock
|
|
|
|
blockCache map[wire.ShaHash]*btcutil.Block
|
|
|
|
|
|
|
|
// These fields are related to checkpoint handling. They are protected
|
|
|
|
// by the chain lock.
|
|
|
|
nextCheckpoint *chaincfg.Checkpoint
|
|
|
|
checkpointBlock *btcutil.Block
|
|
|
|
|
|
|
|
// The state is used as a fairly efficient way to cache information
|
|
|
|
// about the current best chain state that is returned to callers when
|
|
|
|
// requested. It operates on the principle of MVCC such that any time a
|
|
|
|
// new block becomes the best block, the state pointer is replaced with
|
|
|
|
// a new struct and the old state is left untouched. In this way,
|
|
|
|
// multiple callers can be pointing to different best chain states.
|
|
|
|
// This is acceptable for most callers because the state is only being
|
|
|
|
// queried at a specific point in time.
|
|
|
|
//
|
|
|
|
// In addition, some of the fields are stored in the database so the
|
|
|
|
// chain state can be quickly reconstructed on load.
|
|
|
|
stateLock sync.RWMutex
|
|
|
|
stateSnapshot *BestState
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// DisableVerify provides a mechanism to disable transaction script validation
|
|
|
|
// which you DO NOT want to do in production as it could allow double spends
|
2015-08-26 06:03:18 +02:00
|
|
|
// and other undesirable things. It is provided only for debug purposes since
|
2013-07-18 16:49:28 +02:00
|
|
|
// script validation is extremely intensive and when debugging it is sometimes
|
|
|
|
// nice to quickly get the chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function is safe for concurrent access.
|
2013-07-18 16:49:28 +02:00
|
|
|
func (b *BlockChain) DisableVerify(disable bool) {
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Lock()
|
2013-07-18 16:49:28 +02:00
|
|
|
b.noVerify = disable
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Unlock()
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
2013-10-08 19:32:15 +02:00
|
|
|
// HaveBlock returns whether or not the chain instance has the block represented
|
|
|
|
// by the passed hash. This includes checking the various places a block can
|
|
|
|
// be like part of the main chain, on a side chain, or in the orphan pool.
|
2013-08-22 22:50:57 +02:00
|
|
|
//
|
2015-08-26 06:03:18 +02:00
|
|
|
// This function is safe for concurrent access.
|
2015-02-05 22:16:39 +01:00
|
|
|
func (b *BlockChain) HaveBlock(hash *wire.ShaHash) (bool, error) {
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.RLock()
|
|
|
|
defer b.chainLock.RUnlock()
|
|
|
|
|
2014-07-07 18:42:28 +02:00
|
|
|
exists, err := b.blockExists(hash)
|
|
|
|
if err != nil {
|
|
|
|
return false, err
|
|
|
|
}
|
|
|
|
return b.IsKnownOrphan(hash) || exists, nil
|
2013-08-22 22:50:57 +02:00
|
|
|
}
|
|
|
|
|
2013-08-20 18:19:34 +02:00
|
|
|
// IsKnownOrphan returns whether the passed hash is currently a known orphan.
|
|
|
|
// Keep in mind that only a limited number of orphans are held onto for a
|
|
|
|
// limited amount of time, so this function must not be used as an absolute
|
|
|
|
// way to test if a block is an orphan block. A full block (as opposed to just
|
|
|
|
// its hash) must be passed to ProcessBlock for that purpose. However, calling
|
|
|
|
// ProcessBlock with an orphan that already exists results in an error, so this
|
|
|
|
// function provides a mechanism for a caller to intelligently detect *recent*
|
|
|
|
// duplicate orphans and react accordingly.
|
|
|
|
//
|
|
|
|
// This function is safe for concurrent access.
|
2015-02-05 22:16:39 +01:00
|
|
|
func (b *BlockChain) IsKnownOrphan(hash *wire.ShaHash) bool {
|
2013-08-20 18:19:34 +02:00
|
|
|
// Protect concurrent access. Using a read lock only so multiple
|
|
|
|
// readers can query without blocking each other.
|
|
|
|
b.orphanLock.RLock()
|
|
|
|
defer b.orphanLock.RUnlock()
|
|
|
|
|
|
|
|
if _, exists := b.orphans[*hash]; exists {
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
|
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
2013-08-20 18:13:39 +02:00
|
|
|
// GetOrphanRoot returns the head of the chain for the provided hash from the
|
2013-07-18 16:49:28 +02:00
|
|
|
// map of orphan blocks.
|
2013-08-20 18:13:39 +02:00
|
|
|
//
|
|
|
|
// This function is safe for concurrent access.
|
2015-02-05 22:16:39 +01:00
|
|
|
func (b *BlockChain) GetOrphanRoot(hash *wire.ShaHash) *wire.ShaHash {
|
2013-08-20 18:13:39 +02:00
|
|
|
// Protect concurrent access. Using a read lock only so multiple
|
|
|
|
// readers can query without blocking each other.
|
|
|
|
b.orphanLock.RLock()
|
|
|
|
defer b.orphanLock.RUnlock()
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Keep looping while the parent of each orphaned block is
|
|
|
|
// known and is an orphan itself.
|
2013-08-22 21:37:06 +02:00
|
|
|
orphanRoot := hash
|
|
|
|
prevHash := hash
|
2013-07-18 16:49:28 +02:00
|
|
|
for {
|
|
|
|
orphan, exists := b.orphans[*prevHash]
|
|
|
|
if !exists {
|
|
|
|
break
|
|
|
|
}
|
2013-08-22 21:37:06 +02:00
|
|
|
orphanRoot = prevHash
|
2013-07-18 16:49:28 +02:00
|
|
|
prevHash = &orphan.block.MsgBlock().Header.PrevBlock
|
|
|
|
}
|
|
|
|
|
2013-08-22 21:37:06 +02:00
|
|
|
return orphanRoot
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// removeOrphanBlock removes the passed orphan block from the orphan pool and
|
|
|
|
// previous orphan index.
|
|
|
|
func (b *BlockChain) removeOrphanBlock(orphan *orphanBlock) {
|
2013-08-20 18:13:39 +02:00
|
|
|
// Protect concurrent access.
|
|
|
|
b.orphanLock.Lock()
|
|
|
|
defer b.orphanLock.Unlock()
|
|
|
|
|
2015-04-17 07:44:15 +02:00
|
|
|
// Remove the orphan block from the orphan pool.
|
|
|
|
orphanHash := orphan.block.Sha()
|
2013-07-18 16:49:28 +02:00
|
|
|
delete(b.orphans, *orphanHash)
|
|
|
|
|
2013-08-17 21:05:36 +02:00
|
|
|
// Remove the reference from the previous orphan index too. An indexing
|
|
|
|
// for loop is intentionally used over a range here as range does not
|
|
|
|
// reevaluate the slice on each iteration nor does it adjust the index
|
|
|
|
// for the modified slice.
|
2013-07-18 16:49:28 +02:00
|
|
|
prevHash := &orphan.block.MsgBlock().Header.PrevBlock
|
|
|
|
orphans := b.prevOrphans[*prevHash]
|
2013-08-17 21:05:36 +02:00
|
|
|
for i := 0; i < len(orphans); i++ {
|
2015-04-17 07:44:15 +02:00
|
|
|
hash := orphans[i].block.Sha()
|
2013-07-18 16:49:28 +02:00
|
|
|
if hash.IsEqual(orphanHash) {
|
|
|
|
copy(orphans[i:], orphans[i+1:])
|
|
|
|
orphans[len(orphans)-1] = nil
|
2013-08-04 20:41:05 +02:00
|
|
|
orphans = orphans[:len(orphans)-1]
|
2013-08-17 21:05:36 +02:00
|
|
|
i--
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
}
|
2013-08-04 20:41:05 +02:00
|
|
|
b.prevOrphans[*prevHash] = orphans
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// Remove the map entry altogether if there are no longer any orphans
|
|
|
|
// which depend on the parent hash.
|
|
|
|
if len(b.prevOrphans[*prevHash]) == 0 {
|
|
|
|
delete(b.prevOrphans, *prevHash)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// addOrphanBlock adds the passed block (which is already determined to be
|
|
|
|
// an orphan prior calling this function) to the orphan pool. It lazily cleans
|
|
|
|
// up any expired blocks so a separate cleanup poller doesn't need to be run.
|
|
|
|
// It also imposes a maximum limit on the number of outstanding orphan
|
|
|
|
// blocks and will remove the oldest received orphan block if the limit is
|
|
|
|
// exceeded.
|
|
|
|
func (b *BlockChain) addOrphanBlock(block *btcutil.Block) {
|
|
|
|
// Remove expired orphan blocks.
|
|
|
|
for _, oBlock := range b.orphans {
|
|
|
|
if time.Now().After(oBlock.expiration) {
|
|
|
|
b.removeOrphanBlock(oBlock)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the oldest orphan block pointer so it can be discarded
|
|
|
|
// in case the orphan pool fills up.
|
|
|
|
if b.oldestOrphan == nil || oBlock.expiration.Before(b.oldestOrphan.expiration) {
|
|
|
|
b.oldestOrphan = oBlock
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Limit orphan blocks to prevent memory exhaustion.
|
|
|
|
if len(b.orphans)+1 > maxOrphanBlocks {
|
|
|
|
// Remove the oldest orphan to make room for the new one.
|
|
|
|
b.removeOrphanBlock(b.oldestOrphan)
|
|
|
|
b.oldestOrphan = nil
|
|
|
|
}
|
|
|
|
|
2013-08-20 18:13:39 +02:00
|
|
|
// Protect concurrent access. This is intentionally done here instead
|
|
|
|
// of near the top since removeOrphanBlock does its own locking and
|
|
|
|
// the range iterator is not invalidated by removing map entries.
|
|
|
|
b.orphanLock.Lock()
|
2014-03-09 17:04:47 +01:00
|
|
|
defer b.orphanLock.Unlock()
|
2013-08-20 18:13:39 +02:00
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Insert the block into the orphan map with an expiration time
|
|
|
|
// 1 hour from now.
|
|
|
|
expiration := time.Now().Add(time.Hour)
|
|
|
|
oBlock := &orphanBlock{
|
|
|
|
block: block,
|
|
|
|
expiration: expiration,
|
|
|
|
}
|
2015-04-17 07:44:15 +02:00
|
|
|
b.orphans[*block.Sha()] = oBlock
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// Add to previous hash lookup index for faster dependency lookups.
|
|
|
|
prevHash := &block.MsgBlock().Header.PrevBlock
|
|
|
|
b.prevOrphans[*prevHash] = append(b.prevOrphans[*prevHash], oBlock)
|
|
|
|
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// loadBlockNode loads the block identified by hash from the block database,
|
|
|
|
// creates a block node from it, and updates the memory block chain accordingly.
|
2015-08-26 06:03:18 +02:00
|
|
|
// It is used mainly to dynamically load previous blocks from the database as
|
|
|
|
// they are needed to avoid needing to put the entire block chain in memory.
|
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
|
|
|
// The database transaction may be read-only.
|
|
|
|
func (b *BlockChain) loadBlockNode(dbTx database.Tx, hash *wire.ShaHash) (*blockNode, error) {
|
2014-01-19 20:00:12 +01:00
|
|
|
// Load the block header and height from the db.
|
2015-08-26 06:03:18 +02:00
|
|
|
blockHeader, err := dbFetchHeaderByHash(dbTx, hash)
|
2014-01-19 20:00:12 +01:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2015-08-26 06:03:18 +02:00
|
|
|
blockHeight, err := dbFetchHeightByHash(dbTx, hash)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Create the new block node for the block and set the work.
|
2014-01-19 20:00:12 +01:00
|
|
|
node := newBlockNode(blockHeader, hash, blockHeight)
|
2013-07-18 16:49:28 +02:00
|
|
|
node.inMainChain = true
|
|
|
|
|
|
|
|
// Add the node to the chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
// There are a few possibilities here:
|
2013-07-18 16:49:28 +02:00
|
|
|
// 1) This node is a child of an existing block node
|
|
|
|
// 2) This node is the parent of one or more nodes
|
2015-08-26 06:03:18 +02:00
|
|
|
// 3) Neither 1 or 2 is true which implies it's an orphan block and
|
2013-07-18 16:49:28 +02:00
|
|
|
// therefore is an error to insert into the chain
|
2014-01-19 20:00:12 +01:00
|
|
|
prevHash := &blockHeader.PrevBlock
|
2013-07-18 16:49:28 +02:00
|
|
|
if parentNode, ok := b.index[*prevHash]; ok {
|
|
|
|
// Case 1 -- This node is a child of an existing block node.
|
|
|
|
// Update the node's work sum with the sum of the parent node's
|
|
|
|
// work sum and this node's work, append the node as a child of
|
|
|
|
// the parent node and set this node's parent to the parent
|
|
|
|
// node.
|
|
|
|
node.workSum = node.workSum.Add(parentNode.workSum, node.workSum)
|
|
|
|
parentNode.children = append(parentNode.children, node)
|
|
|
|
node.parent = parentNode
|
|
|
|
|
|
|
|
} else if childNodes, ok := b.depNodes[*hash]; ok {
|
|
|
|
// Case 2 -- This node is the parent of one or more nodes.
|
2015-08-26 06:03:18 +02:00
|
|
|
// Update the node's work sum by subtracting this node's work
|
|
|
|
// from the sum of its first child, and connect the node to all
|
|
|
|
// of its children.
|
|
|
|
node.workSum.Sub(childNodes[0].workSum, node.workSum)
|
2013-07-18 16:49:28 +02:00
|
|
|
for _, childNode := range childNodes {
|
|
|
|
childNode.parent = node
|
|
|
|
node.children = append(node.children, childNode)
|
|
|
|
}
|
|
|
|
|
|
|
|
} else {
|
2015-08-26 06:03:18 +02:00
|
|
|
// Case 3 -- The node doesn't have a parent and is not the
|
|
|
|
// parent of another node. This means an arbitrary orphan block
|
|
|
|
// is trying to be loaded which is not allowed.
|
|
|
|
str := "loadBlockNode: attempt to insert orphan block %v"
|
|
|
|
return nil, AssertError(fmt.Sprintf(str, hash))
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Add the new node to the indices for faster lookups.
|
|
|
|
b.index[*hash] = node
|
|
|
|
b.depNodes[*prevHash] = append(b.depNodes[*prevHash], node)
|
|
|
|
|
|
|
|
return node, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// getPrevNodeFromBlock returns a block node for the block previous to the
|
|
|
|
// passed block (the passed block's parent). When it is already in the memory
|
|
|
|
// block chain, it simply returns it. Otherwise, it loads the previous block
|
2015-08-26 06:03:18 +02:00
|
|
|
// header from the block database, creates a new block node from it, and returns
|
|
|
|
// it. The returned node will be nil if the genesis block is passed.
|
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-07-18 16:49:28 +02:00
|
|
|
func (b *BlockChain) getPrevNodeFromBlock(block *btcutil.Block) (*blockNode, error) {
|
|
|
|
// Genesis block.
|
|
|
|
prevHash := &block.MsgBlock().Header.PrevBlock
|
|
|
|
if prevHash.IsEqual(zeroHash) {
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Return the existing previous block node if it's already there.
|
|
|
|
if bn, ok := b.index[*prevHash]; ok {
|
|
|
|
return bn, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Dynamically load the previous block from the block database, create
|
|
|
|
// a new block node for it, and update the memory chain accordingly.
|
2015-08-26 06:03:18 +02:00
|
|
|
var prevBlockNode *blockNode
|
|
|
|
err := b.db.View(func(dbTx database.Tx) error {
|
|
|
|
var err error
|
|
|
|
prevBlockNode, err = b.loadBlockNode(dbTx, prevHash)
|
|
|
|
return err
|
|
|
|
})
|
|
|
|
return prevBlockNode, err
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// getPrevNodeFromNode returns a block node for the block previous to the
|
|
|
|
// passed block node (the passed block node's parent). When the node is already
|
|
|
|
// connected to a parent, it simply returns it. Otherwise, it loads the
|
|
|
|
// associated block from the database to obtain the previous hash and uses that
|
|
|
|
// to dynamically create a new block node and return it. The memory block
|
|
|
|
// chain is updated accordingly. The returned node will be nil if the genesis
|
|
|
|
// block is passed.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-07-18 16:49:28 +02:00
|
|
|
func (b *BlockChain) getPrevNodeFromNode(node *blockNode) (*blockNode, error) {
|
|
|
|
// Return the existing previous block node if it's already there.
|
|
|
|
if node.parent != nil {
|
|
|
|
return node.parent, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Genesis block.
|
2015-02-06 06:18:27 +01:00
|
|
|
if node.hash.IsEqual(b.chainParams.GenesisHash) {
|
2013-07-18 16:49:28 +02:00
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Dynamically load the previous block from the block database, create
|
|
|
|
// a new block node for it, and update the memory chain accordingly.
|
2015-08-26 06:03:18 +02:00
|
|
|
var prevBlockNode *blockNode
|
|
|
|
err := b.db.View(func(dbTx database.Tx) error {
|
|
|
|
var err error
|
|
|
|
prevBlockNode, err = b.loadBlockNode(dbTx, node.parentHash)
|
|
|
|
return err
|
|
|
|
})
|
|
|
|
return prevBlockNode, err
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
2013-08-01 18:31:42 +02:00
|
|
|
// removeBlockNode removes the passed block node from the memory chain by
|
|
|
|
// unlinking all of its children and removing it from the the node and
|
|
|
|
// dependency indices.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-08-01 18:31:42 +02:00
|
|
|
func (b *BlockChain) removeBlockNode(node *blockNode) error {
|
|
|
|
if node.parent != nil {
|
2015-08-26 06:03:18 +02:00
|
|
|
return AssertError(fmt.Sprintf("removeBlockNode must be "+
|
|
|
|
"called with a node at the front of the chain - node %v",
|
|
|
|
node.hash))
|
2013-08-01 18:31:42 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Remove the node from the node index.
|
|
|
|
delete(b.index, *node.hash)
|
|
|
|
|
|
|
|
// Unlink all of the node's children.
|
|
|
|
for _, child := range node.children {
|
|
|
|
child.parent = nil
|
|
|
|
}
|
|
|
|
node.children = nil
|
|
|
|
|
|
|
|
// Remove the reference from the dependency index.
|
|
|
|
prevHash := node.parentHash
|
|
|
|
if children, ok := b.depNodes[*prevHash]; ok {
|
|
|
|
// Find the node amongst the children of the
|
|
|
|
// dependencies for the parent hash and remove it.
|
2013-08-02 05:28:25 +02:00
|
|
|
b.depNodes[*prevHash] = removeChildNode(children, node)
|
2013-08-01 18:31:42 +02:00
|
|
|
|
|
|
|
// Remove the map entry altogether if there are no
|
|
|
|
// longer any nodes which depend on the parent hash.
|
|
|
|
if len(b.depNodes[*prevHash]) == 0 {
|
|
|
|
delete(b.depNodes, *prevHash)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// pruneBlockNodes removes references to old block nodes which are no longer
|
|
|
|
// needed so they may be garbage collected. In order to validate block rules
|
|
|
|
// and choose the best chain, only a portion of the nodes which form the block
|
|
|
|
// chain are needed in memory. This function walks the chain backwards from the
|
|
|
|
// current best chain to find any nodes before the first needed block node.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-08-01 18:31:42 +02:00
|
|
|
func (b *BlockChain) pruneBlockNodes() error {
|
|
|
|
// Walk the chain backwards to find what should be the new root node.
|
|
|
|
// Intentionally use node.parent instead of getPrevNodeFromNode since
|
|
|
|
// the latter loads the node and the goal is to find nodes still in
|
|
|
|
// memory that can be pruned.
|
2015-08-26 06:03:18 +02:00
|
|
|
newRootNode := b.bestNode
|
2015-08-08 04:20:49 +02:00
|
|
|
for i := int32(0); i < minMemoryNodes-1 && newRootNode != nil; i++ {
|
2013-08-01 18:31:42 +02:00
|
|
|
newRootNode = newRootNode.parent
|
|
|
|
}
|
|
|
|
|
|
|
|
// Nothing to do if there are not enough nodes.
|
|
|
|
if newRootNode == nil || newRootNode.parent == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Push the nodes to delete on a list in reverse order since it's easier
|
|
|
|
// to prune them going forwards than it is backwards. This will
|
|
|
|
// typically end up being a single node since pruning is currently done
|
|
|
|
// just before each new node is created. However, that might be tuned
|
|
|
|
// later to only prune at intervals, so the code needs to account for
|
|
|
|
// the possibility of multiple nodes.
|
|
|
|
deleteNodes := list.New()
|
|
|
|
for node := newRootNode.parent; node != nil; node = node.parent {
|
|
|
|
deleteNodes.PushFront(node)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Loop through each node to prune, unlink its children, remove it from
|
|
|
|
// the dependency index, and remove it from the node index.
|
|
|
|
for e := deleteNodes.Front(); e != nil; e = e.Next() {
|
|
|
|
node := e.Value.(*blockNode)
|
|
|
|
err := b.removeBlockNode(node)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// isMajorityVersion determines if a previous number of blocks in the chain
|
|
|
|
// starting with startNode are at least the minimum passed version.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
|
|
|
func (b *BlockChain) isMajorityVersion(minVer int32, startNode *blockNode, numRequired uint64) bool {
|
2013-07-18 16:49:28 +02:00
|
|
|
numFound := uint64(0)
|
|
|
|
iterNode := startNode
|
2015-02-18 21:09:54 +01:00
|
|
|
for i := uint64(0); i < b.chainParams.BlockUpgradeNumToCheck &&
|
|
|
|
numFound < numRequired && iterNode != nil; i++ {
|
2013-07-18 16:49:28 +02:00
|
|
|
// This node has a version that is at least the minimum version.
|
|
|
|
if iterNode.version >= minVer {
|
|
|
|
numFound++
|
|
|
|
}
|
|
|
|
|
|
|
|
// Get the previous block node. This function is used over
|
|
|
|
// simply accessing iterNode.parent directly as it will
|
|
|
|
// dynamically create previous block nodes as needed. This
|
|
|
|
// helps allow only the pieces of the chain that are needed
|
|
|
|
// to remain in memory.
|
|
|
|
var err error
|
|
|
|
iterNode, err = b.getPrevNodeFromNode(iterNode)
|
|
|
|
if err != nil {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
return numFound >= numRequired
|
|
|
|
}
|
|
|
|
|
|
|
|
// calcPastMedianTime calculates the median time of the previous few blocks
|
|
|
|
// prior to, and including, the passed block node. It is primarily used to
|
|
|
|
// validate new blocks have sane timestamps.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2013-07-18 16:49:28 +02:00
|
|
|
func (b *BlockChain) calcPastMedianTime(startNode *blockNode) (time.Time, error) {
|
|
|
|
// Genesis block.
|
|
|
|
if startNode == nil {
|
2015-02-06 06:18:27 +01:00
|
|
|
return b.chainParams.GenesisBlock.Header.Timestamp, nil
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// Create a slice of the previous few block timestamps used to calculate
|
|
|
|
// the median per the number defined by the constant medianTimeBlocks.
|
|
|
|
timestamps := make([]time.Time, medianTimeBlocks)
|
|
|
|
numNodes := 0
|
|
|
|
iterNode := startNode
|
|
|
|
for i := 0; i < medianTimeBlocks && iterNode != nil; i++ {
|
|
|
|
timestamps[i] = iterNode.timestamp
|
|
|
|
numNodes++
|
|
|
|
|
|
|
|
// Get the previous block node. This function is used over
|
|
|
|
// simply accessing iterNode.parent directly as it will
|
|
|
|
// dynamically create previous block nodes as needed. This
|
|
|
|
// helps allow only the pieces of the chain that are needed
|
|
|
|
// to remain in memory.
|
|
|
|
var err error
|
|
|
|
iterNode, err = b.getPrevNodeFromNode(iterNode)
|
|
|
|
if err != nil {
|
2013-07-24 19:31:14 +02:00
|
|
|
log.Errorf("getPrevNodeFromNode: %v", err)
|
2013-07-18 16:49:28 +02:00
|
|
|
return time.Time{}, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Prune the slice to the actual number of available timestamps which
|
|
|
|
// will be fewer than desired near the beginning of the block chain
|
|
|
|
// and sort them.
|
|
|
|
timestamps = timestamps[:numNodes]
|
|
|
|
sort.Sort(timeSorter(timestamps))
|
|
|
|
|
|
|
|
// NOTE: bitcoind incorrectly calculates the median for even numbers of
|
|
|
|
// blocks. A true median averages the middle two elements for a set
|
|
|
|
// with an even number of elements in it. Since the constant for the
|
|
|
|
// previous number of blocks to be used is odd, this is only an issue
|
|
|
|
// for a few blocks near the beginning of the chain. I suspect this is
|
|
|
|
// an optimization even though the result is slightly wrong for a few
|
|
|
|
// of the first blocks since after the first few blocks, there will
|
|
|
|
// always be an odd number of blocks in the set per the constant.
|
|
|
|
//
|
|
|
|
// This code follows suit to ensure the same rules are used as bitcoind
|
|
|
|
// however, be aware that should the medianTimeBlocks constant ever be
|
|
|
|
// changed to an even number, this code will be wrong.
|
|
|
|
medianTimestamp := timestamps[numNodes/2]
|
|
|
|
return medianTimestamp, nil
|
|
|
|
}
|
|
|
|
|
2014-03-15 21:04:10 +01:00
|
|
|
// CalcPastMedianTime calculates the median time of the previous few blocks
|
|
|
|
// prior to, and including, the end of the current best chain. It is primarily
|
|
|
|
// used to ensure new blocks have sane timestamps.
|
|
|
|
//
|
2015-08-26 06:03:18 +02:00
|
|
|
// This function is safe for concurrent access.
|
2014-03-15 21:04:10 +01:00
|
|
|
func (b *BlockChain) CalcPastMedianTime() (time.Time, error) {
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Lock()
|
|
|
|
defer b.chainLock.Unlock()
|
|
|
|
|
|
|
|
return b.calcPastMedianTime(b.bestNode)
|
2014-03-15 21:04:10 +01:00
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// getReorganizeNodes finds the fork point between the main chain and the passed
|
|
|
|
// node and returns a list of block nodes that would need to be detached from
|
|
|
|
// the main chain and a list of block nodes that would need to be attached to
|
|
|
|
// the fork point (which will be the end of the main chain after detaching the
|
|
|
|
// returned list of block nodes) in order to reorganize the chain such that the
|
|
|
|
// passed node is the new end of the main chain. The lists will be empty if the
|
|
|
|
// passed node is not on a side chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for reads).
|
2013-07-18 16:49:28 +02:00
|
|
|
func (b *BlockChain) getReorganizeNodes(node *blockNode) (*list.List, *list.List) {
|
|
|
|
// Nothing to detach or attach if there is no node.
|
|
|
|
attachNodes := list.New()
|
|
|
|
detachNodes := list.New()
|
|
|
|
if node == nil {
|
|
|
|
return detachNodes, attachNodes
|
|
|
|
}
|
|
|
|
|
|
|
|
// Find the fork point (if any) adding each block to the list of nodes
|
|
|
|
// to attach to the main tree. Push them onto the list in reverse order
|
|
|
|
// so they are attached in the appropriate order when iterating the list
|
|
|
|
// later.
|
|
|
|
ancestor := node
|
|
|
|
for ; ancestor.parent != nil; ancestor = ancestor.parent {
|
|
|
|
if ancestor.inMainChain {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
attachNodes.PushFront(ancestor)
|
|
|
|
}
|
|
|
|
|
|
|
|
// TODO(davec): Use prevNodeFromNode function in case the requested
|
|
|
|
// node is further back than the what is in memory. This shouldn't
|
|
|
|
// happen in the normal course of operation, but the ability to fetch
|
|
|
|
// input transactions of arbitrary blocks will likely to be exposed at
|
|
|
|
// some point and that could lead to an issue here.
|
|
|
|
|
|
|
|
// Start from the end of the main chain and work backwards until the
|
|
|
|
// common ancestor adding each block to the list of nodes to detach from
|
|
|
|
// the main chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
for n := b.bestNode; n != nil && n.parent != nil; n = n.parent {
|
2013-07-18 16:49:28 +02:00
|
|
|
if n.hash.IsEqual(ancestor.hash) {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
detachNodes.PushBack(n)
|
|
|
|
}
|
|
|
|
|
|
|
|
return detachNodes, attachNodes
|
|
|
|
}
|
|
|
|
|
2016-02-19 05:51:18 +01:00
|
|
|
// dbMaybeStoreBlock stores the provided block in the database if it's not
|
|
|
|
// already there.
|
|
|
|
func dbMaybeStoreBlock(dbTx database.Tx, block *btcutil.Block) error {
|
|
|
|
hasBlock, err := dbTx.HasBlock(block.Sha())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
if hasBlock {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
return dbTx.StoreBlock(block)
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// connectBlock handles connecting the passed node/block to the end of the main
|
|
|
|
// (best) chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This passed utxo view must have all referenced txos the block spends marked
|
|
|
|
// as spent and all of the new txos the block creates added to it. In addition,
|
|
|
|
// the passed stxos slice must be populated with all of the information for the
|
|
|
|
// spent txos. This approach is used because the connection validation that
|
|
|
|
// must happen prior to calling this function requires the same details, so
|
|
|
|
// it would be inefficient to repeat it.
|
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
|
|
|
func (b *BlockChain) connectBlock(node *blockNode, block *btcutil.Block, view *UtxoViewpoint, stxos []spentTxOut) error {
|
2013-07-18 16:49:28 +02:00
|
|
|
// Make sure it's extending the end of the best chain.
|
|
|
|
prevHash := &block.MsgBlock().Header.PrevBlock
|
2015-08-26 06:03:18 +02:00
|
|
|
if !prevHash.IsEqual(b.bestNode.hash) {
|
|
|
|
return AssertError("connectBlock must be called with a block " +
|
2013-07-18 16:49:28 +02:00
|
|
|
"that extends the main chain")
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Sanity check the correct number of stxos are provided.
|
|
|
|
if len(stxos) != countSpentOutputs(block) {
|
|
|
|
return AssertError("connectBlock called with inconsistent " +
|
|
|
|
"spent transaction out information")
|
|
|
|
}
|
|
|
|
|
|
|
|
// Generate a new best state snapshot that will be used to update the
|
|
|
|
// database and later memory if all database updates are successful.
|
|
|
|
b.stateLock.RLock()
|
|
|
|
curTotalTxns := b.stateSnapshot.TotalTxns
|
|
|
|
b.stateLock.RUnlock()
|
|
|
|
numTxns := uint64(len(block.MsgBlock().Transactions))
|
|
|
|
blockSize := uint64(block.MsgBlock().SerializeSize())
|
|
|
|
state := newBestState(node, blockSize, numTxns, curTotalTxns+numTxns)
|
|
|
|
|
|
|
|
// Atomically insert info into the database.
|
|
|
|
err := b.db.Update(func(dbTx database.Tx) error {
|
|
|
|
// Update best block state.
|
|
|
|
err := dbPutBestState(dbTx, state, node.workSum)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Add the block hash and height to the block index which tracks
|
|
|
|
// the main chain.
|
|
|
|
err = dbPutBlockIndex(dbTx, block.Sha(), node.height)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the utxo set using the state of the utxo view. This
|
|
|
|
// entails removing all of the utxos spent and adding the new
|
|
|
|
// ones created by the block.
|
|
|
|
err = dbPutUtxoView(dbTx, view)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the transaction spend journal by adding a record for
|
|
|
|
// the block that contains all txos spent by it.
|
|
|
|
err = dbPutSpendJournalEntry(dbTx, block.Sha(), stxos)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Insert the block into the database if it's not already there.
|
2016-02-19 05:51:18 +01:00
|
|
|
err = dbMaybeStoreBlock(dbTx, block)
|
2015-08-26 06:03:18 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2016-02-19 05:51:18 +01:00
|
|
|
|
|
|
|
// Allow the index manager to call each of the currently active
|
|
|
|
// optional indexes with the block being connected so they can
|
|
|
|
// update themselves accordingly.
|
|
|
|
if b.indexManager != nil {
|
|
|
|
err := b.indexManager.ConnectBlock(dbTx, block, view)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2015-08-26 06:03:18 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
})
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Prune fully spent entries and mark all entries in the view unmodified
|
|
|
|
// now that the modifications have been committed to the database.
|
|
|
|
view.commit()
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Add the new node to the memory main chain indices for faster
|
|
|
|
// lookups.
|
|
|
|
node.inMainChain = true
|
|
|
|
b.index[*node.hash] = node
|
|
|
|
b.depNodes[*prevHash] = append(b.depNodes[*prevHash], node)
|
|
|
|
|
|
|
|
// This node is now the end of the best chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
b.bestNode = node
|
|
|
|
|
|
|
|
// Update the state for the best block. Notice how this replaces the
|
|
|
|
// entire struct instead of updating the existing one. This effectively
|
|
|
|
// allows the old version to act as a snapshot which callers can use
|
|
|
|
// freely without needing to hold a lock for the duration. See the
|
|
|
|
// comments on the state variable for more details.
|
|
|
|
b.stateLock.Lock()
|
|
|
|
b.stateSnapshot = state
|
|
|
|
b.stateLock.Unlock()
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// Notify the caller that the block was connected to the main chain.
|
|
|
|
// The caller would typically want to react with actions such as
|
|
|
|
// updating wallets.
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Unlock()
|
2013-07-18 16:49:28 +02:00
|
|
|
b.sendNotification(NTBlockConnected, block)
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Lock()
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// disconnectBlock handles disconnecting the passed node/block from the end of
|
|
|
|
// the main (best) chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
|
|
|
func (b *BlockChain) disconnectBlock(node *blockNode, block *btcutil.Block, view *UtxoViewpoint) error {
|
2013-07-18 16:49:28 +02:00
|
|
|
// Make sure the node being disconnected is the end of the best chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
if !node.hash.IsEqual(b.bestNode.hash) {
|
|
|
|
return AssertError("disconnectBlock must be called with the " +
|
2013-07-18 16:49:28 +02:00
|
|
|
"block at the end of the main chain")
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Get the previous block node. This function is used over simply
|
|
|
|
// accessing node.parent directly as it will dynamically create previous
|
|
|
|
// block nodes as needed. This helps allow only the pieces of the chain
|
|
|
|
// that are needed to remain in memory.
|
2013-07-18 16:49:28 +02:00
|
|
|
prevNode, err := b.getPrevNodeFromNode(node)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// Load the previous block since some details for it are needed below.
|
|
|
|
var prevBlock *btcutil.Block
|
|
|
|
err = b.db.View(func(dbTx database.Tx) error {
|
|
|
|
var err error
|
|
|
|
prevBlock, err = dbFetchBlockByHash(dbTx, prevNode.hash)
|
|
|
|
return err
|
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Generate a new best state snapshot that will be used to update the
|
|
|
|
// database and later memory if all database updates are successful.
|
|
|
|
b.stateLock.RLock()
|
|
|
|
curTotalTxns := b.stateSnapshot.TotalTxns
|
|
|
|
b.stateLock.RUnlock()
|
|
|
|
numTxns := uint64(len(prevBlock.MsgBlock().Transactions))
|
|
|
|
blockSize := uint64(prevBlock.MsgBlock().SerializeSize())
|
|
|
|
newTotalTxns := curTotalTxns - uint64(len(block.MsgBlock().Transactions))
|
|
|
|
state := newBestState(prevNode, blockSize, numTxns, newTotalTxns)
|
|
|
|
|
|
|
|
err = b.db.Update(func(dbTx database.Tx) error {
|
|
|
|
// Update best block state.
|
|
|
|
err := dbPutBestState(dbTx, state, node.workSum)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Remove the block hash and height from the block index which
|
|
|
|
// tracks the main chain.
|
|
|
|
err = dbRemoveBlockIndex(dbTx, block.Sha(), node.height)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the utxo set using the state of the utxo view. This
|
|
|
|
// entails restoring all of the utxos spent and removing the new
|
|
|
|
// ones created by the block.
|
|
|
|
err = dbPutUtxoView(dbTx, view)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the transaction spend journal by removing the record
|
|
|
|
// that contains all txos spent by the block .
|
|
|
|
err = dbRemoveSpendJournalEntry(dbTx, block.Sha())
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2016-02-19 05:51:18 +01:00
|
|
|
// Allow the index manager to call each of the currently active
|
|
|
|
// optional indexes with the block being disconnected so they
|
|
|
|
// can update themselves accordingly.
|
|
|
|
if b.indexManager != nil {
|
|
|
|
err := b.indexManager.DisconnectBlock(dbTx, block, view)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
return nil
|
|
|
|
})
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Prune fully spent entries and mark all entries in the view unmodified
|
|
|
|
// now that the modifications have been committed to the database.
|
|
|
|
view.commit()
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Put block in the side chain cache.
|
|
|
|
node.inMainChain = false
|
|
|
|
b.blockCache[*node.hash] = block
|
|
|
|
|
|
|
|
// This node's parent is now the end of the best chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
b.bestNode = node.parent
|
|
|
|
|
|
|
|
// Update the state for the best block. Notice how this replaces the
|
|
|
|
// entire struct instead of updating the existing one. This effectively
|
|
|
|
// allows the old version to act as a snapshot which callers can use
|
|
|
|
// freely without needing to hold a lock for the duration. See the
|
|
|
|
// comments on the state variable for more details.
|
|
|
|
b.stateLock.Lock()
|
|
|
|
b.stateSnapshot = state
|
|
|
|
b.stateLock.Unlock()
|
2013-07-18 16:49:28 +02:00
|
|
|
|
2013-10-11 17:24:13 +02:00
|
|
|
// Notify the caller that the block was disconnected from the main
|
|
|
|
// chain. The caller would typically want to react with actions such as
|
2013-07-18 16:49:28 +02:00
|
|
|
// updating wallets.
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Unlock()
|
2013-07-18 16:49:28 +02:00
|
|
|
b.sendNotification(NTBlockDisconnected, block)
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.Lock()
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// countSpentOutputs returns the number of utxos the passed block spends.
|
|
|
|
func countSpentOutputs(block *btcutil.Block) int {
|
|
|
|
// Exclude the coinbase transaction since it can't spend anything.
|
|
|
|
var numSpent int
|
|
|
|
for _, tx := range block.Transactions()[1:] {
|
|
|
|
numSpent += len(tx.MsgTx().TxIn)
|
|
|
|
}
|
|
|
|
return numSpent
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// reorganizeChain reorganizes the block chain by disconnecting the nodes in the
|
|
|
|
// detachNodes list and connecting the nodes in the attach list. It expects
|
|
|
|
// that the lists are already in the correct order and are in sync with the
|
|
|
|
// end of the current best chain. Specifically, nodes that are being
|
2015-08-26 06:03:18 +02:00
|
|
|
// disconnected must be in reverse order (think of popping them off the end of
|
|
|
|
// the chain) and nodes the are being attached must be in forwards order
|
|
|
|
// (think pushing them onto the end of the chain).
|
2014-06-29 22:11:13 +02:00
|
|
|
//
|
|
|
|
// The flags modify the behavior of this function as follows:
|
|
|
|
// - BFDryRun: Only the checks which ensure the reorganize can be completed
|
|
|
|
// successfully are performed. The chain is not reorganized.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2014-06-29 22:11:13 +02:00
|
|
|
func (b *BlockChain) reorganizeChain(detachNodes, attachNodes *list.List, flags BehaviorFlags) error {
|
2013-07-18 16:49:28 +02:00
|
|
|
// Ensure all of the needed side chain blocks are in the cache.
|
|
|
|
for e := attachNodes.Front(); e != nil; e = e.Next() {
|
|
|
|
n := e.Value.(*blockNode)
|
|
|
|
if _, exists := b.blockCache[*n.hash]; !exists {
|
2015-08-26 06:03:18 +02:00
|
|
|
return AssertError(fmt.Sprintf("block %v is missing "+
|
|
|
|
"from the side chain block cache", n.hash))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// All of the blocks to detach and related spend journal entries needed
|
|
|
|
// to unspend transaction outputs in the blocks being disconnected must
|
|
|
|
// be loaded from the database during the reorg check phase below and
|
|
|
|
// then they are needed again when doing the actual database updates.
|
|
|
|
// Rather than doing two loads, cache the loaded data into these slices.
|
|
|
|
detachBlocks := make([]*btcutil.Block, 0, detachNodes.Len())
|
|
|
|
detachSpentTxOuts := make([][]spentTxOut, 0, detachNodes.Len())
|
|
|
|
|
|
|
|
// Disconnect all of the blocks back to the point of the fork. This
|
|
|
|
// entails loading the blocks and their associated spent txos from the
|
|
|
|
// database and using that information to unspend all of the spent txos
|
|
|
|
// and remove the utxos created by the blocks.
|
|
|
|
view := NewUtxoViewpoint()
|
|
|
|
view.SetBestHash(b.bestNode.hash)
|
|
|
|
for e := detachNodes.Front(); e != nil; e = e.Next() {
|
|
|
|
n := e.Value.(*blockNode)
|
|
|
|
var block *btcutil.Block
|
|
|
|
err := b.db.View(func(dbTx database.Tx) error {
|
|
|
|
var err error
|
|
|
|
block, err = dbFetchBlockByHash(dbTx, n.hash)
|
|
|
|
return err
|
|
|
|
})
|
|
|
|
|
|
|
|
// Load all of the utxos referenced by the block that aren't
|
|
|
|
// already in the view.
|
|
|
|
err = view.fetchInputUtxos(b.db, block)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Load all of the spent txos for the block from the spend
|
|
|
|
// journal.
|
|
|
|
var stxos []spentTxOut
|
|
|
|
err = b.db.View(func(dbTx database.Tx) error {
|
|
|
|
stxos, err = dbFetchSpendJournalEntry(dbTx, block, view)
|
|
|
|
return err
|
|
|
|
})
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Store the loaded block and spend journal entry for later.
|
|
|
|
detachBlocks = append(detachBlocks, block)
|
|
|
|
detachSpentTxOuts = append(detachSpentTxOuts, stxos)
|
|
|
|
|
|
|
|
err = view.disconnectTransactions(block, stxos)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Perform several checks to verify each block that needs to be attached
|
|
|
|
// to the main chain can be connected without violating any rules and
|
|
|
|
// without actually connecting the block.
|
|
|
|
//
|
2015-08-26 06:03:18 +02:00
|
|
|
// NOTE: These checks could be done directly when connecting a block,
|
|
|
|
// however the downside to that approach is that if any of these checks
|
|
|
|
// fail after disconnecting some blocks or attaching others, all of the
|
2013-07-18 16:49:28 +02:00
|
|
|
// operations have to be rolled back to get the chain back into the
|
|
|
|
// state it was before the rule violation (or other failure). There are
|
|
|
|
// at least a couple of ways accomplish that rollback, but both involve
|
2015-08-26 06:03:18 +02:00
|
|
|
// tweaking the chain and/or database. This approach catches these
|
|
|
|
// issues before ever modifying the chain.
|
2013-07-18 16:49:28 +02:00
|
|
|
for e := attachNodes.Front(); e != nil; e = e.Next() {
|
|
|
|
n := e.Value.(*blockNode)
|
|
|
|
block := b.blockCache[*n.hash]
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// Notice the spent txout details are not requested here and
|
|
|
|
// thus will not be generated. This is done because the state
|
|
|
|
// is not being immediately written to the database, so it is
|
|
|
|
// not needed.
|
|
|
|
err := b.checkConnectBlock(n, block, view, nil)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-06-29 22:11:13 +02:00
|
|
|
// Skip disconnecting and connecting the blocks when running with the
|
|
|
|
// dry run flag set.
|
|
|
|
if flags&BFDryRun == BFDryRun {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Reset the view for the actual connection code below. This is
|
|
|
|
// required because the view was previously modified when checking if
|
|
|
|
// the reorg would be successful and the connection code requires the
|
|
|
|
// view to be valid from the viewpoint of each block being connected or
|
|
|
|
// disconnected.
|
|
|
|
view = NewUtxoViewpoint()
|
|
|
|
view.SetBestHash(b.bestNode.hash)
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Disconnect blocks from the main chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
for i, e := 0, detachNodes.Front(); e != nil; i, e = i+1, e.Next() {
|
2013-07-18 16:49:28 +02:00
|
|
|
n := e.Value.(*blockNode)
|
2015-08-26 06:03:18 +02:00
|
|
|
block := detachBlocks[i]
|
|
|
|
|
|
|
|
// Load all of the utxos referenced by the block that aren't
|
|
|
|
// already in the view.
|
|
|
|
err := view.fetchInputUtxos(b.db, block)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// Update the view to unspend all of the spent txos and remove
|
|
|
|
// the utxos created by the block.
|
|
|
|
err = view.disconnectTransactions(block, detachSpentTxOuts[i])
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the database and chain state.
|
|
|
|
err = b.disconnectBlock(n, block, view)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Connect the new best chain blocks.
|
|
|
|
for e := attachNodes.Front(); e != nil; e = e.Next() {
|
|
|
|
n := e.Value.(*blockNode)
|
|
|
|
block := b.blockCache[*n.hash]
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// Load all of the utxos referenced by the block that aren't
|
|
|
|
// already in the view.
|
|
|
|
err := view.fetchInputUtxos(b.db, block)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the view to mark all utxos referenced by the block
|
|
|
|
// as spent and add all transactions being created by this block
|
|
|
|
// to it. Also, provide an stxo slice so the spent txout
|
|
|
|
// details are generated.
|
|
|
|
stxos := make([]spentTxOut, 0, countSpentOutputs(block))
|
|
|
|
err = view.connectTransactions(block, &stxos)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Update the database and chain state.
|
|
|
|
err = b.connectBlock(n, block, view, stxos)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
delete(b.blockCache, *n.hash)
|
|
|
|
}
|
|
|
|
|
2013-07-30 05:32:12 +02:00
|
|
|
// Log the point where the chain forked.
|
|
|
|
firstAttachNode := attachNodes.Front().Value.(*blockNode)
|
|
|
|
forkNode, err := b.getPrevNodeFromNode(firstAttachNode)
|
|
|
|
if err == nil {
|
|
|
|
log.Infof("REORGANIZE: Chain forks at %v", forkNode.hash)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Log the old and new best chain heads.
|
|
|
|
firstDetachNode := detachNodes.Front().Value.(*blockNode)
|
|
|
|
lastAttachNode := attachNodes.Back().Value.(*blockNode)
|
|
|
|
log.Infof("REORGANIZE: Old best chain head was %v", firstDetachNode.hash)
|
|
|
|
log.Infof("REORGANIZE: New best chain head is %v", lastAttachNode.hash)
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// connectBestChain handles connecting the passed block to the chain while
|
|
|
|
// respecting proper chain selection according to the chain with the most
|
|
|
|
// proof of work. In the typical case, the new block simply extends the main
|
|
|
|
// chain. However, it may also be extending (or creating) a side chain (fork)
|
|
|
|
// which may or may not end up becoming the main chain depending on which fork
|
|
|
|
// cumulatively has the most proof of work.
|
2014-06-26 22:50:13 +02:00
|
|
|
//
|
|
|
|
// The flags modify the behavior of this function as follows:
|
2015-08-26 06:03:18 +02:00
|
|
|
// - BFFastAdd: Avoids several expensive transaction validation operations.
|
|
|
|
// This is useful when using checkpoints.
|
2014-06-29 22:11:13 +02:00
|
|
|
// - BFDryRun: Prevents the block from being connected and avoids modifying the
|
|
|
|
// state of the memory chain index. Also, any log messages related to
|
|
|
|
// modifying the state are avoided.
|
2015-08-26 06:03:18 +02:00
|
|
|
//
|
|
|
|
// This function MUST be called with the chain state lock held (for writes).
|
2014-06-26 22:50:13 +02:00
|
|
|
func (b *BlockChain) connectBestChain(node *blockNode, block *btcutil.Block, flags BehaviorFlags) error {
|
|
|
|
fastAdd := flags&BFFastAdd == BFFastAdd
|
2014-06-29 22:11:13 +02:00
|
|
|
dryRun := flags&BFDryRun == BFDryRun
|
2014-06-26 22:50:13 +02:00
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// We are extending the main (best) chain with a new block. This is the
|
|
|
|
// most common case.
|
|
|
|
if node.parentHash.IsEqual(b.bestNode.hash) {
|
2013-07-18 16:49:28 +02:00
|
|
|
// Perform several checks to verify the block can be connected
|
2015-08-26 06:03:18 +02:00
|
|
|
// to the main chain without violating any rules and without
|
|
|
|
// actually connecting the block.
|
|
|
|
view := NewUtxoViewpoint()
|
|
|
|
view.SetBestHash(node.parentHash)
|
|
|
|
stxos := make([]spentTxOut, 0, countSpentOutputs(block))
|
2013-11-18 22:23:51 +01:00
|
|
|
if !fastAdd {
|
2015-08-26 06:03:18 +02:00
|
|
|
err := b.checkConnectBlock(node, block, view, &stxos)
|
2013-11-18 22:23:51 +01:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
|
|
|
|
2014-06-29 22:11:13 +02:00
|
|
|
// Don't connect the block if performing a dry run.
|
|
|
|
if dryRun {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// In the fast add case the code to check the block connection
|
|
|
|
// was skipped, so the utxo view needs to load the referenced
|
|
|
|
// utxos, spend them, and add the new utxos being created by
|
|
|
|
// this block.
|
|
|
|
if fastAdd {
|
|
|
|
err := view.fetchInputUtxos(b.db, block)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
err = view.connectTransactions(block, &stxos)
|
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// Connect the block to the main chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
err := b.connectBlock(node, block, view, stxos)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Connect the parent node to this node.
|
|
|
|
if node.parent != nil {
|
|
|
|
node.parent.children = append(node.parent.children, node)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
2013-11-18 22:23:51 +01:00
|
|
|
if fastAdd {
|
2015-04-17 07:44:15 +02:00
|
|
|
log.Warnf("fastAdd set in the side chain case? %v\n",
|
|
|
|
block.Sha())
|
2013-11-18 22:23:51 +01:00
|
|
|
}
|
2013-07-18 16:49:28 +02:00
|
|
|
|
|
|
|
// We're extending (or creating) a side chain which may or may not
|
|
|
|
// become the main chain, but in either case we need the block stored
|
|
|
|
// for future processing, so add the block to the side chain holding
|
|
|
|
// cache.
|
2014-06-29 22:11:13 +02:00
|
|
|
if !dryRun {
|
|
|
|
log.Debugf("Adding block %v to side chain cache", node.hash)
|
|
|
|
}
|
2013-07-18 16:49:28 +02:00
|
|
|
b.blockCache[*node.hash] = block
|
|
|
|
b.index[*node.hash] = node
|
|
|
|
|
2014-01-28 20:34:42 +01:00
|
|
|
// Connect the parent node to this node.
|
|
|
|
node.inMainChain = false
|
|
|
|
node.parent.children = append(node.parent.children, node)
|
|
|
|
|
2014-06-29 22:11:13 +02:00
|
|
|
// Remove the block from the side chain cache and disconnect it from the
|
|
|
|
// parent node when the function returns when running in dry run mode.
|
|
|
|
if dryRun {
|
|
|
|
defer func() {
|
|
|
|
children := node.parent.children
|
|
|
|
children = removeChildNode(children, node)
|
|
|
|
node.parent.children = children
|
|
|
|
|
|
|
|
delete(b.index, *node.hash)
|
|
|
|
delete(b.blockCache, *node.hash)
|
|
|
|
}()
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
// We're extending (or creating) a side chain, but the cumulative
|
|
|
|
// work for this new side chain is not enough to make it the new chain.
|
2015-08-26 06:03:18 +02:00
|
|
|
if node.workSum.Cmp(b.bestNode.workSum) <= 0 {
|
2014-06-29 22:11:13 +02:00
|
|
|
// Skip Logging info when the dry run flag is set.
|
|
|
|
if dryRun {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-07-30 05:32:12 +02:00
|
|
|
// Find the fork point.
|
|
|
|
fork := node
|
|
|
|
for ; fork.parent != nil; fork = fork.parent {
|
|
|
|
if fork.inMainChain {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Log information about how the block is forking the chain.
|
|
|
|
if fork.hash.IsEqual(node.parent.hash) {
|
|
|
|
log.Infof("FORK: Block %v forks the chain at height %d"+
|
|
|
|
"/block %v, but does not cause a reorganize",
|
|
|
|
node.hash, fork.height, fork.hash)
|
|
|
|
} else {
|
|
|
|
log.Infof("EXTEND FORK: Block %v extends a side chain "+
|
|
|
|
"which forks the chain at height %d/block %v",
|
|
|
|
node.hash, fork.height, fork.hash)
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
2014-06-26 22:50:13 +02:00
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// We're extending (or creating) a side chain and the cumulative work
|
|
|
|
// for this new side chain is more than the old best chain, so this side
|
|
|
|
// chain needs to become the main chain. In order to accomplish that,
|
|
|
|
// find the common ancestor of both sides of the fork, disconnect the
|
|
|
|
// blocks that form the (now) old fork from the main chain, and attach
|
|
|
|
// the blocks that form the new chain to the main chain starting at the
|
|
|
|
// common ancenstor (the point where the chain forked).
|
|
|
|
detachNodes, attachNodes := b.getReorganizeNodes(node)
|
|
|
|
|
|
|
|
// Reorganize the chain.
|
2014-06-29 22:11:13 +02:00
|
|
|
if !dryRun {
|
|
|
|
log.Infof("REORGANIZE: Block %v is causing a reorganize.",
|
|
|
|
node.hash)
|
|
|
|
}
|
|
|
|
err := b.reorganizeChain(detachNodes, attachNodes, flags)
|
2013-07-18 16:49:28 +02:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2013-09-23 15:20:54 +02:00
|
|
|
// IsCurrent returns whether or not the chain believes it is current. Several
|
|
|
|
// factors are used to guess, but the key factors that allow the chain to
|
|
|
|
// believe it is current are:
|
|
|
|
// - Latest block height is after the latest checkpoint (if enabled)
|
|
|
|
// - Latest block has a timestamp newer than 24 hours ago
|
|
|
|
//
|
2015-08-26 06:03:18 +02:00
|
|
|
// This function is safe for concurrent access.
|
2016-07-14 02:36:36 +02:00
|
|
|
func (b *BlockChain) IsCurrent() bool {
|
2015-08-26 06:03:18 +02:00
|
|
|
b.chainLock.RLock()
|
|
|
|
defer b.chainLock.RUnlock()
|
2013-09-23 15:20:54 +02:00
|
|
|
|
|
|
|
// Not current if the latest main (best) chain height is before the
|
|
|
|
// latest known good checkpoint (when checkpoints are enabled).
|
2015-08-26 06:03:18 +02:00
|
|
|
checkpoint := b.latestCheckpoint()
|
|
|
|
if checkpoint != nil && b.bestNode.height < checkpoint.Height {
|
2013-09-23 15:20:54 +02:00
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
// Not current if the latest best block has a timestamp before 24 hours
|
|
|
|
// ago.
|
2016-07-14 02:36:36 +02:00
|
|
|
minus24Hours := b.timeSource.AdjustedTime().Add(-24 * time.Hour)
|
2015-08-26 06:03:18 +02:00
|
|
|
if b.bestNode.timestamp.Before(minus24Hours) {
|
2013-09-23 15:20:54 +02:00
|
|
|
return false
|
|
|
|
}
|
|
|
|
|
|
|
|
// The chain appears to be current if the above checks did not report
|
|
|
|
// otherwise.
|
|
|
|
return true
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// BestSnapshot returns information about the current best chain block and
|
|
|
|
// related state as of the current point in time. The returned instance must be
|
|
|
|
// treated as immutable since it is shared by all callers.
|
|
|
|
//
|
|
|
|
// This function is safe for concurrent access.
|
|
|
|
func (b *BlockChain) BestSnapshot() *BestState {
|
|
|
|
b.stateLock.RLock()
|
|
|
|
snapshot := b.stateSnapshot
|
|
|
|
b.stateLock.RUnlock()
|
|
|
|
return snapshot
|
|
|
|
}
|
|
|
|
|
2016-02-19 05:51:18 +01:00
|
|
|
// IndexManager provides a generic interface that the is called when blocks are
|
|
|
|
// connected and disconnected to and from the tip of the main chain for the
|
|
|
|
// purpose of supporting optional indexes.
|
|
|
|
type IndexManager interface {
|
|
|
|
// Init is invoked during chain initialize in order to allow the index
|
|
|
|
// manager to initialize itself and any indexes it is managing.
|
|
|
|
Init(*BlockChain) error
|
|
|
|
|
|
|
|
// ConnectBlock is invoked when a new block has been connected to the
|
|
|
|
// main chain.
|
|
|
|
ConnectBlock(database.Tx, *btcutil.Block, *UtxoViewpoint) error
|
|
|
|
|
|
|
|
// DisconnectBlock is invoked when a block has been disconnected from
|
|
|
|
// the main chain.
|
|
|
|
DisconnectBlock(database.Tx, *btcutil.Block, *UtxoViewpoint) error
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Config is a descriptor which specifies the blockchain instance configuration.
|
|
|
|
type Config struct {
|
|
|
|
// DB defines the database which houses the blocks and will be used to
|
|
|
|
// store all metadata created by this package such as the utxo set.
|
|
|
|
//
|
|
|
|
// This field is required.
|
|
|
|
DB database.DB
|
|
|
|
|
|
|
|
// ChainParams identifies which chain parameters the chain is associated
|
|
|
|
// with.
|
|
|
|
//
|
|
|
|
// This field is required.
|
|
|
|
ChainParams *chaincfg.Params
|
|
|
|
|
2016-07-14 02:36:36 +02:00
|
|
|
// TimeSource defines the median time source to use for things such as
|
|
|
|
// block processing and determining whether or not the chain is current.
|
|
|
|
//
|
|
|
|
// The caller is expected to keep a reference to the time source as well
|
|
|
|
// and add time samples from other peers on the network so the local
|
|
|
|
// time is adjusted to be in agreement with other peers.
|
|
|
|
TimeSource MedianTimeSource
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
// Notifications defines a callback to which notifications will be sent
|
|
|
|
// when various events take place. See the documentation for
|
|
|
|
// Notification and NotificationType for details on the types and
|
|
|
|
// contents of notifications.
|
|
|
|
//
|
|
|
|
// This field can be nil if the caller is not interested in receiving
|
|
|
|
// notifications.
|
|
|
|
Notifications NotificationCallback
|
|
|
|
|
|
|
|
// SigCache defines a signature cache to use when when validating
|
|
|
|
// signatures. This is typically most useful when individual
|
|
|
|
// transactions are already being validated prior to their inclusion in
|
|
|
|
// a block such as what is usually done via a transaction memory pool.
|
|
|
|
//
|
|
|
|
// This field can be nil if the caller is not interested in using a
|
|
|
|
// signature cache.
|
|
|
|
SigCache *txscript.SigCache
|
2016-02-19 05:51:18 +01:00
|
|
|
|
|
|
|
// IndexManager defines an index manager to use when initializing the
|
|
|
|
// chain and connecting and disconnecting blocks.
|
|
|
|
//
|
|
|
|
// This field can be nil if the caller does not wish to make use of an
|
|
|
|
// index manager.
|
|
|
|
IndexManager IndexManager
|
2015-08-26 06:03:18 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// New returns a BlockChain instance using the provided configuration details.
|
|
|
|
func New(config *Config) (*BlockChain, error) {
|
|
|
|
// Enforce required config fields.
|
|
|
|
if config.DB == nil {
|
|
|
|
return nil, AssertError("blockchain.New database is nil")
|
|
|
|
}
|
|
|
|
if config.ChainParams == nil {
|
|
|
|
return nil, AssertError("blockchain.New chain parameters nil")
|
|
|
|
}
|
|
|
|
|
2014-05-26 17:27:50 +02:00
|
|
|
// Generate a checkpoint by height map from the provided checkpoints.
|
2015-08-26 06:03:18 +02:00
|
|
|
params := config.ChainParams
|
2015-08-08 04:20:49 +02:00
|
|
|
var checkpointsByHeight map[int32]*chaincfg.Checkpoint
|
2014-05-26 17:27:50 +02:00
|
|
|
if len(params.Checkpoints) > 0 {
|
2015-08-08 04:20:49 +02:00
|
|
|
checkpointsByHeight = make(map[int32]*chaincfg.Checkpoint)
|
2014-05-26 17:27:50 +02:00
|
|
|
for i := range params.Checkpoints {
|
|
|
|
checkpoint := ¶ms.Checkpoints[i]
|
|
|
|
checkpointsByHeight[checkpoint.Height] = checkpoint
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2013-07-18 16:49:28 +02:00
|
|
|
b := BlockChain{
|
2014-05-26 17:27:50 +02:00
|
|
|
checkpointsByHeight: checkpointsByHeight,
|
2015-08-26 06:03:18 +02:00
|
|
|
db: config.DB,
|
|
|
|
chainParams: params,
|
2016-07-14 02:36:36 +02:00
|
|
|
timeSource: config.TimeSource,
|
2015-08-26 06:03:18 +02:00
|
|
|
notifications: config.Notifications,
|
|
|
|
sigCache: config.SigCache,
|
2016-02-19 05:51:18 +01:00
|
|
|
indexManager: config.IndexManager,
|
2015-08-26 06:03:18 +02:00
|
|
|
bestNode: nil,
|
2015-02-05 22:16:39 +01:00
|
|
|
index: make(map[wire.ShaHash]*blockNode),
|
|
|
|
depNodes: make(map[wire.ShaHash][]*blockNode),
|
|
|
|
orphans: make(map[wire.ShaHash]*orphanBlock),
|
|
|
|
prevOrphans: make(map[wire.ShaHash][]*orphanBlock),
|
|
|
|
blockCache: make(map[wire.ShaHash]*btcutil.Block),
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|
2015-08-26 06:03:18 +02:00
|
|
|
|
|
|
|
// Initialize the chain state from the passed database. When the db
|
|
|
|
// does not yet contain any chain state, both it and the chain state
|
|
|
|
// will be initialized to contain only the genesis block.
|
|
|
|
if err := b.initChainState(); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2016-02-19 05:51:18 +01:00
|
|
|
// Initialize and catch up all of the currently active optional indexes
|
|
|
|
// as needed.
|
|
|
|
if config.IndexManager != nil {
|
|
|
|
if err := config.IndexManager.Init(&b); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2015-08-26 06:03:18 +02:00
|
|
|
log.Infof("Chain state (height %d, hash %v, totaltx %d, work %v)",
|
|
|
|
b.bestNode.height, b.bestNode.hash, b.stateSnapshot.TotalTxns,
|
|
|
|
b.bestNode.workSum)
|
|
|
|
|
|
|
|
return &b, nil
|
2013-07-18 16:49:28 +02:00
|
|
|
}
|