| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960 |
- // Copyright 2022 The go-ethereum Authors
- // This file is part of the go-ethereum library.
- //
- // The go-ethereum library is free software: you can redistribute it and/or modify
- // it under the terms of the GNU Lesser General Public License as published by
- // the Free Software Foundation, either version 3 of the License, or
- // (at your option) any later version.
- //
- // The go-ethereum library is distributed in the hope that it will be useful,
- // but WITHOUT ANY WARRANTY; without even the implied warranty of
- // MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
- // GNU Lesser General Public License for more details.
- //
- // You should have received a copy of the GNU Lesser General Public License
- // along with the go-ethereum library. If not, see <http://www.gnu.org/licenses/>.
- package js
- import (
- "encoding/json"
- "errors"
- "fmt"
- "math/big"
- "time"
- "github.com/dop251/goja"
- "github.com/ethereum/go-ethereum/common"
- "github.com/ethereum/go-ethereum/common/hexutil"
- "github.com/ethereum/go-ethereum/core/vm"
- "github.com/ethereum/go-ethereum/crypto"
- "github.com/ethereum/go-ethereum/eth/tracers"
- jsassets "github.com/ethereum/go-ethereum/eth/tracers/js/internal/tracers"
- )
- var assetTracers = make(map[string]string)
- // init retrieves the JavaScript transaction tracers included in go-ethereum.
- func init() {
- var err error
- assetTracers, err = jsassets.Load()
- if err != nil {
- panic(err)
- }
- tracers.RegisterLookup(true, newJsTracer)
- }
- // bigIntProgram is compiled once and the exported function mostly invoked to convert
- // hex strings into big ints.
- var bigIntProgram = goja.MustCompile("bigInt", bigIntegerJS, false)
- type toBigFn = func(vm *goja.Runtime, val string) (goja.Value, error)
- type toBufFn = func(vm *goja.Runtime, val []byte) (goja.Value, error)
- type fromBufFn = func(vm *goja.Runtime, buf goja.Value, allowString bool) ([]byte, error)
- func toBuf(vm *goja.Runtime, bufType goja.Value, val []byte) (goja.Value, error) {
- // bufType is usually Uint8Array. This is equivalent to `new Uint8Array(val)` in JS.
- return vm.New(bufType, vm.ToValue(vm.NewArrayBuffer(val)))
- }
- func fromBuf(vm *goja.Runtime, bufType goja.Value, buf goja.Value, allowString bool) ([]byte, error) {
- obj := buf.ToObject(vm)
- switch obj.ClassName() {
- case "String":
- if !allowString {
- break
- }
- return common.FromHex(obj.String()), nil
- case "Array":
- var b []byte
- if err := vm.ExportTo(buf, &b); err != nil {
- return nil, err
- }
- return b, nil
- case "Object":
- if !obj.Get("constructor").SameAs(bufType) {
- break
- }
- b := obj.Get("buffer").Export().(goja.ArrayBuffer).Bytes()
- return b, nil
- }
- return nil, fmt.Errorf("invalid buffer type")
- }
- // jsTracer is an implementation of the Tracer interface which evaluates
- // JS functions on the relevant EVM hooks. It uses Goja as its JS engine.
- type jsTracer struct {
- vm *goja.Runtime
- env *vm.EVM
- toBig toBigFn // Converts a hex string into a JS bigint
- toBuf toBufFn // Converts a []byte into a JS buffer
- fromBuf fromBufFn // Converts an array, hex string or Uint8Array to a []byte
- ctx map[string]goja.Value // KV-bag passed to JS in `result`
- activePrecompiles []common.Address // List of active precompiles at current block
- traceStep bool // True if tracer object exposes a `step()` method
- traceFrame bool // True if tracer object exposes the `enter()` and `exit()` methods
- gasLimit uint64 // Amount of gas bought for the whole tx
- err error // Any error that should stop tracing
- obj *goja.Object // Trace object
- // Methods exposed by tracer
- result goja.Callable
- fault goja.Callable
- step goja.Callable
- enter goja.Callable
- exit goja.Callable
- // Underlying structs being passed into JS
- log *steplog
- frame *callframe
- frameResult *callframeResult
- // Goja-wrapping of types prepared for JS consumption
- logValue goja.Value
- dbValue goja.Value
- frameValue goja.Value
- frameResultValue goja.Value
- }
- // newJsTracer instantiates a new JS tracer instance. code is either
- // the name of a built-in JS tracer or a Javascript snippet which
- // evaluates to an expression returning an object with certain methods.
- // The methods `result` and `fault` are required to be present.
- // The methods `step`, `enter`, and `exit` are optional, but note that
- // `enter` and `exit` always go together.
- func newJsTracer(code string, ctx *tracers.Context, cfg json.RawMessage) (tracers.Tracer, error) {
- if c, ok := assetTracers[code]; ok {
- code = c
- }
- vm := goja.New()
- // By default field names are exported to JS as is, i.e. capitalized.
- vm.SetFieldNameMapper(goja.UncapFieldNameMapper())
- t := &jsTracer{
- vm: vm,
- ctx: make(map[string]goja.Value),
- }
- if ctx == nil {
- ctx = new(tracers.Context)
- }
- if ctx.BlockHash != (common.Hash{}) {
- t.ctx["blockHash"] = vm.ToValue(ctx.BlockHash.Bytes())
- if ctx.TxHash != (common.Hash{}) {
- t.ctx["txIndex"] = vm.ToValue(ctx.TxIndex)
- t.ctx["txHash"] = vm.ToValue(ctx.TxHash.Bytes())
- }
- }
- t.setTypeConverters()
- t.setBuiltinFunctions()
- ret, err := vm.RunString("(" + code + ")")
- if err != nil {
- return nil, err
- }
- // Check tracer's interface for required and optional methods.
- obj := ret.ToObject(vm)
- result, ok := goja.AssertFunction(obj.Get("result"))
- if !ok {
- return nil, errors.New("trace object must expose a function result()")
- }
- fault, ok := goja.AssertFunction(obj.Get("fault"))
- if !ok {
- return nil, errors.New("trace object must expose a function fault()")
- }
- step, ok := goja.AssertFunction(obj.Get("step"))
- t.traceStep = ok
- enter, hasEnter := goja.AssertFunction(obj.Get("enter"))
- exit, hasExit := goja.AssertFunction(obj.Get("exit"))
- if hasEnter != hasExit {
- return nil, errors.New("trace object must expose either both or none of enter() and exit()")
- }
- t.traceFrame = hasEnter
- t.obj = obj
- t.step = step
- t.enter = enter
- t.exit = exit
- t.result = result
- t.fault = fault
- // Pass in config
- if setup, ok := goja.AssertFunction(obj.Get("setup")); ok {
- cfgStr := "{}"
- if cfg != nil {
- cfgStr = string(cfg)
- }
- if _, err := setup(obj, vm.ToValue(cfgStr)); err != nil {
- return nil, err
- }
- }
- // Setup objects carrying data to JS. These are created once and re-used.
- t.log = &steplog{
- vm: vm,
- op: &opObj{vm: vm},
- memory: &memoryObj{vm: vm, toBig: t.toBig, toBuf: t.toBuf},
- stack: &stackObj{vm: vm, toBig: t.toBig},
- contract: &contractObj{vm: vm, toBig: t.toBig, toBuf: t.toBuf},
- }
- t.frame = &callframe{vm: vm, toBig: t.toBig, toBuf: t.toBuf}
- t.frameResult = &callframeResult{vm: vm, toBuf: t.toBuf}
- t.frameValue = t.frame.setupObject()
- t.frameResultValue = t.frameResult.setupObject()
- t.logValue = t.log.setupObject()
- return t, nil
- }
- // CaptureTxStart implements the Tracer interface and is invoked at the beginning of
- // transaction processing.
- func (t *jsTracer) CaptureTxStart(gasLimit uint64) {
- t.gasLimit = gasLimit
- }
- // CaptureTxStart implements the Tracer interface and is invoked at the end of
- // transaction processing.
- func (t *jsTracer) CaptureTxEnd(restGas uint64) {}
- // CaptureStart implements the Tracer interface to initialize the tracing operation.
- func (t *jsTracer) CaptureStart(env *vm.EVM, from common.Address, to common.Address, create bool, input []byte, gas uint64, value *big.Int) {
- t.env = env
- db := &dbObj{db: env.StateDB, vm: t.vm, toBig: t.toBig, toBuf: t.toBuf, fromBuf: t.fromBuf}
- t.dbValue = db.setupObject()
- if create {
- t.ctx["type"] = t.vm.ToValue("CREATE")
- } else {
- t.ctx["type"] = t.vm.ToValue("CALL")
- }
- t.ctx["from"] = t.vm.ToValue(from.Bytes())
- t.ctx["to"] = t.vm.ToValue(to.Bytes())
- t.ctx["input"] = t.vm.ToValue(input)
- t.ctx["gas"] = t.vm.ToValue(gas)
- t.ctx["gasPrice"] = t.vm.ToValue(env.TxContext.GasPrice)
- valueBig, err := t.toBig(t.vm, value.String())
- if err != nil {
- t.err = err
- return
- }
- t.ctx["value"] = valueBig
- t.ctx["block"] = t.vm.ToValue(env.Context.BlockNumber.Uint64())
- // Update list of precompiles based on current block
- rules := env.ChainConfig().Rules(env.Context.BlockNumber, env.Context.Random != nil)
- t.activePrecompiles = vm.ActivePrecompiles(rules)
- t.ctx["intrinsicGas"] = t.vm.ToValue(t.gasLimit - gas)
- }
- // CaptureState implements the Tracer interface to trace a single step of VM execution.
- func (t *jsTracer) CaptureState(pc uint64, op vm.OpCode, gas, cost uint64, scope *vm.ScopeContext, rData []byte, depth int, err error) {
- if !t.traceStep {
- return
- }
- if t.err != nil {
- return
- }
- log := t.log
- log.op.op = op
- log.memory.memory = scope.Memory
- log.stack.stack = scope.Stack
- log.contract.contract = scope.Contract
- log.pc = uint(pc)
- log.gas = uint(gas)
- log.cost = uint(cost)
- log.depth = uint(depth)
- log.err = err
- if _, err := t.step(t.obj, t.logValue, t.dbValue); err != nil {
- t.onError("step", err)
- }
- }
- // CaptureFault implements the Tracer interface to trace an execution fault
- func (t *jsTracer) CaptureFault(pc uint64, op vm.OpCode, gas, cost uint64, scope *vm.ScopeContext, depth int, err error) {
- if t.err != nil {
- return
- }
- // Other log fields have been already set as part of the last CaptureState.
- t.log.err = err
- if _, err := t.fault(t.obj, t.logValue, t.dbValue); err != nil {
- t.onError("fault", err)
- }
- }
- // CaptureEnd is called after the call finishes to finalize the tracing.
- func (t *jsTracer) CaptureEnd(output []byte, gasUsed uint64, duration time.Duration, err error) {
- t.ctx["output"] = t.vm.ToValue(output)
- t.ctx["time"] = t.vm.ToValue(duration.String())
- t.ctx["gasUsed"] = t.vm.ToValue(gasUsed)
- if err != nil {
- t.ctx["error"] = t.vm.ToValue(err.Error())
- }
- }
- // CaptureEnter is called when EVM enters a new scope (via call, create or selfdestruct).
- func (t *jsTracer) CaptureEnter(typ vm.OpCode, from common.Address, to common.Address, input []byte, gas uint64, value *big.Int) {
- if !t.traceFrame {
- return
- }
- if t.err != nil {
- return
- }
- t.frame.typ = typ.String()
- t.frame.from = from
- t.frame.to = to
- t.frame.input = common.CopyBytes(input)
- t.frame.gas = uint(gas)
- t.frame.value = nil
- if value != nil {
- t.frame.value = new(big.Int).SetBytes(value.Bytes())
- }
- if _, err := t.enter(t.obj, t.frameValue); err != nil {
- t.onError("enter", err)
- }
- }
- // CaptureExit is called when EVM exits a scope, even if the scope didn't
- // execute any code.
- func (t *jsTracer) CaptureExit(output []byte, gasUsed uint64, err error) {
- if !t.traceFrame {
- return
- }
- t.frameResult.gasUsed = uint(gasUsed)
- t.frameResult.output = common.CopyBytes(output)
- t.frameResult.err = err
- if _, err := t.exit(t.obj, t.frameResultValue); err != nil {
- t.onError("exit", err)
- }
- }
- // GetResult calls the Javascript 'result' function and returns its value, or any accumulated error
- func (t *jsTracer) GetResult() (json.RawMessage, error) {
- ctx := t.vm.ToValue(t.ctx)
- res, err := t.result(t.obj, ctx, t.dbValue)
- if err != nil {
- return nil, wrapError("result", err)
- }
- encoded, err := json.Marshal(res)
- if err != nil {
- return nil, err
- }
- return json.RawMessage(encoded), t.err
- }
- // Stop terminates execution of the tracer at the first opportune moment.
- func (t *jsTracer) Stop(err error) {
- t.vm.Interrupt(err)
- }
- // onError is called anytime the running JS code is interrupted
- // and returns an error. It in turn pings the EVM to cancel its
- // execution.
- func (t *jsTracer) onError(context string, err error) {
- t.err = wrapError(context, err)
- // `env` is set on CaptureStart which comes before any JS execution.
- // So it should be non-nil.
- t.env.Cancel()
- }
- func wrapError(context string, err error) error {
- return fmt.Errorf("%v in server-side tracer function '%v'", err, context)
- }
- // setBuiltinFunctions injects Go functions which are available to tracers into the environment.
- // It depends on type converters having been set up.
- func (t *jsTracer) setBuiltinFunctions() {
- vm := t.vm
- // TODO: load console from goja-nodejs
- vm.Set("toHex", func(v goja.Value) string {
- b, err := t.fromBuf(vm, v, false)
- if err != nil {
- vm.Interrupt(err)
- return ""
- }
- return hexutil.Encode(b)
- })
- vm.Set("toWord", func(v goja.Value) goja.Value {
- // TODO: add test with []byte len < 32 or > 32
- b, err := t.fromBuf(vm, v, true)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- b = common.BytesToHash(b).Bytes()
- res, err := t.toBuf(vm, b)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- return res
- })
- vm.Set("toAddress", func(v goja.Value) goja.Value {
- a, err := t.fromBuf(vm, v, true)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- a = common.BytesToAddress(a).Bytes()
- res, err := t.toBuf(vm, a)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- return res
- })
- vm.Set("toContract", func(from goja.Value, nonce uint) goja.Value {
- a, err := t.fromBuf(vm, from, true)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- addr := common.BytesToAddress(a)
- b := crypto.CreateAddress(addr, uint64(nonce)).Bytes()
- res, err := t.toBuf(vm, b)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- return res
- })
- vm.Set("toContract2", func(from goja.Value, salt string, initcode goja.Value) goja.Value {
- a, err := t.fromBuf(vm, from, true)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- addr := common.BytesToAddress(a)
- code, err := t.fromBuf(vm, initcode, true)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- code = common.CopyBytes(code)
- codeHash := crypto.Keccak256(code)
- b := crypto.CreateAddress2(addr, common.HexToHash(salt), codeHash).Bytes()
- res, err := t.toBuf(vm, b)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- return res
- })
- vm.Set("isPrecompiled", func(v goja.Value) bool {
- a, err := t.fromBuf(vm, v, true)
- if err != nil {
- vm.Interrupt(err)
- return false
- }
- addr := common.BytesToAddress(a)
- for _, p := range t.activePrecompiles {
- if p == addr {
- return true
- }
- }
- return false
- })
- vm.Set("slice", func(slice goja.Value, start, end int) goja.Value {
- b, err := t.fromBuf(vm, slice, false)
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- if start < 0 || start > end || end > len(b) {
- vm.Interrupt(fmt.Sprintf("Tracer accessed out of bound memory: available %d, offset %d, size %d", len(b), start, end-start))
- return nil
- }
- res, err := t.toBuf(vm, b[start:end])
- if err != nil {
- vm.Interrupt(err)
- return nil
- }
- return res
- })
- }
- // setTypeConverters sets up utilities for converting Go types into those
- // suitable for JS consumption.
- func (t *jsTracer) setTypeConverters() error {
- // Inject bigint logic.
- // TODO: To be replaced after goja adds support for native JS bigint.
- toBigCode, err := t.vm.RunProgram(bigIntProgram)
- if err != nil {
- return err
- }
- // Used to create JS bigint objects from go.
- toBigFn, ok := goja.AssertFunction(toBigCode)
- if !ok {
- return errors.New("failed to bind bigInt func")
- }
- toBigWrapper := func(vm *goja.Runtime, val string) (goja.Value, error) {
- return toBigFn(goja.Undefined(), vm.ToValue(val))
- }
- t.toBig = toBigWrapper
- // NOTE: We need this workaround to create JS buffers because
- // goja doesn't at the moment expose constructors for typed arrays.
- //
- // Cache uint8ArrayType once to be used every time for less overhead.
- uint8ArrayType := t.vm.Get("Uint8Array")
- toBufWrapper := func(vm *goja.Runtime, val []byte) (goja.Value, error) {
- return toBuf(vm, uint8ArrayType, val)
- }
- t.toBuf = toBufWrapper
- fromBufWrapper := func(vm *goja.Runtime, buf goja.Value, allowString bool) ([]byte, error) {
- return fromBuf(vm, uint8ArrayType, buf, allowString)
- }
- t.fromBuf = fromBufWrapper
- return nil
- }
- type opObj struct {
- vm *goja.Runtime
- op vm.OpCode
- }
- func (o *opObj) ToNumber() int {
- return int(o.op)
- }
- func (o *opObj) ToString() string {
- return o.op.String()
- }
- func (o *opObj) IsPush() bool {
- return o.op.IsPush()
- }
- func (o *opObj) setupObject() *goja.Object {
- obj := o.vm.NewObject()
- obj.Set("toNumber", o.vm.ToValue(o.ToNumber))
- obj.Set("toString", o.vm.ToValue(o.ToString))
- obj.Set("isPush", o.vm.ToValue(o.IsPush))
- return obj
- }
- type memoryObj struct {
- memory *vm.Memory
- vm *goja.Runtime
- toBig toBigFn
- toBuf toBufFn
- }
- func (mo *memoryObj) Slice(begin, end int64) goja.Value {
- b, err := mo.slice(begin, end)
- if err != nil {
- mo.vm.Interrupt(err)
- return nil
- }
- res, err := mo.toBuf(mo.vm, b)
- if err != nil {
- mo.vm.Interrupt(err)
- return nil
- }
- return res
- }
- // slice returns the requested range of memory as a byte slice.
- func (mo *memoryObj) slice(begin, end int64) ([]byte, error) {
- if end == begin {
- return []byte{}, nil
- }
- if end < begin || begin < 0 {
- return nil, fmt.Errorf("tracer accessed out of bound memory: offset %d, end %d", begin, end)
- }
- if mo.memory.Len() < int(end) {
- return nil, fmt.Errorf("tracer accessed out of bound memory: available %d, offset %d, size %d", mo.memory.Len(), begin, end-begin)
- }
- return mo.memory.GetCopy(begin, end-begin), nil
- }
- func (mo *memoryObj) GetUint(addr int64) goja.Value {
- value, err := mo.getUint(addr)
- if err != nil {
- mo.vm.Interrupt(err)
- return nil
- }
- res, err := mo.toBig(mo.vm, value.String())
- if err != nil {
- mo.vm.Interrupt(err)
- return nil
- }
- return res
- }
- // getUint returns the 32 bytes at the specified address interpreted as a uint.
- func (mo *memoryObj) getUint(addr int64) (*big.Int, error) {
- if mo.memory.Len() < int(addr)+32 || addr < 0 {
- return nil, fmt.Errorf("tracer accessed out of bound memory: available %d, offset %d, size %d", mo.memory.Len(), addr, 32)
- }
- return new(big.Int).SetBytes(mo.memory.GetPtr(addr, 32)), nil
- }
- func (mo *memoryObj) Length() int {
- return mo.memory.Len()
- }
- func (m *memoryObj) setupObject() *goja.Object {
- o := m.vm.NewObject()
- o.Set("slice", m.vm.ToValue(m.Slice))
- o.Set("getUint", m.vm.ToValue(m.GetUint))
- o.Set("length", m.vm.ToValue(m.Length))
- return o
- }
- type stackObj struct {
- stack *vm.Stack
- vm *goja.Runtime
- toBig toBigFn
- }
- func (s *stackObj) Peek(idx int) goja.Value {
- value, err := s.peek(idx)
- if err != nil {
- s.vm.Interrupt(err)
- return nil
- }
- res, err := s.toBig(s.vm, value.String())
- if err != nil {
- s.vm.Interrupt(err)
- return nil
- }
- return res
- }
- // peek returns the nth-from-the-top element of the stack.
- func (s *stackObj) peek(idx int) (*big.Int, error) {
- if len(s.stack.Data()) <= idx || idx < 0 {
- return nil, fmt.Errorf("tracer accessed out of bound stack: size %d, index %d", len(s.stack.Data()), idx)
- }
- return s.stack.Back(idx).ToBig(), nil
- }
- func (s *stackObj) Length() int {
- return len(s.stack.Data())
- }
- func (s *stackObj) setupObject() *goja.Object {
- o := s.vm.NewObject()
- o.Set("peek", s.vm.ToValue(s.Peek))
- o.Set("length", s.vm.ToValue(s.Length))
- return o
- }
- type dbObj struct {
- db vm.StateDB
- vm *goja.Runtime
- toBig toBigFn
- toBuf toBufFn
- fromBuf fromBufFn
- }
- func (do *dbObj) GetBalance(addrSlice goja.Value) goja.Value {
- a, err := do.fromBuf(do.vm, addrSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- addr := common.BytesToAddress(a)
- value := do.db.GetBalance(addr)
- res, err := do.toBig(do.vm, value.String())
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (do *dbObj) GetNonce(addrSlice goja.Value) uint64 {
- a, err := do.fromBuf(do.vm, addrSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return 0
- }
- addr := common.BytesToAddress(a)
- return do.db.GetNonce(addr)
- }
- func (do *dbObj) GetCode(addrSlice goja.Value) goja.Value {
- a, err := do.fromBuf(do.vm, addrSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- addr := common.BytesToAddress(a)
- code := do.db.GetCode(addr)
- res, err := do.toBuf(do.vm, code)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (do *dbObj) GetState(addrSlice goja.Value, hashSlice goja.Value) goja.Value {
- a, err := do.fromBuf(do.vm, addrSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- addr := common.BytesToAddress(a)
- h, err := do.fromBuf(do.vm, hashSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- hash := common.BytesToHash(h)
- state := do.db.GetState(addr, hash).Bytes()
- res, err := do.toBuf(do.vm, state)
- if err != nil {
- do.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (do *dbObj) Exists(addrSlice goja.Value) bool {
- a, err := do.fromBuf(do.vm, addrSlice, false)
- if err != nil {
- do.vm.Interrupt(err)
- return false
- }
- addr := common.BytesToAddress(a)
- return do.db.Exist(addr)
- }
- func (do *dbObj) setupObject() *goja.Object {
- o := do.vm.NewObject()
- o.Set("getBalance", do.vm.ToValue(do.GetBalance))
- o.Set("getNonce", do.vm.ToValue(do.GetNonce))
- o.Set("getCode", do.vm.ToValue(do.GetCode))
- o.Set("getState", do.vm.ToValue(do.GetState))
- o.Set("exists", do.vm.ToValue(do.Exists))
- return o
- }
- type contractObj struct {
- contract *vm.Contract
- vm *goja.Runtime
- toBig toBigFn
- toBuf toBufFn
- }
- func (co *contractObj) GetCaller() goja.Value {
- caller := co.contract.Caller().Bytes()
- res, err := co.toBuf(co.vm, caller)
- if err != nil {
- co.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (co *contractObj) GetAddress() goja.Value {
- addr := co.contract.Address().Bytes()
- res, err := co.toBuf(co.vm, addr)
- if err != nil {
- co.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (co *contractObj) GetValue() goja.Value {
- value := co.contract.Value()
- res, err := co.toBig(co.vm, value.String())
- if err != nil {
- co.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (co *contractObj) GetInput() goja.Value {
- input := common.CopyBytes(co.contract.Input)
- res, err := co.toBuf(co.vm, input)
- if err != nil {
- co.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (c *contractObj) setupObject() *goja.Object {
- o := c.vm.NewObject()
- o.Set("getCaller", c.vm.ToValue(c.GetCaller))
- o.Set("getAddress", c.vm.ToValue(c.GetAddress))
- o.Set("getValue", c.vm.ToValue(c.GetValue))
- o.Set("getInput", c.vm.ToValue(c.GetInput))
- return o
- }
- type callframe struct {
- vm *goja.Runtime
- toBig toBigFn
- toBuf toBufFn
- typ string
- from common.Address
- to common.Address
- input []byte
- gas uint
- value *big.Int
- }
- func (f *callframe) GetType() string {
- return f.typ
- }
- func (f *callframe) GetFrom() goja.Value {
- from := f.from.Bytes()
- res, err := f.toBuf(f.vm, from)
- if err != nil {
- f.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (f *callframe) GetTo() goja.Value {
- to := f.to.Bytes()
- res, err := f.toBuf(f.vm, to)
- if err != nil {
- f.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (f *callframe) GetInput() goja.Value {
- input := f.input
- res, err := f.toBuf(f.vm, input)
- if err != nil {
- f.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (f *callframe) GetGas() uint {
- return f.gas
- }
- func (f *callframe) GetValue() goja.Value {
- if f.value == nil {
- return goja.Undefined()
- }
- res, err := f.toBig(f.vm, f.value.String())
- if err != nil {
- f.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (f *callframe) setupObject() *goja.Object {
- o := f.vm.NewObject()
- o.Set("getType", f.vm.ToValue(f.GetType))
- o.Set("getFrom", f.vm.ToValue(f.GetFrom))
- o.Set("getTo", f.vm.ToValue(f.GetTo))
- o.Set("getInput", f.vm.ToValue(f.GetInput))
- o.Set("getGas", f.vm.ToValue(f.GetGas))
- o.Set("getValue", f.vm.ToValue(f.GetValue))
- return o
- }
- type callframeResult struct {
- vm *goja.Runtime
- toBuf toBufFn
- gasUsed uint
- output []byte
- err error
- }
- func (r *callframeResult) GetGasUsed() uint {
- return r.gasUsed
- }
- func (r *callframeResult) GetOutput() goja.Value {
- res, err := r.toBuf(r.vm, r.output)
- if err != nil {
- r.vm.Interrupt(err)
- return nil
- }
- return res
- }
- func (r *callframeResult) GetError() goja.Value {
- if r.err != nil {
- return r.vm.ToValue(r.err.Error())
- }
- return goja.Undefined()
- }
- func (r *callframeResult) setupObject() *goja.Object {
- o := r.vm.NewObject()
- o.Set("getGasUsed", r.vm.ToValue(r.GetGasUsed))
- o.Set("getOutput", r.vm.ToValue(r.GetOutput))
- o.Set("getError", r.vm.ToValue(r.GetError))
- return o
- }
- type steplog struct {
- vm *goja.Runtime
- op *opObj
- memory *memoryObj
- stack *stackObj
- contract *contractObj
- pc uint
- gas uint
- cost uint
- depth uint
- refund uint
- err error
- }
- func (l *steplog) GetPC() uint {
- return l.pc
- }
- func (l *steplog) GetGas() uint {
- return l.gas
- }
- func (l *steplog) GetCost() uint {
- return l.cost
- }
- func (l *steplog) GetDepth() uint {
- return l.depth
- }
- func (l *steplog) GetRefund() uint {
- return l.refund
- }
- func (l *steplog) GetError() goja.Value {
- if l.err != nil {
- return l.vm.ToValue(l.err.Error())
- }
- return goja.Undefined()
- }
- func (l *steplog) setupObject() *goja.Object {
- o := l.vm.NewObject()
- // Setup basic fields.
- o.Set("getPC", l.vm.ToValue(l.GetPC))
- o.Set("getGas", l.vm.ToValue(l.GetGas))
- o.Set("getCost", l.vm.ToValue(l.GetCost))
- o.Set("getDepth", l.vm.ToValue(l.GetDepth))
- o.Set("getRefund", l.vm.ToValue(l.GetRefund))
- o.Set("getError", l.vm.ToValue(l.GetError))
- // Setup nested objects.
- o.Set("op", l.op.setupObject())
- o.Set("stack", l.stack.setupObject())
- o.Set("memory", l.memory.setupObject())
- o.Set("contract", l.contract.setupObject())
- return o
- }
|