astra

package
v0.0.0-...-3da4c06 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Jun 16, 2022 License: LGPL-3.0 Imports: 51 Imported by: 0

Documentation

Index

Constants

View Source
const (
	// BloomBitsBlocks is the number of blocks a single bloom bit section vector
	// contains on the server side.
	BloomBitsBlocks uint64 = 4096
)

Variables

View Source
var DefaultMaxPrice = big.NewInt(5e11) // 500 gwei is the max suggested limit
View Source
var (
	// ErrFinalizedTransaction is returned if the transaction to be submitted is already on-chain
	ErrFinalizedTransaction = errors.New("transaction already finalized")
)

Functions

func NewBloomIndexer

func NewBloomIndexer(db ethdb.Database, size, confirms uint64) *core.ChainIndexer

NewBloomIndexer returns a chain indexer that generates bloom bits data for the canonical chain for fast logs filtering.

Types

type Astra

type Astra struct {
	// Channel for shutting down the service
	ShutdownChan  chan bool                      // Channel for shutting down the Astra
	BloomRequests chan chan *bloombits.Retrieval // Channel receiving bloom data retrieval requests
	BlockChain    *core.BlockChain
	BeaconChain   *core.BlockChain
	TxPool        *core.TxPool
	CxPool        *core.CxPool // CxPool is used to store the blockHashes of blocks containing cx receipts to be sent
	// DB interfaces
	BloomIndexer *core.ChainIndexer // Bloom indexer operating during block imports
	NodeAPI      NodeAPI
	// ChainID is used to identify which network we are using
	ChainID uint64
	// EthCompatibleChainID is used to identify the Ethereum compatible chain ID
	EthChainID uint64
	// RPCGasCap is the global gas cap for eth-call variants.
	RPCGasCap *big.Int `toml:",omitempty"`
	ShardID   uint32
	// contains filtered or unexported fields
}

Astra implements the Astra full node service.

func New

func New(
	nodeAPI NodeAPI, txPool *core.TxPool, cxPool *core.CxPool, shardID uint32,
) *Astra

New creates a new Astra object (including the initialisation of the common Astra object)

func (*Astra) BlockByNumber

func (astra *Astra) BlockByNumber(ctx context.Context, blockNum rpc.BlockNumber) (*types.Block, error)

BlockByNumber ...

func (*Astra) BlockByNumberOrHash

func (astra *Astra) BlockByNumberOrHash(ctx context.Context, blockNrOrHash rpc.BlockNumberOrHash) (*types.Block, error)

func (*Astra) BloomStatus

func (astra *Astra) BloomStatus() (uint64, uint64)

BloomStatus ... TODO: this is not implemented or verified yet for astra.

func (*Astra) ChainConfig

func (astra *Astra) ChainConfig() *params.ChainConfig

ChainConfig ...

func (*Astra) ChainDb

func (astra *Astra) ChainDb() ethdb.Database

ChainDb ..

func (*Astra) ComputeStateDB

func (astra *Astra) ComputeStateDB(block *types.Block, reexec uint64) (*state.DB, error)

ComputeStateDB retrieves the state database associated with a certain block. If no state is locally available for the given block, a number of blocks are attempted to be reexecuted to generate the desired state.

func (*Astra) ComputeTxEnv

func (astra *Astra) ComputeTxEnv(block *types.Block, txIndex int, reexec uint64) (core.Message, vm.Context, *state.DB, error)

ComputeTxEnv returns the execution environment of a certain transaction.

func (*Astra) ComputeTxEnvEachBlockWithoutApply

func (astra *Astra) ComputeTxEnvEachBlockWithoutApply(block *types.Block, reexec uint64, cb func(int, *types.Transaction, core.Message, vm.Context, *state.DB) bool) error

ComputeTxEnvEachBlockWithoutApply returns the execution environment of a certain transaction.

func (*Astra) CurrentBlock

func (astra *Astra) CurrentBlock() *types.Block

CurrentBlock ...

func (*Astra) EventMux

func (astra *Astra) EventMux() *event.TypeMux

EventMux ..

func (*Astra) GetAccountNonce

func (astra *Astra) GetAccountNonce(
	ctx context.Context, address common.Address, blockNum rpc.BlockNumber) (uint64, error)

GetAccountNonce returns the nonce value of the given address for the given block number

func (*Astra) GetAllValidatorAddresses

func (astra *Astra) GetAllValidatorAddresses() []common.Address

GetAllValidatorAddresses returns the up to date validator candidates for next epoch

func (*Astra) GetBalance

func (astra *Astra) GetBalance(ctx context.Context, address common.Address, blockNrOrHash rpc.BlockNumberOrHash) (*big.Int, error)

GetBalance returns balance of an given address.

func (*Astra) GetBlock

func (astra *Astra) GetBlock(ctx context.Context, hash common.Hash) (*types.Block, error)

GetBlock ...

func (*Astra) GetBlockSigners

func (astra *Astra) GetBlockSigners(
	ctx context.Context, blockNum rpc.BlockNumber,
) (shard.SlotList, *internal_bls.Mask, error)

GetBlockSigners ..

func (*Astra) GetCurrentBadBlocks

func (astra *Astra) GetCurrentBadBlocks() []core.BadBlock

GetCurrentBadBlocks ..

func (*Astra) GetCurrentStakingErrorSink

func (astra *Astra) GetCurrentStakingErrorSink() types.TransactionErrorReports

GetCurrentStakingErrorSink ..

func (*Astra) GetCurrentTransactionErrorSink

func (astra *Astra) GetCurrentTransactionErrorSink() types.TransactionErrorReports

GetCurrentTransactionErrorSink ..

func (*Astra) GetCurrentUtilityMetrics

func (astra *Astra) GetCurrentUtilityMetrics() (*network.UtilityMetric, error)

GetCurrentUtilityMetrics ..

func (*Astra) GetDelegationLockingPeriodInEpoch

func (astra *Astra) GetDelegationLockingPeriodInEpoch(epoch *big.Int) int

GetDelegationLockingPeriodInEpoch ...

func (*Astra) GetDelegationsByDelegator

func (astra *Astra) GetDelegationsByDelegator(
	delegator common.Address,
) ([]common.Address, []*staking.Delegation)

GetDelegationsByDelegator returns all delegation information of a delegator

func (*Astra) GetDelegationsByDelegatorByBlock

func (astra *Astra) GetDelegationsByDelegatorByBlock(
	delegator common.Address, block *types.Block,
) ([]common.Address, []*staking.Delegation)

GetDelegationsByDelegatorByBlock returns all delegation information of a delegator

func (*Astra) GetDelegationsByValidator

func (astra *Astra) GetDelegationsByValidator(validator common.Address) []staking.Delegation

GetDelegationsByValidator returns all delegation information of a validator

func (*Astra) GetDelegationsByValidatorAtBlock

func (astra *Astra) GetDelegationsByValidatorAtBlock(
	validator common.Address, block *types.Block,
) []staking.Delegation

GetDelegationsByValidatorAtBlock returns all delegation information of a validator at the given block

func (*Astra) GetDetailedBlockSignerInfo

func (astra *Astra) GetDetailedBlockSignerInfo(
	ctx context.Context, blk *types.Block,
) (*DetailedBlockSignerInfo, error)

GetDetailedBlockSignerInfo fetches the block signer information for any non-genesis block

func (*Astra) GetEVM

func (astra *Astra) GetEVM(ctx context.Context, msg core.Message, state *state.DB, header *block.Header) (*vm.EVM, error)

GetEVM returns a new EVM entity

func (*Astra) GetElectedValidatorAddresses

func (astra *Astra) GetElectedValidatorAddresses() []common.Address

GetElectedValidatorAddresses returns the address of elected validators for current epoch

func (astra *Astra) GetLastCrossLinks() ([]*types.CrossLink, error)

GetLastCrossLinks ..

func (*Astra) GetLatestChainHeaders

func (astra *Astra) GetLatestChainHeaders() *block.HeaderPair

GetLatestChainHeaders ..

func (*Astra) GetLeaderAddress

func (astra *Astra) GetLeaderAddress(coinbaseAddr common.Address, epoch *big.Int) string

GetLeaderAddress returns the one address of the leader, given the coinbaseAddr. Note that the coinbaseAddr is overloaded with the BLS pub key hash in staking era.

func (*Astra) GetLogs

func (astra *Astra) GetLogs(ctx context.Context, blockHash common.Hash, isEth bool) ([][]*types.Log, error)

GetLogs ...

func (*Astra) GetMedianRawStakeSnapshot

func (astra *Astra) GetMedianRawStakeSnapshot() (
	*committee.CompletedEPoSRound, error,
)

GetMedianRawStakeSnapshot ..

func (*Astra) GetNodeMetadata

func (astra *Astra) GetNodeMetadata() commonRPC.NodeMetadata

GetNodeMetadata ..

func (*Astra) GetPeerInfo

func (astra *Astra) GetPeerInfo() commonRPC.NodePeerInfo

GetPeerInfo returns the peer info to the node, including blocked peer, connected peer, number of peers

func (*Astra) GetPendingCXReceipts

func (astra *Astra) GetPendingCXReceipts() []*types.CXReceiptsProof

GetPendingCXReceipts ..

func (*Astra) GetPoolNonce

func (astra *Astra) GetPoolNonce(ctx context.Context, addr common.Address) (uint64, error)

GetPoolNonce ...

func (*Astra) GetPoolStats

func (astra *Astra) GetPoolStats() (pendingCount, queuedCount int)

GetPoolStats returns the number of pending and queued transactions

func (*Astra) GetPoolTransaction

func (astra *Astra) GetPoolTransaction(hash common.Hash) types.PoolTransaction

GetPoolTransaction ...

func (*Astra) GetPoolTransactions

func (astra *Astra) GetPoolTransactions() (types.PoolTransactions, error)

GetPoolTransactions returns pool transactions.

func (*Astra) GetPreStakingBlockRewards

func (astra *Astra) GetPreStakingBlockRewards(
	ctx context.Context, blk *types.Block,
) (PreStakingBlockRewards, error)

GetPreStakingBlockRewards for the given block number. Calculated rewards are done exactly like chain.AccumulateRewardsAndCountSigs.

func (*Astra) GetReceipts

func (astra *Astra) GetReceipts(ctx context.Context, hash common.Hash) (types.Receipts, error)

GetReceipts ...

func (*Astra) GetShardState

func (astra *Astra) GetShardState() (*shard.State, error)

GetShardState ...

func (*Astra) GetStakingTransactionsCount

func (astra *Astra) GetStakingTransactionsCount(address, txType string) (uint64, error)

GetStakingTransactionsCount returns the number of staking transactions of address.

func (*Astra) GetStakingTransactionsHistory

func (astra *Astra) GetStakingTransactionsHistory(address, txType, order string) ([]common.Hash, error)

GetStakingTransactionsHistory returns list of staking transactions hashes of address.

func (*Astra) GetSuperCommittees

func (astra *Astra) GetSuperCommittees() (*quorum.Transition, error)

GetSuperCommittees ..

func (*Astra) GetTotalStakingSnapshot

func (astra *Astra) GetTotalStakingSnapshot() *big.Int

GetTotalStakingSnapshot ..

func (*Astra) GetTransactionsCount

func (astra *Astra) GetTransactionsCount(address, txType string) (uint64, error)

GetTransactionsCount returns the number of regular transactions of address.

func (*Astra) GetTransactionsHistory

func (astra *Astra) GetTransactionsHistory(address, txType, order string) ([]common.Hash, error)

GetTransactionsHistory returns list of transactions hashes of address.

func (*Astra) GetUndelegationPayouts

func (astra *Astra) GetUndelegationPayouts(
	ctx context.Context, epoch *big.Int,
) (*UndelegationPayouts, error)

GetUndelegationPayouts returns the undelegation payouts for each delegator

Due to in-memory caching, it is possible to get undelegation payouts for a state / epoch that has been pruned but have it be lost (and unable to recompute) after the node restarts. This not a problem if a full (archival) DB is used.

func (*Astra) GetValidatorInformation

func (astra *Astra) GetValidatorInformation(
	addr common.Address, block *types.Block,
) (*staking.ValidatorRPCEnhanced, error)

GetValidatorInformation returns the information of validator

func (*Astra) GetValidatorSelfDelegation

func (astra *Astra) GetValidatorSelfDelegation(addr common.Address) *big.Int

GetValidatorSelfDelegation returns the amount of staking after applying all delegated stakes

func (*Astra) GetValidators

func (astra *Astra) GetValidators(epoch *big.Int) (*shard.Committee, error)

GetValidators returns validators for a particular epoch.

func (*Astra) HeaderByHash

func (astra *Astra) HeaderByHash(ctx context.Context, blockHash common.Hash) (*block.Header, error)

HeaderByHash ...

func (*Astra) HeaderByNumber

func (astra *Astra) HeaderByNumber(ctx context.Context, blockNum rpc.BlockNumber) (*block.Header, error)

HeaderByNumber ...

func (*Astra) IsCommitteeSelectionBlock

func (astra *Astra) IsCommitteeSelectionBlock(header *block.Header) bool

IsCommitteeSelectionBlock checks if the given block is the committee selection block

func (*Astra) IsLeader

func (astra *Astra) IsLeader() bool

IsLeader exposes if node is currently leader

func (*Astra) IsNoEarlyUnlockEpoch

func (astra *Astra) IsNoEarlyUnlockEpoch(epoch *big.Int) bool

IsNoEarlyUnlockEpoch ...

func (*Astra) IsPreStakingEpoch

func (astra *Astra) IsPreStakingEpoch(epoch *big.Int) bool

IsPreStakingEpoch ...

func (*Astra) IsStakingEpoch

func (astra *Astra) IsStakingEpoch(epoch *big.Int) bool

IsStakingEpoch ...

func (*Astra) ProtocolVersion

func (astra *Astra) ProtocolVersion() int

ProtocolVersion ...

func (*Astra) ResendCx

func (astra *Astra) ResendCx(ctx context.Context, txID common.Hash) (uint64, bool)

ResendCx retrieve blockHash from txID and add blockHash to CxPool for resending Note that cross shard txn is only for regular txns, not for staking txns, so the input txn hash is expected to be regular txn hash

func (*Astra) SendStakingTx

func (astra *Astra) SendStakingTx(ctx context.Context, signedStakingTx *staking.StakingTransaction) error

SendStakingTx adds a staking transaction

func (*Astra) SendTx

func (astra *Astra) SendTx(ctx context.Context, signedTx *types.Transaction) error

SendTx ...

func (*Astra) ServiceFilter

func (astra *Astra) ServiceFilter(ctx context.Context, session *bloombits.MatcherSession)

ServiceFilter ...

func (*Astra) SingleFlightForgetKey

func (astra *Astra) SingleFlightForgetKey(key string)

SingleFlightForgetKey ...

func (*Astra) SingleFlightRequest

func (astra *Astra) SingleFlightRequest(
	key string,
	fn func() (interface{}, error),
) (interface{}, error)

SingleFlightRequest ..

func (*Astra) StateAndHeaderByNumber

func (astra *Astra) StateAndHeaderByNumber(ctx context.Context, blockNum rpc.BlockNumber) (*state.DB, *block.Header, error)

StateAndHeaderByNumber ...

func (*Astra) StateAndHeaderByNumberOrHash

func (astra *Astra) StateAndHeaderByNumberOrHash(ctx context.Context, blockNrOrHash rpc.BlockNumberOrHash) (*state.DB, *block.Header, error)

func (*Astra) SubscribeChainEvent

func (astra *Astra) SubscribeChainEvent(ch chan<- core.ChainEvent) event.Subscription

SubscribeChainEvent subscribes chain event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SubscribeChainHeadEvent

func (astra *Astra) SubscribeChainHeadEvent(ch chan<- core.ChainHeadEvent) event.Subscription

SubscribeChainHeadEvent subcribes chain head event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SubscribeChainSideEvent

func (astra *Astra) SubscribeChainSideEvent(ch chan<- core.ChainSideEvent) event.Subscription

SubscribeChainSideEvent subcribes chain side event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SubscribeLogsEvent

func (astra *Astra) SubscribeLogsEvent(ch chan<- []*types.Log) event.Subscription

SubscribeLogsEvent subcribes log event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SubscribeNewTxsEvent

func (astra *Astra) SubscribeNewTxsEvent(ch chan<- core.NewTxsEvent) event.Subscription

SubscribeNewTxsEvent subscribes new tx event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SubscribeRemovedLogsEvent

func (astra *Astra) SubscribeRemovedLogsEvent(ch chan<- core.RemovedLogsEvent) event.Subscription

SubscribeRemovedLogsEvent subcribes removed logs event. TODO: this is not implemented or verified yet for astra.

func (*Astra) SuggestPrice

func (astra *Astra) SuggestPrice(ctx context.Context) (*big.Int, error)

func (*Astra) TraceBlock

func (astra *Astra) TraceBlock(ctx context.Context, block *types.Block, config *TraceConfig) ([]*TxTraceResult, error)

TraceBlock configures a new tracer according to the provided configuration, and executes all the transactions contained within. The return value will be one item per transaction, dependent on the requested tracer.

func (*Astra) TraceChain

func (astra *Astra) TraceChain(ctx context.Context, start, end *types.Block, config *TraceConfig) (*rpc.Subscription, error)

TraceChain configures a new tracer according to the provided configuration, and executes all the transactions contained within. The return value will be one item per transaction, dependent on the requested tracer.

func (*Astra) TraceTx

func (astra *Astra) TraceTx(ctx context.Context, message core.Message, vmctx vm.Context, statedb *state.DB, config *TraceConfig) (interface{}, 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. NOTE: Only support default StructLogger tracer

type BloomIndexer

type BloomIndexer struct {
	// contains filtered or unexported fields
}

BloomIndexer implements a core.ChainIndexer, building up a rotated bloom bits index for the Ethereum header bloom filters, permitting blazing fast filtering.

func (*BloomIndexer) Commit

func (b *BloomIndexer) Commit() error

Commit implements core.ChainIndexerBackend, finalizing the bloom section and writing it out into the database.

func (*BloomIndexer) Process

func (b *BloomIndexer) Process(ctx context.Context, header *block.Header) error

Process implements core.ChainIndexerBackend, adding a new header's bloom into the index.

func (*BloomIndexer) Reset

func (b *BloomIndexer) Reset(ctx context.Context, section uint64, lastSectionHead common.Hash) error

Reset implements core.ChainIndexerBackend, starting a new bloombits index section.

type DetailedBlockSignerInfo

type DetailedBlockSignerInfo struct {
	// Signers are all the signers for the block
	Signers shard.SlotList
	// Committee when the block was signed.
	Committee shard.SlotList
	BlockHash common.Hash
}

DetailedBlockSignerInfo contains all of the block singing information

type ExecutionResult

type ExecutionResult struct {
	Gas         uint64         `json:"gas"`
	Failed      bool           `json:"failed"`
	ReturnValue string         `json:"returnValue"`
	StructLogs  []StructLogRes `json:"structLogs"`
}

ExecutionResult groups all structured logs emitted by the EVM while replaying a transaction in debug mode as well as transaction execution status, the amount of gas used and the return value Taken from go-ethereum/internal/ethapi/api.go

type GasPriceConfig

type GasPriceConfig struct {
	Blocks     int
	Percentile int
	Default    *big.Int `toml:",omitempty"`
	MaxPrice   *big.Int `toml:",omitempty"`
}

type NodeAPI

type NodeAPI interface {
	AddPendingStakingTransaction(*staking.StakingTransaction) error
	AddPendingTransaction(newTx *types.Transaction) error
	Blockchain() *core.BlockChain
	Beaconchain() *core.BlockChain
	GetTransactionsHistory(address, txType, order string) ([]common.Hash, error)
	GetStakingTransactionsHistory(address, txType, order string) ([]common.Hash, error)
	GetTransactionsCount(address, txType string) (uint64, error)
	GetStakingTransactionsCount(address, txType string) (uint64, error)
	GetTraceResultByHash(hash common.Hash) (json.RawMessage, error)
	IsCurrentlyLeader() bool
	IsOutOfSync(shardID uint32) bool
	SyncStatus(shardID uint32) (bool, uint64, uint64)
	SyncPeers() map[string]int
	ReportStakingErrorSink() types.TransactionErrorReports
	ReportPlainErrorSink() types.TransactionErrorReports
	PendingCXReceipts() []*types.CXReceiptsProof
	GetNodeBootTime() int64
	PeerConnectivity() (int, int, int)
	ListPeer(topic string) []peer.ID
	ListTopic() []string
	ListBlockedPeer() []peer.ID

	GetConsensusInternal() commonRPC.ConsensusInternal
	IsBackup() bool
	SetNodeBackupMode(isBackup bool) bool

	// debug API
	GetConsensusMode() string
	GetConsensusPhase() string
	GetConsensusViewChangingID() uint64
	GetConsensusCurViewID() uint64
	GetConfig() commonRPC.Config
	ShutDown()
	GetLastSigningPower() (float64, error)
}

NodeAPI is the list of functions from node used to call rpc apis.

type Oracle

type Oracle struct {
	// contains filtered or unexported fields
}

Oracle recommends gas prices based on the content of recent blocks. Suitable for both light and full clients.

func NewOracle

func NewOracle(backend *Astra, params GasPriceConfig) *Oracle

NewOracle returns a new gasprice oracle which can recommend suitable gasprice for newly created transaction.

func (*Oracle) SuggestPrice

func (gpo *Oracle) SuggestPrice(ctx context.Context) (*big.Int, error)

SuggestPrice returns a gasprice so that newly created transaction can have a very high chance to be included in the following blocks.

type OracleBackend

type OracleBackend interface {
	HeaderByNumber(ctx context.Context, number rpc.BlockNumber) (*block.Header, error)
	BlockByNumber(ctx context.Context, number rpc.BlockNumber) (*types.Block, error)
	ChainConfig() *params.ChainConfig
}

OracleBackend includes all necessary background APIs for oracle.

type PreStakingBlockRewards

type PreStakingBlockRewards map[common.Address]*big.Int

PreStakingBlockRewards are the rewards for a block in the pre-staking era (epoch < staking epoch).

type StdTraceConfig

type StdTraceConfig struct {
	*vm.LogConfig
	Reexec *uint64
	TxHash common.Hash
}

StdTraceConfig holds extra parameters to standard-json trace functions.

type StructLogRes

type StructLogRes struct {
	Pc              uint64            `json:"pc"`
	Op              string            `json:"op"`
	CallerAddress   common.Address    `json:"callerAddress"`
	ContractAddress common.Address    `json:"contractAddress"`
	Gas             uint64            `json:"gas"`
	GasCost         uint64            `json:"gasCost"`
	Depth           int               `json:"depth"`
	Error           error             `json:"error,omitempty"`
	Stack           []string          `json:"stack,omitempty"`
	AfterStack      []string          `json:"afterStack,omitempty"`
	Memory          []string          `json:"memory,omitempty"`
	Storage         map[string]string `json:"storage,omitempty"`
	// contains filtered or unexported fields
}

StructLogRes stores a structured log emitted by the EVM while replaying a transaction in debug mode

func FormatLogs

func FormatLogs(logs []*vm.StructLog, conf *TraceConfig) []StructLogRes

FormatLogs formats EVM returned structured logs for json output

func (*StructLogRes) FormatAfterStack

func (r *StructLogRes) FormatAfterStack() []string

func (*StructLogRes) FormatMemory

func (r *StructLogRes) FormatMemory() []string

func (*StructLogRes) FormatStack

func (r *StructLogRes) FormatStack() []string

func (*StructLogRes) FormatStorage

func (r *StructLogRes) FormatStorage() map[string]string

func (*StructLogRes) GetOperatorEvent

func (r *StructLogRes) GetOperatorEvent(key string) string

type TraceConfig

type TraceConfig struct {
	*vm.LogConfig
	Tracer  *string
	Timeout *string
	Reexec  *uint64
}

TraceConfig holds extra parameters to trace functions.

type TxTraceResult

type TxTraceResult struct {
	Result interface{} `json:"result,omitempty"` // Trace results produced by the tracer
	Error  string      `json:"error,omitempty"`  // Trace failure produced by the tracer
}

TxTraceResult is the result of a single transaction trace.

type UndelegationPayouts

type UndelegationPayouts struct {
	Data map[common.Address]map[common.Address]*big.Int
}

UndelegationPayouts ..

func NewUndelegationPayouts

func NewUndelegationPayouts() *UndelegationPayouts

func (*UndelegationPayouts) SetPayoutByDelegatorAddrAndValidatorAddr

func (u *UndelegationPayouts) SetPayoutByDelegatorAddrAndValidatorAddr(
	delegator, validator common.Address, amount *big.Int,
)

Directories

Path Synopsis
Package tracers is a collection of JavaScript transaction tracers.
Package tracers is a collection of JavaScript transaction tracers.
internal/tracers
Package tracers contains the actual JavaScript tracer assets.
Package tracers contains the actual JavaScript tracer assets.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL