quorum/miner/worker.go

650 lines
19 KiB
Go
Raw Normal View History

2015-07-06 17:54:22 -07:00
// Copyright 2015 The go-ethereum Authors
// This file is part of the go-ethereum library.
2015-07-06 17:54:22 -07:00
//
// The go-ethereum library is free software: you can redistribute it and/or modify
2015-07-06 17:54:22 -07:00
// 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 go-ethereum library is distributed in the hope that it will be useful,
2015-07-06 17:54:22 -07:00
// but WITHOUT ANY WARRANTY; without even the implied warranty of
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
2015-07-06 17:54:22 -07:00
// GNU Lesser General Public License for more details.
//
// You should have received a copy of the GNU Lesser General Public License
// along with the go-ethereum library. If not, see <http://www.gnu.org/licenses/>.
2015-07-06 17:54:22 -07:00
2015-02-04 05:52:59 -08:00
package miner
import (
"bytes"
2015-02-04 05:52:59 -08:00
"fmt"
"math/big"
"sync"
"sync/atomic"
"time"
2015-02-04 05:52:59 -08:00
"github.com/ethereum/go-ethereum/accounts"
2015-03-18 05:00:01 -07:00
"github.com/ethereum/go-ethereum/common"
2015-02-04 05:52:59 -08:00
"github.com/ethereum/go-ethereum/core"
2015-03-23 10:27:05 -07:00
"github.com/ethereum/go-ethereum/core/state"
2015-02-04 05:52:59 -08:00
"github.com/ethereum/go-ethereum/core/types"
"github.com/ethereum/go-ethereum/core/vm"
"github.com/ethereum/go-ethereum/ethdb"
2015-02-04 05:52:59 -08:00
"github.com/ethereum/go-ethereum/event"
"github.com/ethereum/go-ethereum/log"
"github.com/ethereum/go-ethereum/params"
2015-02-04 05:52:59 -08:00
"github.com/ethereum/go-ethereum/pow"
"gopkg.in/fatih/set.v0"
)
const (
resultQueueSize = 10
miningLogAtDepth = 5
)
// Agent can register themself with the worker
type Agent interface {
Work() chan<- *Work
SetReturnCh(chan<- *Result)
Stop()
Start()
GetHashRate() int64
}
// Work is the workers current environment and holds
// all of the current state information
type Work struct {
2016-11-02 05:44:13 -07:00
config *params.ChainConfig
signer types.Signer
state *state.StateDB // apply state changes here
ancestors *set.Set // ancestor set (used for checking uncle parent validity)
family *set.Set // family set (used for checking uncle invalidity)
uncles *set.Set // uncle set
tcount int // tx count in cycle
ownedAccounts *set.Set
lowGasTxs types.Transactions
failedTxs types.Transactions
2015-02-04 05:52:59 -08:00
Block *types.Block // the new block
2015-02-04 05:52:59 -08:00
2015-06-16 03:41:50 -07:00
header *types.Header
txs []*types.Transaction
receipts []*types.Receipt
createdAt time.Time
}
type Result struct {
Work *Work
Block *types.Block
2015-02-04 05:52:59 -08:00
}
// worker is the main object which takes care of applying messages to the new state
2015-02-04 05:52:59 -08:00
type worker struct {
config *params.ChainConfig
mu sync.Mutex
// update loop
mux *event.TypeMux
events *event.TypeMuxSubscription
wg sync.WaitGroup
agents map[Agent]struct{}
recv chan *Result
2015-02-04 05:52:59 -08:00
pow pow.PoW
eth Backend
chain *core.BlockChain
proc core.Validator
chainDb ethdb.Database
2015-03-18 05:00:01 -07:00
coinbase common.Address
gasPrice *big.Int
extra []byte
2015-02-04 05:52:59 -08:00
2015-04-07 03:32:55 -07:00
currentMu sync.Mutex
current *Work
2015-03-23 04:12:49 -07:00
uncleMu sync.Mutex
possibleUncles map[common.Hash]*types.Block
2015-04-07 03:32:55 -07:00
txQueueMu sync.Mutex
txQueue map[common.Hash]*types.Transaction
unconfirmed *unconfirmedBlocks // set of locally mined blocks pending canonicalness confirmations
// atomic status counters
mining int32
atWork int32
fullValidation bool
2015-02-04 05:52:59 -08:00
}
func newWorker(config *params.ChainConfig, coinbase common.Address, eth Backend, mux *event.TypeMux) *worker {
2015-04-07 03:32:55 -07:00
worker := &worker{
config: config,
2015-03-23 04:12:49 -07:00
eth: eth,
mux: mux,
chainDb: eth.ChainDb(),
recv: make(chan *Result, resultQueueSize),
gasPrice: new(big.Int),
chain: eth.BlockChain(),
proc: eth.BlockChain().Validator(),
2015-03-23 04:12:49 -07:00
possibleUncles: make(map[common.Hash]*types.Block),
coinbase: coinbase,
2015-04-07 03:32:55 -07:00
txQueue: make(map[common.Hash]*types.Transaction),
agents: make(map[Agent]struct{}),
unconfirmed: newUnconfirmedBlocks(eth.BlockChain(), 5),
fullValidation: false,
2015-02-09 07:20:34 -08:00
}
worker.events = worker.mux.Subscribe(core.ChainHeadEvent{}, core.ChainSideEvent{}, core.TxPreEvent{})
2015-04-07 03:32:55 -07:00
go worker.update()
go worker.wait()
2015-04-07 03:32:55 -07:00
worker.commitNewWork()
return worker
2015-02-09 07:20:34 -08:00
}
2015-07-07 01:58:47 -07:00
func (self *worker) setEtherbase(addr common.Address) {
self.mu.Lock()
defer self.mu.Unlock()
self.coinbase = addr
}
func (self *worker) setExtra(extra []byte) {
self.mu.Lock()
defer self.mu.Unlock()
self.extra = extra
}
func (self *worker) pending() (*types.Block, *state.StateDB) {
2015-04-07 03:32:55 -07:00
self.currentMu.Lock()
defer self.currentMu.Unlock()
2015-07-20 04:37:43 -07:00
2015-06-16 03:41:50 -07:00
if atomic.LoadInt32(&self.mining) == 0 {
return types.NewBlock(
self.current.header,
self.current.txs,
nil,
self.current.receipts,
), self.current.state.Copy()
2015-06-16 03:41:50 -07:00
}
return self.current.Block, self.current.state.Copy()
2015-04-07 03:32:55 -07:00
}
func (self *worker) pendingBlock() *types.Block {
self.currentMu.Lock()
defer self.currentMu.Unlock()
if atomic.LoadInt32(&self.mining) == 0 {
return types.NewBlock(
self.current.header,
self.current.txs,
nil,
self.current.receipts,
)
}
return self.current.Block
}
2015-04-07 03:32:55 -07:00
func (self *worker) start() {
self.mu.Lock()
defer self.mu.Unlock()
atomic.StoreInt32(&self.mining, 1)
2015-02-14 07:52:14 -08:00
// spin up agents
for agent := range self.agents {
2015-02-14 07:52:14 -08:00
agent.Start()
}
2015-02-09 07:20:34 -08:00
}
func (self *worker) stop() {
self.wg.Wait()
self.mu.Lock()
defer self.mu.Unlock()
if atomic.LoadInt32(&self.mining) == 1 {
// Stop all agents.
for agent := range self.agents {
2015-04-07 15:30:23 -07:00
agent.Stop()
// Remove CPU agents.
if _, ok := agent.(*CpuAgent); ok {
delete(self.agents, agent)
}
2015-04-07 15:30:23 -07:00
}
}
atomic.StoreInt32(&self.mining, 0)
atomic.StoreInt32(&self.atWork, 0)
2015-02-09 07:20:34 -08:00
}
func (self *worker) register(agent Agent) {
self.mu.Lock()
defer self.mu.Unlock()
self.agents[agent] = struct{}{}
agent.SetReturnCh(self.recv)
2015-02-04 05:52:59 -08:00
}
func (self *worker) unregister(agent Agent) {
self.mu.Lock()
defer self.mu.Unlock()
delete(self.agents, agent)
agent.Stop()
}
2015-02-04 05:52:59 -08:00
func (self *worker) update() {
for event := range self.events.Chan() {
// A real event arrived, process interesting content
switch ev := event.Data.(type) {
case core.ChainHeadEvent:
self.commitNewWork()
case core.ChainSideEvent:
self.uncleMu.Lock()
self.possibleUncles[ev.Block.Hash()] = ev.Block
self.uncleMu.Unlock()
case core.TxPreEvent:
// Apply transaction to the pending state if we're not mining
if atomic.LoadInt32(&self.mining) == 0 {
self.currentMu.Lock()
2016-11-02 05:44:13 -07:00
acc, _ := types.Sender(self.current.signer, ev.Tx)
2017-01-06 06:52:03 -08:00
txs := map[common.Address]types.Transactions{acc: {ev.Tx}}
txset := types.NewTransactionsByPriceAndNonce(txs)
self.current.commitTransactions(self.mux, txset, self.gasPrice, self.chain)
self.currentMu.Unlock()
2015-02-04 05:52:59 -08:00
}
}
}
}
2015-02-09 07:20:34 -08:00
func (self *worker) wait() {
for {
mustCommitNewWork := true
for result := range self.recv {
atomic.AddInt32(&self.atWork, -1)
if result == nil {
continue
}
block := result.Block
2015-08-04 11:38:57 -07:00
work := result.Work
if self.fullValidation {
if _, err := self.chain.InsertChain(types.Blocks{block}); err != nil {
log.Error(fmt.Sprint("mining err", err))
continue
}
2016-04-15 02:06:57 -07:00
go self.mux.Post(core.NewMinedBlockEvent{Block: block})
} else {
work.state.Commit(self.config.IsEIP158(block.Number()))
parent := self.chain.GetBlock(block.ParentHash(), block.NumberU64()-1)
if parent == nil {
log.Error(fmt.Sprint("Invalid block found during mining"))
continue
}
auxValidator := self.eth.BlockChain().AuxValidator()
if err := core.ValidateHeader(self.config, auxValidator, block.Header(), parent.Header(), true, false); err != nil && err != core.BlockFutureErr {
log.Error(fmt.Sprint("Invalid header on mined block:", err))
continue
}
stat, err := self.chain.WriteBlock(block)
if err != nil {
log.Error(fmt.Sprint("error writing block to chain", err))
continue
}
// update block hash since it is now available and not when the receipt/log of individual transactions were created
for _, r := range work.receipts {
for _, l := range r.Logs {
l.BlockHash = block.Hash()
}
}
for _, log := range work.state.Logs() {
log.BlockHash = block.Hash()
}
// check if canon block and write transactions
if stat == core.CanonStatTy {
// This puts transactions in a extra db for rpc
core.WriteTransactions(self.chainDb, block)
// store the receipts
core.WriteReceipts(self.chainDb, work.receipts)
// Write map map bloom filters
core.WriteMipmapBloom(self.chainDb, block.NumberU64(), work.receipts)
// implicit by posting ChainHeadEvent
mustCommitNewWork = false
}
// broadcast before waiting for validation
go func(block *types.Block, logs []*types.Log, receipts []*types.Receipt) {
2016-04-15 02:06:57 -07:00
self.mux.Post(core.NewMinedBlockEvent{Block: block})
self.mux.Post(core.ChainEvent{Block: block, Hash: block.Hash(), Logs: logs})
if stat == core.CanonStatTy {
2016-04-15 02:06:57 -07:00
self.mux.Post(core.ChainHeadEvent{Block: block})
self.mux.Post(logs)
}
if err := core.WriteBlockReceipts(self.chainDb, block.Hash(), block.NumberU64(), receipts); err != nil {
log.Warn(fmt.Sprint("error writing block receipts:", err))
2015-08-18 12:16:33 -07:00
}
}(block, work.state.Logs(), work.receipts)
}
// Insert the block into the set of pending ones to wait for confirmations
self.unconfirmed.Insert(block.NumberU64(), block.Hash())
if mustCommitNewWork {
self.commitNewWork()
}
2015-02-09 07:20:34 -08:00
}
}
}
2016-04-04 03:18:34 -07:00
// push sends a new work task to currently live miner agents.
2015-08-04 11:38:57 -07:00
func (self *worker) push(work *Work) {
2016-04-04 03:18:34 -07:00
if atomic.LoadInt32(&self.mining) != 1 {
return
}
for agent := range self.agents {
atomic.AddInt32(&self.atWork, 1)
if ch := agent.Work(); ch != nil {
ch <- work
}
2015-02-04 05:52:59 -08:00
}
}
2015-06-16 03:41:50 -07:00
// makeCurrent creates a new environment for the current cycle.
func (self *worker) makeCurrent(parent *types.Block, header *types.Header) error {
state, err := self.chain.StateAt(parent.Root())
if err != nil {
return err
}
2015-08-04 11:38:57 -07:00
work := &Work{
config: self.config,
2016-11-02 05:44:13 -07:00
signer: types.NewEIP155Signer(self.config.ChainId),
2015-06-16 03:41:50 -07:00
state: state,
ancestors: set.New(),
family: set.New(),
uncles: set.New(),
header: header,
createdAt: time.Now(),
}
2015-05-18 07:31:26 -07:00
// when 08 is processed ancestors contain 07 (quick block)
2015-06-16 03:41:50 -07:00
for _, ancestor := range self.chain.GetBlocksFromHash(parent.Hash(), 7) {
for _, uncle := range ancestor.Uncles() {
2015-08-04 11:38:57 -07:00
work.family.Add(uncle.Hash())
}
2015-08-04 11:38:57 -07:00
work.family.Add(ancestor.Hash())
work.ancestors.Add(ancestor.Hash())
2015-03-23 04:12:49 -07:00
}
wallets := self.eth.AccountManager().Wallets()
accounts := make([]accounts.Account, 0, len(wallets))
for _, wallet := range wallets {
accounts = append(accounts, wallet.Accounts()...)
}
// Keep track of transactions which return errors so they can be removed
2015-08-04 11:38:57 -07:00
work.tcount = 0
work.ownedAccounts = accountAddressesSet(accounts)
self.current = work
return nil
2015-04-07 03:32:55 -07:00
}
func (w *worker) setGasPrice(p *big.Int) {
w.mu.Lock()
defer w.mu.Unlock()
// calculate the minimal gas price the miner accepts when sorting out transactions.
const pct = int64(90)
w.gasPrice = gasprice(p, pct)
2016-04-15 02:06:57 -07:00
w.mux.Post(core.GasPriceChanged{Price: w.gasPrice})
}
2015-04-07 03:32:55 -07:00
func (self *worker) commitNewWork() {
self.mu.Lock()
defer self.mu.Unlock()
self.uncleMu.Lock()
defer self.uncleMu.Unlock()
self.currentMu.Lock()
defer self.currentMu.Unlock()
tstart := time.Now()
2015-06-16 03:41:50 -07:00
parent := self.chain.CurrentBlock()
2015-06-16 03:41:50 -07:00
tstamp := tstart.Unix()
if parent.Time().Cmp(new(big.Int).SetInt64(tstamp)) >= 0 {
tstamp = parent.Time().Int64() + 1
2015-06-16 03:41:50 -07:00
}
// this will ensure we're not going off too far in the future
if now := time.Now().Unix(); tstamp > now+4 {
wait := time.Duration(tstamp-now) * time.Second
log.Info(fmt.Sprint("We are too far in the future. Waiting for", wait))
time.Sleep(wait)
}
2015-06-16 03:41:50 -07:00
num := parent.Number()
header := &types.Header{
ParentHash: parent.Hash(),
Number: num.Add(num, common.Big1),
Difficulty: core.CalcDifficulty(self.config, uint64(tstamp), parent.Time().Uint64(), parent.Number(), parent.Difficulty()),
2015-06-16 03:41:50 -07:00
GasLimit: core.CalcGasLimit(parent),
GasUsed: new(big.Int),
Coinbase: self.coinbase,
Extra: self.extra,
Time: big.NewInt(tstamp),
2015-06-16 03:41:50 -07:00
}
// If we are care about TheDAO hard-fork check whether to override the extra-data or not
if daoBlock := self.config.DAOForkBlock; daoBlock != nil {
// Check whether the block is among the fork extra-override range
limit := new(big.Int).Add(daoBlock, params.DAOForkExtraRange)
if header.Number.Cmp(daoBlock) >= 0 && header.Number.Cmp(limit) < 0 {
// Depending whether we support or oppose the fork, override differently
if self.config.DAOForkSupport {
header.Extra = common.CopyBytes(params.DAOForkBlockExtra)
} else if bytes.Equal(header.Extra, params.DAOForkBlockExtra) {
header.Extra = []byte{} // If miner opposes, don't let it use the reserved extra-data
}
}
}
// Could potentially happen if starting to mine in an odd state.
err := self.makeCurrent(parent, header)
if err != nil {
log.Info(fmt.Sprint("Could not create new env for mining, retrying on next block."))
return
}
// Create the current work task and check any fork transitions needed
2015-08-04 11:38:57 -07:00
work := self.current
if self.config.DAOForkSupport && self.config.DAOForkBlock != nil && self.config.DAOForkBlock.Cmp(header.Number) == 0 {
core.ApplyDAOHardFork(work.state)
}
pending, err := self.eth.TxPool().Pending()
if err != nil {
log.Error(fmt.Sprintf("Could not fetch pending transactions: %v", err))
return
}
txs := types.NewTransactionsByPriceAndNonce(pending)
work.commitTransactions(self.mux, txs, self.gasPrice, self.chain)
self.eth.TxPool().RemoveBatch(work.lowGasTxs)
self.eth.TxPool().RemoveBatch(work.failedTxs)
2015-02-04 05:52:59 -08:00
2015-06-16 03:41:50 -07:00
// compute uncles for the new block.
2015-03-23 10:27:05 -07:00
var (
uncles []*types.Header
badUncles []common.Hash
)
2015-03-23 04:12:49 -07:00
for hash, uncle := range self.possibleUncles {
2015-03-23 08:14:33 -07:00
if len(uncles) == 2 {
2015-03-23 04:12:49 -07:00
break
}
2015-08-04 11:38:57 -07:00
if err := self.commitUncle(work, uncle.Header()); err != nil {
log.Trace(fmt.Sprintf("Bad uncle found and will be removed (%x)\n", hash[:4]))
log.Trace(fmt.Sprint(uncle))
2015-03-23 10:27:05 -07:00
badUncles = append(badUncles, hash)
2015-03-23 04:12:49 -07:00
} else {
log.Debug(fmt.Sprintf("committing %x as uncle\n", hash[:4]))
2015-03-23 08:14:33 -07:00
uncles = append(uncles, uncle.Header())
2015-03-23 04:12:49 -07:00
}
}
2015-03-23 10:27:05 -07:00
for _, hash := range badUncles {
delete(self.possibleUncles, hash)
}
2015-03-23 08:35:44 -07:00
2015-06-29 06:17:05 -07:00
if atomic.LoadInt32(&self.mining) == 1 {
// commit state root after all state transitions.
2015-08-04 11:38:57 -07:00
core.AccumulateRewards(work.state, header, uncles)
header.Root = work.state.IntermediateRoot(self.config.IsEIP158(header.Number))
2015-06-29 06:17:05 -07:00
}
2015-03-23 04:12:49 -07:00
2015-06-16 03:41:50 -07:00
// create the new block whose nonce will be mined.
2015-08-04 11:38:57 -07:00
work.Block = types.NewBlock(header, work.txs, uncles, work.receipts)
2015-02-04 05:52:59 -08:00
2015-06-16 03:41:50 -07:00
// We only care about logging if we're actually mining.
if atomic.LoadInt32(&self.mining) == 1 {
log.Info(fmt.Sprintf("commit new work on block %v with %d txs & %d uncles. Took %v\n", work.Block.Number(), work.tcount, len(uncles), time.Since(tstart)))
self.unconfirmed.Shift(work.Block.NumberU64() - 1)
2015-06-16 03:41:50 -07:00
}
2015-08-04 11:38:57 -07:00
self.push(work)
2015-02-04 05:52:59 -08:00
}
2015-08-04 11:38:57 -07:00
func (self *worker) commitUncle(work *Work, uncle *types.Header) error {
2015-06-16 03:41:50 -07:00
hash := uncle.Hash()
2015-08-04 11:38:57 -07:00
if work.uncles.Has(hash) {
2015-02-04 05:52:59 -08:00
return core.UncleError("Uncle not unique")
}
2015-08-04 11:38:57 -07:00
if !work.ancestors.Has(uncle.ParentHash) {
2015-02-04 05:52:59 -08:00
return core.UncleError(fmt.Sprintf("Uncle's parent unknown (%x)", uncle.ParentHash[0:4]))
}
2015-08-04 11:38:57 -07:00
if work.family.Has(hash) {
2015-06-16 03:41:50 -07:00
return core.UncleError(fmt.Sprintf("Uncle already in family (%x)", hash))
2015-02-04 05:52:59 -08:00
}
2015-08-04 11:38:57 -07:00
work.uncles.Add(uncle.Hash())
2015-02-04 05:52:59 -08:00
return nil
}
func (env *Work) commitTransactions(mux *event.TypeMux, txs *types.TransactionsByPriceAndNonce, gasPrice *big.Int, bc *core.BlockChain) {
gp := new(core.GasPool).AddGas(env.header.GasLimit)
var coalescedLogs []*types.Log
2016-09-08 01:44:18 -07:00
for {
// Retrieve the next transaction and abort if all done
tx := txs.Peek()
if tx == nil {
break
}
// Error may be ignored here. The error has already been checked
// during transaction acceptance is the transaction pool.
2016-11-02 05:44:13 -07:00
//
// We use the eip155 signer regardless of the current hf.
from, _ := types.Sender(env.signer, tx)
// Check whether the tx is replay protected. If we're not in the EIP155 hf
// phase, start ignoring the sender until we do.
if tx.Protected() && !env.config.IsEIP155(env.header.Number) {
log.Trace(fmt.Sprintf("Transaction (%x) is replay protected, but we haven't yet hardforked. Transaction will be ignored until we hardfork.\n", tx.Hash()))
2016-11-02 05:44:13 -07:00
txs.Pop()
continue
}
// Ignore any transactions (and accounts subsequently) with low gas limits
2015-06-16 03:41:50 -07:00
if tx.GasPrice().Cmp(gasPrice) < 0 && !env.ownedAccounts.Has(from) {
// Pop the current low-priced transaction without shifting in the next from the account
common: move big integer math to common/math (#3699) * common: remove CurrencyToString Move denomination values to params instead. * common: delete dead code * common: move big integer operations to common/math This commit consolidates all big integer operations into common/math and adds tests and documentation. There should be no change in semantics for BigPow, BigMin, BigMax, S256, U256, Exp and their behaviour is now locked in by tests. The BigD, BytesToBig and Bytes2Big functions don't provide additional value, all uses are replaced by new(big.Int).SetBytes(). BigToBytes is now called PaddedBigBytes, its minimum output size parameter is now specified as the number of bytes instead of bits. The single use of this function is in the EVM's MSTORE instruction. Big and String2Big are replaced by ParseBig, which is slightly stricter. It previously accepted leading zeros for hexadecimal inputs but treated decimal inputs as octal if a leading zero digit was present. ParseUint64 is used in places where String2Big was used to decode a uint64. The new functions MustParseBig and MustParseUint64 are now used in many places where parsing errors were previously ignored. * common: delete unused big integer variables * accounts/abi: replace uses of BytesToBig with use of encoding/binary * common: remove BytesToBig * common: remove Bytes2Big * common: remove BigTrue * cmd/utils: add BigFlag and use it for error-checked integer flags While here, remove environment variable processing for DirectoryFlag because we don't use it. * core: add missing error checks in genesis block parser * common: remove String2Big * cmd/evm: use utils.BigFlag * common/math: check for 256 bit overflow in ParseBig This is supposed to prevent silent overflow/truncation of values in the genesis block JSON. Without this check, a genesis block that set a balance larger than 256 bits would lead to weird behaviour in the VM. * cmd/utils: fixup import
2017-02-26 13:21:51 -08:00
log.Info(fmt.Sprintf("Transaction (%x) below gas price (tx=%dwei ask=%dwei). All sequential txs from this address(%x) will be ignored\n", tx.Hash().Bytes()[:4], tx.GasPrice(), gasPrice, from[:4]))
env.lowGasTxs = append(env.lowGasTxs, tx)
txs.Pop()
continue
}
// Start executing the transaction
2016-09-08 01:44:18 -07:00
env.state.StartRecord(tx.Hash(), common.Hash{}, env.tcount)
err, logs := env.commitTransaction(tx, bc, gp)
switch {
case core.IsGasLimitErr(err):
// Pop the current out-of-gas transaction without shifting in the next from the account
log.Trace(fmt.Sprintf("Gas limit reached for (%x) in this block. Continue to try smaller txs\n", from[:4]))
txs.Pop()
case err != nil:
// Pop the current failed transaction without shifting in the next from the account
log.Trace(fmt.Sprintf("Transaction (%x) failed, will be removed: %v\n", tx.Hash().Bytes()[:4], err))
env.failedTxs = append(env.failedTxs, tx)
txs.Pop()
default:
// Everything ok, collect the logs and shift in the next transaction from the same account
coalescedLogs = append(coalescedLogs, logs...)
env.tcount++
txs.Shift()
}
}
if len(coalescedLogs) > 0 || env.tcount > 0 {
// make a copy, the state caches the logs and these logs get "upgraded" from pending to mined
// logs by filling in the block hash when the block was mined by the local miner. This can
// cause a race condition if a log was "upgraded" before the PendingLogsEvent is processed.
cpy := make([]*types.Log, len(coalescedLogs))
for i, l := range coalescedLogs {
cpy[i] = new(types.Log)
*cpy[i] = *l
}
go func(logs []*types.Log, tcount int) {
if len(logs) > 0 {
mux.Post(core.PendingLogsEvent{Logs: logs})
}
if tcount > 0 {
mux.Post(core.PendingStateEvent{})
}
}(cpy, env.tcount)
}
}
func (env *Work) commitTransaction(tx *types.Transaction, bc *core.BlockChain, gp *core.GasPool) (error, []*types.Log) {
snap := env.state.Snapshot()
receipt, _, err := core.ApplyTransaction(env.config, bc, gp, env.state, env.header, tx, env.header.GasUsed, vm.Config{})
if err != nil {
env.state.RevertToSnapshot(snap)
return err, nil
2015-02-04 05:52:59 -08:00
}
2015-06-16 03:41:50 -07:00
env.txs = append(env.txs, tx)
env.receipts = append(env.receipts, receipt)
return nil, receipt.Logs
2015-02-04 05:52:59 -08:00
}
2015-02-28 14:09:49 -08:00
// TODO: remove or use
2015-02-28 14:09:49 -08:00
func (self *worker) HashRate() int64 {
return 0
2015-02-28 14:09:49 -08:00
}
2015-05-09 03:13:46 -07:00
// gasprice calculates a reduced gas price based on the pct
// XXX Use big.Rat?
func gasprice(price *big.Int, pct int64) *big.Int {
p := new(big.Int).Set(price)
p.Div(p, big.NewInt(100))
p.Mul(p, big.NewInt(pct))
return p
}
func accountAddressesSet(accounts []accounts.Account) *set.Set {
accountSet := set.New()
for _, account := range accounts {
accountSet.Add(account.Address)
}
return accountSet
}