lotus/chain/vm/vm.go

590 lines
15 KiB
Go
Raw Normal View History

2019-07-26 04:54:22 +00:00
package vm
2019-07-05 14:29:17 +00:00
import (
"bytes"
2019-07-05 14:29:17 +00:00
"context"
"fmt"
2019-09-21 00:22:28 +00:00
"math/big"
2020-02-18 21:37:59 +00:00
"reflect"
2019-07-05 14:29:17 +00:00
"github.com/filecoin-project/specs-actors/actors/builtin"
block "github.com/ipfs/go-block-format"
2019-07-05 14:29:17 +00:00
cid "github.com/ipfs/go-cid"
2019-10-18 11:39:31 +00:00
blockstore "github.com/ipfs/go-ipfs-blockstore"
2020-02-04 22:19:05 +00:00
cbor "github.com/ipfs/go-ipld-cbor"
logging "github.com/ipfs/go-log/v2"
2020-02-19 19:39:00 +00:00
mh "github.com/multiformats/go-multihash"
2019-10-17 08:57:56 +00:00
cbg "github.com/whyrusleeping/cbor-gen"
"go.opencensus.io/trace"
"golang.org/x/xerrors"
2019-10-17 08:57:56 +00:00
"github.com/filecoin-project/go-address"
2020-02-22 13:10:46 +00:00
commcid "github.com/filecoin-project/go-fil-commcid"
"github.com/filecoin-project/specs-actors/actors/abi"
"github.com/filecoin-project/specs-actors/actors/builtin/account"
init_ "github.com/filecoin-project/specs-actors/actors/builtin/init"
"github.com/filecoin-project/specs-actors/actors/crypto"
"github.com/filecoin-project/specs-actors/actors/runtime"
"github.com/filecoin-project/specs-actors/actors/runtime/exitcode"
2020-02-17 21:11:03 +00:00
2019-10-17 08:57:56 +00:00
"github.com/filecoin-project/lotus/chain/actors/aerrors"
"github.com/filecoin-project/lotus/chain/state"
"github.com/filecoin-project/lotus/chain/types"
"github.com/filecoin-project/lotus/lib/bufbstore"
2019-07-05 14:29:17 +00:00
)
var log = logging.Logger("vm")
const (
gasFundTransfer = 10
gasInvoke = 5
gasGetObj = 10
gasGetPerByte = 1
gasPutObj = 20
gasPutPerByte = 2
gasCommit = 50
gasPerMessageByte = 2
)
const (
outOfGasErrCode = 200
)
type ExecutionResult struct {
2020-03-08 00:46:12 +00:00
Msg *types.Message
MsgRct *types.MessageReceipt
Error string
Subcalls []*ExecutionResult
}
// Storage interface
// End of storage interface
2019-07-05 14:29:17 +00:00
// Send allows the current execution context to invoke methods on other actors in the system
2020-02-04 22:19:05 +00:00
func ResolveToKeyAddr(state types.StateTree, cst cbor.IpldStore, addr address.Address) (address.Address, aerrors.ActorError) {
if addr.Protocol() == address.BLS || addr.Protocol() == address.SECP256K1 {
return addr, nil
}
2019-08-27 00:46:39 +00:00
act, err := state.GetActor(addr)
if err != nil {
return address.Undef, aerrors.Newf(1, "failed to find actor: %s", addr)
}
2020-02-25 20:54:58 +00:00
if act.Code != builtin.AccountActorCodeID {
return address.Undef, aerrors.New(1, "address was not for an account actor")
}
2020-02-12 07:44:20 +00:00
var aast account.State
2019-08-27 00:46:39 +00:00
if err := cst.Get(context.TODO(), act.Head, &aast); err != nil {
return address.Undef, aerrors.Escalate(err, fmt.Sprintf("failed to get account actor state for %s", addr))
}
return aast.Address, nil
}
2020-02-04 22:19:05 +00:00
var _ cbor.IpldBlockstore = (*gasChargingBlocks)(nil)
type gasChargingBlocks struct {
2020-03-18 20:45:37 +00:00
chargeGas func(int64)
2020-02-04 22:19:05 +00:00
under cbor.IpldBlockstore
}
2020-02-04 22:19:05 +00:00
func (bs *gasChargingBlocks) Get(c cid.Cid) (block.Block, error) {
bs.chargeGas(gasGetObj)
2020-02-04 22:19:05 +00:00
blk, err := bs.under.Get(c)
if err != nil {
return nil, aerrors.Escalate(err, "failed to get block from blockstore")
}
2020-03-18 20:45:37 +00:00
bs.chargeGas(int64(len(blk.RawData())) * gasGetPerByte)
return blk, nil
}
2020-02-04 22:19:05 +00:00
func (bs *gasChargingBlocks) Put(blk block.Block) error {
2020-03-18 20:45:37 +00:00
bs.chargeGas(gasPutObj + int64(len(blk.RawData()))*gasPutPerByte)
2020-02-04 22:19:05 +00:00
if err := bs.under.Put(blk); err != nil {
return aerrors.Escalate(err, "failed to write data to disk")
}
return nil
}
2020-03-18 20:45:37 +00:00
func (vm *VM) makeRuntime(ctx context.Context, msg *types.Message, origin address.Address, originNonce uint64, usedGas int64, icc int64) *Runtime {
rt := &Runtime{
ctx: ctx,
vm: vm,
state: vm.cstate,
msg: msg,
origin: origin,
originNonce: originNonce,
height: vm.blockHeight,
sys: vm.Syscalls,
gasUsed: usedGas,
gasAvailable: msg.GasLimit,
internalCallCounter: icc,
2019-07-05 14:29:17 +00:00
}
rt.cst = &cbor.BasicIpldStore{
Blocks: &gasChargingBlocks{rt.ChargeGas, vm.cst.Blocks},
Atlas: vm.cst.Atlas,
}
return rt
2019-07-05 14:29:17 +00:00
}
type VM struct {
cstate *state.StateTree
2019-07-05 14:29:17 +00:00
base cid.Cid
2020-02-04 22:19:05 +00:00
cst *cbor.BasicIpldStore
buf *bufbstore.BufferedBS
2020-02-08 02:18:32 +00:00
blockHeight abi.ChainEpoch
2019-07-05 14:29:17 +00:00
blockMiner address.Address
inv *invoker
rand Rand
Syscalls runtime.Syscalls
2019-07-05 14:29:17 +00:00
}
func NewVM(base cid.Cid, height abi.ChainEpoch, r Rand, maddr address.Address, cbs blockstore.Blockstore, syscalls runtime.Syscalls) (*VM, error) {
2019-10-15 04:33:29 +00:00
buf := bufbstore.NewBufferedBstore(cbs)
2020-02-04 22:19:05 +00:00
cst := cbor.NewCborStore(buf)
state, err := state.LoadStateTree(cst, base)
2019-07-05 14:29:17 +00:00
if err != nil {
return nil, err
}
return &VM{
cstate: state,
base: base,
2019-07-26 04:54:22 +00:00
cst: cst,
2019-07-05 14:29:17 +00:00
buf: buf,
blockHeight: height,
blockMiner: maddr,
inv: NewInvoker(),
2020-01-13 20:47:27 +00:00
rand: r, // TODO: Probably should be a syscall
Syscalls: syscalls,
2019-07-05 14:29:17 +00:00
}, nil
}
type Rand interface {
2020-02-23 20:00:47 +00:00
GetRandomness(ctx context.Context, pers crypto.DomainSeparationTag, round int64, entropy []byte) ([]byte, error)
}
type ApplyRet struct {
types.MessageReceipt
2020-03-08 00:46:12 +00:00
ActorErr aerrors.ActorError
Penalty big.Int
InternalExecutions []*ExecutionResult
}
func (vm *VM) send(ctx context.Context, msg *types.Message, parent *Runtime,
2020-03-18 20:45:37 +00:00
gasCharge int64) ([]byte, aerrors.ActorError, *Runtime) {
st := vm.cstate
fromActor, err := st.GetActor(msg.From)
if err != nil {
return nil, aerrors.Absorb(err, 1, "could not find source actor"), nil
}
toActor, err := st.GetActor(msg.To)
if err != nil {
2020-02-22 13:10:46 +00:00
if xerrors.Is(err, init_.ErrAddressNotFound) {
a, err := TryCreateAccountActor(st, msg.To)
if err != nil {
return nil, aerrors.Absorb(err, 1, "could not create account"), nil
}
toActor = a
} else {
return nil, aerrors.Escalate(err, "getting actor"), nil
}
}
2020-03-18 20:45:37 +00:00
gasUsed := gasCharge
origin := msg.From
on := msg.Nonce
var icc int64 = 0
if parent != nil {
2020-03-18 20:45:37 +00:00
gasUsed = parent.gasUsed + gasUsed
origin = parent.origin
on = parent.originNonce
icc = parent.internalCallCounter + 1
}
rt := vm.makeRuntime(ctx, msg, origin, on, gasUsed, icc)
if parent != nil {
defer func() {
parent.gasUsed = rt.gasUsed
}()
}
if types.BigCmp(msg.Value, types.NewInt(0)) != 0 {
rt.ChargeGas(gasFundTransfer)
if err := Transfer(fromActor, toActor, msg.Value); err != nil {
return nil, aerrors.Absorb(err, 1, "failed to transfer funds"), nil
}
}
if msg.Method != 0 {
ret, err := vm.Invoke(toActor, rt, msg.Method, msg.Params)
return ret, err, rt
}
return nil, nil, rt
}
func checkMessage(msg *types.Message) error {
2020-03-18 20:45:37 +00:00
if msg.GasLimit == 0 {
return xerrors.Errorf("message has no gas limit set")
}
if msg.GasLimit < 0 {
return xerrors.Errorf("message has negative gas limit")
}
if msg.GasPrice == types.EmptyInt {
return xerrors.Errorf("message gas no gas price set")
}
if msg.Value == types.EmptyInt {
return xerrors.Errorf("message no value set")
}
return nil
}
func (vm *VM) ApplyMessage(ctx context.Context, msg *types.Message) (*ApplyRet, error) {
ctx, span := trace.StartSpan(ctx, "vm.ApplyMessage")
defer span.End()
2019-10-10 11:13:26 +00:00
if span.IsRecordingEvents() {
span.AddAttributes(
trace.StringAttribute("to", msg.To.String()),
trace.Int64Attribute("method", int64(msg.Method)),
trace.StringAttribute("value", msg.Value.String()),
)
}
if err := checkMessage(msg); err != nil {
return nil, err
}
2020-03-05 18:13:49 +00:00
serMsg, err := msg.Serialize()
if err != nil {
return nil, xerrors.Errorf("could not serialize message: %w", err)
}
2020-03-18 20:45:37 +00:00
msgGasCost := int64(len(serMsg)) * gasPerMessageByte
if msgGasCost > msg.GasLimit {
2020-03-05 18:13:49 +00:00
return &ApplyRet{
MessageReceipt: types.MessageReceipt{
ExitCode: exitcode.SysErrOutOfGas,
GasUsed: msg.GasLimit,
},
}, nil
}
2019-07-05 14:29:17 +00:00
st := vm.cstate
if err := st.Snapshot(ctx); err != nil {
return nil, xerrors.Errorf("snapshot failed: %w", err)
}
defer st.ClearSnapshot()
2019-07-05 14:29:17 +00:00
fromActor, err := st.GetActor(msg.From)
if err != nil {
if xerrors.Is(err, types.ErrActorNotFound) {
return &ApplyRet{
MessageReceipt: types.MessageReceipt{
ExitCode: exitcode.SysErrActorNotFound,
GasUsed: msg.GasLimit,
},
}, nil
}
return nil, xerrors.Errorf("failed to look up from actor: %w", err)
2019-07-05 14:29:17 +00:00
}
if msg.Nonce != fromActor.Nonce {
return &ApplyRet{
MessageReceipt: types.MessageReceipt{
ExitCode: exitcode.SysErrInvalidCallSeqNum,
GasUsed: msg.GasLimit,
},
}, nil
}
2020-03-18 20:45:37 +00:00
gascost := types.BigMul(types.NewInt(uint64(msg.GasLimit)), msg.GasPrice)
totalCost := types.BigAdd(gascost, msg.Value)
2019-09-23 17:11:44 +00:00
if fromActor.Balance.LessThan(totalCost) {
return &ApplyRet{
MessageReceipt: types.MessageReceipt{
ExitCode: exitcode.SysErrInsufficientFunds,
GasUsed: msg.GasLimit,
},
}, nil
}
gasHolder := &types.Actor{Balance: types.NewInt(0)}
if err := Transfer(fromActor, gasHolder, gascost); err != nil {
return nil, xerrors.Errorf("failed to withdraw gas funds: %w", err)
}
fromActor.Nonce++
ret, actorErr, rt := vm.send(ctx, msg, nil, msgGasCost)
if aerrors.IsFatal(actorErr) {
return nil, xerrors.Errorf("[from=%s,to=%s,n=%d,m=%d,h=%d] fatal error: %w", msg.From, msg.To, msg.Nonce, msg.Method, vm.blockHeight, actorErr)
}
if actorErr != nil {
log.Warnw("Send actor error", "from", msg.From, "to", msg.To, "nonce", msg.Nonce, "method", msg.Method, "height", vm.blockHeight, "error", fmt.Sprintf("%+v", actorErr))
}
var errcode uint8
2020-03-18 20:45:37 +00:00
var gasUsed int64
if errcode = aerrors.RetCode(actorErr); errcode != 0 {
gasUsed = msg.GasLimit
// revert all state changes since snapshot
if err := st.Revert(); err != nil {
return nil, xerrors.Errorf("revert state failed: %w", err)
2019-07-05 14:29:17 +00:00
}
} else {
gasUsed = rt.gasUsed
// refund unused gas
2020-03-18 20:45:37 +00:00
refund := types.BigMul(types.NewInt(uint64(msg.GasLimit-gasUsed)), msg.GasPrice)
if err := Transfer(gasHolder, fromActor, refund); err != nil {
return nil, xerrors.Errorf("failed to refund gas")
}
}
rwAct, err := st.GetActor(builtin.RewardActorAddr)
if err != nil {
return nil, xerrors.Errorf("getting burnt funds actor failed: %w", err)
}
2019-07-05 14:29:17 +00:00
2020-03-18 20:45:37 +00:00
gasReward := types.BigMul(msg.GasPrice, types.NewInt(uint64(gasUsed)))
if err := Transfer(gasHolder, rwAct, gasReward); err != nil {
return nil, xerrors.Errorf("failed to give miner gas reward: %w", err)
}
if types.BigCmp(types.NewInt(0), gasHolder.Balance) != 0 {
return nil, xerrors.Errorf("gas handling math is wrong")
}
2019-07-05 14:29:17 +00:00
return &ApplyRet{
MessageReceipt: types.MessageReceipt{
ExitCode: exitcode.ExitCode(errcode),
Return: ret,
GasUsed: gasUsed,
},
2020-03-08 00:46:12 +00:00
ActorErr: actorErr,
InternalExecutions: rt.internalExecutions,
}, nil
2019-07-05 14:29:17 +00:00
}
func (vm *VM) SetBlockMiner(m address.Address) {
vm.blockMiner = m
}
func (vm *VM) ActorBalance(addr address.Address) (types.BigInt, aerrors.ActorError) {
act, err := vm.cstate.GetActor(addr)
if err != nil {
return types.EmptyInt, aerrors.Absorb(err, 1, "failed to find actor")
}
return act.Balance, nil
}
2019-07-05 14:29:17 +00:00
func (vm *VM) Flush(ctx context.Context) (cid.Cid, error) {
_, span := trace.StartSpan(ctx, "vm.Flush")
defer span.End()
from := vm.buf
to := vm.buf.Read()
2019-07-05 14:29:17 +00:00
root, err := vm.cstate.Flush(ctx)
2019-07-05 14:29:17 +00:00
if err != nil {
return cid.Undef, xerrors.Errorf("flushing vm: %w", err)
2019-07-05 14:29:17 +00:00
}
if err := Copy(from, to, root); err != nil {
return cid.Undef, xerrors.Errorf("copying tree: %w", err)
2019-07-05 14:29:17 +00:00
}
return root, nil
}
2020-02-18 21:37:59 +00:00
// vm.MutateState(idAddr, func(cst cbor.IpldStore, st *ActorStateType) error {...})
func (vm *VM) MutateState(ctx context.Context, addr address.Address, fn interface{}) error {
act, err := vm.cstate.GetActor(addr)
if err != nil {
return xerrors.Errorf("actor not found: %w", err)
}
st := reflect.New(reflect.TypeOf(fn).In(1).Elem())
if err := vm.cst.Get(ctx, act.Head, st.Interface()); err != nil {
return xerrors.Errorf("read actor head: %w", err)
}
out := reflect.ValueOf(fn).Call([]reflect.Value{reflect.ValueOf(vm.cst), st})
if !out[0].IsNil() && out[0].Interface().(error) != nil {
return out[0].Interface().(error)
}
head, err := vm.cst.Put(ctx, st.Interface())
if err != nil {
return xerrors.Errorf("put new actor head: %w", err)
}
act.Head = head
if err := vm.cstate.SetActor(addr, act); err != nil {
return xerrors.Errorf("set actor: %w", err)
}
return nil
}
func linksForObj(blk block.Block) ([]cid.Cid, error) {
switch blk.Cid().Prefix().Codec {
case cid.DagCBOR:
return cbg.ScanForLinks(bytes.NewReader(blk.RawData()))
default:
return nil, xerrors.Errorf("vm flush copy method only supports dag cbor")
}
}
func Copy(from, to blockstore.Blockstore, root cid.Cid) error {
2019-11-17 17:50:04 +00:00
var batch []block.Block
batchCp := func(blk block.Block) error {
batch = append(batch, blk)
if len(batch) > 100 {
if err := to.PutMany(batch); err != nil {
return xerrors.Errorf("batch put in copy: %w", err)
}
batch = batch[:0]
}
return nil
}
if err := copyRec(from, to, root, batchCp); err != nil {
return err
}
if len(batch) > 0 {
if err := to.PutMany(batch); err != nil {
return xerrors.Errorf("batch put in copy: %w", err)
}
}
return nil
}
func copyRec(from, to blockstore.Blockstore, root cid.Cid, cp func(block.Block) error) error {
if root.Prefix().MhType == 0 {
// identity cid, skip
return nil
}
blk, err := from.Get(root)
if err != nil {
return xerrors.Errorf("get %s failed: %w", root, err)
}
links, err := linksForObj(blk)
if err != nil {
return err
}
for _, link := range links {
2020-02-23 15:50:36 +00:00
if link.Prefix().MhType == mh.IDENTITY || link.Prefix().MhType == uint64(commcid.FC_SEALED_V1) || link.Prefix().MhType == uint64(commcid.FC_UNSEALED_V1) {
2019-07-25 22:15:33 +00:00
continue
}
has, err := to.Has(link)
if err != nil {
return err
}
if has {
continue
}
2019-11-17 17:50:04 +00:00
if err := copyRec(from, to, link, cp); err != nil {
return err
}
}
2019-11-17 17:50:04 +00:00
if err := cp(blk); err != nil {
return err
}
return nil
}
2019-08-15 02:30:21 +00:00
func (vm *VM) StateTree() types.StateTree {
return vm.cstate
}
2020-02-08 02:18:32 +00:00
func (vm *VM) SetBlockHeight(h abi.ChainEpoch) {
vm.blockHeight = h
}
func (vm *VM) Invoke(act *types.Actor, rt *Runtime, method abi.MethodNum, params []byte) ([]byte, aerrors.ActorError) {
ctx, span := trace.StartSpan(rt.ctx, "vm.Invoke")
defer span.End()
2019-11-12 19:54:25 +00:00
if span.IsRecordingEvents() {
span.AddAttributes(
trace.StringAttribute("to", rt.Message().Receiver().String()),
2019-11-12 19:54:25 +00:00
trace.Int64Attribute("method", int64(method)),
trace.StringAttribute("value", rt.Message().ValueReceived().String()),
2019-11-12 19:54:25 +00:00
)
}
2019-10-10 11:13:26 +00:00
var oldCtx context.Context
oldCtx, rt.ctx = rt.ctx, ctx
defer func() {
rt.ctx = oldCtx
}()
rt.ChargeGas(gasInvoke)
ret, err := vm.inv.Invoke(act, rt, method, params)
if err != nil {
return nil, err
}
return ret, nil
}
2019-07-26 04:54:22 +00:00
func Transfer(from, to *types.Actor, amt types.BigInt) error {
2019-10-22 11:57:20 +00:00
if from == to {
return nil
}
if amt.LessThan(types.NewInt(0)) {
return xerrors.Errorf("attempted to transfer negative value")
}
if err := deductFunds(from, amt); err != nil {
return err
}
depositFunds(to, amt)
return nil
}
func (vm *VM) SetInvoker(i *invoker) {
vm.inv = i
}
func deductFunds(act *types.Actor, amt types.BigInt) error {
2019-09-23 17:11:44 +00:00
if act.Balance.LessThan(amt) {
2019-07-26 04:54:22 +00:00
return fmt.Errorf("not enough funds")
}
act.Balance = types.BigSub(act.Balance, amt)
return nil
}
func depositFunds(act *types.Actor, amt types.BigInt) {
2019-07-26 04:54:22 +00:00
act.Balance = types.BigAdd(act.Balance, amt)
}