Documentation
¶
Index ¶
- func CheckSenderBalance(balance sdkmath.Int, txData types.TxData) error
- func GasToRefund(availableRefund, gasConsumed, refundQuotient uint64) uint64
- func GetProposerAddress(ctx sdk.Context, proposerAddress sdk.ConsAddress) sdk.ConsAddress
- func VerifyFee(txData types.TxData, denom string, baseFee *big.Int, ...) (sdk.Coins, error)
- type Keeper
- func (k Keeper) Account(c context.Context, req *types.QueryAccountRequest) (*types.QueryAccountResponse, error)
- func (k Keeper) AddTransientGasUsed(ctx sdk.Context, gasUsed uint64) (uint64, error)
- func (k *Keeper) ApplyMessage(ctx sdk.Context, msg core.Message, tracer vm.EVMLogger, commit bool) (*types.MsgEthereumTxResponse, error)
- func (k *Keeper) ApplyMessageWithConfig(ctx sdk.Context, msg core.Message, tracer vm.EVMLogger, commit bool, ...) (*types.MsgEthereumTxResponse, error)
- func (k *Keeper) ApplyTransaction(ctx sdk.Context, tx *ethtypes.Transaction) (*types.MsgEthereumTxResponse, error)
- func (k Keeper) Balance(c context.Context, req *types.QueryBalanceRequest) (*types.QueryBalanceResponse, error)
- func (k Keeper) BaseFee(c context.Context, _ *types.QueryBaseFeeRequest) (*types.QueryBaseFeeResponse, error)
- func (k *Keeper) BeginBlock(ctx sdk.Context) error
- func (k Keeper) CallEVM(ctx sdk.Context, abi abi.ABI, from, contract common.Address, commit bool, ...) (*types.MsgEthereumTxResponse, error)
- func (k Keeper) CallEVMWithData(ctx sdk.Context, from common.Address, contract *common.Address, data []byte, ...) (*types.MsgEthereumTxResponse, error)
- func (k Keeper) Code(c context.Context, req *types.QueryCodeRequest) (*types.QueryCodeResponse, error)
- func (k Keeper) Config(_ context.Context, _ *types.QueryConfigRequest) (*types.QueryConfigResponse, error)
- func (k Keeper) CosmosAccount(c context.Context, req *types.QueryCosmosAccountRequest) (*types.QueryCosmosAccountResponse, error)
- func (k *Keeper) DeductTxCostsFromUserBalance(ctx sdk.Context, fees sdk.Coins, from common.Address) error
- func (k *Keeper) DeleteAccount(ctx sdk.Context, addr common.Address) error
- func (k *Keeper) DeleteCode(ctx sdk.Context, codeHash []byte)
- func (k *Keeper) DeleteCodeHash(ctx sdk.Context, addr common.Address)
- func (k *Keeper) DeleteState(ctx sdk.Context, addr common.Address, key common.Hash)
- func (k *Keeper) EVMConfig(ctx sdk.Context, proposerAddress sdk.ConsAddress) (*statedb.EVMConfig, error)
- func (k Keeper) EmitBlockBloomEvent(ctx sdk.Context, bloom ethtypes.Bloom)
- func (k Keeper) EnableEIPs(ctx sdk.Context, eips ...string) error
- func (k Keeper) EnableStaticPrecompiles(ctx sdk.Context, addresses ...common.Address) error
- func (k *Keeper) EndBlock(ctx sdk.Context) error
- func (k Keeper) EstimateGas(c context.Context, req *types.EthCallRequest) (*types.EstimateGasResponse, error)
- func (k Keeper) EstimateGasInternal(c context.Context, req *types.EthCallRequest, fromType types.CallType) (*types.EstimateGasResponse, error)
- func (k Keeper) EthCall(c context.Context, req *types.EthCallRequest) (*types.MsgEthereumTxResponse, error)
- func (k *Keeper) EthereumTx(goCtx context.Context, msg *types.MsgEthereumTx) (*types.MsgEthereumTxResponse, error)
- func (k *Keeper) ForEachStorage(ctx sdk.Context, addr common.Address, cb func(key, value common.Hash) bool)
- func (k *Keeper) GetAccount(ctx sdk.Context, addr common.Address) *statedb.Account
- func (k *Keeper) GetAccountOrEmpty(ctx sdk.Context, addr common.Address) statedb.Account
- func (k Keeper) GetAccountStorage(ctx sdk.Context, address common.Address) types.Storage
- func (k *Keeper) GetAccountWithoutBalance(ctx sdk.Context, addr common.Address) *statedb.Account
- func (k Keeper) GetAuthority() sdk.AccAddress
- func (k *Keeper) GetBalance(ctx sdk.Context, addr common.Address) *big.Int
- func (k Keeper) GetBaseFee(ctx sdk.Context) *big.Int
- func (k Keeper) GetBlockBloomTransient(ctx sdk.Context) *big.Int
- func (k *Keeper) GetCode(ctx sdk.Context, codeHash common.Hash) []byte
- func (k *Keeper) GetCodeHash(ctx sdk.Context, addr common.Address) common.Hash
- func (k Keeper) GetCoinbaseAddress(ctx sdk.Context, proposerAddress sdk.ConsAddress) (common.Address, error)
- func (k *Keeper) GetEthIntrinsicGas(ctx sdk.Context, msg core.Message, cfg *params.ChainConfig, ...) (uint64, error)
- func (k *Keeper) GetFastState(ctx sdk.Context, addr common.Address, key common.Hash) []byte
- func (k Keeper) GetHashFn(ctx sdk.Context) vm.GetHashFunc
- func (k Keeper) GetLegacyParams(ctx sdk.Context) types.Params
- func (k Keeper) GetLogSizeTransient(ctx sdk.Context) uint64
- func (k Keeper) GetMinGasMultiplier(ctx sdk.Context) math.LegacyDec
- func (k Keeper) GetMinGasPrice(ctx sdk.Context) math.LegacyDec
- func (k *Keeper) GetNonce(ctx sdk.Context, addr common.Address) uint64
- func (k Keeper) GetParams(ctx sdk.Context) (params types.Params)
- func (k *Keeper) GetPrecompileInstance(ctx sdktypes.Context, address common.Address) (*Precompiles, bool, error)
- func (k *Keeper) GetPrecompilesCallHook(ctx sdktypes.Context) types.CallHook
- func (k *Keeper) GetState(ctx sdk.Context, addr common.Address, key common.Hash) common.Hash
- func (k *Keeper) GetStaticPrecompileInstance(params *types.Params, address common.Address) (vm.PrecompiledContract, bool, error)
- func (k Keeper) GetTransientGasUsed(ctx sdk.Context) uint64
- func (k Keeper) GetTxIndexTransient(ctx sdk.Context) uint64
- func (k Keeper) GlobalMinGasPrice(c context.Context, _ *types.QueryGlobalMinGasPriceRequest) (*types.QueryGlobalMinGasPriceResponse, error)
- func (k Keeper) IsAvailableStaticPrecompile(params *types.Params, address common.Address) bool
- func (k *Keeper) IsContract(ctx sdk.Context, addr common.Address) bool
- func (k Keeper) IterateContracts(ctx sdk.Context, ...)
- func (k Keeper) Logger(ctx sdk.Context) log.Logger
- func (k *Keeper) NewEVM(ctx sdk.Context, msg core.Message, cfg *statedb.EVMConfig, tracer vm.EVMLogger, ...) *vm.EVM
- func (k Keeper) Params(c context.Context, _ *types.QueryParamsRequest) (*types.QueryParamsResponse, error)
- func (k *Keeper) RefundGas(ctx sdk.Context, msg core.Message, leftoverGas uint64, denom string) error
- func (k *Keeper) ResetGasMeterAndConsumeGas(ctx sdk.Context, gasUsed uint64)
- func (k Keeper) ResetTransientGasUsed(ctx sdk.Context)
- func (k *Keeper) SetAccount(ctx sdk.Context, addr common.Address, account statedb.Account) error
- func (k *Keeper) SetBalance(ctx sdk.Context, addr common.Address, amount *big.Int) error
- func (k Keeper) SetBlockBloomTransient(ctx sdk.Context, bloom *big.Int)
- func (k *Keeper) SetCode(ctx sdk.Context, codeHash, code []byte)
- func (k *Keeper) SetCodeHash(ctx sdk.Context, addrBytes, hashBytes []byte)
- func (k Keeper) SetLogSizeTransient(ctx sdk.Context, logSize uint64)
- func (k Keeper) SetParams(ctx sdk.Context, params types.Params) error
- func (k *Keeper) SetState(ctx sdk.Context, addr common.Address, key common.Hash, value []byte)
- func (k Keeper) SetTransientGasUsed(ctx sdk.Context, gasUsed uint64)
- func (k Keeper) SetTxIndexTransient(ctx sdk.Context, index uint64)
- func (k Keeper) Storage(c context.Context, req *types.QueryStorageRequest) (*types.QueryStorageResponse, error)
- func (k Keeper) TraceBlock(c context.Context, req *types.QueryTraceBlockRequest) (*types.QueryTraceBlockResponse, error)
- func (k Keeper) TraceTx(c context.Context, req *types.QueryTraceTxRequest) (*types.QueryTraceTxResponse, error)
- func (k Keeper) Tracer(ctx sdk.Context, msg core.Message, ethCfg *params.ChainConfig) vm.EVMLogger
- func (k *Keeper) TxConfig(ctx sdk.Context, txHash common.Hash) statedb.TxConfig
- func (k *Keeper) UpdateParams(goCtx context.Context, req *types.MsgUpdateParams) (*types.MsgUpdateParamsResponse, error)
- func (k Keeper) VMConfig(ctx sdk.Context, _ core.Message, cfg *statedb.EVMConfig, tracer vm.EVMLogger) vm.Config
- func (k Keeper) ValidatorAccount(c context.Context, req *types.QueryValidatorAccountRequest) (*types.QueryValidatorAccountResponse, error)
- func (k *Keeper) WithStaticPrecompiles(precompiles map[common.Address]vm.PrecompiledContract) *Keeper
- type Precompiles
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func CheckSenderBalance ¶
CheckSenderBalance validates that the tx cost value is positive and that the sender has enough funds to pay for the fees and value of the transaction.
func GasToRefund ¶
GasToRefund calculates the amount of gas the state machine should refund to the sender. It is capped by the refund quotient value. Note: do not pass 0 to refundQuotient
func GetProposerAddress ¶
func GetProposerAddress(ctx sdk.Context, proposerAddress sdk.ConsAddress) sdk.ConsAddress
GetProposerAddress returns current block proposer's address when provided proposer address is empty.
func VerifyFee ¶
func VerifyFee( txData types.TxData, denom string, baseFee *big.Int, homestead, istanbul, isCheckTx bool, ) (sdk.Coins, error)
VerifyFee is used to return the fee for the given transaction data in sdk.Coins. It checks that the gas limit is not reached, the gas limit is higher than the intrinsic gas and that the base fee is higher than the gas fee cap.
Types ¶
type Keeper ¶
type Keeper struct {
// contains filtered or unexported fields
}
Keeper grants access to the EVM module state and implements the go-ethereum StateDB interface.
func NewKeeper ¶
func NewKeeper( cdc codec.BinaryCodec, storeKey, transientKey storetypes.StoreKey, authority sdk.AccAddress, ak types.AccountKeeper, bankKeeper types.BankKeeper, sk types.StakingKeeper, fmk types.FeeMarketKeeper, erc20Keeper types.Erc20Keeper, tracer string, ss paramstypes.Subspace, ) *Keeper
NewKeeper generates new evm module keeper
func (Keeper) Account ¶
func (k Keeper) Account(c context.Context, req *types.QueryAccountRequest) (*types.QueryAccountResponse, error)
Account implements the Query/Account gRPC method. The method returns the balance of the account in 18 decimals representation.
func (Keeper) AddTransientGasUsed ¶
AddTransientGasUsed accumulate gas used by each eth msgs included in current cosmos tx.
func (*Keeper) ApplyMessage ¶
func (k *Keeper) ApplyMessage(ctx sdk.Context, msg core.Message, tracer vm.EVMLogger, commit bool) (*types.MsgEthereumTxResponse, error)
ApplyMessage calls ApplyMessageWithConfig with an empty TxConfig.
func (*Keeper) ApplyMessageWithConfig ¶
func (k *Keeper) ApplyMessageWithConfig( ctx sdk.Context, msg core.Message, tracer vm.EVMLogger, commit bool, cfg *statedb.EVMConfig, txConfig statedb.TxConfig, ) (*types.MsgEthereumTxResponse, error)
ApplyMessageWithConfig computes the new state by applying the given message against the existing state. If the message fails, the VM execution error with the reason will be returned to the client and the transaction won't be committed to the store.
Reverted state ¶
The snapshot and rollback are supported by the `statedb.StateDB`.
Different Callers ¶
It's called in three scenarios: 1. `ApplyTransaction`, in the transaction processing flow. 2. `EthCall/EthEstimateGas` grpc query handler. 3. Called by other native modules directly.
Prechecks and Preprocessing ¶
All relevant state transition prechecks for the MsgEthereumTx are performed on the AnteHandler, prior to running the transaction against the state. The prechecks run are the following:
1. the nonce of the message caller is correct 2. caller has enough balance to cover transaction fee(gaslimit * gasprice) 3. the amount of gas required is available in the block 4. the purchased gas is enough to cover intrinsic usage 5. there is no overflow when calculating intrinsic gas 6. caller has enough balance to cover asset transfer for **topmost** call
The preprocessing steps performed by the AnteHandler are:
1. set up the initial access list (iff fork > Berlin)
Tracer parameter ¶
It should be a `vm.Tracer` object or nil, if pass `nil`, it'll create a default one based on keeper options.
Commit parameter ¶
If commit is true, the `StateDB` will be committed, otherwise discarded.
func (*Keeper) ApplyTransaction ¶
func (k *Keeper) ApplyTransaction(ctx sdk.Context, tx *ethtypes.Transaction) (*types.MsgEthereumTxResponse, error)
ApplyTransaction runs and attempts to perform a state transition with the given transaction (i.e Message), that will only be persisted (committed) to the underlying KVStore if the transaction does not fail.
Gas tracking ¶
Ethereum consumes gas according to the EVM opcodes instead of general reads and writes to store. Because of this, the state transition needs to ignore the SDK gas consumption mechanism defined by the GasKVStore and instead consume the amount of gas used by the VM execution. The amount of gas used is tracked by the EVM and returned in the execution result.
Prior to the execution, the starting tx gas meter is saved and replaced with an infinite gas meter in a new context in order to ignore the SDK gas consumption config values (read, write, has, delete). After the execution, the gas used from the message execution will be added to the starting gas consumed, taking into consideration the amount of gas returned. Finally, the context is updated with the EVM gas consumed value prior to returning.
For relevant discussion see: https://github.com/cosmos/cosmos-sdk/discussions/9072
func (Keeper) Balance ¶
func (k Keeper) Balance(c context.Context, req *types.QueryBalanceRequest) (*types.QueryBalanceResponse, error)
Balance implements the Query/Balance gRPC method. The method returns the 18 decimal representation of the account balance.
func (Keeper) BaseFee ¶
func (k Keeper) BaseFee(c context.Context, _ *types.QueryBaseFeeRequest) (*types.QueryBaseFeeResponse, error)
BaseFee implements the Query/BaseFee gRPC method
func (*Keeper) BeginBlock ¶
BeginBlock emits a base fee event which will be adjusted to the evm decimals
func (Keeper) CallEVM ¶
func (k Keeper) CallEVM( ctx sdk.Context, abi abi.ABI, from, contract common.Address, commit bool, method string, args ...interface{}, ) (*types.MsgEthereumTxResponse, error)
CallEVM performs a smart contract method call using given args.
func (Keeper) CallEVMWithData ¶
func (k Keeper) CallEVMWithData( ctx sdk.Context, from common.Address, contract *common.Address, data []byte, commit bool, ) (*types.MsgEthereumTxResponse, error)
CallEVMWithData performs a smart contract method call using contract data.
func (Keeper) Code ¶
func (k Keeper) Code(c context.Context, req *types.QueryCodeRequest) (*types.QueryCodeResponse, error)
Code implements the Query/Code gRPC method
func (Keeper) Config ¶
func (k Keeper) Config(_ context.Context, _ *types.QueryConfigRequest) (*types.QueryConfigResponse, error)
Config implements the Query/Config gRPC method
func (Keeper) CosmosAccount ¶
func (k Keeper) CosmosAccount(c context.Context, req *types.QueryCosmosAccountRequest) (*types.QueryCosmosAccountResponse, error)
func (*Keeper) DeductTxCostsFromUserBalance ¶
func (k *Keeper) DeductTxCostsFromUserBalance( ctx sdk.Context, fees sdk.Coins, from common.Address, ) error
DeductTxCostsFromUserBalance deducts the fees from the user balance.
func (*Keeper) DeleteAccount ¶
DeleteAccount handles contract's suicide call: - clear balance - remove code - remove states - remove the code hash - remove auth account
func (*Keeper) DeleteCode ¶
DeleteCode deletes the contract code for the given code hash bytes in the corresponding store.
func (*Keeper) DeleteCodeHash ¶
DeleteCodeHash deletes the code hash for the given contract address from the store.
func (*Keeper) DeleteState ¶
DeleteState deletes the entry for the given key in the contract storage at the defined contract address.
func (*Keeper) EVMConfig ¶
func (k *Keeper) EVMConfig(ctx sdk.Context, proposerAddress sdk.ConsAddress) (*statedb.EVMConfig, error)
EVMConfig creates the EVMConfig based on current state
func (Keeper) EmitBlockBloomEvent ¶
EmitBlockBloomEvent emit block bloom events
func (Keeper) EnableEIPs ¶
EnableEIPs enables the given EIPs in the EVM parameters.
func (Keeper) EnableStaticPrecompiles ¶
EnableStaticPrecompiles appends the addresses of the given Precompiles to the list of active static precompiles.
func (*Keeper) EndBlock ¶
EndBlock also retrieves the bloom filter value from the transient store and commits it to the KVStore. The EVM end block logic doesn't update the validator set, thus it returns an empty slice.
func (Keeper) EstimateGas ¶
func (k Keeper) EstimateGas(c context.Context, req *types.EthCallRequest) (*types.EstimateGasResponse, error)
EstimateGas implements eth_estimateGas rpc api.
func (Keeper) EstimateGasInternal ¶
func (k Keeper) EstimateGasInternal(c context.Context, req *types.EthCallRequest, fromType types.CallType) (*types.EstimateGasResponse, error)
EstimateGasInternal returns the gas estimation for the corresponding request. This function is called from the RPC client (eth_estimateGas) and internally. When called from the RPC client, we need to reset the gas meter before simulating the transaction to have an accurate gas estimation for EVM extensions transactions.
func (Keeper) EthCall ¶
func (k Keeper) EthCall(c context.Context, req *types.EthCallRequest) (*types.MsgEthereumTxResponse, error)
EthCall implements eth_call rpc api.
func (*Keeper) EthereumTx ¶
func (k *Keeper) EthereumTx(goCtx context.Context, msg *types.MsgEthereumTx) (*types.MsgEthereumTxResponse, error)
EthereumTx implements the gRPC MsgServer interface. It receives a transaction which is then executed (i.e applied) against the go-ethereum EVM. The provided SDK Context is set to the Keeper so that it can implements and call the StateDB methods without receiving it as a function parameter.
func (*Keeper) ForEachStorage ¶
func (k *Keeper) ForEachStorage(ctx sdk.Context, addr common.Address, cb func(key, value common.Hash) bool)
ForEachStorage iterate contract storage, callback return false to break early
func (*Keeper) GetAccount ¶
GetAccount returns nil if account is not exist
func (*Keeper) GetAccountOrEmpty ¶
GetAccountOrEmpty returns empty account if not exist.
func (Keeper) GetAccountStorage ¶
GetAccountStorage return state storage associated with an account
func (*Keeper) GetAccountWithoutBalance ¶
GetAccountWithoutBalance load nonce and codehash without balance, more efficient in cases where balance is not needed.
func (Keeper) GetAuthority ¶
func (k Keeper) GetAuthority() sdk.AccAddress
GetAuthority returns the x/evm module authority address
func (*Keeper) GetBalance ¶
GetBalance load account's balance of gas token.
func (Keeper) GetBaseFee ¶
GetBaseFee returns current base fee, return values: - `nil`: london hardfork not enabled. - `0`: london hardfork enabled but feemarket is not enabled. - `n`: both london hardfork and feemarket are enabled.
func (Keeper) GetBlockBloomTransient ¶
GetBlockBloomTransient returns bloom bytes for the current block height
func (*Keeper) GetCode ¶
GetCode loads contract code from database, implements `statedb.Keeper` interface.
func (*Keeper) GetCodeHash ¶
GetCodeHash loads the code hash from the database for the given contract address.
func (Keeper) GetCoinbaseAddress ¶
func (k Keeper) GetCoinbaseAddress(ctx sdk.Context, proposerAddress sdk.ConsAddress) (common.Address, error)
GetCoinbaseAddress returns the block proposer's validator operator address.
func (*Keeper) GetEthIntrinsicGas ¶
func (k *Keeper) GetEthIntrinsicGas(ctx sdk.Context, msg core.Message, cfg *params.ChainConfig, isContractCreation bool) (uint64, error)
GetEthIntrinsicGas returns the intrinsic gas cost for the transaction
func (*Keeper) GetFastState ¶
GetFastState loads contract state from database.
func (Keeper) GetHashFn ¶
func (k Keeper) GetHashFn(ctx sdk.Context) vm.GetHashFunc
GetHashFn implements vm.GetHashFunc for Ethermint. It handles 3 cases:
- The requested height matches the current height from context (and thus same epoch number)
- The requested height is from an previous height from the same chain epoch
- The requested height is from a height greater than the latest one
func (Keeper) GetLegacyParams ¶
GetLegacyParams returns param set for version before migrate
func (Keeper) GetLogSizeTransient ¶
GetLogSizeTransient returns EVM log index on the current block.
func (Keeper) GetMinGasMultiplier ¶
GetMinGasMultiplier returns the MinGasMultiplier param from the fee market module
func (Keeper) GetMinGasPrice ¶
GetMinGasPrice returns the MinGasPrice param from the fee market module adapted according to the evm denom decimals
func (*Keeper) GetNonce ¶
GetNonce returns the sequence number of an account, returns 0 if not exists.
func (*Keeper) GetPrecompileInstance ¶
func (k *Keeper) GetPrecompileInstance( ctx sdktypes.Context, address common.Address, ) (*Precompiles, bool, error)
GetPrecompileInstance returns the address and instance of the static or dynamic precompile associated with the given address, or return nil if not found.
func (*Keeper) GetPrecompilesCallHook ¶
GetPrecompilesCallHook returns a closure that can be used to instantiate the EVM with a specific precompile instance.
func (*Keeper) GetStaticPrecompileInstance ¶
func (k *Keeper) GetStaticPrecompileInstance(params *types.Params, address common.Address) (vm.PrecompiledContract, bool, error)
GetStaticPrecompileInstance returns the instance of the given static precompile address.
func (Keeper) GetTransientGasUsed ¶
GetTransientGasUsed returns the gas used by current cosmos tx.
func (Keeper) GetTxIndexTransient ¶
GetTxIndexTransient returns EVM transaction index on the current block.
func (Keeper) GlobalMinGasPrice ¶
func (k Keeper) GlobalMinGasPrice(c context.Context, _ *types.QueryGlobalMinGasPriceRequest) (*types.QueryGlobalMinGasPriceResponse, error)
GlobalMinGasPrice implements the Query/GlobalMinGasPrice gRPC method
func (Keeper) IsAvailableStaticPrecompile ¶
IsAvailablePrecompile returns true if the given static precompile address is contained in the EVM keeper's available precompiles map. This function assumes that the Berlin precompiles cannot be disabled.
func (*Keeper) IsContract ¶
IsContract determines if the given address is a smart contract.
func (Keeper) IterateContracts ¶
func (k Keeper) IterateContracts(ctx sdk.Context, cb func(addr common.Address, codeHash common.Hash) (stop bool))
IterateContracts iterates over all smart contract addresses in the EVM keeper and performs a callback function.
The iteration is stopped when the callback function returns true.
func (*Keeper) NewEVM ¶
func (k *Keeper) NewEVM( ctx sdk.Context, msg core.Message, cfg *statedb.EVMConfig, tracer vm.EVMLogger, stateDB vm.StateDB, ) *vm.EVM
NewEVM generates a go-ethereum VM from the provided Message fields and the chain parameters (ChainConfig and module Params). It additionally sets the validator operator address as the coinbase address to make it available for the COINBASE opcode, even though there is no beneficiary of the coinbase transaction (since we're not mining).
NOTE: the RANDOM opcode is currently not supported since it requires RANDAO implementation. See https://github.com/evmos/ethermint/pull/1520#pullrequestreview-1200504697 for more information.
func (Keeper) Params ¶
func (k Keeper) Params(c context.Context, _ *types.QueryParamsRequest) (*types.QueryParamsResponse, error)
Params implements the Query/Params gRPC method
func (*Keeper) RefundGas ¶
func (k *Keeper) RefundGas(ctx sdk.Context, msg core.Message, leftoverGas uint64, denom string) error
RefundGas transfers the leftover gas to the sender of the message, caped to half of the total gas consumed in the transaction. Additionally, the function sets the total gas consumed to the value returned by the EVM execution, thus ignoring the previous intrinsic gas consumed during in the AnteHandler.
func (*Keeper) ResetGasMeterAndConsumeGas ¶
ResetGasMeterAndConsumeGas reset first the gas meter consumed value to zero and set it back to the new value 'gasUsed'
func (Keeper) ResetTransientGasUsed ¶
ResetTransientGasUsed reset gas used to prepare for execution of current cosmos tx, called in ante handler.
func (*Keeper) SetAccount ¶
SetAccount updates nonce/balance/codeHash together.
func (*Keeper) SetBalance ¶
SetBalance update account's balance, compare with current balance first, then decide to mint or burn.
func (Keeper) SetBlockBloomTransient ¶
SetBlockBloomTransient sets the given bloom bytes to the transient store. This value is reset on every block.
func (*Keeper) SetCode ¶
SetCode sets the given contract code bytes for the corresponding code hash bytes key in the code store.
func (*Keeper) SetCodeHash ¶
SetCodeHash sets the code hash for the given contract address.
func (Keeper) SetLogSizeTransient ¶
SetLogSizeTransient fetches the current EVM log index from the transient store, increases its value by one and then sets the new index back to the transient store.
func (Keeper) SetParams ¶
SetParams sets the EVM params each in their individual key for better get performance
func (Keeper) SetTransientGasUsed ¶
SetTransientGasUsed sets the gas used by current cosmos tx.
func (Keeper) SetTxIndexTransient ¶
SetTxIndexTransient set the index of processing transaction
func (Keeper) Storage ¶
func (k Keeper) Storage(c context.Context, req *types.QueryStorageRequest) (*types.QueryStorageResponse, error)
Storage implements the Query/Storage gRPC method
func (Keeper) TraceBlock ¶
func (k Keeper) TraceBlock(c context.Context, req *types.QueryTraceBlockRequest) (*types.QueryTraceBlockResponse, error)
TraceBlock configures a new tracer according to the provided configuration, and executes the given message in the provided environment for all the transactions in the queried block. The return value will be tracer dependent.
func (Keeper) TraceTx ¶
func (k Keeper) TraceTx(c context.Context, req *types.QueryTraceTxRequest) (*types.QueryTraceTxResponse, error)
TraceTx configures a new tracer according to the provided configuration, and executes the given message in the provided environment. The return value will be tracer dependent.
func (*Keeper) UpdateParams ¶
func (k *Keeper) UpdateParams(goCtx context.Context, req *types.MsgUpdateParams) (*types.MsgUpdateParamsResponse, error)
UpdateParams implements the gRPC MsgServer interface. When an UpdateParams proposal passes, it updates the module parameters. The update can only be performed if the requested authority is the Cosmos SDK governance module account.
func (Keeper) VMConfig ¶
func (k Keeper) VMConfig(ctx sdk.Context, _ core.Message, cfg *statedb.EVMConfig, tracer vm.EVMLogger) vm.Config
VMConfig creates an EVM configuration from the debug setting and the extra EIPs enabled on the module parameters. The config generated uses the default JumpTable from the EVM.
func (Keeper) ValidatorAccount ¶
func (k Keeper) ValidatorAccount(c context.Context, req *types.QueryValidatorAccountRequest) (*types.QueryValidatorAccountResponse, error)
ValidatorAccount implements the Query/Balance gRPC method
func (*Keeper) WithStaticPrecompiles ¶
func (k *Keeper) WithStaticPrecompiles(precompiles map[common.Address]vm.PrecompiledContract) *Keeper
WithStaticPrecompiles sets the available static precompiled contracts.