chain

package
v1.58.2 Latest Latest
Warning

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

Go to latest
Published: Aug 14, 2025 License: Apache-2.0 Imports: 97 Imported by: 249

Documentation

Index

Constants

View Source
const (
	SpotOrderbook       = "injective.exchange.v1beta1.EventOrderbookUpdate.spot_orderbooks"
	DerivativeOrderbook = "injective.exchange.v1beta1.EventOrderbookUpdate.derivative_orderbooks"
)
View Source
const (
	DefaultOfacListURL = "https://raw.githubusercontent.com/InjectiveLabs/injective-lists/refs/heads/master/json/wallets/ofacAndRestricted.json"
)

Variables

View Source
var (
	ErrTimedOut       = errors.New("tx timed out")
	ErrQueueClosed    = errors.New("queue is closed")
	ErrEnqueueTimeout = errors.New("enqueue timeout")
	ErrReadOnly       = errors.New("client is in read-only mode")
)
View Source
var (
	CreateSpotLimitOrderAuthz       = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CreateSpotLimitOrderAuthz{}))
	CreateSpotMarketOrderAuthz      = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CreateSpotMarketOrderAuthz{}))
	BatchCreateSpotLimitOrdersAuthz = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.BatchCreateSpotLimitOrdersAuthz{}))
	CancelSpotOrderAuthz            = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CancelSpotOrderAuthz{}))
	BatchCancelSpotOrdersAuthz      = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.BatchCancelSpotOrdersAuthz{}))

	CreateDerivativeLimitOrderAuthz       = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CreateDerivativeLimitOrderAuthz{}))
	CreateDerivativeMarketOrderAuthz      = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CreateDerivativeMarketOrderAuthz{}))
	BatchCreateDerivativeLimitOrdersAuthz = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.BatchCreateDerivativeLimitOrdersAuthz{}))
	CancelDerivativeOrderAuthz            = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.CancelDerivativeOrderAuthz{}))
	BatchCancelDerivativeOrdersAuthz      = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.BatchCancelDerivativeOrdersAuthz{}))

	BatchUpdateOrdersAuthz = ExchangeAuthz("/" + proto.MessageName(&exchangetypes.BatchUpdateOrdersAuthz{}))
)
View Source
var (
	CreateSpotLimitOrderAuthzV2       = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CreateSpotLimitOrderAuthz{}))
	CreateSpotMarketOrderAuthzV2      = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CreateSpotMarketOrderAuthz{}))
	BatchCreateSpotLimitOrdersAuthzV2 = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.BatchCreateSpotLimitOrdersAuthz{}))
	CancelSpotOrderAuthzV2            = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CancelSpotOrderAuthz{}))
	BatchCancelSpotOrdersAuthzV2      = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.BatchCancelSpotOrdersAuthz{}))

	CreateDerivativeLimitOrderAuthzV2       = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CreateDerivativeLimitOrderAuthz{}))
	CreateDerivativeMarketOrderAuthzV2      = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CreateDerivativeMarketOrderAuthz{}))
	BatchCreateDerivativeLimitOrdersAuthzV2 = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.BatchCreateDerivativeLimitOrdersAuthz{}))
	CancelDerivativeOrderAuthzV2            = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.CancelDerivativeOrderAuthz{}))
	BatchCancelDerivativeOrdersAuthzV2      = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.BatchCancelDerivativeOrdersAuthz{}))

	BatchUpdateOrdersAuthzV2 = ExchangeAuthz("/" + proto.MessageName(&exchangev2types.BatchUpdateOrdersAuthz{}))
)
View Source
var (
	OfacListPath     = "injective_data"
	OfacListFilename = "ofac.json"
)
View Source
var AuctionSubaccountID = common.HexToHash("0x1111111111111111111111111111111111111111111111111111111111111111")

Functions

func DownloadOfacList added in v1.52.0

func DownloadOfacList() error

func GetOfacListPath added in v1.53.0

func GetOfacListPath() string

func InitCosmosKeyring

func InitCosmosKeyring(
	cosmosKeyringDir string,
	cosmosKeyringAppName string,
	cosmosKeyringBackend string,
	cosmosKeyFrom string,
	cosmosKeyPassphrase string,
	cosmosPrivKey string,
	cosmosUseLedger bool,
) (cosmtypes.AccAddress, keyring.Keyring, error)

func KeyringForPrivKey

func KeyringForPrivKey(name string, privKey cryptotypes.PrivKey) (keyring.Keyring, error)

KeyringForPrivKey creates a temporary in-mem keyring for a PrivKey. Allows to init Context when the key has been provided in plaintext and parsed.

func NewClientContext

func NewClientContext(
	chainId, fromSpec string, kb keyring.Keyring,
) (client.Context, error)

NewClientContext creates a new Cosmos Client context, where chainID corresponds to Cosmos chain ID, fromSpec is either name of the key, or bech32-address of the Cosmos account. Keyring is required to contain the specified key.

func NewInterfaceRegistry added in v1.51.0

func NewInterfaceRegistry() types.InterfaceRegistry

NewInterfaceRegistry returns a new InterfaceRegistry

func NewTxConfig

func NewTxConfig(signModes []signingtypes.SignMode) client.TxConfig

NewTxConfig initializes new Cosmos TxConfig with certain signModes enabled.

func NewTxFactory

func NewTxFactory(clientCtx client.Context) tx.Factory

func PrepareFactory added in v1.51.0

func PrepareFactory(clientCtx sdkclient.Context, txf tx.Factory) (tx.Factory, error)

PrepareFactory ensures the account defined by ctx.GetFromAddress() exists and if the account number and/or the account sequence number are zero (not set), they will be queried for and set on the provided Factory. A new Factory with the updated fields will be returned.

Types

type ChainClient

type ChainClient interface {
	CanSignTransactions() bool
	FromAddress() sdk.AccAddress
	QueryClient() *grpc.ClientConn
	ClientContext() sdkclient.Context
	// return account number and sequence without increasing sequence
	GetAccNonce() (accNum uint64, accSeq uint64)

	SimulateMsg(clientCtx sdkclient.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)
	AsyncBroadcastMsg(msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	SyncBroadcastMsg(msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	BroadcastMsg(broadcastMode txtypes.BroadcastMode, msgs ...sdk.Msg) (*txtypes.BroadcastTxRequest, *txtypes.BroadcastTxResponse, error)

	// Enhanced broadcast methods with context support
	SimulateMsgWithContext(ctx context.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)
	AsyncBroadcastMsgWithContext(ctx context.Context, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	SyncBroadcastMsgWithContext(ctx context.Context, pollInterval *time.Duration, maxRetries uint32, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	BroadcastMsgWithContext(ctx context.Context, broadcastMode txtypes.BroadcastMode, msgs ...sdk.Msg) (*txtypes.BroadcastTxRequest, *txtypes.BroadcastTxResponse, error)

	// Build signed tx with given accNum and accSeq, useful for offline siging
	// If simulate is set to false, initialGas will be used
	BuildSignedTx(clientCtx sdkclient.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msg ...sdk.Msg) ([]byte, error)
	SyncBroadcastSignedTx(tyBytes []byte) (*txtypes.BroadcastTxResponse, error)
	AsyncBroadcastSignedTx(txBytes []byte) (*txtypes.BroadcastTxResponse, error)
	BroadcastSignedTx(txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)

	// Enhanced signed tx broadcast methods with context support
	BuildSignedTxWithContext(ctx context.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msgs ...sdk.Msg) ([]byte, error)
	SyncBroadcastSignedTxWithContext(ctx context.Context, txBytes []byte, pollInterval *time.Duration, maxRetries uint32) (*txtypes.BroadcastTxResponse, error)
	AsyncBroadcastSignedTxWithContext(ctx context.Context, txBytes []byte) (*txtypes.BroadcastTxResponse, error)
	BroadcastSignedTxWithContext(ctx context.Context, txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)
	QueueBroadcastMsg(msgs ...sdk.Msg) error

	// Bank Module
	GetBankBalances(ctx context.Context, address string) (*banktypes.QueryAllBalancesResponse, error)
	GetBankBalance(ctx context.Context, address string, denom string) (*banktypes.QueryBalanceResponse, error)
	GetBankSpendableBalances(ctx context.Context, address string, pagination *query.PageRequest) (*banktypes.QuerySpendableBalancesResponse, error)
	GetBankSpendableBalancesByDenom(ctx context.Context, address string, denom string) (*banktypes.QuerySpendableBalanceByDenomResponse, error)
	GetBankTotalSupply(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryTotalSupplyResponse, error)
	GetBankSupplyOf(ctx context.Context, denom string) (*banktypes.QuerySupplyOfResponse, error)
	GetDenomMetadata(ctx context.Context, denom string) (*banktypes.QueryDenomMetadataResponse, error)
	GetDenomsMetadata(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryDenomsMetadataResponse, error)
	GetDenomOwners(ctx context.Context, denom string, pagination *query.PageRequest) (*banktypes.QueryDenomOwnersResponse, error)
	GetBankSendEnabled(ctx context.Context, denoms []string, pagination *query.PageRequest) (*banktypes.QuerySendEnabledResponse, error)

	GetAuthzGrants(ctx context.Context, req authztypes.QueryGrantsRequest) (*authztypes.QueryGrantsResponse, error)
	GetAccount(ctx context.Context, address string) (*authtypes.QueryAccountResponse, error)

	BuildGenericAuthz(granter string, grantee string, msgtype string, expireIn time.Time) *authztypes.MsgGrant
	BuildExchangeAuthz(granter string, grantee string, authzType ExchangeAuthz, subaccountId string, markets []string, expireIn time.Time) *authztypes.MsgGrant
	BuildExchangeBatchUpdateOrdersAuthz(
		granter string,
		grantee string,
		subaccountId string,
		spotMarkets []string,
		derivativeMarkets []string,
		expireIn time.Time,
	) *authztypes.MsgGrant

	DefaultSubaccount(acc sdk.AccAddress) ethcommon.Hash
	Subaccount(account sdk.AccAddress, index int) ethcommon.Hash

	GetSubAccountNonce(ctx context.Context, subaccountId ethcommon.Hash) (*exchangetypes.QuerySubaccountTradeNonceResponse, error)
	GetFeeDiscountInfo(ctx context.Context, account string) (*exchangetypes.QueryFeeDiscountAccountInfoResponse, error)

	UpdateSubaccountNonceFromChain() error
	SynchronizeSubaccountNonce(subaccountId ethcommon.Hash) error
	ComputeOrderHashes(spotOrders []exchangetypes.SpotOrder, derivativeOrders []exchangetypes.DerivativeOrder, subaccountId ethcommon.Hash) (OrderHashes, error)

	CreateSpotOrder(defaultSubaccountID ethcommon.Hash, d *SpotOrderData, marketsAssistant MarketsAssistant) *exchangetypes.SpotOrder
	CreateDerivativeOrder(defaultSubaccountID ethcommon.Hash, d *DerivativeOrderData, marketAssistant MarketsAssistant) *exchangetypes.DerivativeOrder
	OrderCancel(defaultSubaccountID ethcommon.Hash, d *OrderCancelData) *exchangetypes.OrderData

	GetGasFee() (string, error)

	StreamEventOrderFail(sender string, failEventCh chan map[string]uint)
	StreamEventOrderFailWithWebsocket(sender string, websocket *rpchttp.HTTP, failEventCh chan map[string]uint)
	StreamOrderbookUpdateEvents(orderbookType OrderbookType, marketIDs []string, orderbookCh chan exchangetypes.Orderbook)
	StreamOrderbookUpdateEventsWithWebsocket(orderbookType OrderbookType, marketIDs []string, websocket *rpchttp.HTTP, orderbookCh chan exchangetypes.Orderbook)

	ChainStream(ctx context.Context, req chainstreamtypes.StreamRequest) (chainstreamtypes.Stream_StreamClient, error)

	// get tx from chain node
	GetTx(ctx context.Context, txHash string) (*txtypes.GetTxResponse, error)

	// wasm module
	FetchContractInfo(ctx context.Context, address string) (*wasmtypes.QueryContractInfoResponse, error)
	FetchContractHistory(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryContractHistoryResponse, error)
	FetchContractsByCode(ctx context.Context, codeId uint64, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCodeResponse, error)
	FetchAllContractsState(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryAllContractStateResponse, error)
	RawContractState(
		ctx context.Context,
		contractAddress string,
		queryData []byte,
	) (*wasmtypes.QueryRawContractStateResponse, error)
	SmartContractState(
		ctx context.Context,
		contractAddress string,
		queryData []byte,
	) (*wasmtypes.QuerySmartContractStateResponse, error)
	FetchCode(ctx context.Context, codeId uint64) (*wasmtypes.QueryCodeResponse, error)
	FetchCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryCodesResponse, error)
	FetchPinnedCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryPinnedCodesResponse, error)
	FetchContractsByCreator(ctx context.Context, creator string, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCreatorResponse, error)

	// tokenfactory module
	FetchDenomAuthorityMetadata(ctx context.Context, creator string, subDenom string) (*tokenfactorytypes.QueryDenomAuthorityMetadataResponse, error)
	FetchDenomsFromCreator(ctx context.Context, creator string) (*tokenfactorytypes.QueryDenomsFromCreatorResponse, error)
	FetchTokenfactoryModuleState(ctx context.Context) (*tokenfactorytypes.QueryModuleStateResponse, error)

	// distribution module
	FetchValidatorDistributionInfo(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorDistributionInfoResponse, error)
	FetchValidatorOutstandingRewards(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorOutstandingRewardsResponse, error)
	FetchValidatorCommission(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorCommissionResponse, error)
	FetchValidatorSlashes(ctx context.Context, validatorAddress string, startingHeight uint64, endingHeight uint64, pagination *query.PageRequest) (*distributiontypes.QueryValidatorSlashesResponse, error)
	FetchDelegationRewards(ctx context.Context, delegatorAddress string, validatorAddress string) (*distributiontypes.QueryDelegationRewardsResponse, error)
	FetchDelegationTotalRewards(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegationTotalRewardsResponse, error)
	FetchDelegatorValidators(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorValidatorsResponse, error)
	FetchDelegatorWithdrawAddress(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorWithdrawAddressResponse, error)
	FetchCommunityPool(ctx context.Context) (*distributiontypes.QueryCommunityPoolResponse, error)

	// chain exchange module
	FetchSubaccountDeposits(ctx context.Context, subaccountID string) (*exchangetypes.QuerySubaccountDepositsResponse, error)
	FetchSubaccountDeposit(ctx context.Context, subaccountId string, denom string) (*exchangetypes.QuerySubaccountDepositResponse, error)
	FetchExchangeBalances(ctx context.Context) (*exchangetypes.QueryExchangeBalancesResponse, error)
	FetchAggregateVolume(ctx context.Context, account string) (*exchangetypes.QueryAggregateVolumeResponse, error)
	FetchAggregateVolumes(ctx context.Context, accounts []string, marketIDs []string) (*exchangetypes.QueryAggregateVolumesResponse, error)
	FetchAggregateMarketVolume(ctx context.Context, marketId string) (*exchangetypes.QueryAggregateMarketVolumeResponse, error)
	FetchAggregateMarketVolumes(ctx context.Context, marketIDs []string) (*exchangetypes.QueryAggregateMarketVolumesResponse, error)
	FetchDenomDecimal(ctx context.Context, denom string) (*exchangetypes.QueryDenomDecimalResponse, error)
	FetchDenomDecimals(ctx context.Context, denoms []string) (*exchangetypes.QueryDenomDecimalsResponse, error)
	FetchChainSpotMarkets(ctx context.Context, status string, marketIDs []string) (*exchangetypes.QuerySpotMarketsResponse, error)
	FetchChainSpotMarket(ctx context.Context, marketId string) (*exchangetypes.QuerySpotMarketResponse, error)
	FetchChainFullSpotMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangetypes.QueryFullSpotMarketsResponse, error)
	FetchChainFullSpotMarket(ctx context.Context, marketId string, withMidPriceAndTob bool) (*exchangetypes.QueryFullSpotMarketResponse, error)
	FetchChainSpotOrderbook(ctx context.Context, marketId string, limit uint64, orderSide exchangetypes.OrderSide, limitCumulativeNotional sdkmath.LegacyDec, limitCumulativeQuantity sdkmath.LegacyDec) (*exchangetypes.QuerySpotOrderbookResponse, error)
	FetchChainTraderSpotOrders(ctx context.Context, marketId string, subaccountId string) (*exchangetypes.QueryTraderSpotOrdersResponse, error)
	FetchChainAccountAddressSpotOrders(ctx context.Context, marketId string, address string) (*exchangetypes.QueryAccountAddressSpotOrdersResponse, error)
	FetchChainSpotOrdersByHashes(ctx context.Context, marketId string, subaccountId string, orderHashes []string) (*exchangetypes.QuerySpotOrdersByHashesResponse, error)
	FetchChainSubaccountOrders(ctx context.Context, subaccountId string, marketId string) (*exchangetypes.QuerySubaccountOrdersResponse, error)
	FetchChainTraderSpotTransientOrders(ctx context.Context, marketId string, subaccountId string) (*exchangetypes.QueryTraderSpotOrdersResponse, error)
	FetchSpotMidPriceAndTOB(ctx context.Context, marketId string) (*exchangetypes.QuerySpotMidPriceAndTOBResponse, error)
	FetchDerivativeMidPriceAndTOB(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMidPriceAndTOBResponse, error)
	FetchChainDerivativeOrderbook(ctx context.Context, marketId string, limit uint64, limitCumulativeNotional sdkmath.LegacyDec) (*exchangetypes.QueryDerivativeOrderbookResponse, error)
	FetchChainTraderDerivativeOrders(ctx context.Context, marketId string, subaccountId string) (*exchangetypes.QueryTraderDerivativeOrdersResponse, error)
	FetchChainAccountAddressDerivativeOrders(ctx context.Context, marketId string, address string) (*exchangetypes.QueryAccountAddressDerivativeOrdersResponse, error)
	FetchChainDerivativeOrdersByHashes(ctx context.Context, marketId string, subaccountId string, orderHashes []string) (*exchangetypes.QueryDerivativeOrdersByHashesResponse, error)
	FetchChainTraderDerivativeTransientOrders(ctx context.Context, marketId string, subaccountId string) (*exchangetypes.QueryTraderDerivativeOrdersResponse, error)
	FetchChainDerivativeMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangetypes.QueryDerivativeMarketsResponse, error)
	FetchChainDerivativeMarket(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMarketResponse, error)
	FetchDerivativeMarketAddress(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMarketAddressResponse, error)
	FetchSubaccountTradeNonce(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountTradeNonceResponse, error)
	FetchChainPositions(ctx context.Context) (*exchangetypes.QueryPositionsResponse, error)
	FetchChainSubaccountPositions(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountPositionsResponse, error)
	FetchChainSubaccountPositionInMarket(ctx context.Context, subaccountId string, marketId string) (*exchangetypes.QuerySubaccountPositionInMarketResponse, error)
	FetchChainSubaccountEffectivePositionInMarket(ctx context.Context, subaccountId string, marketId string) (*exchangetypes.QuerySubaccountEffectivePositionInMarketResponse, error)
	FetchChainPerpetualMarketInfo(ctx context.Context, marketId string) (*exchangetypes.QueryPerpetualMarketInfoResponse, error)
	FetchChainExpiryFuturesMarketInfo(ctx context.Context, marketId string) (*exchangetypes.QueryExpiryFuturesMarketInfoResponse, error)
	FetchChainPerpetualMarketFunding(ctx context.Context, marketId string) (*exchangetypes.QueryPerpetualMarketFundingResponse, error)
	FetchSubaccountOrderMetadata(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountOrderMetadataResponse, error)
	FetchTradeRewardPoints(ctx context.Context, accounts []string) (*exchangetypes.QueryTradeRewardPointsResponse, error)
	FetchPendingTradeRewardPoints(ctx context.Context, accounts []string) (*exchangetypes.QueryTradeRewardPointsResponse, error)
	FetchFeeDiscountAccountInfo(ctx context.Context, account string) (*exchangetypes.QueryFeeDiscountAccountInfoResponse, error)
	FetchTradeRewardCampaign(ctx context.Context) (*exchangetypes.QueryTradeRewardCampaignResponse, error)
	FetchFeeDiscountSchedule(ctx context.Context) (*exchangetypes.QueryFeeDiscountScheduleResponse, error)
	FetchBalanceMismatches(ctx context.Context, dustFactor int64) (*exchangetypes.QueryBalanceMismatchesResponse, error)
	FetchBalanceWithBalanceHolds(ctx context.Context) (*exchangetypes.QueryBalanceWithBalanceHoldsResponse, error)
	FetchFeeDiscountTierStatistics(ctx context.Context) (*exchangetypes.QueryFeeDiscountTierStatisticsResponse, error)
	FetchMitoVaultInfos(ctx context.Context) (*exchangetypes.MitoVaultInfosResponse, error)
	FetchMarketIDFromVault(ctx context.Context, vaultAddress string) (*exchangetypes.QueryMarketIDFromVaultResponse, error)
	FetchHistoricalTradeRecords(ctx context.Context, marketId string) (*exchangetypes.QueryHistoricalTradeRecordsResponse, error)
	FetchIsOptedOutOfRewards(ctx context.Context, account string) (*exchangetypes.QueryIsOptedOutOfRewardsResponse, error)
	FetchOptedOutOfRewardsAccounts(ctx context.Context) (*exchangetypes.QueryOptedOutOfRewardsAccountsResponse, error)
	FetchMarketVolatility(ctx context.Context, marketId string, tradeHistoryOptions *exchangetypes.TradeHistoryOptions) (*exchangetypes.QueryMarketVolatilityResponse, error)
	FetchChainBinaryOptionsMarkets(ctx context.Context, status string) (*exchangetypes.QueryBinaryMarketsResponse, error)
	FetchTraderDerivativeConditionalOrders(ctx context.Context, subaccountId string, marketId string) (*exchangetypes.QueryTraderDerivativeConditionalOrdersResponse, error)
	FetchMarketAtomicExecutionFeeMultiplier(ctx context.Context, marketId string) (*exchangetypes.QueryMarketAtomicExecutionFeeMultiplierResponse, error)
	FetchL3DerivativeOrderBook(ctx context.Context, marketId string) (*exchangetypes.QueryFullDerivativeOrderbookResponse, error)
	FetchL3SpotOrderBook(ctx context.Context, marketId string) (*exchangetypes.QueryFullSpotOrderbookResponse, error)
	FetchMarketBalance(ctx context.Context, marketId string) (*exchangetypes.QueryMarketBalanceResponse, error)
	FetchMarketBalances(ctx context.Context) (*exchangetypes.QueryMarketBalancesResponse, error)
	FetchDenomMinNotional(ctx context.Context, denom string) (*exchangetypes.QueryDenomMinNotionalResponse, error)
	FetchDenomMinNotionals(ctx context.Context) (*exchangetypes.QueryDenomMinNotionalsResponse, error)

	// Tendermint module
	FetchNodeInfo(ctx context.Context) (*cmtservice.GetNodeInfoResponse, error)
	FetchSyncing(ctx context.Context) (*cmtservice.GetSyncingResponse, error)
	FetchLatestBlock(ctx context.Context) (*cmtservice.GetLatestBlockResponse, error)
	FetchBlockByHeight(ctx context.Context, height int64) (*cmtservice.GetBlockByHeightResponse, error)
	FetchLatestValidatorSet(ctx context.Context) (*cmtservice.GetLatestValidatorSetResponse, error)
	FetchValidatorSetByHeight(ctx context.Context, height int64, pagination *query.PageRequest) (*cmtservice.GetValidatorSetByHeightResponse, error)
	ABCIQuery(ctx context.Context, path string, data []byte, height int64, prove bool) (*cmtservice.ABCIQueryResponse, error)

	// IBC Transfer module
	FetchDenomTrace(ctx context.Context, hash string) (*ibctransfertypes.QueryDenomTraceResponse, error)
	FetchDenomTraces(ctx context.Context, pagination *query.PageRequest) (*ibctransfertypes.QueryDenomTracesResponse, error)
	FetchDenomHash(ctx context.Context, trace string) (*ibctransfertypes.QueryDenomHashResponse, error)
	FetchEscrowAddress(ctx context.Context, portId string, channelId string) (*ibctransfertypes.QueryEscrowAddressResponse, error)
	FetchTotalEscrowForDenom(ctx context.Context, denom string) (*ibctransfertypes.QueryTotalEscrowForDenomResponse, error)

	// IBC Core Channel module
	FetchIBCChannel(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryChannelResponse, error)
	FetchIBCChannels(ctx context.Context, pagination *query.PageRequest) (*ibcchanneltypes.QueryChannelsResponse, error)
	FetchIBCConnectionChannels(ctx context.Context, connection string, pagination *query.PageRequest) (*ibcchanneltypes.QueryConnectionChannelsResponse, error)
	FetchIBCChannelClientState(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryChannelClientStateResponse, error)
	FetchIBCChannelConsensusState(ctx context.Context, portId string, channelId string, revisionNumber uint64, revisionHeight uint64) (*ibcchanneltypes.QueryChannelConsensusStateResponse, error)
	FetchIBCPacketCommitment(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketCommitmentResponse, error)
	FetchIBCPacketCommitments(ctx context.Context, portId string, channelId string, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketCommitmentsResponse, error)
	FetchIBCPacketReceipt(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketReceiptResponse, error)
	FetchIBCPacketAcknowledgement(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketAcknowledgementResponse, error)
	FetchIBCPacketAcknowledgements(ctx context.Context, portId string, channelId string, packetCommitmentSequences []uint64, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketAcknowledgementsResponse, error)
	FetchIBCUnreceivedPackets(ctx context.Context, portId string, channelId string, packetCommitmentSequences []uint64) (*ibcchanneltypes.QueryUnreceivedPacketsResponse, error)
	FetchIBCUnreceivedAcks(ctx context.Context, portId string, channelId string, packetAckSequences []uint64) (*ibcchanneltypes.QueryUnreceivedAcksResponse, error)
	FetchIBCNextSequenceReceive(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryNextSequenceReceiveResponse, error)

	// IBC Core Chain module
	FetchIBCClientState(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStateResponse, error)
	FetchIBCClientStates(ctx context.Context, pagination *query.PageRequest) (*ibcclienttypes.QueryClientStatesResponse, error)
	FetchIBCConsensusState(ctx context.Context, clientId string, revisionNumber uint64, revisionHeight uint64, latestHeight bool) (*ibcclienttypes.QueryConsensusStateResponse, error)
	FetchIBCConsensusStates(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStatesResponse, error)
	FetchIBCConsensusStateHeights(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStateHeightsResponse, error)
	FetchIBCClientStatus(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStatusResponse, error)
	FetchIBCClientParams(ctx context.Context) (*ibcclienttypes.QueryClientParamsResponse, error)
	FetchIBCUpgradedClientState(ctx context.Context) (*ibcclienttypes.QueryUpgradedClientStateResponse, error)
	FetchIBCUpgradedConsensusState(ctx context.Context) (*ibcclienttypes.QueryUpgradedConsensusStateResponse, error)

	// IBC Core Connection module
	FetchIBCConnection(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionResponse, error)
	FetchIBCConnections(ctx context.Context, pagination *query.PageRequest) (*ibcconnectiontypes.QueryConnectionsResponse, error)
	FetchIBCClientConnections(ctx context.Context, clientId string) (*ibcconnectiontypes.QueryClientConnectionsResponse, error)
	FetchIBCConnectionClientState(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionClientStateResponse, error)
	FetchIBCConnectionConsensusState(ctx context.Context, connectionId string, revisionNumber uint64, revisionHeight uint64) (*ibcconnectiontypes.QueryConnectionConsensusStateResponse, error)
	FetchIBCConnectionParams(ctx context.Context) (*ibcconnectiontypes.QueryConnectionParamsResponse, error)

	// Permissions module
	FetchPermissionsNamespaceDenoms(ctx context.Context) (*permissionstypes.QueryNamespaceDenomsResponse, error)
	FetchPermissionsNamespaces(ctx context.Context) (*permissionstypes.QueryNamespacesResponse, error)
	FetchPermissionsNamespace(ctx context.Context, denom string) (*permissionstypes.QueryNamespaceResponse, error)
	FetchPermissionsRolesByActor(ctx context.Context, denom, actor string) (*permissionstypes.QueryRolesByActorResponse, error)
	FetchPermissionsActorsByRole(ctx context.Context, denom, role string) (*permissionstypes.QueryActorsByRoleResponse, error)
	FetchPermissionsRoleManagers(ctx context.Context, denom string) (*permissionstypes.QueryRoleManagersResponse, error)
	FetchPermissionsRoleManager(ctx context.Context, denom, manager string) (*permissionstypes.QueryRoleManagerResponse, error)
	FetchPermissionsPolicyStatuses(ctx context.Context, denom string) (*permissionstypes.QueryPolicyStatusesResponse, error)
	FetchPermissionsPolicyManagerCapabilities(ctx context.Context, denom string) (*permissionstypes.QueryPolicyManagerCapabilitiesResponse, error)
	FetchPermissionsVouchers(ctx context.Context, denom string) (*permissionstypes.QueryVouchersResponse, error)
	FetchPermissionsVoucher(ctx context.Context, denom, address string) (*permissionstypes.QueryVoucherResponse, error)
	FetchPermissionsModuleState(ctx context.Context) (*permissionstypes.QueryModuleStateResponse, error)

	// TxFees module
	FetchTxFeesParams(ctx context.Context) (*txfeestypes.QueryParamsResponse, error)
	FetchEipBaseFee(ctx context.Context) (*txfeestypes.QueryEipBaseFeeResponse, error)

	CurrentChainGasPrice() int64
	CurrentChainGasPriceWithContext(ctx context.Context) int64
	SetGasPrice(gasPrice int64)

	GetNetwork() common.Network
	Close()
}

func NewChainClient

func NewChainClient(
	ctx sdkclient.Context,
	network common.Network,
	options ...common.ClientOption,
) (ChainClient, error)

type ChainClientV2 added in v1.58.0

type ChainClientV2 interface {
	CanSignTransactions() bool
	FromAddress() sdk.AccAddress
	QueryClient() *grpc.ClientConn
	ClientContext() sdkclient.Context
	// return account number and sequence without increasing sequence
	GetAccNonce() (accNum uint64, accSeq uint64)

	SimulateMsg(ctx context.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)
	AsyncBroadcastMsg(ctx context.Context, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	SyncBroadcastMsg(ctx context.Context, pollInterval *time.Duration, maxRetries uint32, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)
	BroadcastMsg(ctx context.Context, broadcastMode txtypes.BroadcastMode, msgs ...sdk.Msg) (*txtypes.BroadcastTxRequest, *txtypes.BroadcastTxResponse, error)

	// Build signed tx with given accNum and accSeq, useful for offline siging
	// If simulate is set to false, initialGas will be used
	BuildSignedTx(ctx context.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msg ...sdk.Msg) ([]byte, error)
	SyncBroadcastSignedTx(ctx context.Context, txBytes []byte, pollInterval *time.Duration, maxRetries uint32) (*txtypes.BroadcastTxResponse, error)
	AsyncBroadcastSignedTx(ctx context.Context, txBytes []byte) (*txtypes.BroadcastTxResponse, error)
	BroadcastSignedTx(ctx context.Context, txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)

	// Bank Module
	GetBankBalances(ctx context.Context, address string) (*banktypes.QueryAllBalancesResponse, error)
	GetBankBalance(ctx context.Context, address string, denom string) (*banktypes.QueryBalanceResponse, error)
	GetBankSpendableBalances(ctx context.Context, address string, pagination *query.PageRequest) (*banktypes.QuerySpendableBalancesResponse, error)
	GetBankSpendableBalancesByDenom(ctx context.Context, address string, denom string) (*banktypes.QuerySpendableBalanceByDenomResponse, error)
	GetBankTotalSupply(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryTotalSupplyResponse, error)
	GetBankSupplyOf(ctx context.Context, denom string) (*banktypes.QuerySupplyOfResponse, error)
	GetDenomMetadata(ctx context.Context, denom string) (*banktypes.QueryDenomMetadataResponse, error)
	GetDenomsMetadata(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryDenomsMetadataResponse, error)
	GetDenomOwners(ctx context.Context, denom string, pagination *query.PageRequest) (*banktypes.QueryDenomOwnersResponse, error)
	GetBankSendEnabled(ctx context.Context, denoms []string, pagination *query.PageRequest) (*banktypes.QuerySendEnabledResponse, error)

	GetAuthzGrants(ctx context.Context, req authztypes.QueryGrantsRequest) (*authztypes.QueryGrantsResponse, error)
	GetAccount(ctx context.Context, address string) (*authtypes.QueryAccountResponse, error)

	BuildGenericAuthz(granter string, grantee string, msgtype string, expireIn time.Time) *authztypes.MsgGrant
	BuildExchangeAuthz(granter string, grantee string, authzType ExchangeAuthz, subaccountId string, markets []string, expireIn time.Time) *authztypes.MsgGrant
	BuildExchangeBatchUpdateOrdersAuthz(
		granter string,
		grantee string,
		subaccountId string,
		spotMarkets []string,
		derivativeMarkets []string,
		expireIn time.Time,
	) *authztypes.MsgGrant

	DefaultSubaccount(acc sdk.AccAddress) ethcommon.Hash
	Subaccount(account sdk.AccAddress, index int) ethcommon.Hash

	UpdateSubaccountNonceFromChain() error
	SynchronizeSubaccountNonce(subaccountId ethcommon.Hash) error
	ComputeOrderHashes(spotOrders []exchangev2types.SpotOrder, derivativeOrders []exchangev2types.DerivativeOrder, subaccountId ethcommon.Hash) (OrderHashes, error)

	CreateSpotOrderV2(defaultSubaccountID ethcommon.Hash, d *SpotOrderData) *exchangev2types.SpotOrder
	CreateDerivativeOrderV2(defaultSubaccountID ethcommon.Hash, d *DerivativeOrderData) *exchangev2types.DerivativeOrder
	OrderCancelV2(defaultSubaccountID ethcommon.Hash, d *OrderCancelData) *exchangev2types.OrderData

	GetGasFee() (string, error)

	StreamEventOrderFail(sender string, failEventCh chan map[string]uint)
	StreamEventOrderFailWithWebsocket(sender string, websocket *rpchttp.HTTP, failEventCh chan map[string]uint)
	ChainStreamV2(ctx context.Context, req chainstreamv2types.StreamRequest) (chainstreamv2types.Stream_StreamV2Client, error)

	// get tx from chain node
	GetTx(ctx context.Context, txHash string) (*txtypes.GetTxResponse, error)

	// wasm module
	FetchContractInfo(ctx context.Context, address string) (*wasmtypes.QueryContractInfoResponse, error)
	FetchContractHistory(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryContractHistoryResponse, error)
	FetchContractsByCode(ctx context.Context, codeId uint64, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCodeResponse, error)
	FetchAllContractsState(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryAllContractStateResponse, error)
	RawContractState(
		ctx context.Context,
		contractAddress string,
		queryData []byte,
	) (*wasmtypes.QueryRawContractStateResponse, error)
	SmartContractState(
		ctx context.Context,
		contractAddress string,
		queryData []byte,
	) (*wasmtypes.QuerySmartContractStateResponse, error)
	FetchCode(ctx context.Context, codeId uint64) (*wasmtypes.QueryCodeResponse, error)
	FetchCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryCodesResponse, error)
	FetchPinnedCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryPinnedCodesResponse, error)
	FetchContractsByCreator(ctx context.Context, creator string, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCreatorResponse, error)

	// tokenfactory module
	FetchDenomAuthorityMetadata(ctx context.Context, creator string, subDenom string) (*tokenfactorytypes.QueryDenomAuthorityMetadataResponse, error)
	FetchDenomsFromCreator(ctx context.Context, creator string) (*tokenfactorytypes.QueryDenomsFromCreatorResponse, error)
	FetchTokenfactoryModuleState(ctx context.Context) (*tokenfactorytypes.QueryModuleStateResponse, error)

	// distribution module
	FetchValidatorDistributionInfo(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorDistributionInfoResponse, error)
	FetchValidatorOutstandingRewards(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorOutstandingRewardsResponse, error)
	FetchValidatorCommission(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorCommissionResponse, error)
	FetchValidatorSlashes(ctx context.Context, validatorAddress string, startingHeight uint64, endingHeight uint64, pagination *query.PageRequest) (*distributiontypes.QueryValidatorSlashesResponse, error)
	FetchDelegationRewards(ctx context.Context, delegatorAddress string, validatorAddress string) (*distributiontypes.QueryDelegationRewardsResponse, error)
	FetchDelegationTotalRewards(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegationTotalRewardsResponse, error)
	FetchDelegatorValidators(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorValidatorsResponse, error)
	FetchDelegatorWithdrawAddress(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorWithdrawAddressResponse, error)
	FetchCommunityPool(ctx context.Context) (*distributiontypes.QueryCommunityPoolResponse, error)

	// chain exchange module
	FetchSubaccountDeposits(ctx context.Context, subaccountID string) (*exchangev2types.QuerySubaccountDepositsResponse, error)
	FetchSubaccountDeposit(ctx context.Context, subaccountId string, denom string) (*exchangev2types.QuerySubaccountDepositResponse, error)
	FetchExchangeBalances(ctx context.Context) (*exchangev2types.QueryExchangeBalancesResponse, error)
	FetchAggregateVolume(ctx context.Context, account string) (*exchangev2types.QueryAggregateVolumeResponse, error)
	FetchAggregateVolumes(ctx context.Context, accounts []string, marketIDs []string) (*exchangev2types.QueryAggregateVolumesResponse, error)
	FetchAggregateMarketVolume(ctx context.Context, marketId string) (*exchangev2types.QueryAggregateMarketVolumeResponse, error)
	FetchAggregateMarketVolumes(ctx context.Context, marketIDs []string) (*exchangev2types.QueryAggregateMarketVolumesResponse, error)
	FetchDenomDecimal(ctx context.Context, denom string) (*exchangev2types.QueryDenomDecimalResponse, error)
	FetchDenomDecimals(ctx context.Context, denoms []string) (*exchangev2types.QueryDenomDecimalsResponse, error)
	FetchChainSpotMarkets(ctx context.Context, status string, marketIDs []string) (*exchangev2types.QuerySpotMarketsResponse, error)
	FetchChainSpotMarket(ctx context.Context, marketId string) (*exchangev2types.QuerySpotMarketResponse, error)
	FetchChainFullSpotMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangev2types.QueryFullSpotMarketsResponse, error)
	FetchChainFullSpotMarket(ctx context.Context, marketId string, withMidPriceAndTob bool) (*exchangev2types.QueryFullSpotMarketResponse, error)
	FetchChainSpotOrderbook(ctx context.Context, marketId string, limit uint64, orderSide exchangev2types.OrderSide, limitCumulativeNotional sdkmath.LegacyDec, limitCumulativeQuantity sdkmath.LegacyDec) (*exchangev2types.QuerySpotOrderbookResponse, error)
	FetchChainTraderSpotOrders(ctx context.Context, marketId string, subaccountId string) (*exchangev2types.QueryTraderSpotOrdersResponse, error)
	FetchChainAccountAddressSpotOrders(ctx context.Context, marketId string, address string) (*exchangev2types.QueryAccountAddressSpotOrdersResponse, error)
	FetchChainSpotOrdersByHashes(ctx context.Context, marketId string, subaccountId string, orderHashes []string) (*exchangev2types.QuerySpotOrdersByHashesResponse, error)
	FetchChainSubaccountOrders(ctx context.Context, subaccountId string, marketId string) (*exchangev2types.QuerySubaccountOrdersResponse, error)
	FetchChainTraderSpotTransientOrders(ctx context.Context, marketId string, subaccountId string) (*exchangev2types.QueryTraderSpotOrdersResponse, error)
	FetchSpotMidPriceAndTOB(ctx context.Context, marketId string) (*exchangev2types.QuerySpotMidPriceAndTOBResponse, error)
	FetchDerivativeMidPriceAndTOB(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMidPriceAndTOBResponse, error)
	FetchChainDerivativeOrderbook(ctx context.Context, marketId string, limit uint64, limitCumulativeNotional sdkmath.LegacyDec) (*exchangev2types.QueryDerivativeOrderbookResponse, error)
	FetchChainTraderDerivativeOrders(ctx context.Context, marketId string, subaccountId string) (*exchangev2types.QueryTraderDerivativeOrdersResponse, error)
	FetchChainAccountAddressDerivativeOrders(ctx context.Context, marketId string, address string) (*exchangev2types.QueryAccountAddressDerivativeOrdersResponse, error)
	FetchChainDerivativeOrdersByHashes(ctx context.Context, marketId string, subaccountId string, orderHashes []string) (*exchangev2types.QueryDerivativeOrdersByHashesResponse, error)
	FetchChainTraderDerivativeTransientOrders(ctx context.Context, marketId string, subaccountId string) (*exchangev2types.QueryTraderDerivativeOrdersResponse, error)
	FetchChainDerivativeMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangev2types.QueryDerivativeMarketsResponse, error)
	FetchChainDerivativeMarket(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMarketResponse, error)
	FetchDerivativeMarketAddress(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMarketAddressResponse, error)
	FetchSubaccountTradeNonce(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountTradeNonceResponse, error)
	FetchChainPositions(ctx context.Context) (*exchangev2types.QueryPositionsResponse, error)
	FetchChainPositionsInMarket(ctx context.Context, marketId string) (*exchangev2types.QueryPositionsInMarketResponse, error)
	FetchChainSubaccountPositions(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountPositionsResponse, error)
	FetchChainSubaccountPositionInMarket(ctx context.Context, subaccountId string, marketId string) (*exchangev2types.QuerySubaccountPositionInMarketResponse, error)
	FetchChainSubaccountEffectivePositionInMarket(ctx context.Context, subaccountId string, marketId string) (*exchangev2types.QuerySubaccountEffectivePositionInMarketResponse, error)
	FetchChainPerpetualMarketInfo(ctx context.Context, marketId string) (*exchangev2types.QueryPerpetualMarketInfoResponse, error)
	FetchChainExpiryFuturesMarketInfo(ctx context.Context, marketId string) (*exchangev2types.QueryExpiryFuturesMarketInfoResponse, error)
	FetchChainPerpetualMarketFunding(ctx context.Context, marketId string) (*exchangev2types.QueryPerpetualMarketFundingResponse, error)
	FetchSubaccountOrderMetadata(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountOrderMetadataResponse, error)
	FetchTradeRewardPoints(ctx context.Context, accounts []string) (*exchangev2types.QueryTradeRewardPointsResponse, error)
	FetchPendingTradeRewardPoints(ctx context.Context, accounts []string) (*exchangev2types.QueryTradeRewardPointsResponse, error)
	FetchFeeDiscountAccountInfo(ctx context.Context, account string) (*exchangev2types.QueryFeeDiscountAccountInfoResponse, error)
	FetchTradeRewardCampaign(ctx context.Context) (*exchangev2types.QueryTradeRewardCampaignResponse, error)
	FetchFeeDiscountSchedule(ctx context.Context) (*exchangev2types.QueryFeeDiscountScheduleResponse, error)
	FetchBalanceMismatches(ctx context.Context, dustFactor int64) (*exchangev2types.QueryBalanceMismatchesResponse, error)
	FetchBalanceWithBalanceHolds(ctx context.Context) (*exchangev2types.QueryBalanceWithBalanceHoldsResponse, error)
	FetchFeeDiscountTierStatistics(ctx context.Context) (*exchangev2types.QueryFeeDiscountTierStatisticsResponse, error)
	FetchMitoVaultInfos(ctx context.Context) (*exchangev2types.MitoVaultInfosResponse, error)
	FetchMarketIDFromVault(ctx context.Context, vaultAddress string) (*exchangev2types.QueryMarketIDFromVaultResponse, error)
	FetchHistoricalTradeRecords(ctx context.Context, marketId string) (*exchangev2types.QueryHistoricalTradeRecordsResponse, error)
	FetchIsOptedOutOfRewards(ctx context.Context, account string) (*exchangev2types.QueryIsOptedOutOfRewardsResponse, error)
	FetchOptedOutOfRewardsAccounts(ctx context.Context) (*exchangev2types.QueryOptedOutOfRewardsAccountsResponse, error)
	FetchMarketVolatility(ctx context.Context, marketId string, tradeHistoryOptions *exchangev2types.TradeHistoryOptions) (*exchangev2types.QueryMarketVolatilityResponse, error)
	FetchChainBinaryOptionsMarkets(ctx context.Context, status string) (*exchangev2types.QueryBinaryMarketsResponse, error)
	FetchTraderDerivativeConditionalOrders(ctx context.Context, subaccountId string, marketId string) (*exchangev2types.QueryTraderDerivativeConditionalOrdersResponse, error)
	FetchMarketAtomicExecutionFeeMultiplier(ctx context.Context, marketId string) (*exchangev2types.QueryMarketAtomicExecutionFeeMultiplierResponse, error)
	FetchActiveStakeGrant(ctx context.Context, grantee string) (*exchangev2types.QueryActiveStakeGrantResponse, error)
	FetchGrantAuthorization(ctx context.Context, granter, grantee string) (*exchangev2types.QueryGrantAuthorizationResponse, error)
	FetchGrantAuthorizations(ctx context.Context, granter string) (*exchangev2types.QueryGrantAuthorizationsResponse, error)
	FetchL3DerivativeOrderbook(ctx context.Context, marketId string) (*exchangev2types.QueryFullDerivativeOrderbookResponse, error)
	FetchL3SpotOrderbook(ctx context.Context, marketId string) (*exchangev2types.QueryFullSpotOrderbookResponse, error)
	FetchMarketBalance(ctx context.Context, marketId string) (*exchangev2types.QueryMarketBalanceResponse, error)
	FetchMarketBalances(ctx context.Context) (*exchangev2types.QueryMarketBalancesResponse, error)
	FetchDenomMinNotional(ctx context.Context, denom string) (*exchangev2types.QueryDenomMinNotionalResponse, error)
	FetchDenomMinNotionals(ctx context.Context) (*exchangev2types.QueryDenomMinNotionalsResponse, error)

	// Tendermint module
	FetchNodeInfo(ctx context.Context) (*cmtservice.GetNodeInfoResponse, error)
	FetchSyncing(ctx context.Context) (*cmtservice.GetSyncingResponse, error)
	FetchLatestBlock(ctx context.Context) (*cmtservice.GetLatestBlockResponse, error)
	FetchBlockByHeight(ctx context.Context, height int64) (*cmtservice.GetBlockByHeightResponse, error)
	FetchLatestValidatorSet(ctx context.Context) (*cmtservice.GetLatestValidatorSetResponse, error)
	FetchValidatorSetByHeight(ctx context.Context, height int64, pagination *query.PageRequest) (*cmtservice.GetValidatorSetByHeightResponse, error)
	ABCIQuery(ctx context.Context, path string, data []byte, height int64, prove bool) (*cmtservice.ABCIQueryResponse, error)

	// IBC Transfer module
	FetchDenomTrace(ctx context.Context, hash string) (*ibctransfertypes.QueryDenomTraceResponse, error)
	FetchDenomTraces(ctx context.Context, pagination *query.PageRequest) (*ibctransfertypes.QueryDenomTracesResponse, error)
	FetchDenomHash(ctx context.Context, trace string) (*ibctransfertypes.QueryDenomHashResponse, error)
	FetchEscrowAddress(ctx context.Context, portId string, channelId string) (*ibctransfertypes.QueryEscrowAddressResponse, error)
	FetchTotalEscrowForDenom(ctx context.Context, denom string) (*ibctransfertypes.QueryTotalEscrowForDenomResponse, error)

	// IBC Core Channel module
	FetchIBCChannel(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryChannelResponse, error)
	FetchIBCChannels(ctx context.Context, pagination *query.PageRequest) (*ibcchanneltypes.QueryChannelsResponse, error)
	FetchIBCConnectionChannels(ctx context.Context, connection string, pagination *query.PageRequest) (*ibcchanneltypes.QueryConnectionChannelsResponse, error)
	FetchIBCChannelClientState(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryChannelClientStateResponse, error)
	FetchIBCChannelConsensusState(ctx context.Context, portId string, channelId string, revisionNumber uint64, revisionHeight uint64) (*ibcchanneltypes.QueryChannelConsensusStateResponse, error)
	FetchIBCPacketCommitment(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketCommitmentResponse, error)
	FetchIBCPacketCommitments(ctx context.Context, portId string, channelId string, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketCommitmentsResponse, error)
	FetchIBCPacketReceipt(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketReceiptResponse, error)
	FetchIBCPacketAcknowledgement(ctx context.Context, portId string, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketAcknowledgementResponse, error)
	FetchIBCPacketAcknowledgements(ctx context.Context, portId string, channelId string, packetCommitmentSequences []uint64, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketAcknowledgementsResponse, error)
	FetchIBCUnreceivedPackets(ctx context.Context, portId string, channelId string, packetCommitmentSequences []uint64) (*ibcchanneltypes.QueryUnreceivedPacketsResponse, error)
	FetchIBCUnreceivedAcks(ctx context.Context, portId string, channelId string, packetAckSequences []uint64) (*ibcchanneltypes.QueryUnreceivedAcksResponse, error)
	FetchIBCNextSequenceReceive(ctx context.Context, portId string, channelId string) (*ibcchanneltypes.QueryNextSequenceReceiveResponse, error)

	// IBC Core Chain module
	FetchIBCClientState(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStateResponse, error)
	FetchIBCClientStates(ctx context.Context, pagination *query.PageRequest) (*ibcclienttypes.QueryClientStatesResponse, error)
	FetchIBCConsensusState(ctx context.Context, clientId string, revisionNumber uint64, revisionHeight uint64, latestHeight bool) (*ibcclienttypes.QueryConsensusStateResponse, error)
	FetchIBCConsensusStates(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStatesResponse, error)
	FetchIBCConsensusStateHeights(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStateHeightsResponse, error)
	FetchIBCClientStatus(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStatusResponse, error)
	FetchIBCClientParams(ctx context.Context) (*ibcclienttypes.QueryClientParamsResponse, error)
	FetchIBCUpgradedClientState(ctx context.Context) (*ibcclienttypes.QueryUpgradedClientStateResponse, error)
	FetchIBCUpgradedConsensusState(ctx context.Context) (*ibcclienttypes.QueryUpgradedConsensusStateResponse, error)

	// IBC Core Connection module
	FetchIBCConnection(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionResponse, error)
	FetchIBCConnections(ctx context.Context, pagination *query.PageRequest) (*ibcconnectiontypes.QueryConnectionsResponse, error)
	FetchIBCClientConnections(ctx context.Context, clientId string) (*ibcconnectiontypes.QueryClientConnectionsResponse, error)
	FetchIBCConnectionClientState(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionClientStateResponse, error)
	FetchIBCConnectionConsensusState(ctx context.Context, connectionId string, revisionNumber uint64, revisionHeight uint64) (*ibcconnectiontypes.QueryConnectionConsensusStateResponse, error)
	FetchIBCConnectionParams(ctx context.Context) (*ibcconnectiontypes.QueryConnectionParamsResponse, error)

	// Permissions module
	FetchPermissionsNamespaceDenoms(ctx context.Context) (*permissionstypes.QueryNamespaceDenomsResponse, error)
	FetchPermissionsNamespaces(ctx context.Context) (*permissionstypes.QueryNamespacesResponse, error)
	FetchPermissionsNamespace(ctx context.Context, denom string) (*permissionstypes.QueryNamespaceResponse, error)
	FetchPermissionsRolesByActor(ctx context.Context, denom, actor string) (*permissionstypes.QueryRolesByActorResponse, error)
	FetchPermissionsActorsByRole(ctx context.Context, denom, role string) (*permissionstypes.QueryActorsByRoleResponse, error)
	FetchPermissionsRoleManagers(ctx context.Context, denom string) (*permissionstypes.QueryRoleManagersResponse, error)
	FetchPermissionsRoleManager(ctx context.Context, denom, manager string) (*permissionstypes.QueryRoleManagerResponse, error)
	FetchPermissionsPolicyStatuses(ctx context.Context, denom string) (*permissionstypes.QueryPolicyStatusesResponse, error)
	FetchPermissionsPolicyManagerCapabilities(ctx context.Context, denom string) (*permissionstypes.QueryPolicyManagerCapabilitiesResponse, error)
	FetchPermissionsVouchers(ctx context.Context, denom string) (*permissionstypes.QueryVouchersResponse, error)
	FetchPermissionsVoucher(ctx context.Context, denom, address string) (*permissionstypes.QueryVoucherResponse, error)
	FetchPermissionsModuleState(ctx context.Context) (*permissionstypes.QueryModuleStateResponse, error)

	// TxFees module
	FetchTxFeesParams(ctx context.Context) (*txfeestypes.QueryParamsResponse, error)
	FetchEipBaseFee(ctx context.Context) (*txfeestypes.QueryEipBaseFeeResponse, error)

	// ERC20 module
	FetchAllTokenPairs(ctx context.Context, pagination *query.PageRequest) (*erc20types.QueryAllTokenPairsResponse, error)
	FetchTokenPairByDenom(ctx context.Context, bankDenom string) (*erc20types.QueryTokenPairByDenomResponse, error)
	FetchTokenPairByERC20Address(ctx context.Context, erc20Address string) (*erc20types.QueryTokenPairByERC20AddressResponse, error)

	// EVM module
	FetchEVMAccount(ctx context.Context, evmAddress string) (*evmtypes.QueryAccountResponse, error)
	FetchEVMCosmosAccount(ctx context.Context, address string) (*evmtypes.QueryCosmosAccountResponse, error)
	FetchEVMValidatorAccount(ctx context.Context, consAddress string) (*evmtypes.QueryValidatorAccountResponse, error)
	FetchEVMBalance(ctx context.Context, address string) (*evmtypes.QueryBalanceResponse, error)
	FetchEVMStorage(ctx context.Context, address string, key *string) (*evmtypes.QueryStorageResponse, error)
	FetchEVMCode(ctx context.Context, address string) (*evmtypes.QueryCodeResponse, error)
	FetchEVMBaseFee(ctx context.Context) (*evmtypes.QueryBaseFeeResponse, error)

	CurrentChainGasPrice(ctx context.Context) int64
	SetGasPrice(gasPrice int64)

	GetNetwork() common.Network
	Close()
}

func NewChainClientV2 added in v1.58.0

func NewChainClientV2(
	ctx sdkclient.Context,
	network common.Network,
	options ...common.ClientOption,
) (ChainClientV2, error)

type DenomsMetadataProvider added in v1.58.0

type DenomsMetadataProvider interface {
	GetDenomsMetadata(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryDenomsMetadataResponse, error)
}

type DerivativeOrderData added in v1.34.0

type DerivativeOrderData struct {
	OrderType       int32
	Price           decimal.Decimal
	Quantity        decimal.Decimal
	Leverage        decimal.Decimal
	FeeRecipient    string
	MarketId        string
	IsReduceOnly    bool
	Cid             string
	ExpirationBlock int64
}

type EncodingConfig

type EncodingConfig struct {
	InterfaceRegistry types.InterfaceRegistry
	Marshaler         codec.Codec
	TxConfig          client.TxConfig
}

type ExchangeAuthz added in v1.38.1

type ExchangeAuthz string

type MarketsAssistant added in v1.49.0

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

func NewHumanReadableMarketsAssistant added in v1.58.0

func NewHumanReadableMarketsAssistant(ctx context.Context, chainClient ChainClientV2) (MarketsAssistant, error)

func NewHumanReadableMarketsAssistantWithAllTokens added in v1.58.0

func NewHumanReadableMarketsAssistantWithAllTokens(ctx context.Context, exchangeClient exchange.ExchangeClient, chainClient ChainClientV2) (MarketsAssistant, error)

func NewMarketsAssistant added in v1.49.0

func NewMarketsAssistant(ctx context.Context, chainClient ChainClient) (MarketsAssistant, error)

func NewMarketsAssistantWithAllTokens added in v1.49.0

func NewMarketsAssistantWithAllTokens(ctx context.Context, exchangeClient exchange.ExchangeClient, chainClient ChainClient) (MarketsAssistant, error)

func (*MarketsAssistant) AllBinaryOptionMarkets added in v1.54.0

func (assistant *MarketsAssistant) AllBinaryOptionMarkets() map[string]core.DerivativeMarket

func (*MarketsAssistant) AllDerivativeMarkets added in v1.49.0

func (assistant *MarketsAssistant) AllDerivativeMarkets() map[string]core.DerivativeMarket

func (*MarketsAssistant) AllSpotMarkets added in v1.49.0

func (assistant *MarketsAssistant) AllSpotMarkets() map[string]core.SpotMarket

func (*MarketsAssistant) AllTokens added in v1.49.0

func (assistant *MarketsAssistant) AllTokens() map[string]core.Token

func (*MarketsAssistant) AllTokensByDenom added in v1.54.0

func (assistant *MarketsAssistant) AllTokensByDenom() map[string]core.Token

type MockChainClient added in v1.49.0

type MockChainClient struct {
	Network                         common.Network
	DenomsMetadataResponses         []*banktypes.QueryDenomsMetadataResponse
	QuerySpotMarketsResponses       []*exchangetypes.QuerySpotMarketsResponse
	QueryDerivativeMarketsResponses []*exchangetypes.QueryDerivativeMarketsResponse
	QueryBinaryMarketsResponses     []*exchangetypes.QueryBinaryMarketsResponse
}

func (*MockChainClient) ABCIQuery added in v1.51.0

func (c *MockChainClient) ABCIQuery(ctx context.Context, path string, data []byte, height int64, prove bool) (*cmtservice.ABCIQueryResponse, error)

func (*MockChainClient) AsyncBroadcastMsg added in v1.49.0

func (c *MockChainClient) AsyncBroadcastMsg(msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) AsyncBroadcastMsgWithContext added in v1.58.0

func (c *MockChainClient) AsyncBroadcastMsgWithContext(ctx context.Context, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) AsyncBroadcastSignedTx added in v1.49.0

func (c *MockChainClient) AsyncBroadcastSignedTx(txBytes []byte) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) AsyncBroadcastSignedTxWithContext added in v1.58.0

func (c *MockChainClient) AsyncBroadcastSignedTxWithContext(ctx context.Context, txBytes []byte) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) BroadcastMsg added in v1.55.0

func (*MockChainClient) BroadcastMsgWithContext added in v1.58.0

func (c *MockChainClient) BroadcastMsgWithContext(ctx context.Context, broadcastMode txtypes.BroadcastMode, msgs ...sdk.Msg) (*txtypes.BroadcastTxRequest, *txtypes.BroadcastTxResponse, error)

func (*MockChainClient) BroadcastSignedTx added in v1.56.2

func (c *MockChainClient) BroadcastSignedTx(txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) BroadcastSignedTxWithContext added in v1.58.0

func (c *MockChainClient) BroadcastSignedTxWithContext(ctx context.Context, txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) BuildExchangeAuthz added in v1.49.0

func (c *MockChainClient) BuildExchangeAuthz(granter, grantee string, authzType ExchangeAuthz, subaccountId string, markets []string, expireIn time.Time) *authztypes.MsgGrant

func (*MockChainClient) BuildExchangeBatchUpdateOrdersAuthz added in v1.49.0

func (c *MockChainClient) BuildExchangeBatchUpdateOrdersAuthz(
	granter string,
	grantee string,
	subaccountId string,
	spotMarkets []string,
	derivativeMarkets []string,
	expireIn time.Time,
) *authztypes.MsgGrant

func (*MockChainClient) BuildGenericAuthz added in v1.49.0

func (c *MockChainClient) BuildGenericAuthz(granter, grantee, msgtype string, expireIn time.Time) *authztypes.MsgGrant

func (*MockChainClient) BuildSignedTx added in v1.49.0

func (c *MockChainClient) BuildSignedTx(clientCtx client.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msg ...sdk.Msg) ([]byte, error)

func (*MockChainClient) BuildSignedTxWithContext added in v1.58.0

func (c *MockChainClient) BuildSignedTxWithContext(ctx context.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msgs ...sdk.Msg) ([]byte, error)

func (*MockChainClient) CanSignTransactions added in v1.49.0

func (c *MockChainClient) CanSignTransactions() bool

func (*MockChainClient) ChainStream added in v1.49.0

func (*MockChainClient) ClientContext added in v1.49.0

func (c *MockChainClient) ClientContext() client.Context

func (*MockChainClient) Close added in v1.49.0

func (c *MockChainClient) Close()

func (*MockChainClient) ComputeOrderHashes added in v1.49.0

func (c *MockChainClient) ComputeOrderHashes(spotOrders []exchangetypes.SpotOrder, derivativeOrders []exchangetypes.DerivativeOrder, subaccountId eth.Hash) (OrderHashes, error)

func (*MockChainClient) CreateDerivativeOrder added in v1.49.0

func (c *MockChainClient) CreateDerivativeOrder(defaultSubaccountID eth.Hash, d *DerivativeOrderData, marketAssistant MarketsAssistant) *exchangetypes.DerivativeOrder

func (*MockChainClient) CreateSpotOrder added in v1.49.0

func (c *MockChainClient) CreateSpotOrder(defaultSubaccountID eth.Hash, d *SpotOrderData, marketsAssistant MarketsAssistant) *exchangetypes.SpotOrder

func (*MockChainClient) CurrentChainGasPrice added in v1.57.0

func (c *MockChainClient) CurrentChainGasPrice() int64

func (*MockChainClient) CurrentChainGasPriceWithContext added in v1.58.0

func (c *MockChainClient) CurrentChainGasPriceWithContext(ctx context.Context) int64

func (*MockChainClient) DefaultSubaccount added in v1.49.0

func (c *MockChainClient) DefaultSubaccount(acc sdk.AccAddress) eth.Hash

func (*MockChainClient) FetchAggregateMarketVolume added in v1.51.0

func (c *MockChainClient) FetchAggregateMarketVolume(ctx context.Context, marketId string) (*exchangetypes.QueryAggregateMarketVolumeResponse, error)

func (*MockChainClient) FetchAggregateMarketVolumes added in v1.51.0

func (c *MockChainClient) FetchAggregateMarketVolumes(ctx context.Context, marketIDs []string) (*exchangetypes.QueryAggregateMarketVolumesResponse, error)

func (*MockChainClient) FetchAggregateVolume added in v1.51.0

func (c *MockChainClient) FetchAggregateVolume(ctx context.Context, account string) (*exchangetypes.QueryAggregateVolumeResponse, error)

func (*MockChainClient) FetchAggregateVolumes added in v1.51.0

func (c *MockChainClient) FetchAggregateVolumes(ctx context.Context, accounts, marketIDs []string) (*exchangetypes.QueryAggregateVolumesResponse, error)

func (*MockChainClient) FetchAllContractsState added in v1.49.0

func (c *MockChainClient) FetchAllContractsState(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryAllContractStateResponse, error)

func (*MockChainClient) FetchBalanceMismatches added in v1.51.0

func (c *MockChainClient) FetchBalanceMismatches(ctx context.Context, dustFactor int64) (*exchangetypes.QueryBalanceMismatchesResponse, error)

func (*MockChainClient) FetchBalanceWithBalanceHolds added in v1.51.0

func (*MockChainClient) FetchBlockByHeight added in v1.51.0

func (c *MockChainClient) FetchBlockByHeight(ctx context.Context, height int64) (*cmtservice.GetBlockByHeightResponse, error)

func (*MockChainClient) FetchChainAccountAddressDerivativeOrders added in v1.51.0

func (c *MockChainClient) FetchChainAccountAddressDerivativeOrders(ctx context.Context, marketId, address string) (*exchangetypes.QueryAccountAddressDerivativeOrdersResponse, error)

func (*MockChainClient) FetchChainAccountAddressSpotOrders added in v1.51.0

func (c *MockChainClient) FetchChainAccountAddressSpotOrders(ctx context.Context, marketId, address string) (*exchangetypes.QueryAccountAddressSpotOrdersResponse, error)

func (*MockChainClient) FetchChainBinaryOptionsMarkets added in v1.51.0

func (c *MockChainClient) FetchChainBinaryOptionsMarkets(ctx context.Context, status string) (*exchangetypes.QueryBinaryMarketsResponse, error)

func (*MockChainClient) FetchChainDerivativeMarket added in v1.51.0

func (c *MockChainClient) FetchChainDerivativeMarket(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMarketResponse, error)

func (*MockChainClient) FetchChainDerivativeMarkets added in v1.51.0

func (c *MockChainClient) FetchChainDerivativeMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangetypes.QueryDerivativeMarketsResponse, error)

func (*MockChainClient) FetchChainDerivativeOrderbook added in v1.51.0

func (c *MockChainClient) FetchChainDerivativeOrderbook(ctx context.Context, marketId string, limit uint64, limitCumulativeNotional sdkmath.LegacyDec) (*exchangetypes.QueryDerivativeOrderbookResponse, error)

func (*MockChainClient) FetchChainDerivativeOrdersByHashes added in v1.51.0

func (c *MockChainClient) FetchChainDerivativeOrdersByHashes(ctx context.Context, marketId, subaccountId string, orderHashes []string) (*exchangetypes.QueryDerivativeOrdersByHashesResponse, error)

func (*MockChainClient) FetchChainExpiryFuturesMarketInfo added in v1.51.0

func (c *MockChainClient) FetchChainExpiryFuturesMarketInfo(ctx context.Context, marketId string) (*exchangetypes.QueryExpiryFuturesMarketInfoResponse, error)

func (*MockChainClient) FetchChainFullSpotMarket added in v1.51.0

func (c *MockChainClient) FetchChainFullSpotMarket(ctx context.Context, marketId string, withMidPriceAndTob bool) (*exchangetypes.QueryFullSpotMarketResponse, error)

func (*MockChainClient) FetchChainFullSpotMarkets added in v1.51.0

func (c *MockChainClient) FetchChainFullSpotMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangetypes.QueryFullSpotMarketsResponse, error)

func (*MockChainClient) FetchChainPerpetualMarketFunding added in v1.51.0

func (c *MockChainClient) FetchChainPerpetualMarketFunding(ctx context.Context, marketId string) (*exchangetypes.QueryPerpetualMarketFundingResponse, error)

func (*MockChainClient) FetchChainPerpetualMarketInfo added in v1.51.0

func (c *MockChainClient) FetchChainPerpetualMarketInfo(ctx context.Context, marketId string) (*exchangetypes.QueryPerpetualMarketInfoResponse, error)

func (*MockChainClient) FetchChainPositions added in v1.51.0

func (c *MockChainClient) FetchChainPositions(ctx context.Context) (*exchangetypes.QueryPositionsResponse, error)

func (*MockChainClient) FetchChainSpotMarket added in v1.51.0

func (c *MockChainClient) FetchChainSpotMarket(ctx context.Context, marketId string) (*exchangetypes.QuerySpotMarketResponse, error)

func (*MockChainClient) FetchChainSpotMarkets added in v1.51.0

func (c *MockChainClient) FetchChainSpotMarkets(ctx context.Context, status string, marketIDs []string) (*exchangetypes.QuerySpotMarketsResponse, error)

func (*MockChainClient) FetchChainSpotOrderbook added in v1.51.0

func (c *MockChainClient) FetchChainSpotOrderbook(ctx context.Context, marketId string, limit uint64, orderSide exchangetypes.OrderSide, limitCumulativeNotional, limitCumulativeQuantity sdkmath.LegacyDec) (*exchangetypes.QuerySpotOrderbookResponse, error)

func (*MockChainClient) FetchChainSpotOrdersByHashes added in v1.51.0

func (c *MockChainClient) FetchChainSpotOrdersByHashes(ctx context.Context, marketId, subaccountId string, orderHashes []string) (*exchangetypes.QuerySpotOrdersByHashesResponse, error)

func (*MockChainClient) FetchChainSubaccountEffectivePositionInMarket added in v1.51.0

func (c *MockChainClient) FetchChainSubaccountEffectivePositionInMarket(ctx context.Context, subaccountId, marketId string) (*exchangetypes.QuerySubaccountEffectivePositionInMarketResponse, error)

func (*MockChainClient) FetchChainSubaccountOrders added in v1.51.0

func (c *MockChainClient) FetchChainSubaccountOrders(ctx context.Context, subaccountId, marketId string) (*exchangetypes.QuerySubaccountOrdersResponse, error)

func (*MockChainClient) FetchChainSubaccountPositionInMarket added in v1.51.0

func (c *MockChainClient) FetchChainSubaccountPositionInMarket(ctx context.Context, subaccountId, marketId string) (*exchangetypes.QuerySubaccountPositionInMarketResponse, error)

func (*MockChainClient) FetchChainSubaccountPositions added in v1.51.0

func (c *MockChainClient) FetchChainSubaccountPositions(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountPositionsResponse, error)

func (*MockChainClient) FetchChainTraderDerivativeOrders added in v1.51.0

func (c *MockChainClient) FetchChainTraderDerivativeOrders(ctx context.Context, marketId, subaccountId string) (*exchangetypes.QueryTraderDerivativeOrdersResponse, error)

func (*MockChainClient) FetchChainTraderDerivativeTransientOrders added in v1.51.0

func (c *MockChainClient) FetchChainTraderDerivativeTransientOrders(ctx context.Context, marketId, subaccountId string) (*exchangetypes.QueryTraderDerivativeOrdersResponse, error)

func (*MockChainClient) FetchChainTraderSpotOrders added in v1.51.0

func (c *MockChainClient) FetchChainTraderSpotOrders(ctx context.Context, marketId, subaccountId string) (*exchangetypes.QueryTraderSpotOrdersResponse, error)

func (*MockChainClient) FetchChainTraderSpotTransientOrders added in v1.51.0

func (c *MockChainClient) FetchChainTraderSpotTransientOrders(ctx context.Context, marketId, subaccountId string) (*exchangetypes.QueryTraderSpotOrdersResponse, error)

func (*MockChainClient) FetchCode added in v1.49.0

func (c *MockChainClient) FetchCode(ctx context.Context, codeId uint64) (*wasmtypes.QueryCodeResponse, error)

func (*MockChainClient) FetchCodes added in v1.49.0

func (c *MockChainClient) FetchCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryCodesResponse, error)

func (*MockChainClient) FetchCommunityPool added in v1.51.0

func (*MockChainClient) FetchContractHistory added in v1.49.0

func (c *MockChainClient) FetchContractHistory(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryContractHistoryResponse, error)

func (*MockChainClient) FetchContractInfo added in v1.49.0

func (c *MockChainClient) FetchContractInfo(ctx context.Context, address string) (*wasmtypes.QueryContractInfoResponse, error)

func (*MockChainClient) FetchContractsByCode added in v1.49.0

func (c *MockChainClient) FetchContractsByCode(ctx context.Context, codeId uint64, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCodeResponse, error)

func (*MockChainClient) FetchContractsByCreator added in v1.49.0

func (c *MockChainClient) FetchContractsByCreator(ctx context.Context, creator string, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCreatorResponse, error)

func (*MockChainClient) FetchDelegationRewards added in v1.51.0

func (c *MockChainClient) FetchDelegationRewards(ctx context.Context, delegatorAddress, validatorAddress string) (*distributiontypes.QueryDelegationRewardsResponse, error)

func (*MockChainClient) FetchDelegationTotalRewards added in v1.51.0

func (c *MockChainClient) FetchDelegationTotalRewards(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegationTotalRewardsResponse, error)

func (*MockChainClient) FetchDelegatorValidators added in v1.51.0

func (c *MockChainClient) FetchDelegatorValidators(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorValidatorsResponse, error)

func (*MockChainClient) FetchDelegatorWithdrawAddress added in v1.51.0

func (c *MockChainClient) FetchDelegatorWithdrawAddress(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorWithdrawAddressResponse, error)

func (*MockChainClient) FetchDenomAuthorityMetadata added in v1.49.0

func (c *MockChainClient) FetchDenomAuthorityMetadata(ctx context.Context, creator, subDenom string) (*tokenfactorytypes.QueryDenomAuthorityMetadataResponse, error)

func (*MockChainClient) FetchDenomDecimal added in v1.51.0

func (c *MockChainClient) FetchDenomDecimal(ctx context.Context, denom string) (*exchangetypes.QueryDenomDecimalResponse, error)

func (*MockChainClient) FetchDenomDecimals added in v1.51.0

func (c *MockChainClient) FetchDenomDecimals(ctx context.Context, denoms []string) (*exchangetypes.QueryDenomDecimalsResponse, error)

func (*MockChainClient) FetchDenomHash added in v1.51.0

func (*MockChainClient) FetchDenomMinNotional added in v1.56.0

func (c *MockChainClient) FetchDenomMinNotional(ctx context.Context, denom string) (*exchangetypes.QueryDenomMinNotionalResponse, error)

func (*MockChainClient) FetchDenomMinNotionals added in v1.56.0

func (*MockChainClient) FetchDenomTrace added in v1.51.0

IBC Transfer module

func (*MockChainClient) FetchDenomTraces added in v1.51.0

func (*MockChainClient) FetchDenomsFromCreator added in v1.49.0

func (c *MockChainClient) FetchDenomsFromCreator(ctx context.Context, creator string) (*tokenfactorytypes.QueryDenomsFromCreatorResponse, error)

func (*MockChainClient) FetchDerivativeMarketAddress added in v1.51.0

func (c *MockChainClient) FetchDerivativeMarketAddress(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMarketAddressResponse, error)

func (*MockChainClient) FetchDerivativeMidPriceAndTOB added in v1.51.0

func (c *MockChainClient) FetchDerivativeMidPriceAndTOB(ctx context.Context, marketId string) (*exchangetypes.QueryDerivativeMidPriceAndTOBResponse, error)

func (*MockChainClient) FetchEipBaseFee added in v1.57.0

func (*MockChainClient) FetchEscrowAddress added in v1.51.0

func (c *MockChainClient) FetchEscrowAddress(ctx context.Context, portId, channelId string) (*ibctransfertypes.QueryEscrowAddressResponse, error)

func (*MockChainClient) FetchExchangeBalances added in v1.51.0

func (*MockChainClient) FetchFeeDiscountAccountInfo added in v1.51.0

func (c *MockChainClient) FetchFeeDiscountAccountInfo(ctx context.Context, account string) (*exchangetypes.QueryFeeDiscountAccountInfoResponse, error)

func (*MockChainClient) FetchFeeDiscountSchedule added in v1.51.0

func (*MockChainClient) FetchFeeDiscountTierStatistics added in v1.51.0

func (c *MockChainClient) FetchFeeDiscountTierStatistics(ctx context.Context) (*exchangetypes.QueryFeeDiscountTierStatisticsResponse, error)

func (*MockChainClient) FetchHistoricalTradeRecords added in v1.51.0

func (c *MockChainClient) FetchHistoricalTradeRecords(ctx context.Context, marketId string) (*exchangetypes.QueryHistoricalTradeRecordsResponse, error)

func (*MockChainClient) FetchIBCChannel added in v1.51.0

func (c *MockChainClient) FetchIBCChannel(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryChannelResponse, error)

IBC Core Channel module

func (*MockChainClient) FetchIBCChannelClientState added in v1.51.0

func (c *MockChainClient) FetchIBCChannelClientState(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryChannelClientStateResponse, error)

func (*MockChainClient) FetchIBCChannelConsensusState added in v1.51.0

func (c *MockChainClient) FetchIBCChannelConsensusState(ctx context.Context, portId, channelId string, revisionNumber, revisionHeight uint64) (*ibcchanneltypes.QueryChannelConsensusStateResponse, error)

func (*MockChainClient) FetchIBCChannels added in v1.51.0

func (c *MockChainClient) FetchIBCChannels(ctx context.Context, pagination *query.PageRequest) (*ibcchanneltypes.QueryChannelsResponse, error)

func (*MockChainClient) FetchIBCClientConnections added in v1.51.0

func (c *MockChainClient) FetchIBCClientConnections(ctx context.Context, clientId string) (*ibcconnectiontypes.QueryClientConnectionsResponse, error)

func (*MockChainClient) FetchIBCClientParams added in v1.51.0

func (*MockChainClient) FetchIBCClientState added in v1.51.0

func (c *MockChainClient) FetchIBCClientState(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStateResponse, error)

IBC Core Chain module

func (*MockChainClient) FetchIBCClientStates added in v1.51.0

func (c *MockChainClient) FetchIBCClientStates(ctx context.Context, pagination *query.PageRequest) (*ibcclienttypes.QueryClientStatesResponse, error)

func (*MockChainClient) FetchIBCClientStatus added in v1.51.0

func (c *MockChainClient) FetchIBCClientStatus(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStatusResponse, error)

func (*MockChainClient) FetchIBCConnection added in v1.51.0

func (c *MockChainClient) FetchIBCConnection(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionResponse, error)

IBC Core Connection module

func (*MockChainClient) FetchIBCConnectionChannels added in v1.51.0

func (c *MockChainClient) FetchIBCConnectionChannels(ctx context.Context, connection string, pagination *query.PageRequest) (*ibcchanneltypes.QueryConnectionChannelsResponse, error)

func (*MockChainClient) FetchIBCConnectionClientState added in v1.51.0

func (c *MockChainClient) FetchIBCConnectionClientState(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionClientStateResponse, error)

func (*MockChainClient) FetchIBCConnectionConsensusState added in v1.51.0

func (c *MockChainClient) FetchIBCConnectionConsensusState(ctx context.Context, connectionId string, revisionNumber, revisionHeight uint64) (*ibcconnectiontypes.QueryConnectionConsensusStateResponse, error)

func (*MockChainClient) FetchIBCConnectionParams added in v1.51.0

func (*MockChainClient) FetchIBCConnections added in v1.51.0

func (*MockChainClient) FetchIBCConsensusState added in v1.51.0

func (c *MockChainClient) FetchIBCConsensusState(ctx context.Context, clientId string, revisionNumber, revisionHeight uint64, latestHeight bool) (*ibcclienttypes.QueryConsensusStateResponse, error)

func (*MockChainClient) FetchIBCConsensusStateHeights added in v1.51.0

func (c *MockChainClient) FetchIBCConsensusStateHeights(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStateHeightsResponse, error)

func (*MockChainClient) FetchIBCConsensusStates added in v1.51.0

func (c *MockChainClient) FetchIBCConsensusStates(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStatesResponse, error)

func (*MockChainClient) FetchIBCNextSequenceReceive added in v1.51.0

func (c *MockChainClient) FetchIBCNextSequenceReceive(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryNextSequenceReceiveResponse, error)

func (*MockChainClient) FetchIBCPacketAcknowledgement added in v1.51.0

func (c *MockChainClient) FetchIBCPacketAcknowledgement(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketAcknowledgementResponse, error)

func (*MockChainClient) FetchIBCPacketAcknowledgements added in v1.51.0

func (c *MockChainClient) FetchIBCPacketAcknowledgements(ctx context.Context, portId, channelId string, packetCommitmentSequences []uint64, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketAcknowledgementsResponse, error)

func (*MockChainClient) FetchIBCPacketCommitment added in v1.51.0

func (c *MockChainClient) FetchIBCPacketCommitment(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketCommitmentResponse, error)

func (*MockChainClient) FetchIBCPacketCommitments added in v1.51.0

func (c *MockChainClient) FetchIBCPacketCommitments(ctx context.Context, portId, channelId string, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketCommitmentsResponse, error)

func (*MockChainClient) FetchIBCPacketReceipt added in v1.51.0

func (c *MockChainClient) FetchIBCPacketReceipt(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketReceiptResponse, error)

func (*MockChainClient) FetchIBCUnreceivedAcks added in v1.51.0

func (c *MockChainClient) FetchIBCUnreceivedAcks(ctx context.Context, portId, channelId string, packetAckSequences []uint64) (*ibcchanneltypes.QueryUnreceivedAcksResponse, error)

func (*MockChainClient) FetchIBCUnreceivedPackets added in v1.51.0

func (c *MockChainClient) FetchIBCUnreceivedPackets(ctx context.Context, portId, channelId string, packetCommitmentSequences []uint64) (*ibcchanneltypes.QueryUnreceivedPacketsResponse, error)

func (*MockChainClient) FetchIBCUpgradedClientState added in v1.51.0

func (c *MockChainClient) FetchIBCUpgradedClientState(ctx context.Context) (*ibcclienttypes.QueryUpgradedClientStateResponse, error)

func (*MockChainClient) FetchIBCUpgradedConsensusState added in v1.51.0

func (c *MockChainClient) FetchIBCUpgradedConsensusState(ctx context.Context) (*ibcclienttypes.QueryUpgradedConsensusStateResponse, error)

func (*MockChainClient) FetchIsOptedOutOfRewards added in v1.51.0

func (c *MockChainClient) FetchIsOptedOutOfRewards(ctx context.Context, account string) (*exchangetypes.QueryIsOptedOutOfRewardsResponse, error)

func (*MockChainClient) FetchL3DerivativeOrderBook added in v1.56.0

func (c *MockChainClient) FetchL3DerivativeOrderBook(ctx context.Context, marketId string) (*exchangetypes.QueryFullDerivativeOrderbookResponse, error)

func (*MockChainClient) FetchL3SpotOrderBook added in v1.56.0

func (c *MockChainClient) FetchL3SpotOrderBook(ctx context.Context, marketId string) (*exchangetypes.QueryFullSpotOrderbookResponse, error)

func (*MockChainClient) FetchLatestBlock added in v1.51.0

func (*MockChainClient) FetchLatestValidatorSet added in v1.51.0

func (c *MockChainClient) FetchLatestValidatorSet(ctx context.Context) (*cmtservice.GetLatestValidatorSetResponse, error)

func (*MockChainClient) FetchMarketAtomicExecutionFeeMultiplier added in v1.51.0

func (c *MockChainClient) FetchMarketAtomicExecutionFeeMultiplier(ctx context.Context, marketId string) (*exchangetypes.QueryMarketAtomicExecutionFeeMultiplierResponse, error)

func (*MockChainClient) FetchMarketBalance added in v1.56.0

func (c *MockChainClient) FetchMarketBalance(ctx context.Context, marketId string) (*exchangetypes.QueryMarketBalanceResponse, error)

func (*MockChainClient) FetchMarketBalances added in v1.56.0

func (*MockChainClient) FetchMarketIDFromVault added in v1.51.0

func (c *MockChainClient) FetchMarketIDFromVault(ctx context.Context, vaultAddress string) (*exchangetypes.QueryMarketIDFromVaultResponse, error)

func (*MockChainClient) FetchMarketVolatility added in v1.51.0

func (c *MockChainClient) FetchMarketVolatility(ctx context.Context, marketId string, tradeHistoryOptions *exchangetypes.TradeHistoryOptions) (*exchangetypes.QueryMarketVolatilityResponse, error)

func (*MockChainClient) FetchMitoVaultInfos added in v1.51.0

func (c *MockChainClient) FetchMitoVaultInfos(ctx context.Context) (*exchangetypes.MitoVaultInfosResponse, error)

func (*MockChainClient) FetchNodeInfo added in v1.51.0

func (*MockChainClient) FetchOptedOutOfRewardsAccounts added in v1.51.0

func (c *MockChainClient) FetchOptedOutOfRewardsAccounts(ctx context.Context) (*exchangetypes.QueryOptedOutOfRewardsAccountsResponse, error)

func (*MockChainClient) FetchPendingTradeRewardPoints added in v1.51.0

func (c *MockChainClient) FetchPendingTradeRewardPoints(ctx context.Context, accounts []string) (*exchangetypes.QueryTradeRewardPointsResponse, error)

func (*MockChainClient) FetchPermissionsActorsByRole added in v1.56.0

func (c *MockChainClient) FetchPermissionsActorsByRole(ctx context.Context, denom, role string) (*permissionstypes.QueryActorsByRoleResponse, error)

func (*MockChainClient) FetchPermissionsModuleState added in v1.56.0

func (c *MockChainClient) FetchPermissionsModuleState(ctx context.Context) (*permissionstypes.QueryModuleStateResponse, error)

func (*MockChainClient) FetchPermissionsNamespace added in v1.56.0

func (c *MockChainClient) FetchPermissionsNamespace(ctx context.Context, denom string) (*permissionstypes.QueryNamespaceResponse, error)

func (*MockChainClient) FetchPermissionsNamespaceDenoms added in v1.56.0

func (c *MockChainClient) FetchPermissionsNamespaceDenoms(ctx context.Context) (*permissionstypes.QueryNamespaceDenomsResponse, error)

func (*MockChainClient) FetchPermissionsNamespaces added in v1.56.0

func (c *MockChainClient) FetchPermissionsNamespaces(ctx context.Context) (*permissionstypes.QueryNamespacesResponse, error)

func (*MockChainClient) FetchPermissionsPolicyManagerCapabilities added in v1.56.0

func (c *MockChainClient) FetchPermissionsPolicyManagerCapabilities(ctx context.Context, denom string) (*permissionstypes.QueryPolicyManagerCapabilitiesResponse, error)

func (*MockChainClient) FetchPermissionsPolicyStatuses added in v1.56.0

func (c *MockChainClient) FetchPermissionsPolicyStatuses(ctx context.Context, denom string) (*permissionstypes.QueryPolicyStatusesResponse, error)

func (*MockChainClient) FetchPermissionsRoleManager added in v1.56.0

func (c *MockChainClient) FetchPermissionsRoleManager(ctx context.Context, denom, manager string) (*permissionstypes.QueryRoleManagerResponse, error)

func (*MockChainClient) FetchPermissionsRoleManagers added in v1.56.0

func (c *MockChainClient) FetchPermissionsRoleManagers(ctx context.Context, denom string) (*permissionstypes.QueryRoleManagersResponse, error)

func (*MockChainClient) FetchPermissionsRolesByActor added in v1.56.0

func (c *MockChainClient) FetchPermissionsRolesByActor(ctx context.Context, denom, actor string) (*permissionstypes.QueryRolesByActorResponse, error)

func (*MockChainClient) FetchPermissionsVoucher added in v1.56.0

func (c *MockChainClient) FetchPermissionsVoucher(ctx context.Context, denom, address string) (*permissionstypes.QueryVoucherResponse, error)

func (*MockChainClient) FetchPermissionsVouchers added in v1.56.0

func (c *MockChainClient) FetchPermissionsVouchers(ctx context.Context, denom string) (*permissionstypes.QueryVouchersResponse, error)

func (*MockChainClient) FetchPinnedCodes added in v1.49.0

func (c *MockChainClient) FetchPinnedCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryPinnedCodesResponse, error)

func (*MockChainClient) FetchSpotMidPriceAndTOB added in v1.51.0

func (c *MockChainClient) FetchSpotMidPriceAndTOB(ctx context.Context, marketId string) (*exchangetypes.QuerySpotMidPriceAndTOBResponse, error)

func (*MockChainClient) FetchSubaccountDeposit added in v1.51.0

func (c *MockChainClient) FetchSubaccountDeposit(ctx context.Context, subaccountId, denom string) (*exchangetypes.QuerySubaccountDepositResponse, error)

func (*MockChainClient) FetchSubaccountDeposits added in v1.51.0

func (c *MockChainClient) FetchSubaccountDeposits(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountDepositsResponse, error)

Chain exchange module

func (*MockChainClient) FetchSubaccountOrderMetadata added in v1.51.0

func (c *MockChainClient) FetchSubaccountOrderMetadata(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountOrderMetadataResponse, error)

func (*MockChainClient) FetchSubaccountTradeNonce added in v1.51.0

func (c *MockChainClient) FetchSubaccountTradeNonce(ctx context.Context, subaccountId string) (*exchangetypes.QuerySubaccountTradeNonceResponse, error)

func (*MockChainClient) FetchSyncing added in v1.51.0

func (*MockChainClient) FetchTokenfactoryModuleState added in v1.49.0

func (c *MockChainClient) FetchTokenfactoryModuleState(ctx context.Context) (*tokenfactorytypes.QueryModuleStateResponse, error)

func (*MockChainClient) FetchTotalEscrowForDenom added in v1.51.0

func (c *MockChainClient) FetchTotalEscrowForDenom(ctx context.Context, denom string) (*ibctransfertypes.QueryTotalEscrowForDenomResponse, error)

func (*MockChainClient) FetchTradeRewardCampaign added in v1.51.0

func (*MockChainClient) FetchTradeRewardPoints added in v1.51.0

func (c *MockChainClient) FetchTradeRewardPoints(ctx context.Context, accounts []string) (*exchangetypes.QueryTradeRewardPointsResponse, error)

func (*MockChainClient) FetchTraderDerivativeConditionalOrders added in v1.51.0

func (c *MockChainClient) FetchTraderDerivativeConditionalOrders(ctx context.Context, subaccountId, marketId string) (*exchangetypes.QueryTraderDerivativeConditionalOrdersResponse, error)

func (*MockChainClient) FetchTxFeesParams added in v1.57.0

func (c *MockChainClient) FetchTxFeesParams(ctx context.Context) (*txfeestypes.QueryParamsResponse, error)

TxFees module

func (*MockChainClient) FetchValidatorCommission added in v1.51.0

func (c *MockChainClient) FetchValidatorCommission(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorCommissionResponse, error)

func (*MockChainClient) FetchValidatorDistributionInfo added in v1.51.0

func (c *MockChainClient) FetchValidatorDistributionInfo(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorDistributionInfoResponse, error)

Distribution module

func (*MockChainClient) FetchValidatorOutstandingRewards added in v1.51.0

func (c *MockChainClient) FetchValidatorOutstandingRewards(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorOutstandingRewardsResponse, error)

func (*MockChainClient) FetchValidatorSetByHeight added in v1.51.0

func (c *MockChainClient) FetchValidatorSetByHeight(ctx context.Context, height int64, pagination *query.PageRequest) (*cmtservice.GetValidatorSetByHeightResponse, error)

func (*MockChainClient) FetchValidatorSlashes added in v1.51.0

func (c *MockChainClient) FetchValidatorSlashes(ctx context.Context, validatorAddress string, startingHeight, endingHeight uint64, pagination *query.PageRequest) (*distributiontypes.QueryValidatorSlashesResponse, error)

func (*MockChainClient) FromAddress added in v1.49.0

func (c *MockChainClient) FromAddress() sdk.AccAddress

func (*MockChainClient) GetAccNonce added in v1.49.0

func (c *MockChainClient) GetAccNonce() (accNum, accSeq uint64)

func (*MockChainClient) GetAccount added in v1.49.0

func (c *MockChainClient) GetAccount(ctx context.Context, address string) (*authtypes.QueryAccountResponse, error)

func (*MockChainClient) GetAuthzGrants added in v1.49.0

func (*MockChainClient) GetBankBalance added in v1.49.0

func (c *MockChainClient) GetBankBalance(ctx context.Context, address, denom string) (*banktypes.QueryBalanceResponse, error)

func (*MockChainClient) GetBankBalances added in v1.49.0

func (c *MockChainClient) GetBankBalances(ctx context.Context, address string) (*banktypes.QueryAllBalancesResponse, error)

func (*MockChainClient) GetBankSendEnabled added in v1.49.0

func (c *MockChainClient) GetBankSendEnabled(ctx context.Context, denoms []string, pagination *query.PageRequest) (*banktypes.QuerySendEnabledResponse, error)

func (*MockChainClient) GetBankSpendableBalances added in v1.49.0

func (c *MockChainClient) GetBankSpendableBalances(ctx context.Context, address string, pagination *query.PageRequest) (*banktypes.QuerySpendableBalancesResponse, error)

func (*MockChainClient) GetBankSpendableBalancesByDenom added in v1.49.0

func (c *MockChainClient) GetBankSpendableBalancesByDenom(ctx context.Context, address, denom string) (*banktypes.QuerySpendableBalanceByDenomResponse, error)

func (*MockChainClient) GetBankSupplyOf added in v1.49.0

func (c *MockChainClient) GetBankSupplyOf(ctx context.Context, denom string) (*banktypes.QuerySupplyOfResponse, error)

func (*MockChainClient) GetBankTotalSupply added in v1.49.0

func (c *MockChainClient) GetBankTotalSupply(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryTotalSupplyResponse, error)

func (*MockChainClient) GetDenomMetadata added in v1.49.0

func (c *MockChainClient) GetDenomMetadata(ctx context.Context, denom string) (*banktypes.QueryDenomMetadataResponse, error)

func (*MockChainClient) GetDenomOwners added in v1.49.0

func (c *MockChainClient) GetDenomOwners(ctx context.Context, denom string, pagination *query.PageRequest) (*banktypes.QueryDenomOwnersResponse, error)

func (*MockChainClient) GetDenomsMetadata added in v1.49.0

func (c *MockChainClient) GetDenomsMetadata(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryDenomsMetadataResponse, error)

func (*MockChainClient) GetFeeDiscountInfo added in v1.49.0

func (*MockChainClient) GetGasFee added in v1.49.0

func (c *MockChainClient) GetGasFee() (string, error)

func (*MockChainClient) GetNetwork added in v1.54.0

func (c *MockChainClient) GetNetwork() common.Network

func (*MockChainClient) GetSubAccountNonce added in v1.49.0

func (c *MockChainClient) GetSubAccountNonce(ctx context.Context, subaccountId eth.Hash) (*exchangetypes.QuerySubaccountTradeNonceResponse, error)

func (*MockChainClient) GetTx added in v1.49.0

func (c *MockChainClient) GetTx(ctx context.Context, txHash string) (*txtypes.GetTxResponse, error)

func (*MockChainClient) OrderCancel added in v1.49.0

func (c *MockChainClient) OrderCancel(defaultSubaccountID eth.Hash, d *OrderCancelData) *exchangetypes.OrderData

func (*MockChainClient) QueryClient added in v1.49.0

func (c *MockChainClient) QueryClient() *grpc.ClientConn

func (*MockChainClient) QueueBroadcastMsg added in v1.49.0

func (c *MockChainClient) QueueBroadcastMsg(msgs ...sdk.Msg) error

func (*MockChainClient) RawContractState added in v1.49.0

func (c *MockChainClient) RawContractState(
	ctx context.Context,
	contractAddress string,
	queryData []byte,
) (*wasmtypes.QueryRawContractStateResponse, error)

func (*MockChainClient) SetGasPrice added in v1.57.0

func (c *MockChainClient) SetGasPrice(gasPrice int64)

func (*MockChainClient) SimulateMsg added in v1.49.0

func (c *MockChainClient) SimulateMsg(clientCtx client.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)

func (*MockChainClient) SimulateMsgWithContext added in v1.58.0

func (c *MockChainClient) SimulateMsgWithContext(ctx context.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)

func (*MockChainClient) SmartContractState added in v1.49.0

func (c *MockChainClient) SmartContractState(
	ctx context.Context,
	contractAddress string,
	queryData []byte,
) (*wasmtypes.QuerySmartContractStateResponse, error)

func (*MockChainClient) StreamEventOrderFail added in v1.49.0

func (c *MockChainClient) StreamEventOrderFail(sender string, failEventCh chan map[string]uint)

func (*MockChainClient) StreamEventOrderFailWithWebsocket added in v1.49.0

func (c *MockChainClient) StreamEventOrderFailWithWebsocket(sender string, websocket *rpchttp.HTTP, failEventCh chan map[string]uint)

func (*MockChainClient) StreamOrderbookUpdateEvents added in v1.49.0

func (c *MockChainClient) StreamOrderbookUpdateEvents(orderbookType OrderbookType, marketIDs []string, orderbookCh chan exchangetypes.Orderbook)

func (*MockChainClient) StreamOrderbookUpdateEventsWithWebsocket added in v1.49.0

func (c *MockChainClient) StreamOrderbookUpdateEventsWithWebsocket(orderbookType OrderbookType, marketIDs []string, websocket *rpchttp.HTTP, orderbookCh chan exchangetypes.Orderbook)

func (*MockChainClient) Subaccount added in v1.49.0

func (c *MockChainClient) Subaccount(account sdk.AccAddress, index int) eth.Hash

func (*MockChainClient) SyncBroadcastMsg added in v1.49.0

func (c *MockChainClient) SyncBroadcastMsg(msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) SyncBroadcastMsgWithContext added in v1.58.0

func (c *MockChainClient) SyncBroadcastMsgWithContext(ctx context.Context, pollInterval *time.Duration, maxRetries uint32, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) SyncBroadcastSignedTx added in v1.49.0

func (c *MockChainClient) SyncBroadcastSignedTx(tyBytes []byte) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) SyncBroadcastSignedTxWithContext added in v1.58.0

func (c *MockChainClient) SyncBroadcastSignedTxWithContext(ctx context.Context, txBytes []byte, pollInterval *time.Duration, maxRetries uint32) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClient) SynchronizeSubaccountNonce added in v1.49.0

func (c *MockChainClient) SynchronizeSubaccountNonce(subaccountId eth.Hash) error

func (*MockChainClient) UpdateSubaccountNonceFromChain added in v1.49.0

func (c *MockChainClient) UpdateSubaccountNonceFromChain() error

type MockChainClientV2 added in v1.58.0

type MockChainClientV2 struct {
	Network                           common.Network
	DenomsMetadataResponses           []*banktypes.QueryDenomsMetadataResponse
	QuerySpotMarketsV2Responses       []*exchangev2types.QuerySpotMarketsResponse
	QueryDerivativeMarketsV2Responses []*exchangev2types.QueryDerivativeMarketsResponse
	QueryBinaryMarketsV2Responses     []*exchangev2types.QueryBinaryMarketsResponse
}

func (*MockChainClientV2) ABCIQuery added in v1.58.0

func (c *MockChainClientV2) ABCIQuery(ctx context.Context, path string, data []byte, height int64, prove bool) (*cmtservice.ABCIQueryResponse, error)

func (*MockChainClientV2) AsyncBroadcastMsg added in v1.58.0

func (c *MockChainClientV2) AsyncBroadcastMsg(ctx context.Context, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClientV2) AsyncBroadcastSignedTx added in v1.58.0

func (c *MockChainClientV2) AsyncBroadcastSignedTx(ctx context.Context, txBytes []byte) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClientV2) BroadcastMsg added in v1.58.0

func (*MockChainClientV2) BroadcastSignedTx added in v1.58.0

func (c *MockChainClientV2) BroadcastSignedTx(ctx context.Context, txBytes []byte, broadcastMode txtypes.BroadcastMode) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClientV2) BuildExchangeAuthz added in v1.58.0

func (c *MockChainClientV2) BuildExchangeAuthz(granter, grantee string, authzType ExchangeAuthz, subaccountId string, markets []string, expireIn time.Time) *authztypes.MsgGrant

func (*MockChainClientV2) BuildExchangeBatchUpdateOrdersAuthz added in v1.58.0

func (c *MockChainClientV2) BuildExchangeBatchUpdateOrdersAuthz(
	granter string,
	grantee string,
	subaccountId string,
	spotMarkets []string,
	derivativeMarkets []string,
	expireIn time.Time,
) *authztypes.MsgGrant

func (*MockChainClientV2) BuildGenericAuthz added in v1.58.0

func (c *MockChainClientV2) BuildGenericAuthz(granter, grantee, msgtype string, expireIn time.Time) *authztypes.MsgGrant

func (*MockChainClientV2) BuildSignedTx added in v1.58.0

func (c *MockChainClientV2) BuildSignedTx(ctx context.Context, accNum, accSeq, initialGas uint64, gasPrice uint64, msg ...sdk.Msg) ([]byte, error)

func (*MockChainClientV2) CanSignTransactions added in v1.58.0

func (c *MockChainClientV2) CanSignTransactions() bool

func (*MockChainClientV2) ChainStreamV2 added in v1.58.0

func (*MockChainClientV2) ClientContext added in v1.58.0

func (c *MockChainClientV2) ClientContext() client.Context

func (*MockChainClientV2) Close added in v1.58.0

func (c *MockChainClientV2) Close()

func (*MockChainClientV2) ComputeOrderHashes added in v1.58.0

func (c *MockChainClientV2) ComputeOrderHashes(spotOrders []exchangev2types.SpotOrder, derivativeOrders []exchangev2types.DerivativeOrder, subaccountId ethcommon.Hash) (OrderHashes, error)

func (*MockChainClientV2) CreateDerivativeOrder added in v1.58.0

func (c *MockChainClientV2) CreateDerivativeOrder(defaultSubaccountID ethcommon.Hash, d *DerivativeOrderData, marketAssistant MarketsAssistant) *exchangetypes.DerivativeOrder

func (*MockChainClientV2) CreateDerivativeOrderV2 added in v1.58.0

func (c *MockChainClientV2) CreateDerivativeOrderV2(defaultSubaccountID ethcommon.Hash, d *DerivativeOrderData) *exchangev2types.DerivativeOrder

func (*MockChainClientV2) CreateSpotOrder added in v1.58.0

func (c *MockChainClientV2) CreateSpotOrder(defaultSubaccountID ethcommon.Hash, d *SpotOrderData, marketAssistant MarketsAssistant) *exchangetypes.SpotOrder

func (*MockChainClientV2) CreateSpotOrderV2 added in v1.58.0

func (c *MockChainClientV2) CreateSpotOrderV2(defaultSubaccountID ethcommon.Hash, d *SpotOrderData) *exchangev2types.SpotOrder

func (*MockChainClientV2) CurrentChainGasPrice added in v1.58.0

func (c *MockChainClientV2) CurrentChainGasPrice(ctx context.Context) int64

func (*MockChainClientV2) DefaultSubaccount added in v1.58.0

func (c *MockChainClientV2) DefaultSubaccount(acc sdk.AccAddress) ethcommon.Hash

func (*MockChainClientV2) FetchActiveStakeGrant added in v1.58.0

func (c *MockChainClientV2) FetchActiveStakeGrant(ctx context.Context, grantee string) (*exchangev2types.QueryActiveStakeGrantResponse, error)

func (*MockChainClientV2) FetchAggregateMarketVolume added in v1.58.0

func (c *MockChainClientV2) FetchAggregateMarketVolume(ctx context.Context, marketId string) (*exchangev2types.QueryAggregateMarketVolumeResponse, error)

func (*MockChainClientV2) FetchAggregateMarketVolumes added in v1.58.0

func (c *MockChainClientV2) FetchAggregateMarketVolumes(ctx context.Context, marketIDs []string) (*exchangev2types.QueryAggregateMarketVolumesResponse, error)

func (*MockChainClientV2) FetchAggregateVolume added in v1.58.0

func (c *MockChainClientV2) FetchAggregateVolume(ctx context.Context, account string) (*exchangev2types.QueryAggregateVolumeResponse, error)

func (*MockChainClientV2) FetchAggregateVolumes added in v1.58.0

func (c *MockChainClientV2) FetchAggregateVolumes(ctx context.Context, accounts, marketIDs []string) (*exchangev2types.QueryAggregateVolumesResponse, error)

func (*MockChainClientV2) FetchAllContractsState added in v1.58.0

func (c *MockChainClientV2) FetchAllContractsState(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryAllContractStateResponse, error)

func (*MockChainClientV2) FetchAllTokenPairs added in v1.58.0

func (c *MockChainClientV2) FetchAllTokenPairs(ctx context.Context, pagination *query.PageRequest) (*erc20types.QueryAllTokenPairsResponse, error)

ERC20 module

func (*MockChainClientV2) FetchBalanceMismatches added in v1.58.0

func (c *MockChainClientV2) FetchBalanceMismatches(ctx context.Context, dustFactor int64) (*exchangev2types.QueryBalanceMismatchesResponse, error)

func (*MockChainClientV2) FetchBalanceWithBalanceHolds added in v1.58.0

func (*MockChainClientV2) FetchBlockByHeight added in v1.58.0

func (c *MockChainClientV2) FetchBlockByHeight(ctx context.Context, height int64) (*cmtservice.GetBlockByHeightResponse, error)

func (*MockChainClientV2) FetchChainAccountAddressDerivativeOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainAccountAddressDerivativeOrders(ctx context.Context, marketId, address string) (*exchangev2types.QueryAccountAddressDerivativeOrdersResponse, error)

func (*MockChainClientV2) FetchChainAccountAddressSpotOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainAccountAddressSpotOrders(ctx context.Context, marketId, address string) (*exchangev2types.QueryAccountAddressSpotOrdersResponse, error)

func (*MockChainClientV2) FetchChainBinaryOptionsMarkets added in v1.58.0

func (c *MockChainClientV2) FetchChainBinaryOptionsMarkets(ctx context.Context, status string) (*exchangev2types.QueryBinaryMarketsResponse, error)

func (*MockChainClientV2) FetchChainDerivativeMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainDerivativeMarket(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMarketResponse, error)

func (*MockChainClientV2) FetchChainDerivativeMarkets added in v1.58.0

func (c *MockChainClientV2) FetchChainDerivativeMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangev2types.QueryDerivativeMarketsResponse, error)

func (*MockChainClientV2) FetchChainDerivativeOrderbook added in v1.58.0

func (c *MockChainClientV2) FetchChainDerivativeOrderbook(ctx context.Context, marketId string, limit uint64, limitCumulativeNotional sdkmath.LegacyDec) (*exchangev2types.QueryDerivativeOrderbookResponse, error)

func (*MockChainClientV2) FetchChainDerivativeOrdersByHashes added in v1.58.0

func (c *MockChainClientV2) FetchChainDerivativeOrdersByHashes(ctx context.Context, marketId, subaccountId string, orderHashes []string) (*exchangev2types.QueryDerivativeOrdersByHashesResponse, error)

func (*MockChainClientV2) FetchChainExpiryFuturesMarketInfo added in v1.58.0

func (c *MockChainClientV2) FetchChainExpiryFuturesMarketInfo(ctx context.Context, marketId string) (*exchangev2types.QueryExpiryFuturesMarketInfoResponse, error)

func (*MockChainClientV2) FetchChainFullSpotMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainFullSpotMarket(ctx context.Context, marketId string, withMidPriceAndTob bool) (*exchangev2types.QueryFullSpotMarketResponse, error)

func (*MockChainClientV2) FetchChainFullSpotMarkets added in v1.58.0

func (c *MockChainClientV2) FetchChainFullSpotMarkets(ctx context.Context, status string, marketIDs []string, withMidPriceAndTob bool) (*exchangev2types.QueryFullSpotMarketsResponse, error)

func (*MockChainClientV2) FetchChainPerpetualMarketFunding added in v1.58.0

func (c *MockChainClientV2) FetchChainPerpetualMarketFunding(ctx context.Context, marketId string) (*exchangev2types.QueryPerpetualMarketFundingResponse, error)

func (*MockChainClientV2) FetchChainPerpetualMarketInfo added in v1.58.0

func (c *MockChainClientV2) FetchChainPerpetualMarketInfo(ctx context.Context, marketId string) (*exchangev2types.QueryPerpetualMarketInfoResponse, error)

func (*MockChainClientV2) FetchChainPositions added in v1.58.0

func (*MockChainClientV2) FetchChainPositionsInMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainPositionsInMarket(ctx context.Context, marketId string) (*exchangev2types.QueryPositionsInMarketResponse, error)

func (*MockChainClientV2) FetchChainSpotMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainSpotMarket(ctx context.Context, marketId string) (*exchangev2types.QuerySpotMarketResponse, error)

func (*MockChainClientV2) FetchChainSpotMarkets added in v1.58.0

func (c *MockChainClientV2) FetchChainSpotMarkets(ctx context.Context, status string, marketIDs []string) (*exchangev2types.QuerySpotMarketsResponse, error)

func (*MockChainClientV2) FetchChainSpotOrderbook added in v1.58.0

func (c *MockChainClientV2) FetchChainSpotOrderbook(ctx context.Context, marketId string, limit uint64, orderSide exchangev2types.OrderSide, limitCumulativeNotional, limitCumulativeQuantity sdkmath.LegacyDec) (*exchangev2types.QuerySpotOrderbookResponse, error)

func (*MockChainClientV2) FetchChainSpotOrdersByHashes added in v1.58.0

func (c *MockChainClientV2) FetchChainSpotOrdersByHashes(ctx context.Context, marketId, subaccountId string, orderHashes []string) (*exchangev2types.QuerySpotOrdersByHashesResponse, error)

func (*MockChainClientV2) FetchChainSubaccountEffectivePositionInMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainSubaccountEffectivePositionInMarket(ctx context.Context, subaccountId, marketId string) (*exchangev2types.QuerySubaccountEffectivePositionInMarketResponse, error)

func (*MockChainClientV2) FetchChainSubaccountOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainSubaccountOrders(ctx context.Context, subaccountId, marketId string) (*exchangev2types.QuerySubaccountOrdersResponse, error)

func (*MockChainClientV2) FetchChainSubaccountPositionInMarket added in v1.58.0

func (c *MockChainClientV2) FetchChainSubaccountPositionInMarket(ctx context.Context, subaccountId, marketId string) (*exchangev2types.QuerySubaccountPositionInMarketResponse, error)

func (*MockChainClientV2) FetchChainSubaccountPositions added in v1.58.0

func (c *MockChainClientV2) FetchChainSubaccountPositions(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountPositionsResponse, error)

func (*MockChainClientV2) FetchChainTraderDerivativeOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainTraderDerivativeOrders(ctx context.Context, marketId, subaccountId string) (*exchangev2types.QueryTraderDerivativeOrdersResponse, error)

func (*MockChainClientV2) FetchChainTraderDerivativeTransientOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainTraderDerivativeTransientOrders(ctx context.Context, marketId, subaccountId string) (*exchangev2types.QueryTraderDerivativeOrdersResponse, error)

func (*MockChainClientV2) FetchChainTraderSpotOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainTraderSpotOrders(ctx context.Context, marketId, subaccountId string) (*exchangev2types.QueryTraderSpotOrdersResponse, error)

func (*MockChainClientV2) FetchChainTraderSpotTransientOrders added in v1.58.0

func (c *MockChainClientV2) FetchChainTraderSpotTransientOrders(ctx context.Context, marketId, subaccountId string) (*exchangev2types.QueryTraderSpotOrdersResponse, error)

func (*MockChainClientV2) FetchCode added in v1.58.0

func (*MockChainClientV2) FetchCodes added in v1.58.0

func (*MockChainClientV2) FetchCommunityPool added in v1.58.0

func (*MockChainClientV2) FetchContractHistory added in v1.58.0

func (c *MockChainClientV2) FetchContractHistory(ctx context.Context, address string, pagination *query.PageRequest) (*wasmtypes.QueryContractHistoryResponse, error)

func (*MockChainClientV2) FetchContractInfo added in v1.58.0

func (c *MockChainClientV2) FetchContractInfo(ctx context.Context, address string) (*wasmtypes.QueryContractInfoResponse, error)

func (*MockChainClientV2) FetchContractsByCode added in v1.58.0

func (c *MockChainClientV2) FetchContractsByCode(ctx context.Context, codeId uint64, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCodeResponse, error)

func (*MockChainClientV2) FetchContractsByCreator added in v1.58.0

func (c *MockChainClientV2) FetchContractsByCreator(ctx context.Context, creator string, pagination *query.PageRequest) (*wasmtypes.QueryContractsByCreatorResponse, error)

func (*MockChainClientV2) FetchDelegationRewards added in v1.58.0

func (c *MockChainClientV2) FetchDelegationRewards(ctx context.Context, delegatorAddress, validatorAddress string) (*distributiontypes.QueryDelegationRewardsResponse, error)

func (*MockChainClientV2) FetchDelegationTotalRewards added in v1.58.0

func (c *MockChainClientV2) FetchDelegationTotalRewards(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegationTotalRewardsResponse, error)

func (*MockChainClientV2) FetchDelegatorValidators added in v1.58.0

func (c *MockChainClientV2) FetchDelegatorValidators(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorValidatorsResponse, error)

func (*MockChainClientV2) FetchDelegatorWithdrawAddress added in v1.58.0

func (c *MockChainClientV2) FetchDelegatorWithdrawAddress(ctx context.Context, delegatorAddress string) (*distributiontypes.QueryDelegatorWithdrawAddressResponse, error)

func (*MockChainClientV2) FetchDenomAuthorityMetadata added in v1.58.0

func (c *MockChainClientV2) FetchDenomAuthorityMetadata(ctx context.Context, creator, subDenom string) (*tokenfactorytypes.QueryDenomAuthorityMetadataResponse, error)

func (*MockChainClientV2) FetchDenomDecimal added in v1.58.0

func (*MockChainClientV2) FetchDenomDecimals added in v1.58.0

func (c *MockChainClientV2) FetchDenomDecimals(ctx context.Context, denoms []string) (*exchangev2types.QueryDenomDecimalsResponse, error)

func (*MockChainClientV2) FetchDenomHash added in v1.58.0

func (*MockChainClientV2) FetchDenomMinNotional added in v1.58.0

func (*MockChainClientV2) FetchDenomMinNotionals added in v1.58.0

func (*MockChainClientV2) FetchDenomTrace added in v1.58.0

IBC Transfer module

func (*MockChainClientV2) FetchDenomTraces added in v1.58.0

func (*MockChainClientV2) FetchDenomsFromCreator added in v1.58.0

func (*MockChainClientV2) FetchDerivativeMarketAddress added in v1.58.0

func (c *MockChainClientV2) FetchDerivativeMarketAddress(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMarketAddressResponse, error)

func (*MockChainClientV2) FetchDerivativeMidPriceAndTOB added in v1.58.0

func (c *MockChainClientV2) FetchDerivativeMidPriceAndTOB(ctx context.Context, marketId string) (*exchangev2types.QueryDerivativeMidPriceAndTOBResponse, error)

func (*MockChainClientV2) FetchEVMAccount added in v1.58.0

func (c *MockChainClientV2) FetchEVMAccount(ctx context.Context, address string) (*evmtypes.QueryAccountResponse, error)

EVM module

func (*MockChainClientV2) FetchEVMBalance added in v1.58.0

func (c *MockChainClientV2) FetchEVMBalance(ctx context.Context, address string) (*evmtypes.QueryBalanceResponse, error)

func (*MockChainClientV2) FetchEVMBaseFee added in v1.58.0

func (*MockChainClientV2) FetchEVMCode added in v1.58.0

func (c *MockChainClientV2) FetchEVMCode(ctx context.Context, address string) (*evmtypes.QueryCodeResponse, error)

func (*MockChainClientV2) FetchEVMCosmosAccount added in v1.58.0

func (c *MockChainClientV2) FetchEVMCosmosAccount(ctx context.Context, address string) (*evmtypes.QueryCosmosAccountResponse, error)

func (*MockChainClientV2) FetchEVMStorage added in v1.58.0

func (c *MockChainClientV2) FetchEVMStorage(ctx context.Context, address string, key *string) (*evmtypes.QueryStorageResponse, error)

func (*MockChainClientV2) FetchEVMValidatorAccount added in v1.58.0

func (c *MockChainClientV2) FetchEVMValidatorAccount(ctx context.Context, consAddress string) (*evmtypes.QueryValidatorAccountResponse, error)

func (*MockChainClientV2) FetchEipBaseFee added in v1.58.0

func (*MockChainClientV2) FetchEscrowAddress added in v1.58.0

func (c *MockChainClientV2) FetchEscrowAddress(ctx context.Context, portId, channelId string) (*ibctransfertypes.QueryEscrowAddressResponse, error)

func (*MockChainClientV2) FetchExchangeBalances added in v1.58.0

func (*MockChainClientV2) FetchFeeDiscountAccountInfo added in v1.58.0

func (c *MockChainClientV2) FetchFeeDiscountAccountInfo(ctx context.Context, account string) (*exchangev2types.QueryFeeDiscountAccountInfoResponse, error)

func (*MockChainClientV2) FetchFeeDiscountSchedule added in v1.58.0

func (*MockChainClientV2) FetchFeeDiscountTierStatistics added in v1.58.0

func (*MockChainClientV2) FetchGrantAuthorization added in v1.58.0

func (c *MockChainClientV2) FetchGrantAuthorization(ctx context.Context, granter, grantee string) (*exchangev2types.QueryGrantAuthorizationResponse, error)

func (*MockChainClientV2) FetchGrantAuthorizations added in v1.58.0

func (c *MockChainClientV2) FetchGrantAuthorizations(ctx context.Context, granter string) (*exchangev2types.QueryGrantAuthorizationsResponse, error)

func (*MockChainClientV2) FetchHistoricalTradeRecords added in v1.58.0

func (c *MockChainClientV2) FetchHistoricalTradeRecords(ctx context.Context, marketId string) (*exchangev2types.QueryHistoricalTradeRecordsResponse, error)

func (*MockChainClientV2) FetchIBCChannel added in v1.58.0

func (c *MockChainClientV2) FetchIBCChannel(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryChannelResponse, error)

IBC Core Channel module

func (*MockChainClientV2) FetchIBCChannelClientState added in v1.58.0

func (c *MockChainClientV2) FetchIBCChannelClientState(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryChannelClientStateResponse, error)

func (*MockChainClientV2) FetchIBCChannelConsensusState added in v1.58.0

func (c *MockChainClientV2) FetchIBCChannelConsensusState(ctx context.Context, portId, channelId string, revisionNumber, revisionHeight uint64) (*ibcchanneltypes.QueryChannelConsensusStateResponse, error)

func (*MockChainClientV2) FetchIBCChannels added in v1.58.0

func (*MockChainClientV2) FetchIBCClientConnections added in v1.58.0

func (c *MockChainClientV2) FetchIBCClientConnections(ctx context.Context, clientId string) (*ibcconnectiontypes.QueryClientConnectionsResponse, error)

func (*MockChainClientV2) FetchIBCClientParams added in v1.58.0

func (*MockChainClientV2) FetchIBCClientState added in v1.58.0

func (c *MockChainClientV2) FetchIBCClientState(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStateResponse, error)

IBC Core Chain module

func (*MockChainClientV2) FetchIBCClientStates added in v1.58.0

func (c *MockChainClientV2) FetchIBCClientStates(ctx context.Context, pagination *query.PageRequest) (*ibcclienttypes.QueryClientStatesResponse, error)

func (*MockChainClientV2) FetchIBCClientStatus added in v1.58.0

func (c *MockChainClientV2) FetchIBCClientStatus(ctx context.Context, clientId string) (*ibcclienttypes.QueryClientStatusResponse, error)

func (*MockChainClientV2) FetchIBCConnection added in v1.58.0

func (c *MockChainClientV2) FetchIBCConnection(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionResponse, error)

IBC Core Connection module

func (*MockChainClientV2) FetchIBCConnectionChannels added in v1.58.0

func (c *MockChainClientV2) FetchIBCConnectionChannels(ctx context.Context, connection string, pagination *query.PageRequest) (*ibcchanneltypes.QueryConnectionChannelsResponse, error)

func (*MockChainClientV2) FetchIBCConnectionClientState added in v1.58.0

func (c *MockChainClientV2) FetchIBCConnectionClientState(ctx context.Context, connectionId string) (*ibcconnectiontypes.QueryConnectionClientStateResponse, error)

func (*MockChainClientV2) FetchIBCConnectionConsensusState added in v1.58.0

func (c *MockChainClientV2) FetchIBCConnectionConsensusState(ctx context.Context, connectionId string, revisionNumber, revisionHeight uint64) (*ibcconnectiontypes.QueryConnectionConsensusStateResponse, error)

func (*MockChainClientV2) FetchIBCConnectionParams added in v1.58.0

func (*MockChainClientV2) FetchIBCConnections added in v1.58.0

func (*MockChainClientV2) FetchIBCConsensusState added in v1.58.0

func (c *MockChainClientV2) FetchIBCConsensusState(ctx context.Context, clientId string, revisionNumber, revisionHeight uint64, latestHeight bool) (*ibcclienttypes.QueryConsensusStateResponse, error)

func (*MockChainClientV2) FetchIBCConsensusStateHeights added in v1.58.0

func (c *MockChainClientV2) FetchIBCConsensusStateHeights(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStateHeightsResponse, error)

func (*MockChainClientV2) FetchIBCConsensusStates added in v1.58.0

func (c *MockChainClientV2) FetchIBCConsensusStates(ctx context.Context, clientId string, pagination *query.PageRequest) (*ibcclienttypes.QueryConsensusStatesResponse, error)

func (*MockChainClientV2) FetchIBCNextSequenceReceive added in v1.58.0

func (c *MockChainClientV2) FetchIBCNextSequenceReceive(ctx context.Context, portId, channelId string) (*ibcchanneltypes.QueryNextSequenceReceiveResponse, error)

func (*MockChainClientV2) FetchIBCPacketAcknowledgement added in v1.58.0

func (c *MockChainClientV2) FetchIBCPacketAcknowledgement(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketAcknowledgementResponse, error)

func (*MockChainClientV2) FetchIBCPacketAcknowledgements added in v1.58.0

func (c *MockChainClientV2) FetchIBCPacketAcknowledgements(ctx context.Context, portId, channelId string, packetCommitmentSequences []uint64, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketAcknowledgementsResponse, error)

func (*MockChainClientV2) FetchIBCPacketCommitment added in v1.58.0

func (c *MockChainClientV2) FetchIBCPacketCommitment(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketCommitmentResponse, error)

func (*MockChainClientV2) FetchIBCPacketCommitments added in v1.58.0

func (c *MockChainClientV2) FetchIBCPacketCommitments(ctx context.Context, portId, channelId string, pagination *query.PageRequest) (*ibcchanneltypes.QueryPacketCommitmentsResponse, error)

func (*MockChainClientV2) FetchIBCPacketReceipt added in v1.58.0

func (c *MockChainClientV2) FetchIBCPacketReceipt(ctx context.Context, portId, channelId string, sequence uint64) (*ibcchanneltypes.QueryPacketReceiptResponse, error)

func (*MockChainClientV2) FetchIBCUnreceivedAcks added in v1.58.0

func (c *MockChainClientV2) FetchIBCUnreceivedAcks(ctx context.Context, portId, channelId string, packetAckSequences []uint64) (*ibcchanneltypes.QueryUnreceivedAcksResponse, error)

func (*MockChainClientV2) FetchIBCUnreceivedPackets added in v1.58.0

func (c *MockChainClientV2) FetchIBCUnreceivedPackets(ctx context.Context, portId, channelId string, packetCommitmentSequences []uint64) (*ibcchanneltypes.QueryUnreceivedPacketsResponse, error)

func (*MockChainClientV2) FetchIBCUpgradedClientState added in v1.58.0

func (*MockChainClientV2) FetchIBCUpgradedConsensusState added in v1.58.0

func (c *MockChainClientV2) FetchIBCUpgradedConsensusState(ctx context.Context) (*ibcclienttypes.QueryUpgradedConsensusStateResponse, error)

func (*MockChainClientV2) FetchIsOptedOutOfRewards added in v1.58.0

func (c *MockChainClientV2) FetchIsOptedOutOfRewards(ctx context.Context, account string) (*exchangev2types.QueryIsOptedOutOfRewardsResponse, error)

func (*MockChainClientV2) FetchL3DerivativeOrderbook added in v1.58.0

func (c *MockChainClientV2) FetchL3DerivativeOrderbook(ctx context.Context, marketId string) (*exchangev2types.QueryFullDerivativeOrderbookResponse, error)

func (*MockChainClientV2) FetchL3SpotOrderbook added in v1.58.0

func (c *MockChainClientV2) FetchL3SpotOrderbook(ctx context.Context, marketId string) (*exchangev2types.QueryFullSpotOrderbookResponse, error)

func (*MockChainClientV2) FetchLatestBlock added in v1.58.0

func (*MockChainClientV2) FetchLatestValidatorSet added in v1.58.0

func (c *MockChainClientV2) FetchLatestValidatorSet(ctx context.Context) (*cmtservice.GetLatestValidatorSetResponse, error)

func (*MockChainClientV2) FetchMarketAtomicExecutionFeeMultiplier added in v1.58.0

func (c *MockChainClientV2) FetchMarketAtomicExecutionFeeMultiplier(ctx context.Context, marketId string) (*exchangev2types.QueryMarketAtomicExecutionFeeMultiplierResponse, error)

func (*MockChainClientV2) FetchMarketBalance added in v1.58.0

func (c *MockChainClientV2) FetchMarketBalance(ctx context.Context, marketId string) (*exchangev2types.QueryMarketBalanceResponse, error)

func (*MockChainClientV2) FetchMarketBalances added in v1.58.0

func (*MockChainClientV2) FetchMarketIDFromVault added in v1.58.0

func (c *MockChainClientV2) FetchMarketIDFromVault(ctx context.Context, vaultAddress string) (*exchangev2types.QueryMarketIDFromVaultResponse, error)

func (*MockChainClientV2) FetchMarketVolatility added in v1.58.0

func (c *MockChainClientV2) FetchMarketVolatility(ctx context.Context, marketId string, tradeHistoryOptions *exchangev2types.TradeHistoryOptions) (*exchangev2types.QueryMarketVolatilityResponse, error)

func (*MockChainClientV2) FetchMitoVaultInfos added in v1.58.0

func (*MockChainClientV2) FetchNodeInfo added in v1.58.0

func (*MockChainClientV2) FetchOptedOutOfRewardsAccounts added in v1.58.0

func (*MockChainClientV2) FetchPendingTradeRewardPoints added in v1.58.0

func (c *MockChainClientV2) FetchPendingTradeRewardPoints(ctx context.Context, accounts []string) (*exchangev2types.QueryTradeRewardPointsResponse, error)

func (*MockChainClientV2) FetchPermissionsActorsByRole added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsActorsByRole(ctx context.Context, denom, role string) (*permissionstypes.QueryActorsByRoleResponse, error)

func (*MockChainClientV2) FetchPermissionsModuleState added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsModuleState(ctx context.Context) (*permissionstypes.QueryModuleStateResponse, error)

func (*MockChainClientV2) FetchPermissionsNamespace added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsNamespace(ctx context.Context, denom string) (*permissionstypes.QueryNamespaceResponse, error)

func (*MockChainClientV2) FetchPermissionsNamespaceDenoms added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsNamespaceDenoms(ctx context.Context) (*permissionstypes.QueryNamespaceDenomsResponse, error)

func (*MockChainClientV2) FetchPermissionsNamespaces added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsNamespaces(ctx context.Context) (*permissionstypes.QueryNamespacesResponse, error)

func (*MockChainClientV2) FetchPermissionsPolicyManagerCapabilities added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsPolicyManagerCapabilities(ctx context.Context, denom string) (*permissionstypes.QueryPolicyManagerCapabilitiesResponse, error)

func (*MockChainClientV2) FetchPermissionsPolicyStatuses added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsPolicyStatuses(ctx context.Context, denom string) (*permissionstypes.QueryPolicyStatusesResponse, error)

func (*MockChainClientV2) FetchPermissionsRoleManager added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsRoleManager(ctx context.Context, denom, manager string) (*permissionstypes.QueryRoleManagerResponse, error)

func (*MockChainClientV2) FetchPermissionsRoleManagers added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsRoleManagers(ctx context.Context, denom string) (*permissionstypes.QueryRoleManagersResponse, error)

func (*MockChainClientV2) FetchPermissionsRolesByActor added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsRolesByActor(ctx context.Context, denom, actor string) (*permissionstypes.QueryRolesByActorResponse, error)

func (*MockChainClientV2) FetchPermissionsVoucher added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsVoucher(ctx context.Context, denom, address string) (*permissionstypes.QueryVoucherResponse, error)

func (*MockChainClientV2) FetchPermissionsVouchers added in v1.58.0

func (c *MockChainClientV2) FetchPermissionsVouchers(ctx context.Context, denom string) (*permissionstypes.QueryVouchersResponse, error)

func (*MockChainClientV2) FetchPinnedCodes added in v1.58.0

func (c *MockChainClientV2) FetchPinnedCodes(ctx context.Context, pagination *query.PageRequest) (*wasmtypes.QueryPinnedCodesResponse, error)

func (*MockChainClientV2) FetchSpotMidPriceAndTOB added in v1.58.0

func (c *MockChainClientV2) FetchSpotMidPriceAndTOB(ctx context.Context, marketId string) (*exchangev2types.QuerySpotMidPriceAndTOBResponse, error)

func (*MockChainClientV2) FetchSubaccountDeposit added in v1.58.0

func (c *MockChainClientV2) FetchSubaccountDeposit(ctx context.Context, subaccountId, denom string) (*exchangev2types.QuerySubaccountDepositResponse, error)

func (*MockChainClientV2) FetchSubaccountDeposits added in v1.58.0

func (c *MockChainClientV2) FetchSubaccountDeposits(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountDepositsResponse, error)

Chain exchange V2 module

func (*MockChainClientV2) FetchSubaccountOrderMetadata added in v1.58.0

func (c *MockChainClientV2) FetchSubaccountOrderMetadata(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountOrderMetadataResponse, error)

func (*MockChainClientV2) FetchSubaccountTradeNonce added in v1.58.0

func (c *MockChainClientV2) FetchSubaccountTradeNonce(ctx context.Context, subaccountId string) (*exchangev2types.QuerySubaccountTradeNonceResponse, error)

func (*MockChainClientV2) FetchSyncing added in v1.58.0

func (*MockChainClientV2) FetchTokenPairByDenom added in v1.58.0

func (c *MockChainClientV2) FetchTokenPairByDenom(ctx context.Context, bankDenom string) (*erc20types.QueryTokenPairByDenomResponse, error)

func (*MockChainClientV2) FetchTokenPairByERC20Address added in v1.58.0

func (c *MockChainClientV2) FetchTokenPairByERC20Address(ctx context.Context, erc20Address string) (*erc20types.QueryTokenPairByERC20AddressResponse, error)

func (*MockChainClientV2) FetchTokenfactoryModuleState added in v1.58.0

func (c *MockChainClientV2) FetchTokenfactoryModuleState(ctx context.Context) (*tokenfactorytypes.QueryModuleStateResponse, error)

func (*MockChainClientV2) FetchTotalEscrowForDenom added in v1.58.0

func (*MockChainClientV2) FetchTradeRewardCampaign added in v1.58.0

func (*MockChainClientV2) FetchTradeRewardPoints added in v1.58.0

func (c *MockChainClientV2) FetchTradeRewardPoints(ctx context.Context, accounts []string) (*exchangev2types.QueryTradeRewardPointsResponse, error)

func (*MockChainClientV2) FetchTraderDerivativeConditionalOrders added in v1.58.0

func (c *MockChainClientV2) FetchTraderDerivativeConditionalOrders(ctx context.Context, subaccountId, marketId string) (*exchangev2types.QueryTraderDerivativeConditionalOrdersResponse, error)

func (*MockChainClientV2) FetchTxFeesParams added in v1.58.0

func (c *MockChainClientV2) FetchTxFeesParams(ctx context.Context) (*txfeestypes.QueryParamsResponse, error)

TxFees module

func (*MockChainClientV2) FetchValidatorCommission added in v1.58.0

func (c *MockChainClientV2) FetchValidatorCommission(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorCommissionResponse, error)

func (*MockChainClientV2) FetchValidatorDistributionInfo added in v1.58.0

func (c *MockChainClientV2) FetchValidatorDistributionInfo(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorDistributionInfoResponse, error)

Distribution module

func (*MockChainClientV2) FetchValidatorOutstandingRewards added in v1.58.0

func (c *MockChainClientV2) FetchValidatorOutstandingRewards(ctx context.Context, validatorAddress string) (*distributiontypes.QueryValidatorOutstandingRewardsResponse, error)

func (*MockChainClientV2) FetchValidatorSetByHeight added in v1.58.0

func (c *MockChainClientV2) FetchValidatorSetByHeight(ctx context.Context, height int64, pagination *query.PageRequest) (*cmtservice.GetValidatorSetByHeightResponse, error)

func (*MockChainClientV2) FetchValidatorSlashes added in v1.58.0

func (c *MockChainClientV2) FetchValidatorSlashes(ctx context.Context, validatorAddress string, startingHeight, endingHeight uint64, pagination *query.PageRequest) (*distributiontypes.QueryValidatorSlashesResponse, error)

func (*MockChainClientV2) FromAddress added in v1.58.0

func (c *MockChainClientV2) FromAddress() sdk.AccAddress

func (*MockChainClientV2) GetAccNonce added in v1.58.0

func (c *MockChainClientV2) GetAccNonce() (accNum, accSeq uint64)

func (*MockChainClientV2) GetAccount added in v1.58.0

func (*MockChainClientV2) GetAuthzGrants added in v1.58.0

func (*MockChainClientV2) GetBankBalance added in v1.58.0

func (c *MockChainClientV2) GetBankBalance(ctx context.Context, address, denom string) (*banktypes.QueryBalanceResponse, error)

func (*MockChainClientV2) GetBankBalances added in v1.58.0

func (c *MockChainClientV2) GetBankBalances(ctx context.Context, address string) (*banktypes.QueryAllBalancesResponse, error)

func (*MockChainClientV2) GetBankSendEnabled added in v1.58.0

func (c *MockChainClientV2) GetBankSendEnabled(ctx context.Context, denoms []string, pagination *query.PageRequest) (*banktypes.QuerySendEnabledResponse, error)

func (*MockChainClientV2) GetBankSpendableBalances added in v1.58.0

func (c *MockChainClientV2) GetBankSpendableBalances(ctx context.Context, address string, pagination *query.PageRequest) (*banktypes.QuerySpendableBalancesResponse, error)

func (*MockChainClientV2) GetBankSpendableBalancesByDenom added in v1.58.0

func (c *MockChainClientV2) GetBankSpendableBalancesByDenom(ctx context.Context, address, denom string) (*banktypes.QuerySpendableBalanceByDenomResponse, error)

func (*MockChainClientV2) GetBankSupplyOf added in v1.58.0

func (c *MockChainClientV2) GetBankSupplyOf(ctx context.Context, denom string) (*banktypes.QuerySupplyOfResponse, error)

func (*MockChainClientV2) GetBankTotalSupply added in v1.58.0

func (c *MockChainClientV2) GetBankTotalSupply(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryTotalSupplyResponse, error)

func (*MockChainClientV2) GetDenomMetadata added in v1.58.0

func (*MockChainClientV2) GetDenomOwners added in v1.58.0

func (c *MockChainClientV2) GetDenomOwners(ctx context.Context, denom string, pagination *query.PageRequest) (*banktypes.QueryDenomOwnersResponse, error)

func (*MockChainClientV2) GetDenomsMetadata added in v1.58.0

func (c *MockChainClientV2) GetDenomsMetadata(ctx context.Context, pagination *query.PageRequest) (*banktypes.QueryDenomsMetadataResponse, error)

func (*MockChainClientV2) GetFeeDiscountInfo added in v1.58.0

func (*MockChainClientV2) GetGasFee added in v1.58.0

func (c *MockChainClientV2) GetGasFee() (string, error)

func (*MockChainClientV2) GetNetwork added in v1.58.0

func (c *MockChainClientV2) GetNetwork() common.Network

func (*MockChainClientV2) GetSubAccountNonce added in v1.58.0

func (*MockChainClientV2) GetTx added in v1.58.0

func (*MockChainClientV2) OrderCancel added in v1.58.0

func (c *MockChainClientV2) OrderCancel(defaultSubaccountID ethcommon.Hash, d *OrderCancelData) *exchangetypes.OrderData

func (*MockChainClientV2) OrderCancelV2 added in v1.58.0

func (c *MockChainClientV2) OrderCancelV2(defaultSubaccountID ethcommon.Hash, d *OrderCancelData) *exchangev2types.OrderData

func (*MockChainClientV2) QueryClient added in v1.58.0

func (c *MockChainClientV2) QueryClient() *grpc.ClientConn

func (*MockChainClientV2) QueueBroadcastMsg added in v1.58.0

func (c *MockChainClientV2) QueueBroadcastMsg(msgs ...sdk.Msg) error

func (*MockChainClientV2) RawContractState added in v1.58.0

func (c *MockChainClientV2) RawContractState(
	ctx context.Context,
	contractAddress string,
	queryData []byte,
) (*wasmtypes.QueryRawContractStateResponse, error)

func (*MockChainClientV2) SetGasPrice added in v1.58.0

func (c *MockChainClientV2) SetGasPrice(gasPrice int64)

func (*MockChainClientV2) SimulateMsg added in v1.58.0

func (c *MockChainClientV2) SimulateMsg(ctx context.Context, msgs ...sdk.Msg) (*txtypes.SimulateResponse, error)

func (*MockChainClientV2) SmartContractState added in v1.58.0

func (c *MockChainClientV2) SmartContractState(
	ctx context.Context,
	contractAddress string,
	queryData []byte,
) (*wasmtypes.QuerySmartContractStateResponse, error)

func (*MockChainClientV2) StreamEventOrderFail added in v1.58.0

func (c *MockChainClientV2) StreamEventOrderFail(sender string, failEventCh chan map[string]uint)

func (*MockChainClientV2) StreamEventOrderFailWithWebsocket added in v1.58.0

func (c *MockChainClientV2) StreamEventOrderFailWithWebsocket(sender string, websocket *rpchttp.HTTP, failEventCh chan map[string]uint)

func (*MockChainClientV2) StreamOrderbookUpdateEvents added in v1.58.0

func (c *MockChainClientV2) StreamOrderbookUpdateEvents(orderbookType OrderbookType, marketIDs []string, orderbookCh chan exchangetypes.Orderbook)

func (*MockChainClientV2) StreamOrderbookUpdateEventsWithWebsocket added in v1.58.0

func (c *MockChainClientV2) StreamOrderbookUpdateEventsWithWebsocket(orderbookType OrderbookType, marketIDs []string, websocket *rpchttp.HTTP, orderbookCh chan exchangetypes.Orderbook)

func (*MockChainClientV2) Subaccount added in v1.58.0

func (c *MockChainClientV2) Subaccount(account sdk.AccAddress, index int) ethcommon.Hash

func (*MockChainClientV2) SyncBroadcastMsg added in v1.58.0

func (c *MockChainClientV2) SyncBroadcastMsg(ctx context.Context, pollInterval *time.Duration, maxRetries uint32, msgs ...sdk.Msg) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClientV2) SyncBroadcastSignedTx added in v1.58.0

func (c *MockChainClientV2) SyncBroadcastSignedTx(ctx context.Context, txBytes []byte, pollInterval *time.Duration, maxRetries uint32) (*txtypes.BroadcastTxResponse, error)

func (*MockChainClientV2) SynchronizeSubaccountNonce added in v1.58.0

func (c *MockChainClientV2) SynchronizeSubaccountNonce(subaccountId ethcommon.Hash) error

func (*MockChainClientV2) UpdateSubaccountNonceFromChain added in v1.58.0

func (c *MockChainClientV2) UpdateSubaccountNonceFromChain() error

type OfacChecker added in v1.52.0

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

func NewOfacChecker added in v1.52.0

func NewOfacChecker() (*OfacChecker, error)

func (*OfacChecker) IsBlacklisted added in v1.52.0

func (oc *OfacChecker) IsBlacklisted(address string) bool

type OrderCancelData added in v1.34.0

type OrderCancelData struct {
	MarketId  string
	OrderHash string
	Cid       string
}

type OrderHashes added in v1.38.0

type OrderHashes struct {
	Spot       []common.Hash
	Derivative []common.Hash
}

type OrderbookType added in v1.43.1

type OrderbookType string

type SpotOrderData added in v1.34.0

type SpotOrderData struct {
	OrderType       int32
	Price           decimal.Decimal
	Quantity        decimal.Decimal
	FeeRecipient    string
	MarketId        string
	Cid             string
	ExpirationBlock int64
}

type TokenMetadata added in v1.51.0

type TokenMetadata interface {
	GetName() string
	GetAddress() string
	GetSymbol() string
	GetDecimals() int32
	GetUpdatedAt() int64
}

Jump to

Keyboard shortcuts

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