本文整理匯總了Golang中github.com/NebulousLabs/Sia/types.Block類的典型用法代碼示例。如果您正苦於以下問題:Golang Block類的具體用法?Golang Block怎麽用?Golang Block使用的例子?那麽, 這裏精選的類代碼示例或許可以為您提供幫助。
在下文中一共展示了Block類的15個代碼示例,這些例子默認根據受歡迎程度排序。您可以為喜歡或者感覺有用的代碼點讚,您的評價將有助於係統推薦出更棒的Golang代碼示例。
示例1: newChild
// newChild creates a blockNode from a block and adds it to the parent's set of
// children. The new node is also returned. It necessairly modifies the database
//
// TODO: newChild has a fair amount of room for optimization.
func (cs *ConsensusSet) newChild(pb *processedBlock, b types.Block) *processedBlock {
// Create the child node.
childID := b.ID()
child := &processedBlock{
Block: b,
Parent: b.ParentID,
Height: pb.Height + 1,
Depth: pb.childDepth(),
}
err := cs.db.Update(func(tx *bolt.Tx) error {
blockMap := tx.Bucket(BlockMap)
err := cs.setChildTarget(blockMap, child)
if err != nil {
return err
}
pb.Children = append(pb.Children, childID)
err = blockMap.Put(child.Block.ParentID[:], encoding.Marshal(*pb))
if err != nil {
return err
}
return blockMap.Put(childID[:], encoding.Marshal(*child))
})
if build.DEBUG && err != nil {
panic(err)
}
return child
}
示例2: managedSubmitBlock
// managedSubmitBlock takes a solved block and submits it to the blockchain.
// managedSubmitBlock should not be called with a lock.
func (m *Miner) managedSubmitBlock(b types.Block) error {
// Give the block to the consensus set.
err := m.cs.AcceptBlock(b)
// Add the miner to the blocks list if the only problem is that it's stale.
if err == modules.ErrNonExtendingBlock {
m.mu.Lock()
m.persist.BlocksFound = append(m.persist.BlocksFound, b.ID())
m.mu.Unlock()
m.log.Println("Mined a stale block - block appears valid but does not extend the blockchain")
return err
}
if err == modules.ErrBlockUnsolved {
m.log.Println("Mined an unsolved block - header submission appears to be incorrect")
return err
}
if err != nil {
m.tpool.PurgeTransactionPool()
m.log.Critical("ERROR: an invalid block was submitted:", err)
return err
}
m.mu.Lock()
defer m.mu.Unlock()
// Grab a new address for the miner. Call may fail if the wallet is locked
// or if the wallet addresses have been exhausted.
m.persist.BlocksFound = append(m.persist.BlocksFound, b.ID())
var uc types.UnlockConditions
uc, err = m.wallet.NextAddress()
if err != nil {
return err
}
m.persist.Address = uc.UnlockHash()
return m.saveSync()
}
示例3: SubmitBlock
// SubmitBlock takes a solved block and submits it to the blockchain.
// SubmitBlock should not be called with a lock.
func (m *Miner) SubmitBlock(b types.Block) error {
// Give the block to the consensus set.
err := m.cs.AcceptBlock(b)
// Add the miner to the blocks list if the only problem is that it's stale.
if err == modules.ErrNonExtendingBlock {
m.mu.Lock()
m.blocksFound = append(m.blocksFound, b.ID())
m.mu.Unlock()
}
if err != nil {
m.tpool.PurgeTransactionPool()
m.log.Println("ERROR: an invalid block was submitted:", err)
return err
}
m.mu.Lock()
defer m.mu.Unlock()
// Grab a new address for the miner. Call may fail if the wallet is locked
// or if the wallet addresses have been exhausted.
m.blocksFound = append(m.blocksFound, b.ID())
var uc types.UnlockConditions
uc, err = m.wallet.NextAddress()
if err == nil { // Only update the address if there was no error.
m.address = uc.UnlockHash()
}
return err
}
示例4: validateHeader
// validateHeader does some early, low computation verification on the block.
// Callers should not assume that validation will happen in a particular order.
func (cs *ConsensusSet) validateHeader(tx dbTx, b types.Block) error {
// See if the block is known already.
id := b.ID()
_, exists := cs.dosBlocks[id]
if exists {
return errDoSBlock
}
// Check if the block is already known.
blockMap := tx.Bucket(BlockMap)
if blockMap == nil {
return errNoBlockMap
}
if blockMap.Get(id[:]) != nil {
return modules.ErrBlockKnown
}
// Check for the parent.
parentID := b.ParentID
parentBytes := blockMap.Get(parentID[:])
if parentBytes == nil {
return errOrphan
}
var parent processedBlock
err := cs.marshaler.Unmarshal(parentBytes, &parent)
if err != nil {
return err
}
// Check that the timestamp is not too far in the past to be acceptable.
minTimestamp := cs.blockRuleHelper.minimumValidChildTimestamp(blockMap, &parent)
return cs.blockValidator.ValidateBlock(b, minTimestamp, parent.ChildTarget, parent.Height+1)
}
示例5: addBlockToTree
// addBlockToTree inserts a block into the blockNode tree by adding it to its
// parent's list of children. If the new blockNode is heavier than the current
// node, the blockchain is forked to put the new block and its parents at the
// tip. An error will be returned if block verification fails or if the block
// does not extend the longest fork.
func (cs *State) addBlockToTree(b types.Block) (revertedNodes, appliedNodes []*blockNode, err error) {
parentNode := cs.blockMap[b.ParentID]
newNode := parentNode.newChild(b)
cs.blockMap[b.ID()] = newNode
if newNode.heavierThan(cs.currentBlockNode()) {
return cs.forkBlockchain(newNode)
}
return nil, nil, modules.ErrNonExtendingBlock
}
示例6: HeaderForWork
// HeaderForWork returns a block that is ready for nonce grinding, along with
// the root hash of the block.
func (m *Miner) HeaderForWork() (types.BlockHeader, types.Target, error) {
if !m.wallet.Unlocked() {
return types.BlockHeader{}, types.Target{}, modules.ErrLockedWallet
}
lockID := m.mu.Lock()
defer m.mu.Unlock(lockID)
err := m.checkAddress()
if err != nil {
return types.BlockHeader{}, types.Target{}, err
}
if time.Since(m.lastBlock).Seconds() > secondsBetweenBlocks {
m.prepareNewBlock()
}
// The header that will be returned for nonce grinding.
// The header is constructed from a block and some arbitrary data. The
// arbitrary data allows for multiple unique blocks to be generated from
// a single block in memory. A block pointer is used in order to avoid
// storing multiple copies of the same block in memory
var header types.BlockHeader
var arbData []byte
var block *types.Block
if m.memProgress%(headerForWorkMemory/blockForWorkMemory) == 0 {
// Grab a new block. Allocate space for the pointer to store it as well
block = new(types.Block)
*block, _ = m.blockForWork()
header = block.Header()
arbData = block.Transactions[0].ArbitraryData[0]
m.lastBlock = time.Now()
} else {
// Set block to previous block, but create new arbData
block = m.blockMem[m.headerMem[m.memProgress-1]]
arbData, _ = crypto.RandBytes(types.SpecifierLen)
block.Transactions[0].ArbitraryData[0] = arbData
header = block.Header()
}
// Save a mapping from the header to its block as well as from the
// header to its arbitrary data, replacing the block that was
// stored 'headerForWorkMemory' requests ago.
delete(m.blockMem, m.headerMem[m.memProgress])
delete(m.arbDataMem, m.headerMem[m.memProgress])
m.blockMem[header] = block
m.arbDataMem[header] = arbData
m.headerMem[m.memProgress] = header
m.memProgress++
if m.memProgress == headerForWorkMemory {
m.memProgress = 0
}
// Return the header and target.
return header, m.target, nil
}
示例7: checkMinerPayouts
// checkMinerPayouts compares a block's miner payouts to the block's subsidy and
// returns true if they are equal.
func checkMinerPayouts(b types.Block, height types.BlockHeight) bool {
// Add up the payouts and check that all values are legal.
var payoutSum types.Currency
for _, payout := range b.MinerPayouts {
if payout.Value.IsZero() {
return false
}
payoutSum = payoutSum.Add(payout.Value)
}
return b.CalculateSubsidy(height).Cmp(payoutSum) == 0
}
示例8: validHeader
// validHeader does some early, low computation verification on the block.
func (cs *State) validHeader(b types.Block) error {
// Grab the parent of the block and verify the ID of the child meets the
// target. This is done as early as possible to enforce that any
// block-related DoS must use blocks that have sufficient work.
parent, exists := cs.blockMap[b.ParentID]
if !exists {
return ErrOrphan
}
if !b.CheckTarget(parent.childTarget) {
return ErrMissedTarget
}
// Check that the block is below the size limit.
if uint64(len(encoding.Marshal(b))) > types.BlockSizeLimit {
return ErrLargeBlock
}
// Check that the timestamp is not in 'the past', where the past is defined
// by earliestChildTimestamp.
if parent.earliestChildTimestamp() > b.Timestamp {
return ErrEarlyTimestamp
}
// If the block is in the extreme future, return an error and do nothing
// more with the block. There is an assumption that by the time the extreme
// future arrives, this block will no longer be a part of the longest fork
// because it will have been ignored by all of the miners.
if b.Timestamp > types.CurrentTimestamp()+types.ExtremeFutureThreshold {
return ErrExtremeFutureTimestamp
}
// Verify that the miner payouts are valid.
if !b.CheckMinerPayouts(parent.height + 1) {
return ErrBadMinerPayouts
}
// If the block is in the near future, but too far to be acceptable, then
// the block will be saved and added to the consensus set after it is no
// longer too far in the future. This is the last check because it's an
// expensive check, and not worth performing if the payouts are incorrect.
if b.Timestamp > types.CurrentTimestamp()+types.FutureThreshold {
go func() {
time.Sleep(time.Duration(b.Timestamp-(types.CurrentTimestamp()+types.FutureThreshold)) * time.Second)
lockID := cs.mu.Lock()
defer cs.mu.Unlock(lockID)
cs.acceptBlock(b) // NOTE: Error is not handled.
}()
return ErrFutureTimestamp
}
return nil
}
示例9: managedBroadcastBlock
// managedBroadcastBlock will broadcast a block to the consensus set's peers.
func (cs *ConsensusSet) managedBroadcastBlock(b types.Block) {
// COMPATv0.5.1 - broadcast the block to all peers <= v0.5.1 and block header to all peers > v0.5.1.
var relayBlockPeers, relayHeaderPeers []modules.Peer
for _, p := range cs.gateway.Peers() {
if build.VersionCmp(p.Version, "0.5.1") <= 0 {
relayBlockPeers = append(relayBlockPeers, p)
} else {
relayHeaderPeers = append(relayHeaderPeers, p)
}
}
go cs.gateway.Broadcast("RelayBlock", b, relayBlockPeers)
go cs.gateway.Broadcast("RelayHeader", b.Header(), relayHeaderPeers)
}
示例10: SubmitHeader
// SubmitHeader accepts a block header.
func (m *Miner) SubmitHeader(bh types.BlockHeader) error {
if err := m.tg.Add(); err != nil {
return err
}
defer m.tg.Done()
// Because a call to managedSubmitBlock is required at the end of this
// function, the first part needs to be wrapped in an anonymous function
// for lock safety.
var b types.Block
err := func() error {
m.mu.Lock()
defer m.mu.Unlock()
// Lookup the block that corresponds to the provided header.
nonce := bh.Nonce
bh.Nonce = [8]byte{}
bPointer, bExists := m.blockMem[bh]
arbData, arbExists := m.arbDataMem[bh]
if !bExists || !arbExists {
return errLateHeader
}
// Block is going to be passed to external memory, but the memory pointed
// to by the transactions slice is still being modified - needs to be
// copied. Same with the memory being pointed to by the arb data slice.
b = *bPointer
txns := make([]types.Transaction, len(b.Transactions))
copy(txns, b.Transactions)
b.Transactions = txns
b.Transactions[0].ArbitraryData = [][]byte{arbData[:]}
b.Nonce = nonce
// Sanity check - block should have same id as header.
bh.Nonce = nonce
if types.BlockID(crypto.HashObject(bh)) != b.ID() {
m.log.Critical("block reconstruction failed")
}
return nil
}()
if err != nil {
m.log.Println("ERROR during call to SubmitHeader, pre SubmitBlock:", err)
return err
}
err = m.managedSubmitBlock(b)
if err != nil {
m.log.Println("ERROR returned by managedSubmitBlock:", err)
return err
}
return nil
}
示例11: TestCheckTarget
// TestCheckTarget probes the checkTarget function.
func TestCheckTarget(t *testing.T) {
var b types.Block
lowTarget := types.RootDepth
highTarget := types.Target{}
sameTarget := types.Target(b.ID())
if !checkTarget(b, lowTarget) {
t.Error("CheckTarget failed for a low target")
}
if checkTarget(b, highTarget) {
t.Error("CheckTarget passed for a high target")
}
if !checkTarget(b, sameTarget) {
t.Error("CheckTarget failed for a same target")
}
}
示例12: newChild
// newChild creates a blockNode from a block and adds it to the parent's set of
// children. The new node is also returned. It necessairly modifies the database
func (cs *ConsensusSet) newChild(tx *bolt.Tx, pb *processedBlock, b types.Block) *processedBlock {
// Create the child node.
childID := b.ID()
child := &processedBlock{
Block: b,
Height: pb.Height + 1,
Depth: pb.childDepth(),
}
blockMap := tx.Bucket(BlockMap)
cs.setChildTarget(blockMap, child)
err := blockMap.Put(childID[:], encoding.Marshal(*child))
if build.DEBUG && err != nil {
panic(err)
}
return child
}
示例13: TestBuriedBadFork
// TestBuriedBadFork creates a block with an invalid transaction that's not on
// the longest fork. The consensus set will not validate that block. Then valid
// blocks are added on top of it to make it the longest fork. When it becomes
// the longest fork, all the blocks should be fully validated and thrown out
// because a parent is invalid.
func TestBuriedBadFork(t *testing.T) {
if testing.Short() {
t.SkipNow()
}
t.Parallel()
cst, err := createConsensusSetTester("TestBuriedBadFork")
if err != nil {
t.Fatal(err)
}
defer cst.Close()
pb := cst.cs.dbCurrentProcessedBlock()
// Create a bad block that builds on a parent, so that it is part of not
// the longest fork.
badBlock := types.Block{
ParentID: pb.Block.ParentID,
Timestamp: types.CurrentTimestamp(),
MinerPayouts: []types.SiacoinOutput{{Value: types.CalculateCoinbase(pb.Height)}},
Transactions: []types.Transaction{{
SiacoinInputs: []types.SiacoinInput{{}}, // Will trigger an error on full verification but not partial verification.
}},
}
parent, err := cst.cs.dbGetBlockMap(pb.Block.ParentID)
if err != nil {
t.Fatal(err)
}
badBlock, _ = cst.miner.SolveBlock(badBlock, parent.ChildTarget)
err = cst.cs.AcceptBlock(badBlock)
if err != modules.ErrNonExtendingBlock {
t.Fatal(err)
}
// Build another bock on top of the bad block that is fully valid, this
// will cause a fork and full validation of the bad block, both the bad
// block and this block should be thrown away.
block := types.Block{
ParentID: badBlock.ID(),
Timestamp: types.CurrentTimestamp(),
MinerPayouts: []types.SiacoinOutput{{Value: types.CalculateCoinbase(pb.Height + 1)}},
}
block, _ = cst.miner.SolveBlock(block, parent.ChildTarget) // okay because the target will not change
err = cst.cs.AcceptBlock(block)
if err == nil {
t.Fatal("a bad block failed to cause an error")
}
}
示例14: SolveBlock
// SolveBlock takes a block, target, and number of iterations as input and
// tries to find a block that meets the target. This function can take a long
// time to complete, and should not be called with a lock.
func (m *Miner) SolveBlock(b types.Block, target types.Target) (types.Block, bool) {
// Assemble the header.
merkleRoot := b.MerkleRoot()
header := make([]byte, 80)
copy(header, b.ParentID[:])
binary.LittleEndian.PutUint64(header[40:48], uint64(b.Timestamp))
copy(header[48:], merkleRoot[:])
nonce := (*uint64)(unsafe.Pointer(&header[32]))
for i := 0; i < iterationsPerAttempt; i++ {
id := crypto.HashBytes(header)
if bytes.Compare(target[:], id[:]) >= 0 {
copy(b.Nonce[:], header[32:40])
return b, true
}
*nonce++
}
return b, false
}
示例15: SubmitBlock
// submitBlock takes a solved block and submits it to the blockchain.
// submitBlock should not be called with a lock.
func (m *Miner) SubmitBlock(b types.Block) error {
// Give the block to the consensus set.
err := m.cs.AcceptBlock(b)
if err != nil {
m.tpool.PurgeTransactionPool()
m.log.Println("ERROR: an invalid block was submitted:", err)
return err
}
// Grab a new address for the miner.
lockID := m.mu.Lock()
m.blocksFound = append(m.blocksFound, b.ID())
var addr types.UnlockHash
addr, _, err = m.wallet.CoinAddress(false) // false indicates that the address should not be visible to the user.
if err == nil { // Special case: only update the address if there was no error.
m.address = addr
}
m.mu.Unlock(lockID)
return err
}