types

package
v0.30.0 Latest Latest
Warning

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

Go to latest
Published: Apr 23, 2024 License: Apache-2.0 Imports: 39 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	OneShareExponent = 18

	BalancerGasFeeForSwap = 10_000
)
View Source
const (
	InvalidInputDenomsErrFormat                  = "input denoms must already exist in the pool (%s)"
	FormatRepeatingPoolAssetsNotAllowedErrFormat = "repeating pool assets not allowed, found %s"
	FormatNoPoolAssetFoundErrFormat              = "can't find the PoolAsset (%s)"
	ErrMsgFormatSharesLargerThanMax              = "%s resulted shares is larger than the max amount of %s"
)
View Source
const (
	TypeEvtPoolJoined   = "pool_joined"
	TypeEvtPoolExited   = "pool_exited"
	TypeEvtPoolCreated  = "pool_created"
	TypeEvtTokenSwapped = "token_swapped"

	AttributeValueCategory = ModuleName
	AttributeKeyPoolId     = "pool_id"
	AttributeKeyTokensIn   = "tokens_in"
	AttributeKeyTokensOut  = "tokens_out"
	AttributeKeyRecipient  = "recipient"
)
View Source
const (
	// ModuleName defines the module name
	ModuleName = "amm"

	// StoreKey defines the primary module store key
	StoreKey = ModuleName

	// RouterKey defines the module's message routing key
	RouterKey = ModuleName

	// TStoreKey defines the transient store key
	TStoreKey = "transient_amm"

	// PoolKeyPrefix is the prefix to retrieve all Pool
	PoolKeyPrefix = "Pool/value/"
	// OraclePoolSlippageTrackPrefix is the prefix to retrieve slippage tracked
	OraclePoolSlippageTrackPrefix = "OraclePool/slippage/track/value/"

	// DenomLiquidityKeyPrefix is the prefix to retrieve all DenomLiquidity
	DenomLiquidityKeyPrefix = "DenomLiquidity/value/"

	TLastSwapRequestIndex  = "last-swap-request-index"
	TSwapExactAmountInKey  = "batch/swap-exact-amount-in"
	TSwapExactAmountOutKey = "batch/swap-exact-amount-out"

	// ParamsKey is the prefix to retrieve all Params
	ParamsKey = "Params/value/"
)
View Source
const DefaultIndex uint64 = 1

DefaultIndex is the default global index

View Source
const TypeMsgCreatePool = "create_pool"
View Source
const TypeMsgExitPool = "exit_pool"
View Source
const TypeMsgFeedMultipleExternalLiquidity = "feed_multiple_external_liquidity"
View Source
const TypeMsgJoinPool = "join_pool"
View Source
const TypeMsgSwapByDenom = "swap_by_denom"
View Source
const TypeMsgSwapExactAmountIn = "swap_exact_amount_in"
View Source
const TypeMsgSwapExactAmountOut = "swap_exact_amount_out"
View Source
const TypeMsgUpdateParams = "update_params"
View Source
const TypeMsgUpdatePoolParams = "update_pool_params"

Variables

View Source
var (
	// OneShare represents the amount of subshares in a single pool share.
	OneShare = math.NewIntWithDecimal(1, OneShareExponent)

	// InitPoolSharesSupply is the amount of new shares to initialize a pool with.
	InitPoolSharesSupply = OneShare.MulRaw(100)

	// Scaling factor for every weight. The pool weight is:
	// weight_in_MsgCreateBalancerPool * GuaranteedWeightPrecision
	//
	// This is done so that smooth weight changes have enough precision to actually be smooth.
	GuaranteedWeightPrecision int64 = 1 << 30
)
View Source
var (
	ErrInvalidLengthDenomLiquidity        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowDenomLiquidity          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupDenomLiquidity = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrLimitMaxAmount      = errors.Register(ModuleName, 6, "calculated amount is larger than max amount")
	ErrLimitMinAmount      = errors.Register(ModuleName, 7, "calculated amount is less than min amount")
	ErrInvalidMathApprox   = errors.Register(ModuleName, 8, "invalid calculated result")
	ErrInvalidPool         = errors.Register(ModuleName, 10, "attempting to create an invalid pool")
	ErrDenomNotFoundInPool = errors.Register(ModuleName, 11, "denom does not exist in pool")

	ErrEmptyRoutes     = errors.Register(ModuleName, 21, "routes not defined")
	ErrNegativeSwapFee = errors.Register(ModuleName, 23, "swap fee is negative")
	ErrNegativeExitFee = errors.Register(ModuleName, 24, "exit fee is negative")
	ErrTooMuchSwapFee  = errors.Register(ModuleName, 25, "swap fee should be less than 1 (100%)")
	ErrTooMuchExitFee  = errors.Register(ModuleName, 26, "exit fee should be less than 1 (100%)")

	ErrTooManyTokensOut = errors.Register(ModuleName, 31, "tx is trying to get more tokens out of the pool than exist")

	ErrInvalidPoolId      = errors.Register(ModuleName, 91, "invalid pool id")
	ErrInvalidSwapMsgType = errors.Register(ModuleName, 92, "unexpected swap message type")

	ErrSameDenom              = errors.Register(ModuleName, 101, "denom in and denom out are the same")
	ErrPoolNotFound           = errors.Register(ModuleName, 102, "pool not found")
	ErrAmountTooLow           = errors.Register(ModuleName, 103, "amount too low")
	ErrInvalidDenom           = errors.Register(ModuleName, 104, "invalid denom")
	ErrInvalidDiscount        = errors.Register(ModuleName, 105, "invalid discount")
	ErrInitialSpotPriceIsZero = errors.Register(ModuleName, 106, "initial spot price is zero")
	ErrSpotPriceIsZero        = errors.Register(ModuleName, 107, "spot price is zero")

	ErrPoolParamsShouldNotBeNil         = errors.Register(ModuleName, 108, "pool params should not be nil")
	ErrSwapFeeShouldNotExceedTwoPercent = errors.Register(ModuleName, 109, "swap fee should not exceed 2%")
	ErrExitFeeShouldNotExceedTwoPercent = errors.Register(ModuleName, 110, "exit fee should not exceed 2%")
	ErrFeeShouldNotBeNegative           = errors.Register(ModuleName, 111, "fee should not be negative")
)

x/amm module sentinel errors

View Source
var (
	ErrInvalidLengthGenesis        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGenesis          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGenesis = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupParams = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthPool        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPool          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPool = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthPoolAsset        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPoolAsset          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPoolAsset = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthPoolParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPoolParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPoolParams = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthProposal        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowProposal          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupProposal = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthQuery        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowQuery          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupQuery = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthSwapRoute        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowSwapRoute          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupSwapRoute = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthTx        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTx          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTx = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthTypes        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowTypes          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupTypes = fmt.Errorf("proto: unexpected end of group")
)
View Source
var FilterType_name = map[int32]string{
	0: "FilterAll",
	1: "FilterPerpetual",
	2: "FilterFixedWeight",
	3: "FilterDynamicWeight",
	4: "FilterLeverage",
}
View Source
var FilterType_value = map[string]int32{
	"FilterAll":           0,
	"FilterPerpetual":     1,
	"FilterFixedWeight":   2,
	"FilterDynamicWeight": 3,
	"FilterLeverage":      4,
}

Functions

func AbsDifferenceWithSign

func AbsDifferenceWithSign(a, b sdk.Dec) (sdk.Dec, bool)

AbsDifferenceWithSign returns | a - b |, (a - b).sign() a is mutated and returned.

func ApplyDiscount added in v0.19.0

func ApplyDiscount(swapFee sdk.Dec, discount sdk.Dec) sdk.Dec

ApplyDiscount applies discount to swap fee if applicable

func CalcExitPool

func CalcExitPool(ctx sdk.Context, oracleKeeper OracleKeeper, pool Pool, accountedPoolKeeper AccountedPoolKeeper, exitingShares math.Int, tokenOutDenom string) (sdk.Coins, error)

CalcExitPool returns how many tokens should come out, when exiting k LP shares against a "standard" CFMM

func CalcExitValueWithoutSlippage added in v0.11.0

func CalcExitValueWithoutSlippage(ctx sdk.Context, oracleKeeper OracleKeeper, accPoolKeeper AccountedPoolKeeper, pool Pool, exitingShares math.Int, tokenOutDenom string) (sdk.Dec, error)

func CalculateTokenARate added in v0.29.14

func CalculateTokenARate(tokenBalanceA, tokenWeightA, tokenBalanceB, tokenWeightB sdk.Dec) sdk.Dec

E.g. tokenA: ELYS, tokenB: USDC

func DenomLiquidityKey

func DenomLiquidityKey(denom string) []byte

DenomLiquidityKey returns the store key to retrieve a DenomLiquidity from the index fields

func EmitAddLiquidityEvent

func EmitAddLiquidityEvent(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, liquidity sdk.Coins)

func EmitRemoveLiquidityEvent

func EmitRemoveLiquidityEvent(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, liquidity sdk.Coins)

func EmitSwapEvent

func EmitSwapEvent(ctx sdk.Context, sender, recipient sdk.AccAddress, poolId uint64, input sdk.Coins, output sdk.Coins)

func EnsureDenomInPool

func EnsureDenomInPool(poolAssetsByDenom map[string]PoolAsset, tokensIn sdk.Coins) error

ensureDenomInPool check to make sure the input denoms exist in the provided pool asset map

func FirstPoolIdFromSwapExactAmountIn added in v0.11.0

func FirstPoolIdFromSwapExactAmountIn(m *MsgSwapExactAmountIn) uint64

func FirstPoolIdFromSwapExactAmountOut added in v0.11.0

func FirstPoolIdFromSwapExactAmountOut(m *MsgSwapExactAmountOut) uint64

func GetPoolAssetsByDenom

func GetPoolAssetsByDenom(poolAssets []PoolAsset) (map[string]PoolAsset, error)

GetPoolAssetsByDenom return a mapping from pool asset denom to the pool asset itself. There must be no duplicates. Returns error, if any found.

func GetPoolShareDenom

func GetPoolShareDenom(poolId uint64) string

func GetWeightBreakingFee added in v0.23.0

func GetWeightBreakingFee(weightIn, weightOut, targetWeightIn, targetWeightOut sdk.Dec, poolParams PoolParams) sdk.Dec

func KeyPrefix

func KeyPrefix(p string) []byte

func MaximalExactRatioJoin

func MaximalExactRatioJoin(p *Pool, tokensIn sdk.Coins) (numShares math.Int, remCoins sdk.Coins, err error)

MaximalExactRatioJoin calculates the maximal amount of tokens that can be joined whilst maintaining pool asset's ratio returning the number of shares that'd be and how many coins would be left over.

e.g) suppose we have a pool of 10 foo tokens and 10 bar tokens, with the total amount of 100 shares.
	 if `tokensIn` provided is 1 foo token and 2 bar tokens, `MaximalExactRatioJoin`
	 would be returning (10 shares, 1 bar token, nil)

This can be used when `tokensIn` are not guaranteed the same ratio as assets in the pool. Calculation for this is done in the following steps.

  1. iterate through all the tokens provided as an argument, calculate how much ratio it accounts for the asset in the pool
  2. get the minimal share ratio that would work as the benchmark for all tokens.
  3. calculate the number of shares that could be joined (total share * min share ratio), return the remaining coins

func NewAddLiquidityEvent

func NewAddLiquidityEvent(sender sdk.AccAddress, poolId uint64, liquidity sdk.Coins) sdk.Event

func NewPoolAddress

func NewPoolAddress(poolId uint64) sdk.AccAddress

func NewPoolRebalanceTreasury

func NewPoolRebalanceTreasury(poolId uint64) sdk.AccAddress

func NewPoolRevenueAddress

func NewPoolRevenueAddress(poolId uint64) sdk.AccAddress

func NewRemoveLiquidityEvent

func NewRemoveLiquidityEvent(sender sdk.AccAddress, poolId uint64, liquidity sdk.Coins) sdk.Event

func NewSwapEvent

func NewSwapEvent(sender, recipient sdk.AccAddress, poolId uint64, input sdk.Coins, output sdk.Coins) sdk.Event

func NormalizedWeight added in v0.23.0

func NormalizedWeight(ctx sdk.Context, poolAssets []PoolAsset, denom string) sdk.Dec

func OracleAssetWeight added in v0.23.0

func OracleAssetWeight(ctx sdk.Context, oracleKeeper OracleKeeper, poolAssets []PoolAsset, denom string) sdk.Dec

func OraclePoolSlippageTrackKey added in v0.13.0

func OraclePoolSlippageTrackKey(poolId uint64, timestamp uint64) []byte

func PoolKey

func PoolKey(poolId uint64) []byte

PoolKey returns the store key to retrieve a Pool from the index fields

func Pow

func Pow(base sdk.Dec, exp sdk.Dec) sdk.Dec

Pow computes base^(exp) However since the exponent is not an integer, we must do an approximation algorithm. TODO: In the future, lets add some optimized routines for common exponents, e.g. for common wIn / wOut ratios Many simple exponents like 2:1 pools.

func PowApprox

func PowApprox(base sdk.Dec, exp sdk.Dec, precision sdk.Dec) sdk.Dec

Contract: 0 < base <= 2 0 <= exp < 1.

func RegisterCodec

func RegisterCodec(cdc *codec.LegacyAmino)

func RegisterInterfaces

func RegisterInterfaces(registry cdctypes.InterfaceRegistry)

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

func RegisterQueryHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error

RegisterQueryHandler registers the http handlers for service Query to "mux". The handlers forward requests to the grpc endpoint over "conn".

func RegisterQueryHandlerClient

func RegisterQueryHandlerClient(ctx context.Context, mux *runtime.ServeMux, client QueryClient) error

RegisterQueryHandlerClient registers the http handlers for service Query to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "QueryClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "QueryClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "QueryClient" to call the correct interceptors.

func RegisterQueryHandlerFromEndpoint

func RegisterQueryHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)

RegisterQueryHandlerFromEndpoint is same as RegisterQueryHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.

func RegisterQueryHandlerServer

func RegisterQueryHandlerServer(ctx context.Context, mux *runtime.ServeMux, server QueryServer) error

RegisterQueryHandlerServer registers the http handlers for service Query to "mux". UnaryRPC :call QueryServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features (such as grpc.SendHeader, etc) to stop working. Consider using RegisterQueryHandlerFromEndpoint instead.

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func TKeyPrefixSwapExactAmountIn added in v0.11.0

func TKeyPrefixSwapExactAmountIn(m *MsgSwapExactAmountIn, index uint64) []byte

func TKeyPrefixSwapExactAmountInPrefix added in v0.11.0

func TKeyPrefixSwapExactAmountInPrefix(m *MsgSwapExactAmountIn) []byte

func TKeyPrefixSwapExactAmountOut added in v0.11.0

func TKeyPrefixSwapExactAmountOut(m *MsgSwapExactAmountOut, index uint64) []byte

func TKeyPrefixSwapExactAmountOutPrefix added in v0.11.0

func TKeyPrefixSwapExactAmountOutPrefix(m *MsgSwapExactAmountOut) []byte

Types

type AccountKeeper

type AccountKeeper interface {
	NewAccount(sdk.Context, authtypes.AccountI) authtypes.AccountI
	GetAccount(ctx sdk.Context, addr sdk.AccAddress) authtypes.AccountI
	SetAccount(ctx sdk.Context, acc authtypes.AccountI)
}

AccountKeeper defines the expected account keeper used for simulations (noalias)

type AccountedPoolKeeper added in v0.11.0

type AccountedPoolKeeper interface {
	GetAccountedBalance(sdk.Context, uint64, string) math.Int
}

AccountedPoolKeeper defines the expected interfaces

type AmmHooks

type AmmHooks interface {
	// AfterPoolCreated is called after CreatePool
	AfterPoolCreated(ctx sdk.Context, sender sdk.AccAddress, pool Pool)

	// AfterJoinPool is called after JoinPool, JoinSwapExternAmountIn, and JoinSwapShareAmountOut
	AfterJoinPool(ctx sdk.Context, sender sdk.AccAddress, pool Pool, enterCoins sdk.Coins, shareOutAmount math.Int)

	// AfterExitPool is called after ExitPool, ExitSwapShareAmountIn, and ExitSwapExternAmountOut
	AfterExitPool(ctx sdk.Context, sender sdk.AccAddress, pool Pool, shareInAmount math.Int, exitCoins sdk.Coins) error

	// AfterSwap is called after SwapExactAmountIn and SwapExactAmountOut
	AfterSwap(ctx sdk.Context, sender sdk.AccAddress, pool Pool, input sdk.Coins, output sdk.Coins) error
}

type AssetAmountDepth added in v0.12.0

type AssetAmountDepth struct {
	Asset  string                                 `protobuf:"bytes,1,opt,name=asset,proto3" json:"asset,omitempty"`
	Amount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=amount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"amount"`
	Depth  github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=depth,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"depth"`
}

func (*AssetAmountDepth) Descriptor added in v0.12.0

func (*AssetAmountDepth) Descriptor() ([]byte, []int)

func (*AssetAmountDepth) GetAsset added in v0.12.0

func (m *AssetAmountDepth) GetAsset() string

func (*AssetAmountDepth) Marshal added in v0.12.0

func (m *AssetAmountDepth) Marshal() (dAtA []byte, err error)

func (*AssetAmountDepth) MarshalTo added in v0.12.0

func (m *AssetAmountDepth) MarshalTo(dAtA []byte) (int, error)

func (*AssetAmountDepth) MarshalToSizedBuffer added in v0.12.0

func (m *AssetAmountDepth) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*AssetAmountDepth) ProtoMessage added in v0.12.0

func (*AssetAmountDepth) ProtoMessage()

func (*AssetAmountDepth) Reset added in v0.12.0

func (m *AssetAmountDepth) Reset()

func (*AssetAmountDepth) Size added in v0.12.0

func (m *AssetAmountDepth) Size() (n int)

func (*AssetAmountDepth) String added in v0.12.0

func (m *AssetAmountDepth) String() string

func (*AssetAmountDepth) Unmarshal added in v0.12.0

func (m *AssetAmountDepth) Unmarshal(dAtA []byte) error

func (*AssetAmountDepth) XXX_DiscardUnknown added in v0.12.0

func (m *AssetAmountDepth) XXX_DiscardUnknown()

func (*AssetAmountDepth) XXX_Marshal added in v0.12.0

func (m *AssetAmountDepth) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*AssetAmountDepth) XXX_Merge added in v0.12.0

func (m *AssetAmountDepth) XXX_Merge(src proto.Message)

func (*AssetAmountDepth) XXX_Size added in v0.12.0

func (m *AssetAmountDepth) XXX_Size() int

func (*AssetAmountDepth) XXX_Unmarshal added in v0.12.0

func (m *AssetAmountDepth) XXX_Unmarshal(b []byte) error

type AssetProfileKeeper

type AssetProfileKeeper interface {
	// SetEntry set a specific entry in the store from its index
	SetEntry(ctx sdk.Context, entry atypes.Entry)
	// GetEntry returns a entry from its index
	GetEntry(ctx sdk.Context, baseDenom string) (val atypes.Entry, found bool)
	// GetEntryByDenom returns a entry from its denom value
	GetEntryByDenom(ctx sdk.Context, denom string) (val atypes.Entry, found bool)
}

AssetProfileKeeper defines the expected interfaces

type AssetWeight

type AssetWeight struct {
	Asset  string
	Weight sdk.Dec
}

func NormalizedWeights

func NormalizedWeights(poolAssets []PoolAsset) (poolWeights []AssetWeight)

func OraclePoolNormalizedWeights

func OraclePoolNormalizedWeights(ctx sdk.Context, oracleKeeper OracleKeeper, poolAssets []PoolAsset) ([]AssetWeight, error)

type BankKeeper

type BankKeeper interface {
	GetBalance(ctx sdk.Context, addr sdk.AccAddress, denom string) sdk.Coin
	SpendableCoins(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	MintCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error
	BurnCoins(ctx sdk.Context, name string, amt sdk.Coins) error
	SendCoinsFromModuleToAccount(ctx sdk.Context, senderModule string, recipientAddr sdk.AccAddress, amt sdk.Coins) error
	SendCoinsFromAccountToModule(ctx sdk.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error
	SetDenomMetaData(ctx sdk.Context, denomMetaData banktypes.Metadata)
	SendCoins(ctx sdk.Context, fromAddr sdk.AccAddress, toAddr sdk.AccAddress, amt sdk.Coins) error
}

BankKeeper defines the expected interface needed to retrieve account balances.

type DenomLiquidity

type DenomLiquidity struct {
	Denom     string                                 `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
	Liquidity github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,2,opt,name=liquidity,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"liquidity"`
}

func (*DenomLiquidity) Descriptor

func (*DenomLiquidity) Descriptor() ([]byte, []int)

func (*DenomLiquidity) GetDenom

func (m *DenomLiquidity) GetDenom() string

func (*DenomLiquidity) Marshal

func (m *DenomLiquidity) Marshal() (dAtA []byte, err error)

func (*DenomLiquidity) MarshalTo

func (m *DenomLiquidity) MarshalTo(dAtA []byte) (int, error)

func (*DenomLiquidity) MarshalToSizedBuffer

func (m *DenomLiquidity) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*DenomLiquidity) ProtoMessage

func (*DenomLiquidity) ProtoMessage()

func (*DenomLiquidity) Reset

func (m *DenomLiquidity) Reset()

func (*DenomLiquidity) Size

func (m *DenomLiquidity) Size() (n int)

func (*DenomLiquidity) String

func (m *DenomLiquidity) String() string

func (*DenomLiquidity) Unmarshal

func (m *DenomLiquidity) Unmarshal(dAtA []byte) error

func (*DenomLiquidity) XXX_DiscardUnknown

func (m *DenomLiquidity) XXX_DiscardUnknown()

func (*DenomLiquidity) XXX_Marshal

func (m *DenomLiquidity) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*DenomLiquidity) XXX_Merge

func (m *DenomLiquidity) XXX_Merge(src proto.Message)

func (*DenomLiquidity) XXX_Size

func (m *DenomLiquidity) XXX_Size() int

func (*DenomLiquidity) XXX_Unmarshal

func (m *DenomLiquidity) XXX_Unmarshal(b []byte) error

type EarnPool added in v0.20.0

type EarnPool struct {
	PoolId       uint64                                   `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	Assets       []PoolAsset                              `protobuf:"bytes,2,rep,name=assets,proto3" json:"assets"`
	PoolRatio    string                                   `protobuf:"bytes,3,opt,name=pool_ratio,json=poolRatio,proto3" json:"pool_ratio,omitempty"`
	RewardsApr   github_com_cosmos_cosmos_sdk_types.Dec   `` /* 131-byte string literal not displayed */
	BorrowApr    github_com_cosmos_cosmos_sdk_types.Dec   `` /* 128-byte string literal not displayed */
	LeverageLp   github_com_cosmos_cosmos_sdk_types.Dec   `` /* 131-byte string literal not displayed */
	Perpetual    github_com_cosmos_cosmos_sdk_types.Dec   `protobuf:"bytes,7,opt,name=perpetual,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"perpetual"`
	Tvl          github_com_cosmos_cosmos_sdk_types.Dec   `protobuf:"bytes,8,opt,name=tvl,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"tvl"`
	LpTokenPrice github_com_cosmos_cosmos_sdk_types.Dec   `` /* 139-byte string literal not displayed */
	RewardsUsd   github_com_cosmos_cosmos_sdk_types.Dec   `` /* 132-byte string literal not displayed */
	RewardCoins  github_com_cosmos_cosmos_sdk_types.Coins `` /* 139-byte string literal not displayed */
	TotalShares  github_com_cosmos_cosmos_sdk_types.Coin  `` /* 136-byte string literal not displayed */
	SwapFee      github_com_cosmos_cosmos_sdk_types.Dec   `protobuf:"bytes,13,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	FeeDenom     string                                   `protobuf:"bytes,14,opt,name=fee_denom,json=feeDenom,proto3" json:"fee_denom,omitempty"`
	UseOracle    bool                                     `protobuf:"varint,15,opt,name=use_oracle,json=useOracle,proto3" json:"use_oracle,omitempty"`
}

func (*EarnPool) Descriptor added in v0.20.0

func (*EarnPool) Descriptor() ([]byte, []int)

func (*EarnPool) GetAssets added in v0.20.0

func (m *EarnPool) GetAssets() []PoolAsset

func (*EarnPool) GetFeeDenom added in v0.29.29

func (m *EarnPool) GetFeeDenom() string

func (*EarnPool) GetPoolId added in v0.29.19

func (m *EarnPool) GetPoolId() uint64

func (*EarnPool) GetPoolRatio added in v0.20.0

func (m *EarnPool) GetPoolRatio() string

func (*EarnPool) GetRewardCoins added in v0.29.27

func (*EarnPool) GetUseOracle added in v0.29.29

func (m *EarnPool) GetUseOracle() bool

func (*EarnPool) Marshal added in v0.20.0

func (m *EarnPool) Marshal() (dAtA []byte, err error)

func (*EarnPool) MarshalTo added in v0.20.0

func (m *EarnPool) MarshalTo(dAtA []byte) (int, error)

func (*EarnPool) MarshalToSizedBuffer added in v0.20.0

func (m *EarnPool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*EarnPool) ProtoMessage added in v0.20.0

func (*EarnPool) ProtoMessage()

func (*EarnPool) Reset added in v0.20.0

func (m *EarnPool) Reset()

func (*EarnPool) Size added in v0.20.0

func (m *EarnPool) Size() (n int)

func (*EarnPool) String added in v0.20.0

func (m *EarnPool) String() string

func (*EarnPool) Unmarshal added in v0.20.0

func (m *EarnPool) Unmarshal(dAtA []byte) error

func (*EarnPool) XXX_DiscardUnknown added in v0.20.0

func (m *EarnPool) XXX_DiscardUnknown()

func (*EarnPool) XXX_Marshal added in v0.20.0

func (m *EarnPool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*EarnPool) XXX_Merge added in v0.20.0

func (m *EarnPool) XXX_Merge(src proto.Message)

func (*EarnPool) XXX_Size added in v0.20.0

func (m *EarnPool) XXX_Size() int

func (*EarnPool) XXX_Unmarshal added in v0.20.0

func (m *EarnPool) XXX_Unmarshal(b []byte) error

type ExternalLiquidity added in v0.12.0

type ExternalLiquidity struct {
	PoolId          uint64             `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	AmountDepthInfo []AssetAmountDepth `protobuf:"bytes,2,rep,name=amount_depth_info,json=amountDepthInfo,proto3" json:"amount_depth_info"`
}

ExternalLiquidity defines price, volume, and time information for an exchange rate.

func (*ExternalLiquidity) Descriptor added in v0.12.0

func (*ExternalLiquidity) Descriptor() ([]byte, []int)

func (*ExternalLiquidity) GetAmountDepthInfo added in v0.12.0

func (m *ExternalLiquidity) GetAmountDepthInfo() []AssetAmountDepth

func (*ExternalLiquidity) GetPoolId added in v0.12.0

func (m *ExternalLiquidity) GetPoolId() uint64

func (*ExternalLiquidity) Marshal added in v0.12.0

func (m *ExternalLiquidity) Marshal() (dAtA []byte, err error)

func (*ExternalLiquidity) MarshalTo added in v0.12.0

func (m *ExternalLiquidity) MarshalTo(dAtA []byte) (int, error)

func (*ExternalLiquidity) MarshalToSizedBuffer added in v0.12.0

func (m *ExternalLiquidity) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ExternalLiquidity) ProtoMessage added in v0.12.0

func (*ExternalLiquidity) ProtoMessage()

func (*ExternalLiquidity) Reset added in v0.12.0

func (m *ExternalLiquidity) Reset()

func (*ExternalLiquidity) Size added in v0.12.0

func (m *ExternalLiquidity) Size() (n int)

func (*ExternalLiquidity) String added in v0.12.0

func (m *ExternalLiquidity) String() string

func (*ExternalLiquidity) Unmarshal added in v0.12.0

func (m *ExternalLiquidity) Unmarshal(dAtA []byte) error

func (*ExternalLiquidity) XXX_DiscardUnknown added in v0.12.0

func (m *ExternalLiquidity) XXX_DiscardUnknown()

func (*ExternalLiquidity) XXX_Marshal added in v0.12.0

func (m *ExternalLiquidity) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ExternalLiquidity) XXX_Merge added in v0.12.0

func (m *ExternalLiquidity) XXX_Merge(src proto.Message)

func (*ExternalLiquidity) XXX_Size added in v0.12.0

func (m *ExternalLiquidity) XXX_Size() int

func (*ExternalLiquidity) XXX_Unmarshal added in v0.12.0

func (m *ExternalLiquidity) XXX_Unmarshal(b []byte) error

type FilterType added in v0.20.0

type FilterType int32
const (
	FilterType_FilterAll           FilterType = 0
	FilterType_FilterPerpetual     FilterType = 1
	FilterType_FilterFixedWeight   FilterType = 2
	FilterType_FilterDynamicWeight FilterType = 3
	FilterType_FilterLeverage      FilterType = 4
)

func (FilterType) EnumDescriptor added in v0.20.0

func (FilterType) EnumDescriptor() ([]byte, []int)

func (FilterType) String added in v0.20.0

func (x FilterType) String() string

type GenesisState

type GenesisState struct {
	Params             Params                    `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	PoolList           []Pool                    `protobuf:"bytes,2,rep,name=pool_list,json=poolList,proto3" json:"pool_list"`
	DenomLiquidityList []DenomLiquidity          `protobuf:"bytes,3,rep,name=denom_liquidity_list,json=denomLiquidityList,proto3" json:"denom_liquidity_list"`
	SlippageTracks     []OraclePoolSlippageTrack `protobuf:"bytes,4,rep,name=slippage_tracks,json=slippageTracks,proto3" json:"slippage_tracks"`
}

GenesisState defines the amm module's genesis state.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis returns the default genesis state

func (*GenesisState) Descriptor

func (*GenesisState) Descriptor() ([]byte, []int)

func (*GenesisState) GetDenomLiquidityList

func (m *GenesisState) GetDenomLiquidityList() []DenomLiquidity

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPoolList

func (m *GenesisState) GetPoolList() []Pool

func (*GenesisState) GetSlippageTracks added in v0.13.0

func (m *GenesisState) GetSlippageTracks() []OraclePoolSlippageTrack

func (*GenesisState) Marshal

func (m *GenesisState) Marshal() (dAtA []byte, err error)

func (*GenesisState) MarshalTo

func (m *GenesisState) MarshalTo(dAtA []byte) (int, error)

func (*GenesisState) MarshalToSizedBuffer

func (m *GenesisState) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*GenesisState) ProtoMessage

func (*GenesisState) ProtoMessage()

func (*GenesisState) Reset

func (m *GenesisState) Reset()

func (*GenesisState) Size

func (m *GenesisState) Size() (n int)

func (*GenesisState) String

func (m *GenesisState) String() string

func (*GenesisState) Unmarshal

func (m *GenesisState) Unmarshal(dAtA []byte) error

func (GenesisState) Validate

func (gs GenesisState) Validate() error

Validate performs basic genesis state validation returning an error upon any failure.

func (*GenesisState) XXX_DiscardUnknown

func (m *GenesisState) XXX_DiscardUnknown()

func (*GenesisState) XXX_Marshal

func (m *GenesisState) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*GenesisState) XXX_Merge

func (m *GenesisState) XXX_Merge(src proto.Message)

func (*GenesisState) XXX_Size

func (m *GenesisState) XXX_Size() int

func (*GenesisState) XXX_Unmarshal

func (m *GenesisState) XXX_Unmarshal(b []byte) error

type InternalSwapRequest added in v0.11.0

type InternalSwapRequest struct {
	InAmount sdk.Coin
	OutToken string
}

type MsgClient

MsgClient is the client API for Msg service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewMsgClient

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgCreatePool

type MsgCreatePool struct {
	Sender     string      `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	PoolParams *PoolParams `protobuf:"bytes,2,opt,name=pool_params,json=poolParams,proto3" json:"pool_params,omitempty"`
	PoolAssets []PoolAsset `protobuf:"bytes,3,rep,name=pool_assets,json=poolAssets,proto3" json:"pool_assets"`
}

func NewMsgCreatePool

func NewMsgCreatePool(sender string, poolParams *PoolParams, poolAssets []PoolAsset) *MsgCreatePool

func (*MsgCreatePool) Descriptor

func (*MsgCreatePool) Descriptor() ([]byte, []int)

func (*MsgCreatePool) GetPoolAssets

func (m *MsgCreatePool) GetPoolAssets() []PoolAsset

func (*MsgCreatePool) GetPoolParams

func (m *MsgCreatePool) GetPoolParams() *PoolParams

func (*MsgCreatePool) GetSender

func (m *MsgCreatePool) GetSender() string

func (*MsgCreatePool) GetSignBytes

func (msg *MsgCreatePool) GetSignBytes() []byte

func (*MsgCreatePool) GetSigners

func (msg *MsgCreatePool) GetSigners() []sdk.AccAddress

func (*MsgCreatePool) InitialLiquidity

func (msg *MsgCreatePool) InitialLiquidity() sdk.Coins

func (*MsgCreatePool) Marshal

func (m *MsgCreatePool) Marshal() (dAtA []byte, err error)

func (*MsgCreatePool) MarshalTo

func (m *MsgCreatePool) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreatePool) MarshalToSizedBuffer

func (m *MsgCreatePool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreatePool) ProtoMessage

func (*MsgCreatePool) ProtoMessage()

func (*MsgCreatePool) Reset

func (m *MsgCreatePool) Reset()

func (*MsgCreatePool) Route

func (msg *MsgCreatePool) Route() string

func (*MsgCreatePool) Size

func (m *MsgCreatePool) Size() (n int)

func (*MsgCreatePool) String

func (m *MsgCreatePool) String() string

func (*MsgCreatePool) Type

func (msg *MsgCreatePool) Type() string

func (*MsgCreatePool) Unmarshal

func (m *MsgCreatePool) Unmarshal(dAtA []byte) error

func (*MsgCreatePool) ValidateBasic

func (msg *MsgCreatePool) ValidateBasic() error

func (*MsgCreatePool) XXX_DiscardUnknown

func (m *MsgCreatePool) XXX_DiscardUnknown()

func (*MsgCreatePool) XXX_Marshal

func (m *MsgCreatePool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreatePool) XXX_Merge

func (m *MsgCreatePool) XXX_Merge(src proto.Message)

func (*MsgCreatePool) XXX_Size

func (m *MsgCreatePool) XXX_Size() int

func (*MsgCreatePool) XXX_Unmarshal

func (m *MsgCreatePool) XXX_Unmarshal(b []byte) error

type MsgCreatePoolResponse

type MsgCreatePoolResponse struct {
	PoolID uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
}

func (*MsgCreatePoolResponse) Descriptor

func (*MsgCreatePoolResponse) Descriptor() ([]byte, []int)

func (*MsgCreatePoolResponse) GetPoolID

func (m *MsgCreatePoolResponse) GetPoolID() uint64

func (*MsgCreatePoolResponse) Marshal

func (m *MsgCreatePoolResponse) Marshal() (dAtA []byte, err error)

func (*MsgCreatePoolResponse) MarshalTo

func (m *MsgCreatePoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgCreatePoolResponse) MarshalToSizedBuffer

func (m *MsgCreatePoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgCreatePoolResponse) ProtoMessage

func (*MsgCreatePoolResponse) ProtoMessage()

func (*MsgCreatePoolResponse) Reset

func (m *MsgCreatePoolResponse) Reset()

func (*MsgCreatePoolResponse) Size

func (m *MsgCreatePoolResponse) Size() (n int)

func (*MsgCreatePoolResponse) String

func (m *MsgCreatePoolResponse) String() string

func (*MsgCreatePoolResponse) Unmarshal

func (m *MsgCreatePoolResponse) Unmarshal(dAtA []byte) error

func (*MsgCreatePoolResponse) XXX_DiscardUnknown

func (m *MsgCreatePoolResponse) XXX_DiscardUnknown()

func (*MsgCreatePoolResponse) XXX_Marshal

func (m *MsgCreatePoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgCreatePoolResponse) XXX_Merge

func (m *MsgCreatePoolResponse) XXX_Merge(src proto.Message)

func (*MsgCreatePoolResponse) XXX_Size

func (m *MsgCreatePoolResponse) XXX_Size() int

func (*MsgCreatePoolResponse) XXX_Unmarshal

func (m *MsgCreatePoolResponse) XXX_Unmarshal(b []byte) error

type MsgExitPool

type MsgExitPool struct {
	Sender        string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	PoolId        uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	MinAmountsOut []types.Coin                           `protobuf:"bytes,3,rep,name=min_amounts_out,json=minAmountsOut,proto3" json:"min_amounts_out"`
	ShareAmountIn github_com_cosmos_cosmos_sdk_types.Int `` /* 142-byte string literal not displayed */
	TokenOutDenom string                                 `protobuf:"bytes,5,opt,name=token_out_denom,json=tokenOutDenom,proto3" json:"token_out_denom,omitempty"`
}

func NewMsgExitPool

func NewMsgExitPool(sender string, poolId uint64, minAmountsOut sdk.Coins, shareAmountIn math.Int) *MsgExitPool

func (*MsgExitPool) Descriptor

func (*MsgExitPool) Descriptor() ([]byte, []int)

func (*MsgExitPool) GetMinAmountsOut

func (m *MsgExitPool) GetMinAmountsOut() []types.Coin

func (*MsgExitPool) GetPoolId

func (m *MsgExitPool) GetPoolId() uint64

func (*MsgExitPool) GetSender

func (m *MsgExitPool) GetSender() string

func (*MsgExitPool) GetSignBytes

func (msg *MsgExitPool) GetSignBytes() []byte

func (*MsgExitPool) GetSigners

func (msg *MsgExitPool) GetSigners() []sdk.AccAddress

func (*MsgExitPool) GetTokenOutDenom

func (m *MsgExitPool) GetTokenOutDenom() string

func (*MsgExitPool) Marshal

func (m *MsgExitPool) Marshal() (dAtA []byte, err error)

func (*MsgExitPool) MarshalTo

func (m *MsgExitPool) MarshalTo(dAtA []byte) (int, error)

func (*MsgExitPool) MarshalToSizedBuffer

func (m *MsgExitPool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgExitPool) ProtoMessage

func (*MsgExitPool) ProtoMessage()

func (*MsgExitPool) Reset

func (m *MsgExitPool) Reset()

func (*MsgExitPool) Route

func (msg *MsgExitPool) Route() string

func (*MsgExitPool) Size

func (m *MsgExitPool) Size() (n int)

func (*MsgExitPool) String

func (m *MsgExitPool) String() string

func (*MsgExitPool) Type

func (msg *MsgExitPool) Type() string

func (*MsgExitPool) Unmarshal

func (m *MsgExitPool) Unmarshal(dAtA []byte) error

func (*MsgExitPool) ValidateBasic

func (msg *MsgExitPool) ValidateBasic() error

func (*MsgExitPool) XXX_DiscardUnknown

func (m *MsgExitPool) XXX_DiscardUnknown()

func (*MsgExitPool) XXX_Marshal

func (m *MsgExitPool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgExitPool) XXX_Merge

func (m *MsgExitPool) XXX_Merge(src proto.Message)

func (*MsgExitPool) XXX_Size

func (m *MsgExitPool) XXX_Size() int

func (*MsgExitPool) XXX_Unmarshal

func (m *MsgExitPool) XXX_Unmarshal(b []byte) error

type MsgExitPoolResponse

type MsgExitPoolResponse struct {
	TokenOut []types.Coin `protobuf:"bytes,2,rep,name=token_out,json=tokenOut,proto3" json:"token_out"`
}

func (*MsgExitPoolResponse) Descriptor

func (*MsgExitPoolResponse) Descriptor() ([]byte, []int)

func (*MsgExitPoolResponse) GetTokenOut

func (m *MsgExitPoolResponse) GetTokenOut() []types.Coin

func (*MsgExitPoolResponse) Marshal

func (m *MsgExitPoolResponse) Marshal() (dAtA []byte, err error)

func (*MsgExitPoolResponse) MarshalTo

func (m *MsgExitPoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgExitPoolResponse) MarshalToSizedBuffer

func (m *MsgExitPoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgExitPoolResponse) ProtoMessage

func (*MsgExitPoolResponse) ProtoMessage()

func (*MsgExitPoolResponse) Reset

func (m *MsgExitPoolResponse) Reset()

func (*MsgExitPoolResponse) Size

func (m *MsgExitPoolResponse) Size() (n int)

func (*MsgExitPoolResponse) String

func (m *MsgExitPoolResponse) String() string

func (*MsgExitPoolResponse) Unmarshal

func (m *MsgExitPoolResponse) Unmarshal(dAtA []byte) error

func (*MsgExitPoolResponse) XXX_DiscardUnknown

func (m *MsgExitPoolResponse) XXX_DiscardUnknown()

func (*MsgExitPoolResponse) XXX_Marshal

func (m *MsgExitPoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgExitPoolResponse) XXX_Merge

func (m *MsgExitPoolResponse) XXX_Merge(src proto.Message)

func (*MsgExitPoolResponse) XXX_Size

func (m *MsgExitPoolResponse) XXX_Size() int

func (*MsgExitPoolResponse) XXX_Unmarshal

func (m *MsgExitPoolResponse) XXX_Unmarshal(b []byte) error

type MsgFeedMultipleExternalLiquidity added in v0.12.0

type MsgFeedMultipleExternalLiquidity struct {
	Sender    string              `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	Liquidity []ExternalLiquidity `protobuf:"bytes,2,rep,name=liquidity,proto3" json:"liquidity"`
}

func NewMsgFeedMultipleExternalLiquidity added in v0.12.0

func NewMsgFeedMultipleExternalLiquidity(sender string) *MsgFeedMultipleExternalLiquidity

func (*MsgFeedMultipleExternalLiquidity) Descriptor added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) Descriptor() ([]byte, []int)

func (*MsgFeedMultipleExternalLiquidity) GetLiquidity added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) GetSender added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) GetSignBytes added in v0.12.0

func (msg *MsgFeedMultipleExternalLiquidity) GetSignBytes() []byte

func (*MsgFeedMultipleExternalLiquidity) GetSigners added in v0.12.0

func (msg *MsgFeedMultipleExternalLiquidity) GetSigners() []sdk.AccAddress

func (*MsgFeedMultipleExternalLiquidity) Marshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) Marshal() (dAtA []byte, err error)

func (*MsgFeedMultipleExternalLiquidity) MarshalTo added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) MarshalTo(dAtA []byte) (int, error)

func (*MsgFeedMultipleExternalLiquidity) MarshalToSizedBuffer added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgFeedMultipleExternalLiquidity) ProtoMessage added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) ProtoMessage()

func (*MsgFeedMultipleExternalLiquidity) Reset added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) Route added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) Size added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) Size() (n int)

func (*MsgFeedMultipleExternalLiquidity) String added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) Type added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) Unmarshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) Unmarshal(dAtA []byte) error

func (*MsgFeedMultipleExternalLiquidity) ValidateBasic added in v0.12.0

func (msg *MsgFeedMultipleExternalLiquidity) ValidateBasic() error

func (*MsgFeedMultipleExternalLiquidity) XXX_DiscardUnknown added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) XXX_DiscardUnknown()

func (*MsgFeedMultipleExternalLiquidity) XXX_Marshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgFeedMultipleExternalLiquidity) XXX_Merge added in v0.12.0

func (*MsgFeedMultipleExternalLiquidity) XXX_Size added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) XXX_Size() int

func (*MsgFeedMultipleExternalLiquidity) XXX_Unmarshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidity) XXX_Unmarshal(b []byte) error

type MsgFeedMultipleExternalLiquidityResponse added in v0.12.0

type MsgFeedMultipleExternalLiquidityResponse struct {
}

func (*MsgFeedMultipleExternalLiquidityResponse) Descriptor added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) Descriptor() ([]byte, []int)

func (*MsgFeedMultipleExternalLiquidityResponse) Marshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) Marshal() (dAtA []byte, err error)

func (*MsgFeedMultipleExternalLiquidityResponse) MarshalTo added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgFeedMultipleExternalLiquidityResponse) MarshalToSizedBuffer added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgFeedMultipleExternalLiquidityResponse) ProtoMessage added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) Reset added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) Size added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) String added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) Unmarshal added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) XXX_DiscardUnknown added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) XXX_DiscardUnknown()

func (*MsgFeedMultipleExternalLiquidityResponse) XXX_Marshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgFeedMultipleExternalLiquidityResponse) XXX_Merge added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) XXX_Size added in v0.12.0

func (*MsgFeedMultipleExternalLiquidityResponse) XXX_Unmarshal added in v0.12.0

func (m *MsgFeedMultipleExternalLiquidityResponse) XXX_Unmarshal(b []byte) error

type MsgJoinPool

type MsgJoinPool struct {
	Sender         string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	PoolId         uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	MaxAmountsIn   []types.Coin                           `protobuf:"bytes,3,rep,name=max_amounts_in,json=maxAmountsIn,proto3" json:"max_amounts_in"`
	ShareAmountOut github_com_cosmos_cosmos_sdk_types.Int `` /* 145-byte string literal not displayed */
}

func NewMsgJoinPool

func NewMsgJoinPool(sender string, poolId uint64, maxAmountsIn sdk.Coins, shareAmountOut math.Int) *MsgJoinPool

func (*MsgJoinPool) Descriptor

func (*MsgJoinPool) Descriptor() ([]byte, []int)

func (*MsgJoinPool) GetMaxAmountsIn

func (m *MsgJoinPool) GetMaxAmountsIn() []types.Coin

func (*MsgJoinPool) GetPoolId

func (m *MsgJoinPool) GetPoolId() uint64

func (*MsgJoinPool) GetSender

func (m *MsgJoinPool) GetSender() string

func (*MsgJoinPool) GetSignBytes

func (msg *MsgJoinPool) GetSignBytes() []byte

func (*MsgJoinPool) GetSigners

func (msg *MsgJoinPool) GetSigners() []sdk.AccAddress

func (*MsgJoinPool) Marshal

func (m *MsgJoinPool) Marshal() (dAtA []byte, err error)

func (*MsgJoinPool) MarshalTo

func (m *MsgJoinPool) MarshalTo(dAtA []byte) (int, error)

func (*MsgJoinPool) MarshalToSizedBuffer

func (m *MsgJoinPool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgJoinPool) ProtoMessage

func (*MsgJoinPool) ProtoMessage()

func (*MsgJoinPool) Reset

func (m *MsgJoinPool) Reset()

func (*MsgJoinPool) Route

func (msg *MsgJoinPool) Route() string

func (*MsgJoinPool) Size

func (m *MsgJoinPool) Size() (n int)

func (*MsgJoinPool) String

func (m *MsgJoinPool) String() string

func (*MsgJoinPool) Type

func (msg *MsgJoinPool) Type() string

func (*MsgJoinPool) Unmarshal

func (m *MsgJoinPool) Unmarshal(dAtA []byte) error

func (*MsgJoinPool) ValidateBasic

func (msg *MsgJoinPool) ValidateBasic() error

func (*MsgJoinPool) XXX_DiscardUnknown

func (m *MsgJoinPool) XXX_DiscardUnknown()

func (*MsgJoinPool) XXX_Marshal

func (m *MsgJoinPool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgJoinPool) XXX_Merge

func (m *MsgJoinPool) XXX_Merge(src proto.Message)

func (*MsgJoinPool) XXX_Size

func (m *MsgJoinPool) XXX_Size() int

func (*MsgJoinPool) XXX_Unmarshal

func (m *MsgJoinPool) XXX_Unmarshal(b []byte) error

type MsgJoinPoolResponse

type MsgJoinPoolResponse struct {
	ShareAmountOut github_com_cosmos_cosmos_sdk_types.Int `` /* 145-byte string literal not displayed */
	TokenIn        []types.Coin                           `protobuf:"bytes,2,rep,name=token_in,json=tokenIn,proto3" json:"token_in"`
}

func (*MsgJoinPoolResponse) Descriptor

func (*MsgJoinPoolResponse) Descriptor() ([]byte, []int)

func (*MsgJoinPoolResponse) GetTokenIn

func (m *MsgJoinPoolResponse) GetTokenIn() []types.Coin

func (*MsgJoinPoolResponse) Marshal

func (m *MsgJoinPoolResponse) Marshal() (dAtA []byte, err error)

func (*MsgJoinPoolResponse) MarshalTo

func (m *MsgJoinPoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgJoinPoolResponse) MarshalToSizedBuffer

func (m *MsgJoinPoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgJoinPoolResponse) ProtoMessage

func (*MsgJoinPoolResponse) ProtoMessage()

func (*MsgJoinPoolResponse) Reset

func (m *MsgJoinPoolResponse) Reset()

func (*MsgJoinPoolResponse) Size

func (m *MsgJoinPoolResponse) Size() (n int)

func (*MsgJoinPoolResponse) String

func (m *MsgJoinPoolResponse) String() string

func (*MsgJoinPoolResponse) Unmarshal

func (m *MsgJoinPoolResponse) Unmarshal(dAtA []byte) error

func (*MsgJoinPoolResponse) XXX_DiscardUnknown

func (m *MsgJoinPoolResponse) XXX_DiscardUnknown()

func (*MsgJoinPoolResponse) XXX_Marshal

func (m *MsgJoinPoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgJoinPoolResponse) XXX_Merge

func (m *MsgJoinPoolResponse) XXX_Merge(src proto.Message)

func (*MsgJoinPoolResponse) XXX_Size

func (m *MsgJoinPoolResponse) XXX_Size() int

func (*MsgJoinPoolResponse) XXX_Unmarshal

func (m *MsgJoinPoolResponse) XXX_Unmarshal(b []byte) error

type MsgSwapByDenom added in v0.17.0

type MsgSwapByDenom struct {
	Sender    string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	Amount    types.Coin                             `protobuf:"bytes,2,opt,name=amount,proto3" json:"amount"`
	MinAmount types.Coin                             `protobuf:"bytes,3,opt,name=min_amount,json=minAmount,proto3" json:"min_amount"`
	MaxAmount types.Coin                             `protobuf:"bytes,4,opt,name=max_amount,json=maxAmount,proto3" json:"max_amount"`
	DenomIn   string                                 `protobuf:"bytes,5,opt,name=denom_in,json=denomIn,proto3" json:"denom_in,omitempty"`
	DenomOut  string                                 `protobuf:"bytes,6,opt,name=denom_out,json=denomOut,proto3" json:"denom_out,omitempty"`
	Discount  github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,7,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient string                                 `protobuf:"bytes,8,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func NewMsgSwapByDenom added in v0.17.0

func NewMsgSwapByDenom(sender, recipient string, amount sdk.Coin, minAmount sdk.Coin, maxAmount sdk.Coin, denomIn string, denomOut string, discount sdk.Dec) *MsgSwapByDenom

func (*MsgSwapByDenom) Descriptor added in v0.17.0

func (*MsgSwapByDenom) Descriptor() ([]byte, []int)

func (*MsgSwapByDenom) GetAmount added in v0.17.0

func (m *MsgSwapByDenom) GetAmount() types.Coin

func (*MsgSwapByDenom) GetDenomIn added in v0.17.0

func (m *MsgSwapByDenom) GetDenomIn() string

func (*MsgSwapByDenom) GetDenomOut added in v0.17.0

func (m *MsgSwapByDenom) GetDenomOut() string

func (*MsgSwapByDenom) GetMaxAmount added in v0.17.0

func (m *MsgSwapByDenom) GetMaxAmount() types.Coin

func (*MsgSwapByDenom) GetMinAmount added in v0.17.0

func (m *MsgSwapByDenom) GetMinAmount() types.Coin

func (*MsgSwapByDenom) GetRecipient added in v0.18.0

func (m *MsgSwapByDenom) GetRecipient() string

func (*MsgSwapByDenom) GetSender added in v0.17.0

func (m *MsgSwapByDenom) GetSender() string

func (*MsgSwapByDenom) GetSignBytes added in v0.17.0

func (msg *MsgSwapByDenom) GetSignBytes() []byte

func (*MsgSwapByDenom) GetSigners added in v0.17.0

func (msg *MsgSwapByDenom) GetSigners() []sdk.AccAddress

func (*MsgSwapByDenom) Marshal added in v0.17.0

func (m *MsgSwapByDenom) Marshal() (dAtA []byte, err error)

func (*MsgSwapByDenom) MarshalTo added in v0.17.0

func (m *MsgSwapByDenom) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapByDenom) MarshalToSizedBuffer added in v0.17.0

func (m *MsgSwapByDenom) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapByDenom) ProtoMessage added in v0.17.0

func (*MsgSwapByDenom) ProtoMessage()

func (*MsgSwapByDenom) Reset added in v0.17.0

func (m *MsgSwapByDenom) Reset()

func (*MsgSwapByDenom) Route added in v0.17.0

func (msg *MsgSwapByDenom) Route() string

func (*MsgSwapByDenom) Size added in v0.17.0

func (m *MsgSwapByDenom) Size() (n int)

func (*MsgSwapByDenom) String added in v0.17.0

func (m *MsgSwapByDenom) String() string

func (*MsgSwapByDenom) Type added in v0.17.0

func (msg *MsgSwapByDenom) Type() string

func (*MsgSwapByDenom) Unmarshal added in v0.17.0

func (m *MsgSwapByDenom) Unmarshal(dAtA []byte) error

func (*MsgSwapByDenom) ValidateBasic added in v0.17.0

func (msg *MsgSwapByDenom) ValidateBasic() error

func (*MsgSwapByDenom) XXX_DiscardUnknown added in v0.17.0

func (m *MsgSwapByDenom) XXX_DiscardUnknown()

func (*MsgSwapByDenom) XXX_Marshal added in v0.17.0

func (m *MsgSwapByDenom) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapByDenom) XXX_Merge added in v0.17.0

func (m *MsgSwapByDenom) XXX_Merge(src proto.Message)

func (*MsgSwapByDenom) XXX_Size added in v0.17.0

func (m *MsgSwapByDenom) XXX_Size() int

func (*MsgSwapByDenom) XXX_Unmarshal added in v0.17.0

func (m *MsgSwapByDenom) XXX_Unmarshal(b []byte) error

type MsgSwapByDenomResponse added in v0.17.0

type MsgSwapByDenomResponse struct {
	Amount    types.Coin                             `protobuf:"bytes,1,opt,name=amount,proto3" json:"amount"`
	InRoute   []*SwapAmountInRoute                   `protobuf:"bytes,2,rep,name=in_route,json=inRoute,proto3" json:"in_route,omitempty"`
	OutRoute  []*SwapAmountOutRoute                  `protobuf:"bytes,3,rep,name=out_route,json=outRoute,proto3" json:"out_route,omitempty"`
	SpotPrice github_com_cosmos_cosmos_sdk_types.Dec `` /* 128-byte string literal not displayed */
	SwapFee   github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,5,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	Discount  github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,6,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient string                                 `protobuf:"bytes,7,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func (*MsgSwapByDenomResponse) Descriptor added in v0.17.0

func (*MsgSwapByDenomResponse) Descriptor() ([]byte, []int)

func (*MsgSwapByDenomResponse) GetAmount added in v0.17.0

func (m *MsgSwapByDenomResponse) GetAmount() types.Coin

func (*MsgSwapByDenomResponse) GetInRoute added in v0.17.0

func (m *MsgSwapByDenomResponse) GetInRoute() []*SwapAmountInRoute

func (*MsgSwapByDenomResponse) GetOutRoute added in v0.17.0

func (m *MsgSwapByDenomResponse) GetOutRoute() []*SwapAmountOutRoute

func (*MsgSwapByDenomResponse) GetRecipient added in v0.18.0

func (m *MsgSwapByDenomResponse) GetRecipient() string

func (*MsgSwapByDenomResponse) Marshal added in v0.17.0

func (m *MsgSwapByDenomResponse) Marshal() (dAtA []byte, err error)

func (*MsgSwapByDenomResponse) MarshalTo added in v0.17.0

func (m *MsgSwapByDenomResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapByDenomResponse) MarshalToSizedBuffer added in v0.17.0

func (m *MsgSwapByDenomResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapByDenomResponse) ProtoMessage added in v0.17.0

func (*MsgSwapByDenomResponse) ProtoMessage()

func (*MsgSwapByDenomResponse) Reset added in v0.17.0

func (m *MsgSwapByDenomResponse) Reset()

func (*MsgSwapByDenomResponse) Size added in v0.17.0

func (m *MsgSwapByDenomResponse) Size() (n int)

func (*MsgSwapByDenomResponse) String added in v0.17.0

func (m *MsgSwapByDenomResponse) String() string

func (*MsgSwapByDenomResponse) Unmarshal added in v0.17.0

func (m *MsgSwapByDenomResponse) Unmarshal(dAtA []byte) error

func (*MsgSwapByDenomResponse) XXX_DiscardUnknown added in v0.17.0

func (m *MsgSwapByDenomResponse) XXX_DiscardUnknown()

func (*MsgSwapByDenomResponse) XXX_Marshal added in v0.17.0

func (m *MsgSwapByDenomResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapByDenomResponse) XXX_Merge added in v0.17.0

func (m *MsgSwapByDenomResponse) XXX_Merge(src proto.Message)

func (*MsgSwapByDenomResponse) XXX_Size added in v0.17.0

func (m *MsgSwapByDenomResponse) XXX_Size() int

func (*MsgSwapByDenomResponse) XXX_Unmarshal added in v0.17.0

func (m *MsgSwapByDenomResponse) XXX_Unmarshal(b []byte) error

type MsgSwapExactAmountIn

type MsgSwapExactAmountIn struct {
	Sender            string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	Routes            []SwapAmountInRoute                    `protobuf:"bytes,2,rep,name=routes,proto3" json:"routes"`
	TokenIn           types.Coin                             `protobuf:"bytes,3,opt,name=token_in,json=tokenIn,proto3" json:"token_in"`
	TokenOutMinAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 156-byte string literal not displayed */
	Discount          github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,5,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient         string                                 `protobuf:"bytes,6,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func NewMsgSwapExactAmountIn

func NewMsgSwapExactAmountIn(sender, recipient string, tokenIn sdk.Coin, tokenOutMinAmount math.Int, swapRoutePoolIds []uint64, swapRouteDenoms []string, discount sdk.Dec) *MsgSwapExactAmountIn

func (*MsgSwapExactAmountIn) Descriptor

func (*MsgSwapExactAmountIn) Descriptor() ([]byte, []int)

func (*MsgSwapExactAmountIn) GetRecipient added in v0.18.0

func (m *MsgSwapExactAmountIn) GetRecipient() string

func (*MsgSwapExactAmountIn) GetRoutes

func (m *MsgSwapExactAmountIn) GetRoutes() []SwapAmountInRoute

func (*MsgSwapExactAmountIn) GetSender

func (m *MsgSwapExactAmountIn) GetSender() string

func (*MsgSwapExactAmountIn) GetSignBytes

func (msg *MsgSwapExactAmountIn) GetSignBytes() []byte

func (*MsgSwapExactAmountIn) GetSigners

func (msg *MsgSwapExactAmountIn) GetSigners() []sdk.AccAddress

func (*MsgSwapExactAmountIn) GetTokenIn

func (m *MsgSwapExactAmountIn) GetTokenIn() types.Coin

func (*MsgSwapExactAmountIn) Marshal

func (m *MsgSwapExactAmountIn) Marshal() (dAtA []byte, err error)

func (*MsgSwapExactAmountIn) MarshalTo

func (m *MsgSwapExactAmountIn) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapExactAmountIn) MarshalToSizedBuffer

func (m *MsgSwapExactAmountIn) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapExactAmountIn) ProtoMessage

func (*MsgSwapExactAmountIn) ProtoMessage()

func (*MsgSwapExactAmountIn) Reset

func (m *MsgSwapExactAmountIn) Reset()

func (*MsgSwapExactAmountIn) Route

func (msg *MsgSwapExactAmountIn) Route() string

func (*MsgSwapExactAmountIn) Size

func (m *MsgSwapExactAmountIn) Size() (n int)

func (*MsgSwapExactAmountIn) String

func (m *MsgSwapExactAmountIn) String() string

func (*MsgSwapExactAmountIn) Type

func (msg *MsgSwapExactAmountIn) Type() string

func (*MsgSwapExactAmountIn) Unmarshal

func (m *MsgSwapExactAmountIn) Unmarshal(dAtA []byte) error

func (*MsgSwapExactAmountIn) ValidateBasic

func (msg *MsgSwapExactAmountIn) ValidateBasic() error

func (*MsgSwapExactAmountIn) XXX_DiscardUnknown

func (m *MsgSwapExactAmountIn) XXX_DiscardUnknown()

func (*MsgSwapExactAmountIn) XXX_Marshal

func (m *MsgSwapExactAmountIn) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapExactAmountIn) XXX_Merge

func (m *MsgSwapExactAmountIn) XXX_Merge(src proto.Message)

func (*MsgSwapExactAmountIn) XXX_Size

func (m *MsgSwapExactAmountIn) XXX_Size() int

func (*MsgSwapExactAmountIn) XXX_Unmarshal

func (m *MsgSwapExactAmountIn) XXX_Unmarshal(b []byte) error

type MsgSwapExactAmountInResponse

type MsgSwapExactAmountInResponse struct {
	TokenOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 145-byte string literal not displayed */
	SwapFee        github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	Discount       github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient      string                                 `protobuf:"bytes,4,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func (*MsgSwapExactAmountInResponse) Descriptor

func (*MsgSwapExactAmountInResponse) Descriptor() ([]byte, []int)

func (*MsgSwapExactAmountInResponse) GetRecipient added in v0.18.0

func (m *MsgSwapExactAmountInResponse) GetRecipient() string

func (*MsgSwapExactAmountInResponse) Marshal

func (m *MsgSwapExactAmountInResponse) Marshal() (dAtA []byte, err error)

func (*MsgSwapExactAmountInResponse) MarshalTo

func (m *MsgSwapExactAmountInResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapExactAmountInResponse) MarshalToSizedBuffer

func (m *MsgSwapExactAmountInResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapExactAmountInResponse) ProtoMessage

func (*MsgSwapExactAmountInResponse) ProtoMessage()

func (*MsgSwapExactAmountInResponse) Reset

func (m *MsgSwapExactAmountInResponse) Reset()

func (*MsgSwapExactAmountInResponse) Size

func (m *MsgSwapExactAmountInResponse) Size() (n int)

func (*MsgSwapExactAmountInResponse) String

func (*MsgSwapExactAmountInResponse) Unmarshal

func (m *MsgSwapExactAmountInResponse) Unmarshal(dAtA []byte) error

func (*MsgSwapExactAmountInResponse) XXX_DiscardUnknown

func (m *MsgSwapExactAmountInResponse) XXX_DiscardUnknown()

func (*MsgSwapExactAmountInResponse) XXX_Marshal

func (m *MsgSwapExactAmountInResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapExactAmountInResponse) XXX_Merge

func (m *MsgSwapExactAmountInResponse) XXX_Merge(src proto.Message)

func (*MsgSwapExactAmountInResponse) XXX_Size

func (m *MsgSwapExactAmountInResponse) XXX_Size() int

func (*MsgSwapExactAmountInResponse) XXX_Unmarshal

func (m *MsgSwapExactAmountInResponse) XXX_Unmarshal(b []byte) error

type MsgSwapExactAmountOut

type MsgSwapExactAmountOut struct {
	Sender           string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty"`
	Routes           []SwapAmountOutRoute                   `protobuf:"bytes,2,rep,name=routes,proto3" json:"routes"`
	TokenOut         types.Coin                             `protobuf:"bytes,3,opt,name=token_out,json=tokenOut,proto3" json:"token_out"`
	TokenInMaxAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 153-byte string literal not displayed */
	Discount         github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,5,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient        string                                 `protobuf:"bytes,6,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func NewMsgSwapExactAmountOut

func NewMsgSwapExactAmountOut(sender, recipient string, tokenOut sdk.Coin, tokenInMaxAmount math.Int, swapRoutePoolIds []uint64, swapRouteDenoms []string, discount sdk.Dec) *MsgSwapExactAmountOut

func (*MsgSwapExactAmountOut) Descriptor

func (*MsgSwapExactAmountOut) Descriptor() ([]byte, []int)

func (*MsgSwapExactAmountOut) GetRecipient added in v0.18.0

func (m *MsgSwapExactAmountOut) GetRecipient() string

func (*MsgSwapExactAmountOut) GetRoutes

func (m *MsgSwapExactAmountOut) GetRoutes() []SwapAmountOutRoute

func (*MsgSwapExactAmountOut) GetSender

func (m *MsgSwapExactAmountOut) GetSender() string

func (*MsgSwapExactAmountOut) GetSignBytes

func (msg *MsgSwapExactAmountOut) GetSignBytes() []byte

func (*MsgSwapExactAmountOut) GetSigners

func (msg *MsgSwapExactAmountOut) GetSigners() []sdk.AccAddress

func (*MsgSwapExactAmountOut) GetTokenOut

func (m *MsgSwapExactAmountOut) GetTokenOut() types.Coin

func (*MsgSwapExactAmountOut) Marshal

func (m *MsgSwapExactAmountOut) Marshal() (dAtA []byte, err error)

func (*MsgSwapExactAmountOut) MarshalTo

func (m *MsgSwapExactAmountOut) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapExactAmountOut) MarshalToSizedBuffer

func (m *MsgSwapExactAmountOut) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapExactAmountOut) ProtoMessage

func (*MsgSwapExactAmountOut) ProtoMessage()

func (*MsgSwapExactAmountOut) Reset

func (m *MsgSwapExactAmountOut) Reset()

func (*MsgSwapExactAmountOut) Route

func (msg *MsgSwapExactAmountOut) Route() string

func (*MsgSwapExactAmountOut) Size

func (m *MsgSwapExactAmountOut) Size() (n int)

func (*MsgSwapExactAmountOut) String

func (m *MsgSwapExactAmountOut) String() string

func (*MsgSwapExactAmountOut) Type

func (msg *MsgSwapExactAmountOut) Type() string

func (*MsgSwapExactAmountOut) Unmarshal

func (m *MsgSwapExactAmountOut) Unmarshal(dAtA []byte) error

func (*MsgSwapExactAmountOut) ValidateBasic

func (msg *MsgSwapExactAmountOut) ValidateBasic() error

func (*MsgSwapExactAmountOut) XXX_DiscardUnknown

func (m *MsgSwapExactAmountOut) XXX_DiscardUnknown()

func (*MsgSwapExactAmountOut) XXX_Marshal

func (m *MsgSwapExactAmountOut) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapExactAmountOut) XXX_Merge

func (m *MsgSwapExactAmountOut) XXX_Merge(src proto.Message)

func (*MsgSwapExactAmountOut) XXX_Size

func (m *MsgSwapExactAmountOut) XXX_Size() int

func (*MsgSwapExactAmountOut) XXX_Unmarshal

func (m *MsgSwapExactAmountOut) XXX_Unmarshal(b []byte) error

type MsgSwapExactAmountOutResponse

type MsgSwapExactAmountOutResponse struct {
	TokenInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 142-byte string literal not displayed */
	SwapFee       github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	Discount      github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	Recipient     string                                 `protobuf:"bytes,4,opt,name=recipient,proto3" json:"recipient,omitempty"`
}

func (*MsgSwapExactAmountOutResponse) Descriptor

func (*MsgSwapExactAmountOutResponse) Descriptor() ([]byte, []int)

func (*MsgSwapExactAmountOutResponse) GetRecipient added in v0.18.0

func (m *MsgSwapExactAmountOutResponse) GetRecipient() string

func (*MsgSwapExactAmountOutResponse) Marshal

func (m *MsgSwapExactAmountOutResponse) Marshal() (dAtA []byte, err error)

func (*MsgSwapExactAmountOutResponse) MarshalTo

func (m *MsgSwapExactAmountOutResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgSwapExactAmountOutResponse) MarshalToSizedBuffer

func (m *MsgSwapExactAmountOutResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgSwapExactAmountOutResponse) ProtoMessage

func (*MsgSwapExactAmountOutResponse) ProtoMessage()

func (*MsgSwapExactAmountOutResponse) Reset

func (m *MsgSwapExactAmountOutResponse) Reset()

func (*MsgSwapExactAmountOutResponse) Size

func (m *MsgSwapExactAmountOutResponse) Size() (n int)

func (*MsgSwapExactAmountOutResponse) String

func (*MsgSwapExactAmountOutResponse) Unmarshal

func (m *MsgSwapExactAmountOutResponse) Unmarshal(dAtA []byte) error

func (*MsgSwapExactAmountOutResponse) XXX_DiscardUnknown

func (m *MsgSwapExactAmountOutResponse) XXX_DiscardUnknown()

func (*MsgSwapExactAmountOutResponse) XXX_Marshal

func (m *MsgSwapExactAmountOutResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgSwapExactAmountOutResponse) XXX_Merge

func (m *MsgSwapExactAmountOutResponse) XXX_Merge(src proto.Message)

func (*MsgSwapExactAmountOutResponse) XXX_Size

func (m *MsgSwapExactAmountOutResponse) XXX_Size() int

func (*MsgSwapExactAmountOutResponse) XXX_Unmarshal

func (m *MsgSwapExactAmountOutResponse) XXX_Unmarshal(b []byte) error

type MsgUpdateParams added in v0.29.31

type MsgUpdateParams struct {
	Authority string  `protobuf:"bytes,1,opt,name=authority,proto3" json:"authority,omitempty"`
	Params    *Params `protobuf:"bytes,2,opt,name=params,proto3" json:"params,omitempty"`
}

func NewMsgUpdateParams added in v0.29.31

func NewMsgUpdateParams(authority string, params *Params) *MsgUpdateParams

func (*MsgUpdateParams) Descriptor added in v0.29.31

func (*MsgUpdateParams) Descriptor() ([]byte, []int)

func (*MsgUpdateParams) GetAuthority added in v0.29.31

func (m *MsgUpdateParams) GetAuthority() string

func (*MsgUpdateParams) GetParams added in v0.29.31

func (m *MsgUpdateParams) GetParams() *Params

func (*MsgUpdateParams) GetSignBytes added in v0.29.31

func (msg *MsgUpdateParams) GetSignBytes() []byte

func (*MsgUpdateParams) GetSigners added in v0.29.31

func (msg *MsgUpdateParams) GetSigners() []sdk.AccAddress

func (*MsgUpdateParams) Marshal added in v0.29.31

func (m *MsgUpdateParams) Marshal() (dAtA []byte, err error)

func (*MsgUpdateParams) MarshalTo added in v0.29.31

func (m *MsgUpdateParams) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdateParams) MarshalToSizedBuffer added in v0.29.31

func (m *MsgUpdateParams) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdateParams) ProtoMessage added in v0.29.31

func (*MsgUpdateParams) ProtoMessage()

func (*MsgUpdateParams) Reset added in v0.29.31

func (m *MsgUpdateParams) Reset()

func (*MsgUpdateParams) Route added in v0.29.31

func (msg *MsgUpdateParams) Route() string

func (*MsgUpdateParams) Size added in v0.29.31

func (m *MsgUpdateParams) Size() (n int)

func (*MsgUpdateParams) String added in v0.29.31

func (m *MsgUpdateParams) String() string

func (*MsgUpdateParams) Type added in v0.29.31

func (msg *MsgUpdateParams) Type() string

func (*MsgUpdateParams) Unmarshal added in v0.29.31

func (m *MsgUpdateParams) Unmarshal(dAtA []byte) error

func (*MsgUpdateParams) ValidateBasic added in v0.29.31

func (msg *MsgUpdateParams) ValidateBasic() error

func (*MsgUpdateParams) XXX_DiscardUnknown added in v0.29.31

func (m *MsgUpdateParams) XXX_DiscardUnknown()

func (*MsgUpdateParams) XXX_Marshal added in v0.29.31

func (m *MsgUpdateParams) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdateParams) XXX_Merge added in v0.29.31

func (m *MsgUpdateParams) XXX_Merge(src proto.Message)

func (*MsgUpdateParams) XXX_Size added in v0.29.31

func (m *MsgUpdateParams) XXX_Size() int

func (*MsgUpdateParams) XXX_Unmarshal added in v0.29.31

func (m *MsgUpdateParams) XXX_Unmarshal(b []byte) error

type MsgUpdateParamsResponse added in v0.29.31

type MsgUpdateParamsResponse struct {
}

func (*MsgUpdateParamsResponse) Descriptor added in v0.29.31

func (*MsgUpdateParamsResponse) Descriptor() ([]byte, []int)

func (*MsgUpdateParamsResponse) Marshal added in v0.29.31

func (m *MsgUpdateParamsResponse) Marshal() (dAtA []byte, err error)

func (*MsgUpdateParamsResponse) MarshalTo added in v0.29.31

func (m *MsgUpdateParamsResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdateParamsResponse) MarshalToSizedBuffer added in v0.29.31

func (m *MsgUpdateParamsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdateParamsResponse) ProtoMessage added in v0.29.31

func (*MsgUpdateParamsResponse) ProtoMessage()

func (*MsgUpdateParamsResponse) Reset added in v0.29.31

func (m *MsgUpdateParamsResponse) Reset()

func (*MsgUpdateParamsResponse) Size added in v0.29.31

func (m *MsgUpdateParamsResponse) Size() (n int)

func (*MsgUpdateParamsResponse) String added in v0.29.31

func (m *MsgUpdateParamsResponse) String() string

func (*MsgUpdateParamsResponse) Unmarshal added in v0.29.31

func (m *MsgUpdateParamsResponse) Unmarshal(dAtA []byte) error

func (*MsgUpdateParamsResponse) XXX_DiscardUnknown added in v0.29.31

func (m *MsgUpdateParamsResponse) XXX_DiscardUnknown()

func (*MsgUpdateParamsResponse) XXX_Marshal added in v0.29.31

func (m *MsgUpdateParamsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdateParamsResponse) XXX_Merge added in v0.29.31

func (m *MsgUpdateParamsResponse) XXX_Merge(src proto.Message)

func (*MsgUpdateParamsResponse) XXX_Size added in v0.29.31

func (m *MsgUpdateParamsResponse) XXX_Size() int

func (*MsgUpdateParamsResponse) XXX_Unmarshal added in v0.29.31

func (m *MsgUpdateParamsResponse) XXX_Unmarshal(b []byte) error

type MsgUpdatePoolParams added in v0.18.0

type MsgUpdatePoolParams struct {
	Authority  string      `protobuf:"bytes,1,opt,name=authority,proto3" json:"authority,omitempty"`
	PoolId     uint64      `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	PoolParams *PoolParams `protobuf:"bytes,3,opt,name=pool_params,json=poolParams,proto3" json:"pool_params,omitempty"`
}

func NewMsgUpdatePoolParams added in v0.18.0

func NewMsgUpdatePoolParams(authority string, poolId uint64, poolParams *PoolParams) *MsgUpdatePoolParams

func (*MsgUpdatePoolParams) Descriptor added in v0.18.0

func (*MsgUpdatePoolParams) Descriptor() ([]byte, []int)

func (*MsgUpdatePoolParams) GetAuthority added in v0.29.31

func (m *MsgUpdatePoolParams) GetAuthority() string

func (*MsgUpdatePoolParams) GetPoolId added in v0.18.0

func (m *MsgUpdatePoolParams) GetPoolId() uint64

func (*MsgUpdatePoolParams) GetPoolParams added in v0.18.0

func (m *MsgUpdatePoolParams) GetPoolParams() *PoolParams

func (*MsgUpdatePoolParams) GetSignBytes added in v0.18.0

func (msg *MsgUpdatePoolParams) GetSignBytes() []byte

func (*MsgUpdatePoolParams) GetSigners added in v0.18.0

func (msg *MsgUpdatePoolParams) GetSigners() []sdk.AccAddress

func (*MsgUpdatePoolParams) Marshal added in v0.18.0

func (m *MsgUpdatePoolParams) Marshal() (dAtA []byte, err error)

func (*MsgUpdatePoolParams) MarshalTo added in v0.18.0

func (m *MsgUpdatePoolParams) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdatePoolParams) MarshalToSizedBuffer added in v0.18.0

func (m *MsgUpdatePoolParams) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdatePoolParams) ProtoMessage added in v0.18.0

func (*MsgUpdatePoolParams) ProtoMessage()

func (*MsgUpdatePoolParams) Reset added in v0.18.0

func (m *MsgUpdatePoolParams) Reset()

func (*MsgUpdatePoolParams) Route added in v0.18.0

func (msg *MsgUpdatePoolParams) Route() string

func (*MsgUpdatePoolParams) Size added in v0.18.0

func (m *MsgUpdatePoolParams) Size() (n int)

func (*MsgUpdatePoolParams) String added in v0.18.0

func (m *MsgUpdatePoolParams) String() string

func (*MsgUpdatePoolParams) Type added in v0.18.0

func (msg *MsgUpdatePoolParams) Type() string

func (*MsgUpdatePoolParams) Unmarshal added in v0.18.0

func (m *MsgUpdatePoolParams) Unmarshal(dAtA []byte) error

func (*MsgUpdatePoolParams) ValidateBasic added in v0.18.0

func (msg *MsgUpdatePoolParams) ValidateBasic() error

func (*MsgUpdatePoolParams) XXX_DiscardUnknown added in v0.18.0

func (m *MsgUpdatePoolParams) XXX_DiscardUnknown()

func (*MsgUpdatePoolParams) XXX_Marshal added in v0.18.0

func (m *MsgUpdatePoolParams) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdatePoolParams) XXX_Merge added in v0.18.0

func (m *MsgUpdatePoolParams) XXX_Merge(src proto.Message)

func (*MsgUpdatePoolParams) XXX_Size added in v0.18.0

func (m *MsgUpdatePoolParams) XXX_Size() int

func (*MsgUpdatePoolParams) XXX_Unmarshal added in v0.18.0

func (m *MsgUpdatePoolParams) XXX_Unmarshal(b []byte) error

type MsgUpdatePoolParamsResponse added in v0.18.0

type MsgUpdatePoolParamsResponse struct {
	PoolId     uint64      `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	PoolParams *PoolParams `protobuf:"bytes,2,opt,name=pool_params,json=poolParams,proto3" json:"pool_params,omitempty"`
}

func (*MsgUpdatePoolParamsResponse) Descriptor added in v0.18.0

func (*MsgUpdatePoolParamsResponse) Descriptor() ([]byte, []int)

func (*MsgUpdatePoolParamsResponse) GetPoolId added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) GetPoolId() uint64

func (*MsgUpdatePoolParamsResponse) GetPoolParams added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) GetPoolParams() *PoolParams

func (*MsgUpdatePoolParamsResponse) Marshal added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) Marshal() (dAtA []byte, err error)

func (*MsgUpdatePoolParamsResponse) MarshalTo added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) MarshalTo(dAtA []byte) (int, error)

func (*MsgUpdatePoolParamsResponse) MarshalToSizedBuffer added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*MsgUpdatePoolParamsResponse) ProtoMessage added in v0.18.0

func (*MsgUpdatePoolParamsResponse) ProtoMessage()

func (*MsgUpdatePoolParamsResponse) Reset added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) Reset()

func (*MsgUpdatePoolParamsResponse) Size added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) Size() (n int)

func (*MsgUpdatePoolParamsResponse) String added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) String() string

func (*MsgUpdatePoolParamsResponse) Unmarshal added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) Unmarshal(dAtA []byte) error

func (*MsgUpdatePoolParamsResponse) XXX_DiscardUnknown added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) XXX_DiscardUnknown()

func (*MsgUpdatePoolParamsResponse) XXX_Marshal added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*MsgUpdatePoolParamsResponse) XXX_Merge added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) XXX_Merge(src proto.Message)

func (*MsgUpdatePoolParamsResponse) XXX_Size added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) XXX_Size() int

func (*MsgUpdatePoolParamsResponse) XXX_Unmarshal added in v0.18.0

func (m *MsgUpdatePoolParamsResponse) XXX_Unmarshal(b []byte) error

type MultiAmmHooks

type MultiAmmHooks []AmmHooks

combine multiple amm hooks, all hook functions are run in array sequence.

func NewMultiAmmHooks

func NewMultiAmmHooks(hooks ...AmmHooks) MultiAmmHooks

Creates hooks for the Amm Module.

func (MultiAmmHooks) AfterExitPool

func (h MultiAmmHooks) AfterExitPool(ctx sdk.Context, sender sdk.AccAddress, pool Pool, shareInAmount math.Int, exitCoins sdk.Coins) error

func (MultiAmmHooks) AfterJoinPool

func (h MultiAmmHooks) AfterJoinPool(ctx sdk.Context, sender sdk.AccAddress, pool Pool, enterCoins sdk.Coins, shareOutAmount math.Int)

func (MultiAmmHooks) AfterPoolCreated

func (h MultiAmmHooks) AfterPoolCreated(ctx sdk.Context, sender sdk.AccAddress, pool Pool)

func (MultiAmmHooks) AfterSwap

func (h MultiAmmHooks) AfterSwap(ctx sdk.Context, sender sdk.AccAddress, pool Pool, input sdk.Coins, output sdk.Coins) error

type MultihopRoute

type MultihopRoute interface {
	Length() int
	PoolIds() []uint64
	IntermediateDenoms() []string
}

type OracleKeeper

type OracleKeeper interface {
	GetAssetPrice(ctx sdk.Context, asset string) (oracletypes.Price, bool)
	GetAssetPriceFromDenom(ctx sdk.Context, denom string) sdk.Dec
	GetPriceFeeder(ctx sdk.Context, feeder string) (val oracletypes.PriceFeeder, found bool)
}

OracleKeeper defines the expected interface needed to retrieve price info

type OraclePoolSlippageTrack added in v0.13.0

type OraclePoolSlippageTrack struct {
	PoolId    uint64                                   `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	Timestamp uint64                                   `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	Tracked   github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,3,rep,name=tracked,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"tracked"`
}

func (*OraclePoolSlippageTrack) Descriptor added in v0.13.0

func (*OraclePoolSlippageTrack) Descriptor() ([]byte, []int)

func (*OraclePoolSlippageTrack) GetPoolId added in v0.13.0

func (m *OraclePoolSlippageTrack) GetPoolId() uint64

func (*OraclePoolSlippageTrack) GetTimestamp added in v0.13.0

func (m *OraclePoolSlippageTrack) GetTimestamp() uint64

func (*OraclePoolSlippageTrack) GetTracked added in v0.13.0

func (*OraclePoolSlippageTrack) Marshal added in v0.13.0

func (m *OraclePoolSlippageTrack) Marshal() (dAtA []byte, err error)

func (*OraclePoolSlippageTrack) MarshalTo added in v0.13.0

func (m *OraclePoolSlippageTrack) MarshalTo(dAtA []byte) (int, error)

func (*OraclePoolSlippageTrack) MarshalToSizedBuffer added in v0.13.0

func (m *OraclePoolSlippageTrack) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*OraclePoolSlippageTrack) ProtoMessage added in v0.13.0

func (*OraclePoolSlippageTrack) ProtoMessage()

func (*OraclePoolSlippageTrack) Reset added in v0.13.0

func (m *OraclePoolSlippageTrack) Reset()

func (*OraclePoolSlippageTrack) Size added in v0.13.0

func (m *OraclePoolSlippageTrack) Size() (n int)

func (*OraclePoolSlippageTrack) String added in v0.13.0

func (m *OraclePoolSlippageTrack) String() string

func (*OraclePoolSlippageTrack) Unmarshal added in v0.13.0

func (m *OraclePoolSlippageTrack) Unmarshal(dAtA []byte) error

func (*OraclePoolSlippageTrack) XXX_DiscardUnknown added in v0.13.0

func (m *OraclePoolSlippageTrack) XXX_DiscardUnknown()

func (*OraclePoolSlippageTrack) XXX_Marshal added in v0.13.0

func (m *OraclePoolSlippageTrack) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*OraclePoolSlippageTrack) XXX_Merge added in v0.13.0

func (m *OraclePoolSlippageTrack) XXX_Merge(src proto.Message)

func (*OraclePoolSlippageTrack) XXX_Size added in v0.13.0

func (m *OraclePoolSlippageTrack) XXX_Size() int

func (*OraclePoolSlippageTrack) XXX_Unmarshal added in v0.13.0

func (m *OraclePoolSlippageTrack) XXX_Unmarshal(b []byte) error

type Params

type Params struct {
	PoolCreationFee       github_com_cosmos_cosmos_sdk_types.Int `` /* 148-byte string literal not displayed */
	SlippageTrackDuration uint64                                 `` /* 127-byte string literal not displayed */
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams(poolCreationFee math.Int, slippageTrackDuration uint64) Params

NewParams creates a new Params instance

func (*Params) Descriptor

func (*Params) Descriptor() ([]byte, []int)

func (*Params) GetSlippageTrackDuration added in v0.29.31

func (m *Params) GetSlippageTrackDuration() uint64

func (*Params) Marshal

func (m *Params) Marshal() (dAtA []byte, err error)

func (*Params) MarshalTo

func (m *Params) MarshalTo(dAtA []byte) (int, error)

func (*Params) MarshalToSizedBuffer

func (m *Params) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

func (m *Params) Size() (n int)

func (Params) String

func (p Params) String() string

String implements the Stringer interface.

func (*Params) Unmarshal

func (m *Params) Unmarshal(dAtA []byte) error

func (Params) Validate

func (p Params) Validate() error

Validate validates the set of params

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

func (m *Params) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Params) XXX_Merge

func (m *Params) XXX_Merge(src proto.Message)

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

func (m *Params) XXX_Unmarshal(b []byte) error

type Pool

type Pool struct {
	PoolId            uint64                                 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	Address           string                                 `protobuf:"bytes,2,opt,name=address,proto3" json:"address,omitempty"`
	PoolParams        PoolParams                             `protobuf:"bytes,3,opt,name=pool_params,json=poolParams,proto3" json:"pool_params"`
	TotalShares       types.Coin                             `protobuf:"bytes,4,opt,name=total_shares,json=totalShares,proto3" json:"total_shares"`
	PoolAssets        []PoolAsset                            `protobuf:"bytes,5,rep,name=pool_assets,json=poolAssets,proto3" json:"pool_assets"`
	TotalWeight       github_com_cosmos_cosmos_sdk_types.Int `` /* 134-byte string literal not displayed */
	RebalanceTreasury string                                 `protobuf:"bytes,7,opt,name=rebalance_treasury,json=rebalanceTreasury,proto3" json:"rebalance_treasury,omitempty"`
}

func NewBalancerPool

func NewBalancerPool(poolId uint64, balancerPoolParams PoolParams, assets []PoolAsset, blockTime time.Time) (Pool, error)

NewPool returns a weighted CPMM pool with the provided parameters, and initial assets. Invariants that are assumed to be satisfied and not checked: (This is handled in ValidateBasic) * 2 <= len(assets) <= 8 * FutureGovernor is valid * poolID doesn't already exist

func (*Pool) AddTotalShares

func (p *Pool) AddTotalShares(amt math.Int)

func (*Pool) CalcExitPoolCoinsFromShares

func (p *Pool) CalcExitPoolCoinsFromShares(ctx sdk.Context, oracleKeeper OracleKeeper, accountedPoolKeeper AccountedPoolKeeper, exitingShares math.Int, tokenOutDenom string) (exitedCoins sdk.Coins, err error)

func (Pool) CalcGivenInSlippage added in v0.11.0

func (p Pool) CalcGivenInSlippage(
	ctx sdk.Context,
	oracleKeeper OracleKeeper,
	snapshot *Pool,
	tokensIn sdk.Coins,
	tokenOutDenom string,
	accPoolKeeper AccountedPoolKeeper,
) (sdk.Dec, error)

func (Pool) CalcGivenOutSlippage added in v0.11.0

func (p Pool) CalcGivenOutSlippage(
	ctx sdk.Context,
	oracleKeeper OracleKeeper,
	snapshot *Pool,
	tokensOut sdk.Coins,
	tokenInDenom string,
	accPoolKeeper AccountedPoolKeeper,
) (sdk.Dec, error)

func (Pool) CalcInAmtGivenOut

func (p Pool) CalcInAmtGivenOut(
	ctx sdk.Context,
	oracle OracleKeeper,
	snapshot *Pool,
	tokensOut sdk.Coins, tokenInDenom string, swapFee sdk.Dec, accountedPool AccountedPoolKeeper) (
	tokenIn sdk.Coin, slippage sdk.Dec, err error,
)

CalcInAmtGivenOut calculates token to be provided, fee added, given the swapped out amount, using solveConstantFunctionInvariant.

func (*Pool) CalcJoinPoolNoSwapShares

func (p *Pool) CalcJoinPoolNoSwapShares(tokensIn sdk.Coins) (numShares math.Int, tokensJoined sdk.Coins, err error)

CalcJoinPoolNoSwapShares calculates the number of shares created to execute an all-asset pool join with the provided amount of `tokensIn`. The input tokens must contain the same tokens as in the pool.

Returns the number of shares created, the amount of coins actually joined into the pool, (in case of not being able to fully join), and the remaining tokens in `tokensIn` after joining. If an all-asset join is not possible, returns an error.

Since CalcJoinPoolNoSwapShares is non-mutative, the steps for updating pool shares / liquidity are more complex / don't just alter the state. We should simplify this logic further in the future using multi-join equations.

func (*Pool) CalcJoinValueWithoutSlippage added in v0.11.0

func (p *Pool) CalcJoinValueWithoutSlippage(ctx sdk.Context, oracleKeeper OracleKeeper, accountedPoolKeeper AccountedPoolKeeper, tokensIn sdk.Coins) (math.LegacyDec, error)

func (Pool) CalcOutAmtGivenIn

func (p Pool) CalcOutAmtGivenIn(
	ctx sdk.Context,
	oracle OracleKeeper,
	snapshot *Pool,
	tokensIn sdk.Coins,
	tokenOutDenom string,
	swapFee sdk.Dec,
	accountedPool AccountedPoolKeeper,
) (sdk.Coin, sdk.Dec, error)

CalcOutAmtGivenIn calculates tokens to be swapped out given the provided amount and fee deducted, using solveConstantFunctionInvariant.

func (*Pool) CalcSingleAssetJoinPoolShares added in v0.12.0

func (p *Pool) CalcSingleAssetJoinPoolShares(tokensIn sdk.Coins) (numShares math.Int, tokensJoined sdk.Coins, err error)

CalcJoinPoolShares calculates the number of shares created to join pool with the provided amount of `tokenIn`. The input tokens must either be: - a single token - contain exactly the same tokens as the pool contains

It returns the number of shares created, the amount of coins actually joined into the pool (in case of not being able to fully join), or an error.

func (*Pool) Descriptor

func (*Pool) Descriptor() ([]byte, []int)

func (*Pool) ExitPool

func (p *Pool) ExitPool(ctx sdk.Context, oracleKeeper OracleKeeper, accountedPoolKeeper AccountedPoolKeeper, exitingShares math.Int, tokenOutDenom string) (exitingCoins sdk.Coins, err error)

func (*Pool) GetAddress

func (m *Pool) GetAddress() string

func (Pool) GetAllPoolAssets

func (p Pool) GetAllPoolAssets() []PoolAsset

func (Pool) GetMaximalNoSwapLPAmount added in v0.23.0

func (pool Pool) GetMaximalNoSwapLPAmount(shareOutAmount math.Int) (neededLpLiquidity sdk.Coins, err error)

getMaximalNoSwapLPAmount returns the coins(lp liquidity) needed to get the specified amount of shares in the pool. Steps to getting the needed lp liquidity coins needed for the share of the pools are 1. calculate how much percent of the pool does given share account for(# of input shares / # of current total shares) 2. since we know how much % of the pool we want, iterate through all pool liquidity to calculate how much coins we need for each pool asset.

func (Pool) GetPoolAssetAndIndex

func (p Pool) GetPoolAssetAndIndex(denom string) (int, PoolAsset, error)

Returns a pool asset, and its index. If err != nil, then the index will be valid.

func (*Pool) GetPoolAssets

func (m *Pool) GetPoolAssets() []PoolAsset

func (*Pool) GetPoolId

func (m *Pool) GetPoolId() uint64

func (*Pool) GetPoolParams

func (m *Pool) GetPoolParams() PoolParams

func (*Pool) GetRebalanceTreasury

func (m *Pool) GetRebalanceTreasury() string

func (*Pool) GetTokenARate added in v0.29.14

func (p *Pool) GetTokenARate(
	ctx sdk.Context,
	oracleKeeper OracleKeeper,
	snapshot *Pool,
	tokenA string,
	tokenB string,
	accPoolKeeper AccountedPoolKeeper,
) (rate sdk.Dec, err error)

SwapOutAmtGivenIn is a mutative method for CalcOutAmtGivenIn, which includes the actual swap.

func (Pool) GetTotalPoolLiquidity

func (p Pool) GetTotalPoolLiquidity() sdk.Coins

func (*Pool) GetTotalShares

func (m *Pool) GetTotalShares() types.Coin

func (*Pool) IncreaseLiquidity

func (p *Pool) IncreaseLiquidity(sharesOut math.Int, coinsIn sdk.Coins)

func (*Pool) JoinPool added in v0.12.0

func (p *Pool) JoinPool(
	ctx sdk.Context, snapshot *Pool,
	oracleKeeper OracleKeeper,
	accountedPoolKeeper AccountedPoolKeeper, tokensIn sdk.Coins,
) (numShares math.Int, slippage sdk.Dec, weightBalanceBonus sdk.Dec, err error)

JoinPool calculates the number of shares needed for an all-asset join given tokensIn with swapFee applied. It updates the liquidity if the pool is joined successfully. If not, returns error.

func (*Pool) LpTokenPrice added in v0.29.31

func (p *Pool) LpTokenPrice(ctx sdk.Context, oracleKeeper OracleKeeper) (sdk.Dec, error)

func (*Pool) Marshal

func (m *Pool) Marshal() (dAtA []byte, err error)

func (*Pool) MarshalTo

func (m *Pool) MarshalTo(dAtA []byte) (int, error)

func (*Pool) MarshalToSizedBuffer

func (m *Pool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (Pool) NewPoolAssetsAfterSwap

func (p Pool) NewPoolAssetsAfterSwap(inCoins sdk.Coins, outCoins sdk.Coins) (poolAssets []PoolAsset, err error)

func (*Pool) ProtoMessage

func (*Pool) ProtoMessage()

func (*Pool) Reset

func (m *Pool) Reset()

func (*Pool) SetInitialPoolAssets

func (p *Pool) SetInitialPoolAssets(PoolAssets []PoolAsset) error

SetInitialPoolAssets sets the PoolAssets in the pool. It is only designed to be called at the pool's creation. If the same denom's PoolAsset exists, will return error.

The list of PoolAssets must be sorted. This is done to enable fast searching for a PoolAsset by denomination. TODO: Unify story for validation of []PoolAsset, some is here, some is in CreatePool.ValidateBasic()

func (*Pool) Size

func (m *Pool) Size() (n int)

func (Pool) StackedRatioFromSnapshot added in v0.11.0

func (p Pool) StackedRatioFromSnapshot(ctx sdk.Context, oracleKeeper OracleKeeper, snapshot *Pool) sdk.Dec

func (*Pool) String

func (m *Pool) String() string

func (*Pool) SwapInAmtGivenOut

func (p *Pool) SwapInAmtGivenOut(
	ctx sdk.Context, oracleKeeper OracleKeeper, snapshot *Pool,
	tokensOut sdk.Coins, tokenInDenom string, swapFee sdk.Dec, accPoolKeeper AccountedPoolKeeper) (
	tokenIn sdk.Coin, slippage, slippageAmount sdk.Dec, weightBalanceBonus sdk.Dec, err error,
)

SwapInAmtGivenOut is a mutative method for CalcOutAmtGivenIn, which includes the actual swap.

func (*Pool) SwapOutAmtGivenIn

func (p *Pool) SwapOutAmtGivenIn(
	ctx sdk.Context,
	oracleKeeper OracleKeeper,
	snapshot *Pool,
	tokensIn sdk.Coins,
	tokenOutDenom string,
	swapFee sdk.Dec,
	accPoolKeeper AccountedPoolKeeper,
) (tokenOut sdk.Coin, slippage, slippageAmount sdk.Dec, weightBalanceBonus sdk.Dec, err error)

SwapOutAmtGivenIn is a mutative method for CalcOutAmtGivenIn, which includes the actual swap.

func (*Pool) TVL

func (p *Pool) TVL(ctx sdk.Context, oracleKeeper OracleKeeper) (sdk.Dec, error)

func (*Pool) Unmarshal

func (m *Pool) Unmarshal(dAtA []byte) error

func (*Pool) UpdatePoolAssetBalance

func (p *Pool) UpdatePoolAssetBalance(coin sdk.Coin) error

func (*Pool) UpdatePoolAssetBalances

func (p *Pool) UpdatePoolAssetBalances(coins sdk.Coins) error

func (Pool) Validate

func (pool Pool) Validate(poolId uint64) error

func (Pool) WeightDistanceFromTarget

func (p Pool) WeightDistanceFromTarget(ctx sdk.Context, oracleKeeper OracleKeeper, poolAssets []PoolAsset) sdk.Dec

func (*Pool) XXX_DiscardUnknown

func (m *Pool) XXX_DiscardUnknown()

func (*Pool) XXX_Marshal

func (m *Pool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*Pool) XXX_Merge

func (m *Pool) XXX_Merge(src proto.Message)

func (*Pool) XXX_Size

func (m *Pool) XXX_Size() int

func (*Pool) XXX_Unmarshal

func (m *Pool) XXX_Unmarshal(b []byte) error

type PoolAsset

type PoolAsset struct {
	Token  types.Coin                             `protobuf:"bytes,1,opt,name=token,proto3" json:"token"`
	Weight github_com_cosmos_cosmos_sdk_types.Int `protobuf:"bytes,2,opt,name=weight,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Int" json:"weight"`
}

func GetPoolAssetByDenom

func GetPoolAssetByDenom(assets []PoolAsset, denom string) (PoolAsset, bool)

func (*PoolAsset) Descriptor

func (*PoolAsset) Descriptor() ([]byte, []int)

func (*PoolAsset) GetToken

func (m *PoolAsset) GetToken() types.Coin

func (*PoolAsset) Marshal

func (m *PoolAsset) Marshal() (dAtA []byte, err error)

func (*PoolAsset) MarshalTo

func (m *PoolAsset) MarshalTo(dAtA []byte) (int, error)

func (*PoolAsset) MarshalToSizedBuffer

func (m *PoolAsset) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PoolAsset) ProtoMessage

func (*PoolAsset) ProtoMessage()

func (*PoolAsset) Reset

func (m *PoolAsset) Reset()

func (*PoolAsset) Size

func (m *PoolAsset) Size() (n int)

func (*PoolAsset) String

func (m *PoolAsset) String() string

func (*PoolAsset) Unmarshal

func (m *PoolAsset) Unmarshal(dAtA []byte) error

func (*PoolAsset) XXX_DiscardUnknown

func (m *PoolAsset) XXX_DiscardUnknown()

func (*PoolAsset) XXX_Marshal

func (m *PoolAsset) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PoolAsset) XXX_Merge

func (m *PoolAsset) XXX_Merge(src proto.Message)

func (*PoolAsset) XXX_Size

func (m *PoolAsset) XXX_Size() int

func (*PoolAsset) XXX_Unmarshal

func (m *PoolAsset) XXX_Unmarshal(b []byte) error

type PoolAssetUSDValue added in v0.11.0

type PoolAssetUSDValue struct {
	Asset string
	Value sdk.Dec
}

type PoolExtraInfo added in v0.29.31

type PoolExtraInfo struct {
	Tvl          github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,1,opt,name=tvl,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"tvl"`
	LpTokenPrice github_com_cosmos_cosmos_sdk_types.Dec `` /* 139-byte string literal not displayed */
}

func (*PoolExtraInfo) Descriptor added in v0.29.31

func (*PoolExtraInfo) Descriptor() ([]byte, []int)

func (*PoolExtraInfo) Marshal added in v0.29.31

func (m *PoolExtraInfo) Marshal() (dAtA []byte, err error)

func (*PoolExtraInfo) MarshalTo added in v0.29.31

func (m *PoolExtraInfo) MarshalTo(dAtA []byte) (int, error)

func (*PoolExtraInfo) MarshalToSizedBuffer added in v0.29.31

func (m *PoolExtraInfo) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PoolExtraInfo) ProtoMessage added in v0.29.31

func (*PoolExtraInfo) ProtoMessage()

func (*PoolExtraInfo) Reset added in v0.29.31

func (m *PoolExtraInfo) Reset()

func (*PoolExtraInfo) Size added in v0.29.31

func (m *PoolExtraInfo) Size() (n int)

func (*PoolExtraInfo) String added in v0.29.31

func (m *PoolExtraInfo) String() string

func (*PoolExtraInfo) Unmarshal added in v0.29.31

func (m *PoolExtraInfo) Unmarshal(dAtA []byte) error

func (*PoolExtraInfo) XXX_DiscardUnknown added in v0.29.31

func (m *PoolExtraInfo) XXX_DiscardUnknown()

func (*PoolExtraInfo) XXX_Marshal added in v0.29.31

func (m *PoolExtraInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PoolExtraInfo) XXX_Merge added in v0.29.31

func (m *PoolExtraInfo) XXX_Merge(src proto.Message)

func (*PoolExtraInfo) XXX_Size added in v0.29.31

func (m *PoolExtraInfo) XXX_Size() int

func (*PoolExtraInfo) XXX_Unmarshal added in v0.29.31

func (m *PoolExtraInfo) XXX_Unmarshal(b []byte) error

type PoolParams

type PoolParams struct {
	SwapFee                     github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,1,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	ExitFee                     github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=exit_fee,json=exitFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"exit_fee"`
	UseOracle                   bool                                   `protobuf:"varint,3,opt,name=use_oracle,json=useOracle,proto3" json:"use_oracle,omitempty"`
	WeightBreakingFeeMultiplier github_com_cosmos_cosmos_sdk_types.Dec `` /* 186-byte string literal not displayed */
	WeightBreakingFeeExponent   github_com_cosmos_cosmos_sdk_types.Dec `` /* 181-byte string literal not displayed */
	ExternalLiquidityRatio      github_com_cosmos_cosmos_sdk_types.Dec `` /* 169-byte string literal not displayed */
	WeightRecoveryFeePortion    github_com_cosmos_cosmos_sdk_types.Dec `` /* 177-byte string literal not displayed */
	ThresholdWeightDifference   github_com_cosmos_cosmos_sdk_types.Dec `` /* 178-byte string literal not displayed */
	FeeDenom                    string                                 `protobuf:"bytes,8,opt,name=fee_denom,json=feeDenom,proto3" json:"fee_denom,omitempty"`
}

func (*PoolParams) Descriptor

func (*PoolParams) Descriptor() ([]byte, []int)

func (*PoolParams) GetFeeDenom

func (m *PoolParams) GetFeeDenom() string

func (*PoolParams) GetUseOracle

func (m *PoolParams) GetUseOracle() bool

func (*PoolParams) Marshal

func (m *PoolParams) Marshal() (dAtA []byte, err error)

func (*PoolParams) MarshalTo

func (m *PoolParams) MarshalTo(dAtA []byte) (int, error)

func (*PoolParams) MarshalToSizedBuffer

func (m *PoolParams) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*PoolParams) ProtoMessage

func (*PoolParams) ProtoMessage()

func (*PoolParams) Reset

func (m *PoolParams) Reset()

func (*PoolParams) Size

func (m *PoolParams) Size() (n int)

func (*PoolParams) String

func (m *PoolParams) String() string

func (*PoolParams) Unmarshal

func (m *PoolParams) Unmarshal(dAtA []byte) error

func (PoolParams) Validate

func (params PoolParams) Validate(poolWeights []PoolAsset) error

func (*PoolParams) XXX_DiscardUnknown

func (m *PoolParams) XXX_DiscardUnknown()

func (*PoolParams) XXX_Marshal

func (m *PoolParams) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*PoolParams) XXX_Merge

func (m *PoolParams) XXX_Merge(src proto.Message)

func (*PoolParams) XXX_Size

func (m *PoolParams) XXX_Size() int

func (*PoolParams) XXX_Unmarshal

func (m *PoolParams) XXX_Unmarshal(b []byte) error

type ProposalCreateBalancerPool

type ProposalCreateBalancerPool struct {
	Title       string      `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string      `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	PoolParams  *PoolParams `protobuf:"bytes,3,opt,name=pool_params,json=poolParams,proto3" json:"pool_params,omitempty"`
	PoolAssets  []PoolAsset `protobuf:"bytes,4,rep,name=pool_assets,json=poolAssets,proto3" json:"pool_assets"`
}

func (*ProposalCreateBalancerPool) Descriptor

func (*ProposalCreateBalancerPool) Descriptor() ([]byte, []int)

func (*ProposalCreateBalancerPool) GetDescription

func (m *ProposalCreateBalancerPool) GetDescription() string

func (*ProposalCreateBalancerPool) GetPoolAssets

func (m *ProposalCreateBalancerPool) GetPoolAssets() []PoolAsset

func (*ProposalCreateBalancerPool) GetPoolParams

func (m *ProposalCreateBalancerPool) GetPoolParams() *PoolParams

func (*ProposalCreateBalancerPool) GetTitle

func (m *ProposalCreateBalancerPool) GetTitle() string

func (*ProposalCreateBalancerPool) Marshal

func (m *ProposalCreateBalancerPool) Marshal() (dAtA []byte, err error)

func (*ProposalCreateBalancerPool) MarshalTo

func (m *ProposalCreateBalancerPool) MarshalTo(dAtA []byte) (int, error)

func (*ProposalCreateBalancerPool) MarshalToSizedBuffer

func (m *ProposalCreateBalancerPool) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ProposalCreateBalancerPool) ProtoMessage

func (*ProposalCreateBalancerPool) ProtoMessage()

func (*ProposalCreateBalancerPool) Reset

func (m *ProposalCreateBalancerPool) Reset()

func (*ProposalCreateBalancerPool) Size

func (m *ProposalCreateBalancerPool) Size() (n int)

func (*ProposalCreateBalancerPool) String

func (m *ProposalCreateBalancerPool) String() string

func (*ProposalCreateBalancerPool) Unmarshal

func (m *ProposalCreateBalancerPool) Unmarshal(dAtA []byte) error

func (*ProposalCreateBalancerPool) XXX_DiscardUnknown

func (m *ProposalCreateBalancerPool) XXX_DiscardUnknown()

func (*ProposalCreateBalancerPool) XXX_Marshal

func (m *ProposalCreateBalancerPool) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ProposalCreateBalancerPool) XXX_Merge

func (m *ProposalCreateBalancerPool) XXX_Merge(src proto.Message)

func (*ProposalCreateBalancerPool) XXX_Size

func (m *ProposalCreateBalancerPool) XXX_Size() int

func (*ProposalCreateBalancerPool) XXX_Unmarshal

func (m *ProposalCreateBalancerPool) XXX_Unmarshal(b []byte) error

type ProposalUpdatePoolParams

type ProposalUpdatePoolParams struct {
	Title       string     `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string     `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	PoolId      uint64     `protobuf:"varint,3,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	PoolParams  PoolParams `protobuf:"bytes,4,opt,name=pool_params,json=poolParams,proto3" json:"pool_params"`
}

func (*ProposalUpdatePoolParams) Descriptor

func (*ProposalUpdatePoolParams) Descriptor() ([]byte, []int)

func (*ProposalUpdatePoolParams) GetDescription

func (m *ProposalUpdatePoolParams) GetDescription() string

func (*ProposalUpdatePoolParams) GetPoolId

func (m *ProposalUpdatePoolParams) GetPoolId() uint64

func (*ProposalUpdatePoolParams) GetPoolParams

func (m *ProposalUpdatePoolParams) GetPoolParams() PoolParams

func (*ProposalUpdatePoolParams) GetTitle

func (m *ProposalUpdatePoolParams) GetTitle() string

func (*ProposalUpdatePoolParams) Marshal

func (m *ProposalUpdatePoolParams) Marshal() (dAtA []byte, err error)

func (*ProposalUpdatePoolParams) MarshalTo

func (m *ProposalUpdatePoolParams) MarshalTo(dAtA []byte) (int, error)

func (*ProposalUpdatePoolParams) MarshalToSizedBuffer

func (m *ProposalUpdatePoolParams) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*ProposalUpdatePoolParams) ProtoMessage

func (*ProposalUpdatePoolParams) ProtoMessage()

func (*ProposalUpdatePoolParams) Reset

func (m *ProposalUpdatePoolParams) Reset()

func (*ProposalUpdatePoolParams) Size

func (m *ProposalUpdatePoolParams) Size() (n int)

func (*ProposalUpdatePoolParams) String

func (m *ProposalUpdatePoolParams) String() string

func (*ProposalUpdatePoolParams) Unmarshal

func (m *ProposalUpdatePoolParams) Unmarshal(dAtA []byte) error

func (*ProposalUpdatePoolParams) XXX_DiscardUnknown

func (m *ProposalUpdatePoolParams) XXX_DiscardUnknown()

func (*ProposalUpdatePoolParams) XXX_Marshal

func (m *ProposalUpdatePoolParams) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*ProposalUpdatePoolParams) XXX_Merge

func (m *ProposalUpdatePoolParams) XXX_Merge(src proto.Message)

func (*ProposalUpdatePoolParams) XXX_Size

func (m *ProposalUpdatePoolParams) XXX_Size() int

func (*ProposalUpdatePoolParams) XXX_Unmarshal

func (m *ProposalUpdatePoolParams) XXX_Unmarshal(b []byte) error

type QueryAMMPriceRequest added in v0.17.0

type QueryAMMPriceRequest struct {
	TokenIn  types.Coin                             `protobuf:"bytes,1,opt,name=token_in,json=tokenIn,proto3" json:"token_in"`
	Discount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

func (*QueryAMMPriceRequest) Descriptor added in v0.17.0

func (*QueryAMMPriceRequest) Descriptor() ([]byte, []int)

func (*QueryAMMPriceRequest) GetTokenIn added in v0.17.0

func (m *QueryAMMPriceRequest) GetTokenIn() types.Coin

func (*QueryAMMPriceRequest) Marshal added in v0.17.0

func (m *QueryAMMPriceRequest) Marshal() (dAtA []byte, err error)

func (*QueryAMMPriceRequest) MarshalTo added in v0.17.0

func (m *QueryAMMPriceRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryAMMPriceRequest) MarshalToSizedBuffer added in v0.17.0

func (m *QueryAMMPriceRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryAMMPriceRequest) ProtoMessage added in v0.17.0

func (*QueryAMMPriceRequest) ProtoMessage()

func (*QueryAMMPriceRequest) Reset added in v0.17.0

func (m *QueryAMMPriceRequest) Reset()

func (*QueryAMMPriceRequest) Size added in v0.17.0

func (m *QueryAMMPriceRequest) Size() (n int)

func (*QueryAMMPriceRequest) String added in v0.17.0

func (m *QueryAMMPriceRequest) String() string

func (*QueryAMMPriceRequest) Unmarshal added in v0.17.0

func (m *QueryAMMPriceRequest) Unmarshal(dAtA []byte) error

func (*QueryAMMPriceRequest) XXX_DiscardUnknown added in v0.17.0

func (m *QueryAMMPriceRequest) XXX_DiscardUnknown()

func (*QueryAMMPriceRequest) XXX_Marshal added in v0.17.0

func (m *QueryAMMPriceRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryAMMPriceRequest) XXX_Merge added in v0.17.0

func (m *QueryAMMPriceRequest) XXX_Merge(src proto.Message)

func (*QueryAMMPriceRequest) XXX_Size added in v0.17.0

func (m *QueryAMMPriceRequest) XXX_Size() int

func (*QueryAMMPriceRequest) XXX_Unmarshal added in v0.17.0

func (m *QueryAMMPriceRequest) XXX_Unmarshal(b []byte) error

type QueryAllDenomLiquidityRequest

type QueryAllDenomLiquidityRequest struct {
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllDenomLiquidityRequest) Descriptor

func (*QueryAllDenomLiquidityRequest) Descriptor() ([]byte, []int)

func (*QueryAllDenomLiquidityRequest) GetPagination

func (m *QueryAllDenomLiquidityRequest) GetPagination() *query.PageRequest

func (*QueryAllDenomLiquidityRequest) Marshal

func (m *QueryAllDenomLiquidityRequest) Marshal() (dAtA []byte, err error)

func (*QueryAllDenomLiquidityRequest) MarshalTo

func (m *QueryAllDenomLiquidityRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryAllDenomLiquidityRequest) MarshalToSizedBuffer

func (m *QueryAllDenomLiquidityRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryAllDenomLiquidityRequest) ProtoMessage

func (*QueryAllDenomLiquidityRequest) ProtoMessage()

func (*QueryAllDenomLiquidityRequest) Reset

func (m *QueryAllDenomLiquidityRequest) Reset()

func (*QueryAllDenomLiquidityRequest) Size

func (m *QueryAllDenomLiquidityRequest) Size() (n int)

func (*QueryAllDenomLiquidityRequest) String

func (*QueryAllDenomLiquidityRequest) Unmarshal

func (m *QueryAllDenomLiquidityRequest) Unmarshal(dAtA []byte) error

func (*QueryAllDenomLiquidityRequest) XXX_DiscardUnknown

func (m *QueryAllDenomLiquidityRequest) XXX_DiscardUnknown()

func (*QueryAllDenomLiquidityRequest) XXX_Marshal

func (m *QueryAllDenomLiquidityRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryAllDenomLiquidityRequest) XXX_Merge

func (m *QueryAllDenomLiquidityRequest) XXX_Merge(src proto.Message)

func (*QueryAllDenomLiquidityRequest) XXX_Size

func (m *QueryAllDenomLiquidityRequest) XXX_Size() int

func (*QueryAllDenomLiquidityRequest) XXX_Unmarshal

func (m *QueryAllDenomLiquidityRequest) XXX_Unmarshal(b []byte) error

type QueryAllDenomLiquidityResponse

type QueryAllDenomLiquidityResponse struct {
	DenomLiquidity []DenomLiquidity    `protobuf:"bytes,1,rep,name=denom_liquidity,json=denomLiquidity,proto3" json:"denom_liquidity"`
	Pagination     *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllDenomLiquidityResponse) Descriptor

func (*QueryAllDenomLiquidityResponse) Descriptor() ([]byte, []int)

func (*QueryAllDenomLiquidityResponse) GetDenomLiquidity

func (m *QueryAllDenomLiquidityResponse) GetDenomLiquidity() []DenomLiquidity

func (*QueryAllDenomLiquidityResponse) GetPagination

func (*QueryAllDenomLiquidityResponse) Marshal

func (m *QueryAllDenomLiquidityResponse) Marshal() (dAtA []byte, err error)

func (*QueryAllDenomLiquidityResponse) MarshalTo

func (m *QueryAllDenomLiquidityResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryAllDenomLiquidityResponse) MarshalToSizedBuffer

func (m *QueryAllDenomLiquidityResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryAllDenomLiquidityResponse) ProtoMessage

func (*QueryAllDenomLiquidityResponse) ProtoMessage()

func (*QueryAllDenomLiquidityResponse) Reset

func (m *QueryAllDenomLiquidityResponse) Reset()

func (*QueryAllDenomLiquidityResponse) Size

func (m *QueryAllDenomLiquidityResponse) Size() (n int)

func (*QueryAllDenomLiquidityResponse) String

func (*QueryAllDenomLiquidityResponse) Unmarshal

func (m *QueryAllDenomLiquidityResponse) Unmarshal(dAtA []byte) error

func (*QueryAllDenomLiquidityResponse) XXX_DiscardUnknown

func (m *QueryAllDenomLiquidityResponse) XXX_DiscardUnknown()

func (*QueryAllDenomLiquidityResponse) XXX_Marshal

func (m *QueryAllDenomLiquidityResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryAllDenomLiquidityResponse) XXX_Merge

func (m *QueryAllDenomLiquidityResponse) XXX_Merge(src proto.Message)

func (*QueryAllDenomLiquidityResponse) XXX_Size

func (m *QueryAllDenomLiquidityResponse) XXX_Size() int

func (*QueryAllDenomLiquidityResponse) XXX_Unmarshal

func (m *QueryAllDenomLiquidityResponse) XXX_Unmarshal(b []byte) error

type QueryAllPoolRequest

type QueryAllPoolRequest struct {
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllPoolRequest) Descriptor

func (*QueryAllPoolRequest) Descriptor() ([]byte, []int)

func (*QueryAllPoolRequest) GetPagination

func (m *QueryAllPoolRequest) GetPagination() *query.PageRequest

func (*QueryAllPoolRequest) Marshal

func (m *QueryAllPoolRequest) Marshal() (dAtA []byte, err error)

func (*QueryAllPoolRequest) MarshalTo

func (m *QueryAllPoolRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryAllPoolRequest) MarshalToSizedBuffer

func (m *QueryAllPoolRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryAllPoolRequest) ProtoMessage

func (*QueryAllPoolRequest) ProtoMessage()

func (*QueryAllPoolRequest) Reset

func (m *QueryAllPoolRequest) Reset()

func (*QueryAllPoolRequest) Size

func (m *QueryAllPoolRequest) Size() (n int)

func (*QueryAllPoolRequest) String

func (m *QueryAllPoolRequest) String() string

func (*QueryAllPoolRequest) Unmarshal

func (m *QueryAllPoolRequest) Unmarshal(dAtA []byte) error

func (*QueryAllPoolRequest) XXX_DiscardUnknown

func (m *QueryAllPoolRequest) XXX_DiscardUnknown()

func (*QueryAllPoolRequest) XXX_Marshal

func (m *QueryAllPoolRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryAllPoolRequest) XXX_Merge

func (m *QueryAllPoolRequest) XXX_Merge(src proto.Message)

func (*QueryAllPoolRequest) XXX_Size

func (m *QueryAllPoolRequest) XXX_Size() int

func (*QueryAllPoolRequest) XXX_Unmarshal

func (m *QueryAllPoolRequest) XXX_Unmarshal(b []byte) error

type QueryAllPoolResponse

type QueryAllPoolResponse struct {
	Pool       []Pool              `protobuf:"bytes,1,rep,name=pool,proto3" json:"pool"`
	ExtraInfos []PoolExtraInfo     `protobuf:"bytes,2,rep,name=extra_infos,json=extraInfos,proto3" json:"extra_infos"`
	Pagination *query.PageResponse `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllPoolResponse) Descriptor

func (*QueryAllPoolResponse) Descriptor() ([]byte, []int)

func (*QueryAllPoolResponse) GetExtraInfos added in v0.29.31

func (m *QueryAllPoolResponse) GetExtraInfos() []PoolExtraInfo

func (*QueryAllPoolResponse) GetPagination

func (m *QueryAllPoolResponse) GetPagination() *query.PageResponse

func (*QueryAllPoolResponse) GetPool

func (m *QueryAllPoolResponse) GetPool() []Pool

func (*QueryAllPoolResponse) Marshal

func (m *QueryAllPoolResponse) Marshal() (dAtA []byte, err error)

func (*QueryAllPoolResponse) MarshalTo

func (m *QueryAllPoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryAllPoolResponse) MarshalToSizedBuffer

func (m *QueryAllPoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryAllPoolResponse) ProtoMessage

func (*QueryAllPoolResponse) ProtoMessage()

func (*QueryAllPoolResponse) Reset

func (m *QueryAllPoolResponse) Reset()

func (*QueryAllPoolResponse) Size

func (m *QueryAllPoolResponse) Size() (n int)

func (*QueryAllPoolResponse) String

func (m *QueryAllPoolResponse) String() string

func (*QueryAllPoolResponse) Unmarshal

func (m *QueryAllPoolResponse) Unmarshal(dAtA []byte) error

func (*QueryAllPoolResponse) XXX_DiscardUnknown

func (m *QueryAllPoolResponse) XXX_DiscardUnknown()

func (*QueryAllPoolResponse) XXX_Marshal

func (m *QueryAllPoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryAllPoolResponse) XXX_Merge

func (m *QueryAllPoolResponse) XXX_Merge(src proto.Message)

func (*QueryAllPoolResponse) XXX_Size

func (m *QueryAllPoolResponse) XXX_Size() int

func (*QueryAllPoolResponse) XXX_Unmarshal

func (m *QueryAllPoolResponse) XXX_Unmarshal(b []byte) error

type QueryBalanceRequest added in v0.14.0

type QueryBalanceRequest struct {
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	Denom   string `protobuf:"bytes,2,opt,name=denom,proto3" json:"denom,omitempty"`
}

func (*QueryBalanceRequest) Descriptor added in v0.14.0

func (*QueryBalanceRequest) Descriptor() ([]byte, []int)

func (*QueryBalanceRequest) GetAddress added in v0.14.0

func (m *QueryBalanceRequest) GetAddress() string

func (*QueryBalanceRequest) GetDenom added in v0.14.0

func (m *QueryBalanceRequest) GetDenom() string

func (*QueryBalanceRequest) Marshal added in v0.14.0

func (m *QueryBalanceRequest) Marshal() (dAtA []byte, err error)

func (*QueryBalanceRequest) MarshalTo added in v0.14.0

func (m *QueryBalanceRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryBalanceRequest) MarshalToSizedBuffer added in v0.14.0

func (m *QueryBalanceRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryBalanceRequest) ProtoMessage added in v0.14.0

func (*QueryBalanceRequest) ProtoMessage()

func (*QueryBalanceRequest) Reset added in v0.14.0

func (m *QueryBalanceRequest) Reset()

func (*QueryBalanceRequest) Size added in v0.14.0

func (m *QueryBalanceRequest) Size() (n int)

func (*QueryBalanceRequest) String added in v0.14.0

func (m *QueryBalanceRequest) String() string

func (*QueryBalanceRequest) Unmarshal added in v0.14.0

func (m *QueryBalanceRequest) Unmarshal(dAtA []byte) error

func (*QueryBalanceRequest) XXX_DiscardUnknown added in v0.14.0

func (m *QueryBalanceRequest) XXX_DiscardUnknown()

func (*QueryBalanceRequest) XXX_Marshal added in v0.14.0

func (m *QueryBalanceRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryBalanceRequest) XXX_Merge added in v0.14.0

func (m *QueryBalanceRequest) XXX_Merge(src proto.Message)

func (*QueryBalanceRequest) XXX_Size added in v0.14.0

func (m *QueryBalanceRequest) XXX_Size() int

func (*QueryBalanceRequest) XXX_Unmarshal added in v0.14.0

func (m *QueryBalanceRequest) XXX_Unmarshal(b []byte) error

type QueryBalanceResponse added in v0.14.0

type QueryBalanceResponse struct {
	Balance types.Coin `protobuf:"bytes,1,opt,name=balance,proto3" json:"balance"`
}

func (*QueryBalanceResponse) Descriptor added in v0.14.0

func (*QueryBalanceResponse) Descriptor() ([]byte, []int)

func (*QueryBalanceResponse) GetBalance added in v0.14.0

func (m *QueryBalanceResponse) GetBalance() types.Coin

func (*QueryBalanceResponse) Marshal added in v0.14.0

func (m *QueryBalanceResponse) Marshal() (dAtA []byte, err error)

func (*QueryBalanceResponse) MarshalTo added in v0.14.0

func (m *QueryBalanceResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryBalanceResponse) MarshalToSizedBuffer added in v0.14.0

func (m *QueryBalanceResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryBalanceResponse) ProtoMessage added in v0.14.0

func (*QueryBalanceResponse) ProtoMessage()

func (*QueryBalanceResponse) Reset added in v0.14.0

func (m *QueryBalanceResponse) Reset()

func (*QueryBalanceResponse) Size added in v0.14.0

func (m *QueryBalanceResponse) Size() (n int)

func (*QueryBalanceResponse) String added in v0.14.0

func (m *QueryBalanceResponse) String() string

func (*QueryBalanceResponse) Unmarshal added in v0.14.0

func (m *QueryBalanceResponse) Unmarshal(dAtA []byte) error

func (*QueryBalanceResponse) XXX_DiscardUnknown added in v0.14.0

func (m *QueryBalanceResponse) XXX_DiscardUnknown()

func (*QueryBalanceResponse) XXX_Marshal added in v0.14.0

func (m *QueryBalanceResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryBalanceResponse) XXX_Merge added in v0.14.0

func (m *QueryBalanceResponse) XXX_Merge(src proto.Message)

func (*QueryBalanceResponse) XXX_Size added in v0.14.0

func (m *QueryBalanceResponse) XXX_Size() int

func (*QueryBalanceResponse) XXX_Unmarshal added in v0.14.0

func (m *QueryBalanceResponse) XXX_Unmarshal(b []byte) error

type QueryClient

type QueryClient interface {
	// Parameters queries the parameters of the module.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// Queries a list of Pool items.
	Pool(ctx context.Context, in *QueryGetPoolRequest, opts ...grpc.CallOption) (*QueryGetPoolResponse, error)
	PoolAll(ctx context.Context, in *QueryAllPoolRequest, opts ...grpc.CallOption) (*QueryAllPoolResponse, error)
	// Queries a list of DenomLiquidity items.
	DenomLiquidity(ctx context.Context, in *QueryGetDenomLiquidityRequest, opts ...grpc.CallOption) (*QueryGetDenomLiquidityResponse, error)
	DenomLiquidityAll(ctx context.Context, in *QueryAllDenomLiquidityRequest, opts ...grpc.CallOption) (*QueryAllDenomLiquidityResponse, error)
	// Queries a list of SwapEstimation items.
	SwapEstimation(ctx context.Context, in *QuerySwapEstimationRequest, opts ...grpc.CallOption) (*QuerySwapEstimationResponse, error)
	// Queries JoinPool estimation
	JoinPoolEstimation(ctx context.Context, in *QueryJoinPoolEstimationRequest, opts ...grpc.CallOption) (*QueryJoinPoolEstimationResponse, error)
	// Queries ExistPool estimation
	ExitPoolEstimation(ctx context.Context, in *QueryExitPoolEstimationRequest, opts ...grpc.CallOption) (*QueryExitPoolEstimationResponse, error)
	// Queries slippage track for a week.
	SlippageTrack(ctx context.Context, in *QuerySlippageTrackRequest, opts ...grpc.CallOption) (*QuerySlippageTrackResponse, error)
	// Queries all slippage tracks for a week.
	SlippageTrackAll(ctx context.Context, in *QuerySlippageTrackAllRequest, opts ...grpc.CallOption) (*QuerySlippageTrackAllResponse, error)
	// Queries a list of Balance items.
	Balance(ctx context.Context, in *QueryBalanceRequest, opts ...grpc.CallOption) (*QueryBalanceResponse, error)
	// Queries a list of InRouteByDenom items.
	InRouteByDenom(ctx context.Context, in *QueryInRouteByDenomRequest, opts ...grpc.CallOption) (*QueryInRouteByDenomResponse, error)
	// Queries a list of OutRouteByDenom items.
	OutRouteByDenom(ctx context.Context, in *QueryOutRouteByDenomRequest, opts ...grpc.CallOption) (*QueryOutRouteByDenomResponse, error)
	// Queries a list of SwapEstimationByDenom items.
	SwapEstimationByDenom(ctx context.Context, in *QuerySwapEstimationByDenomRequest, opts ...grpc.CallOption) (*QuerySwapEstimationByDenomResponse, error)
}

QueryClient is the client API for Query service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewQueryClient

func NewQueryClient(cc grpc1.ClientConn) QueryClient

type QueryEarnPoolRequest added in v0.20.0

type QueryEarnPoolRequest struct {
	PoolIds    []uint64           `protobuf:"varint,1,rep,packed,name=pool_ids,json=poolIds,proto3" json:"pool_ids,omitempty"`
	FilterType FilterType         `protobuf:"varint,2,opt,name=filter_type,json=filterType,proto3,enum=elys.amm.FilterType" json:"filter_type,omitempty"`
	Pagination *query.PageRequest `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryEarnPoolRequest) Descriptor added in v0.20.0

func (*QueryEarnPoolRequest) Descriptor() ([]byte, []int)

func (*QueryEarnPoolRequest) GetFilterType added in v0.20.0

func (m *QueryEarnPoolRequest) GetFilterType() FilterType

func (*QueryEarnPoolRequest) GetPagination added in v0.20.0

func (m *QueryEarnPoolRequest) GetPagination() *query.PageRequest

func (*QueryEarnPoolRequest) GetPoolIds added in v0.20.0

func (m *QueryEarnPoolRequest) GetPoolIds() []uint64

func (*QueryEarnPoolRequest) Marshal added in v0.20.0

func (m *QueryEarnPoolRequest) Marshal() (dAtA []byte, err error)

func (*QueryEarnPoolRequest) MarshalTo added in v0.20.0

func (m *QueryEarnPoolRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryEarnPoolRequest) MarshalToSizedBuffer added in v0.20.0

func (m *QueryEarnPoolRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryEarnPoolRequest) ProtoMessage added in v0.20.0

func (*QueryEarnPoolRequest) ProtoMessage()

func (*QueryEarnPoolRequest) Reset added in v0.20.0

func (m *QueryEarnPoolRequest) Reset()

func (*QueryEarnPoolRequest) Size added in v0.20.0

func (m *QueryEarnPoolRequest) Size() (n int)

func (*QueryEarnPoolRequest) String added in v0.20.0

func (m *QueryEarnPoolRequest) String() string

func (*QueryEarnPoolRequest) Unmarshal added in v0.20.0

func (m *QueryEarnPoolRequest) Unmarshal(dAtA []byte) error

func (*QueryEarnPoolRequest) XXX_DiscardUnknown added in v0.20.0

func (m *QueryEarnPoolRequest) XXX_DiscardUnknown()

func (*QueryEarnPoolRequest) XXX_Marshal added in v0.20.0

func (m *QueryEarnPoolRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryEarnPoolRequest) XXX_Merge added in v0.20.0

func (m *QueryEarnPoolRequest) XXX_Merge(src proto.Message)

func (*QueryEarnPoolRequest) XXX_Size added in v0.20.0

func (m *QueryEarnPoolRequest) XXX_Size() int

func (*QueryEarnPoolRequest) XXX_Unmarshal added in v0.20.0

func (m *QueryEarnPoolRequest) XXX_Unmarshal(b []byte) error

type QueryEarnPoolResponse added in v0.20.0

type QueryEarnPoolResponse struct {
	Pools []EarnPool `protobuf:"bytes,1,rep,name=pools,proto3" json:"pools"`
}

func (*QueryEarnPoolResponse) Descriptor added in v0.20.0

func (*QueryEarnPoolResponse) Descriptor() ([]byte, []int)

func (*QueryEarnPoolResponse) GetPools added in v0.20.0

func (m *QueryEarnPoolResponse) GetPools() []EarnPool

func (*QueryEarnPoolResponse) Marshal added in v0.20.0

func (m *QueryEarnPoolResponse) Marshal() (dAtA []byte, err error)

func (*QueryEarnPoolResponse) MarshalTo added in v0.20.0

func (m *QueryEarnPoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryEarnPoolResponse) MarshalToSizedBuffer added in v0.20.0

func (m *QueryEarnPoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryEarnPoolResponse) ProtoMessage added in v0.20.0

func (*QueryEarnPoolResponse) ProtoMessage()

func (*QueryEarnPoolResponse) Reset added in v0.20.0

func (m *QueryEarnPoolResponse) Reset()

func (*QueryEarnPoolResponse) Size added in v0.20.0

func (m *QueryEarnPoolResponse) Size() (n int)

func (*QueryEarnPoolResponse) String added in v0.20.0

func (m *QueryEarnPoolResponse) String() string

func (*QueryEarnPoolResponse) Unmarshal added in v0.20.0

func (m *QueryEarnPoolResponse) Unmarshal(dAtA []byte) error

func (*QueryEarnPoolResponse) XXX_DiscardUnknown added in v0.20.0

func (m *QueryEarnPoolResponse) XXX_DiscardUnknown()

func (*QueryEarnPoolResponse) XXX_Marshal added in v0.20.0

func (m *QueryEarnPoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryEarnPoolResponse) XXX_Merge added in v0.20.0

func (m *QueryEarnPoolResponse) XXX_Merge(src proto.Message)

func (*QueryEarnPoolResponse) XXX_Size added in v0.20.0

func (m *QueryEarnPoolResponse) XXX_Size() int

func (*QueryEarnPoolResponse) XXX_Unmarshal added in v0.20.0

func (m *QueryEarnPoolResponse) XXX_Unmarshal(b []byte) error

type QueryExitPoolEstimationRequest added in v0.29.22

type QueryExitPoolEstimationRequest struct {
	PoolId        uint64                                 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	ShareAmountIn github_com_cosmos_cosmos_sdk_types.Int `` /* 142-byte string literal not displayed */
	TokenOutDenom string                                 `protobuf:"bytes,3,opt,name=token_out_denom,json=tokenOutDenom,proto3" json:"token_out_denom,omitempty"`
}

func (*QueryExitPoolEstimationRequest) Descriptor added in v0.29.22

func (*QueryExitPoolEstimationRequest) Descriptor() ([]byte, []int)

func (*QueryExitPoolEstimationRequest) GetPoolId added in v0.29.22

func (m *QueryExitPoolEstimationRequest) GetPoolId() uint64

func (*QueryExitPoolEstimationRequest) GetTokenOutDenom added in v0.29.22

func (m *QueryExitPoolEstimationRequest) GetTokenOutDenom() string

func (*QueryExitPoolEstimationRequest) Marshal added in v0.29.22

func (m *QueryExitPoolEstimationRequest) Marshal() (dAtA []byte, err error)

func (*QueryExitPoolEstimationRequest) MarshalTo added in v0.29.22

func (m *QueryExitPoolEstimationRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryExitPoolEstimationRequest) MarshalToSizedBuffer added in v0.29.22

func (m *QueryExitPoolEstimationRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryExitPoolEstimationRequest) ProtoMessage added in v0.29.22

func (*QueryExitPoolEstimationRequest) ProtoMessage()

func (*QueryExitPoolEstimationRequest) Reset added in v0.29.22

func (m *QueryExitPoolEstimationRequest) Reset()

func (*QueryExitPoolEstimationRequest) Size added in v0.29.22

func (m *QueryExitPoolEstimationRequest) Size() (n int)

func (*QueryExitPoolEstimationRequest) String added in v0.29.22

func (*QueryExitPoolEstimationRequest) Unmarshal added in v0.29.22

func (m *QueryExitPoolEstimationRequest) Unmarshal(dAtA []byte) error

func (*QueryExitPoolEstimationRequest) XXX_DiscardUnknown added in v0.29.22

func (m *QueryExitPoolEstimationRequest) XXX_DiscardUnknown()

func (*QueryExitPoolEstimationRequest) XXX_Marshal added in v0.29.22

func (m *QueryExitPoolEstimationRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryExitPoolEstimationRequest) XXX_Merge added in v0.29.22

func (m *QueryExitPoolEstimationRequest) XXX_Merge(src proto.Message)

func (*QueryExitPoolEstimationRequest) XXX_Size added in v0.29.22

func (m *QueryExitPoolEstimationRequest) XXX_Size() int

func (*QueryExitPoolEstimationRequest) XXX_Unmarshal added in v0.29.22

func (m *QueryExitPoolEstimationRequest) XXX_Unmarshal(b []byte) error

type QueryExitPoolEstimationResponse added in v0.29.22

type QueryExitPoolEstimationResponse struct {
	AmountsOut []types.Coin `protobuf:"bytes,1,rep,name=amounts_out,json=amountsOut,proto3" json:"amounts_out"`
}

func (*QueryExitPoolEstimationResponse) Descriptor added in v0.29.22

func (*QueryExitPoolEstimationResponse) Descriptor() ([]byte, []int)

func (*QueryExitPoolEstimationResponse) GetAmountsOut added in v0.29.22

func (m *QueryExitPoolEstimationResponse) GetAmountsOut() []types.Coin

func (*QueryExitPoolEstimationResponse) Marshal added in v0.29.22

func (m *QueryExitPoolEstimationResponse) Marshal() (dAtA []byte, err error)

func (*QueryExitPoolEstimationResponse) MarshalTo added in v0.29.22

func (m *QueryExitPoolEstimationResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryExitPoolEstimationResponse) MarshalToSizedBuffer added in v0.29.22

func (m *QueryExitPoolEstimationResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryExitPoolEstimationResponse) ProtoMessage added in v0.29.22

func (*QueryExitPoolEstimationResponse) ProtoMessage()

func (*QueryExitPoolEstimationResponse) Reset added in v0.29.22

func (*QueryExitPoolEstimationResponse) Size added in v0.29.22

func (m *QueryExitPoolEstimationResponse) Size() (n int)

func (*QueryExitPoolEstimationResponse) String added in v0.29.22

func (*QueryExitPoolEstimationResponse) Unmarshal added in v0.29.22

func (m *QueryExitPoolEstimationResponse) Unmarshal(dAtA []byte) error

func (*QueryExitPoolEstimationResponse) XXX_DiscardUnknown added in v0.29.22

func (m *QueryExitPoolEstimationResponse) XXX_DiscardUnknown()

func (*QueryExitPoolEstimationResponse) XXX_Marshal added in v0.29.22

func (m *QueryExitPoolEstimationResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryExitPoolEstimationResponse) XXX_Merge added in v0.29.22

func (m *QueryExitPoolEstimationResponse) XXX_Merge(src proto.Message)

func (*QueryExitPoolEstimationResponse) XXX_Size added in v0.29.22

func (m *QueryExitPoolEstimationResponse) XXX_Size() int

func (*QueryExitPoolEstimationResponse) XXX_Unmarshal added in v0.29.22

func (m *QueryExitPoolEstimationResponse) XXX_Unmarshal(b []byte) error

type QueryGetDenomLiquidityRequest

type QueryGetDenomLiquidityRequest struct {
	Denom string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
}

func (*QueryGetDenomLiquidityRequest) Descriptor

func (*QueryGetDenomLiquidityRequest) Descriptor() ([]byte, []int)

func (*QueryGetDenomLiquidityRequest) GetDenom

func (m *QueryGetDenomLiquidityRequest) GetDenom() string

func (*QueryGetDenomLiquidityRequest) Marshal

func (m *QueryGetDenomLiquidityRequest) Marshal() (dAtA []byte, err error)

func (*QueryGetDenomLiquidityRequest) MarshalTo

func (m *QueryGetDenomLiquidityRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryGetDenomLiquidityRequest) MarshalToSizedBuffer

func (m *QueryGetDenomLiquidityRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryGetDenomLiquidityRequest) ProtoMessage

func (*QueryGetDenomLiquidityRequest) ProtoMessage()

func (*QueryGetDenomLiquidityRequest) Reset

func (m *QueryGetDenomLiquidityRequest) Reset()

func (*QueryGetDenomLiquidityRequest) Size

func (m *QueryGetDenomLiquidityRequest) Size() (n int)

func (*QueryGetDenomLiquidityRequest) String

func (*QueryGetDenomLiquidityRequest) Unmarshal

func (m *QueryGetDenomLiquidityRequest) Unmarshal(dAtA []byte) error

func (*QueryGetDenomLiquidityRequest) XXX_DiscardUnknown

func (m *QueryGetDenomLiquidityRequest) XXX_DiscardUnknown()

func (*QueryGetDenomLiquidityRequest) XXX_Marshal

func (m *QueryGetDenomLiquidityRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryGetDenomLiquidityRequest) XXX_Merge

func (m *QueryGetDenomLiquidityRequest) XXX_Merge(src proto.Message)

func (*QueryGetDenomLiquidityRequest) XXX_Size

func (m *QueryGetDenomLiquidityRequest) XXX_Size() int

func (*QueryGetDenomLiquidityRequest) XXX_Unmarshal

func (m *QueryGetDenomLiquidityRequest) XXX_Unmarshal(b []byte) error

type QueryGetDenomLiquidityResponse

type QueryGetDenomLiquidityResponse struct {
	DenomLiquidity DenomLiquidity `protobuf:"bytes,1,opt,name=denom_liquidity,json=denomLiquidity,proto3" json:"denom_liquidity"`
}

func (*QueryGetDenomLiquidityResponse) Descriptor

func (*QueryGetDenomLiquidityResponse) Descriptor() ([]byte, []int)

func (*QueryGetDenomLiquidityResponse) GetDenomLiquidity

func (m *QueryGetDenomLiquidityResponse) GetDenomLiquidity() DenomLiquidity

func (*QueryGetDenomLiquidityResponse) Marshal

func (m *QueryGetDenomLiquidityResponse) Marshal() (dAtA []byte, err error)

func (*QueryGetDenomLiquidityResponse) MarshalTo

func (m *QueryGetDenomLiquidityResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryGetDenomLiquidityResponse) MarshalToSizedBuffer

func (m *QueryGetDenomLiquidityResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryGetDenomLiquidityResponse) ProtoMessage

func (*QueryGetDenomLiquidityResponse) ProtoMessage()

func (*QueryGetDenomLiquidityResponse) Reset

func (m *QueryGetDenomLiquidityResponse) Reset()

func (*QueryGetDenomLiquidityResponse) Size

func (m *QueryGetDenomLiquidityResponse) Size() (n int)

func (*QueryGetDenomLiquidityResponse) String

func (*QueryGetDenomLiquidityResponse) Unmarshal

func (m *QueryGetDenomLiquidityResponse) Unmarshal(dAtA []byte) error

func (*QueryGetDenomLiquidityResponse) XXX_DiscardUnknown

func (m *QueryGetDenomLiquidityResponse) XXX_DiscardUnknown()

func (*QueryGetDenomLiquidityResponse) XXX_Marshal

func (m *QueryGetDenomLiquidityResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryGetDenomLiquidityResponse) XXX_Merge

func (m *QueryGetDenomLiquidityResponse) XXX_Merge(src proto.Message)

func (*QueryGetDenomLiquidityResponse) XXX_Size

func (m *QueryGetDenomLiquidityResponse) XXX_Size() int

func (*QueryGetDenomLiquidityResponse) XXX_Unmarshal

func (m *QueryGetDenomLiquidityResponse) XXX_Unmarshal(b []byte) error

type QueryGetPoolRequest

type QueryGetPoolRequest struct {
	PoolId uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
}

func (*QueryGetPoolRequest) Descriptor

func (*QueryGetPoolRequest) Descriptor() ([]byte, []int)

func (*QueryGetPoolRequest) GetPoolId

func (m *QueryGetPoolRequest) GetPoolId() uint64

func (*QueryGetPoolRequest) Marshal

func (m *QueryGetPoolRequest) Marshal() (dAtA []byte, err error)

func (*QueryGetPoolRequest) MarshalTo

func (m *QueryGetPoolRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryGetPoolRequest) MarshalToSizedBuffer

func (m *QueryGetPoolRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryGetPoolRequest) ProtoMessage

func (*QueryGetPoolRequest) ProtoMessage()

func (*QueryGetPoolRequest) Reset

func (m *QueryGetPoolRequest) Reset()

func (*QueryGetPoolRequest) Size

func (m *QueryGetPoolRequest) Size() (n int)

func (*QueryGetPoolRequest) String

func (m *QueryGetPoolRequest) String() string

func (*QueryGetPoolRequest) Unmarshal

func (m *QueryGetPoolRequest) Unmarshal(dAtA []byte) error

func (*QueryGetPoolRequest) XXX_DiscardUnknown

func (m *QueryGetPoolRequest) XXX_DiscardUnknown()

func (*QueryGetPoolRequest) XXX_Marshal

func (m *QueryGetPoolRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryGetPoolRequest) XXX_Merge

func (m *QueryGetPoolRequest) XXX_Merge(src proto.Message)

func (*QueryGetPoolRequest) XXX_Size

func (m *QueryGetPoolRequest) XXX_Size() int

func (*QueryGetPoolRequest) XXX_Unmarshal

func (m *QueryGetPoolRequest) XXX_Unmarshal(b []byte) error

type QueryGetPoolResponse

type QueryGetPoolResponse struct {
	Pool      Pool          `protobuf:"bytes,1,opt,name=pool,proto3" json:"pool"`
	ExtraInfo PoolExtraInfo `protobuf:"bytes,2,opt,name=extra_info,json=extraInfo,proto3" json:"extra_info"`
}

func (*QueryGetPoolResponse) Descriptor

func (*QueryGetPoolResponse) Descriptor() ([]byte, []int)

func (*QueryGetPoolResponse) GetExtraInfo added in v0.29.31

func (m *QueryGetPoolResponse) GetExtraInfo() PoolExtraInfo

func (*QueryGetPoolResponse) GetPool

func (m *QueryGetPoolResponse) GetPool() Pool

func (*QueryGetPoolResponse) Marshal

func (m *QueryGetPoolResponse) Marshal() (dAtA []byte, err error)

func (*QueryGetPoolResponse) MarshalTo

func (m *QueryGetPoolResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryGetPoolResponse) MarshalToSizedBuffer

func (m *QueryGetPoolResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryGetPoolResponse) ProtoMessage

func (*QueryGetPoolResponse) ProtoMessage()

func (*QueryGetPoolResponse) Reset

func (m *QueryGetPoolResponse) Reset()

func (*QueryGetPoolResponse) Size

func (m *QueryGetPoolResponse) Size() (n int)

func (*QueryGetPoolResponse) String

func (m *QueryGetPoolResponse) String() string

func (*QueryGetPoolResponse) Unmarshal

func (m *QueryGetPoolResponse) Unmarshal(dAtA []byte) error

func (*QueryGetPoolResponse) XXX_DiscardUnknown

func (m *QueryGetPoolResponse) XXX_DiscardUnknown()

func (*QueryGetPoolResponse) XXX_Marshal

func (m *QueryGetPoolResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryGetPoolResponse) XXX_Merge

func (m *QueryGetPoolResponse) XXX_Merge(src proto.Message)

func (*QueryGetPoolResponse) XXX_Size

func (m *QueryGetPoolResponse) XXX_Size() int

func (*QueryGetPoolResponse) XXX_Unmarshal

func (m *QueryGetPoolResponse) XXX_Unmarshal(b []byte) error

type QueryInRouteByDenomRequest added in v0.16.0

type QueryInRouteByDenomRequest struct {
	DenomIn  string `protobuf:"bytes,1,opt,name=denom_in,json=denomIn,proto3" json:"denom_in,omitempty"`
	DenomOut string `protobuf:"bytes,2,opt,name=denom_out,json=denomOut,proto3" json:"denom_out,omitempty"`
}

func (*QueryInRouteByDenomRequest) Descriptor added in v0.16.0

func (*QueryInRouteByDenomRequest) Descriptor() ([]byte, []int)

func (*QueryInRouteByDenomRequest) GetDenomIn added in v0.16.0

func (m *QueryInRouteByDenomRequest) GetDenomIn() string

func (*QueryInRouteByDenomRequest) GetDenomOut added in v0.16.0

func (m *QueryInRouteByDenomRequest) GetDenomOut() string

func (*QueryInRouteByDenomRequest) Marshal added in v0.16.0

func (m *QueryInRouteByDenomRequest) Marshal() (dAtA []byte, err error)

func (*QueryInRouteByDenomRequest) MarshalTo added in v0.16.0

func (m *QueryInRouteByDenomRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryInRouteByDenomRequest) MarshalToSizedBuffer added in v0.16.0

func (m *QueryInRouteByDenomRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryInRouteByDenomRequest) ProtoMessage added in v0.16.0

func (*QueryInRouteByDenomRequest) ProtoMessage()

func (*QueryInRouteByDenomRequest) Reset added in v0.16.0

func (m *QueryInRouteByDenomRequest) Reset()

func (*QueryInRouteByDenomRequest) Size added in v0.16.0

func (m *QueryInRouteByDenomRequest) Size() (n int)

func (*QueryInRouteByDenomRequest) String added in v0.16.0

func (m *QueryInRouteByDenomRequest) String() string

func (*QueryInRouteByDenomRequest) Unmarshal added in v0.16.0

func (m *QueryInRouteByDenomRequest) Unmarshal(dAtA []byte) error

func (*QueryInRouteByDenomRequest) XXX_DiscardUnknown added in v0.16.0

func (m *QueryInRouteByDenomRequest) XXX_DiscardUnknown()

func (*QueryInRouteByDenomRequest) XXX_Marshal added in v0.16.0

func (m *QueryInRouteByDenomRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryInRouteByDenomRequest) XXX_Merge added in v0.16.0

func (m *QueryInRouteByDenomRequest) XXX_Merge(src proto.Message)

func (*QueryInRouteByDenomRequest) XXX_Size added in v0.16.0

func (m *QueryInRouteByDenomRequest) XXX_Size() int

func (*QueryInRouteByDenomRequest) XXX_Unmarshal added in v0.16.0

func (m *QueryInRouteByDenomRequest) XXX_Unmarshal(b []byte) error

type QueryInRouteByDenomResponse added in v0.16.0

type QueryInRouteByDenomResponse struct {
	InRoute []*SwapAmountInRoute `protobuf:"bytes,1,rep,name=in_route,json=inRoute,proto3" json:"in_route,omitempty"`
}

func (*QueryInRouteByDenomResponse) Descriptor added in v0.16.0

func (*QueryInRouteByDenomResponse) Descriptor() ([]byte, []int)

func (*QueryInRouteByDenomResponse) GetInRoute added in v0.16.0

func (*QueryInRouteByDenomResponse) Marshal added in v0.16.0

func (m *QueryInRouteByDenomResponse) Marshal() (dAtA []byte, err error)

func (*QueryInRouteByDenomResponse) MarshalTo added in v0.16.0

func (m *QueryInRouteByDenomResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryInRouteByDenomResponse) MarshalToSizedBuffer added in v0.16.0

func (m *QueryInRouteByDenomResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryInRouteByDenomResponse) ProtoMessage added in v0.16.0

func (*QueryInRouteByDenomResponse) ProtoMessage()

func (*QueryInRouteByDenomResponse) Reset added in v0.16.0

func (m *QueryInRouteByDenomResponse) Reset()

func (*QueryInRouteByDenomResponse) Size added in v0.16.0

func (m *QueryInRouteByDenomResponse) Size() (n int)

func (*QueryInRouteByDenomResponse) String added in v0.16.0

func (m *QueryInRouteByDenomResponse) String() string

func (*QueryInRouteByDenomResponse) Unmarshal added in v0.16.0

func (m *QueryInRouteByDenomResponse) Unmarshal(dAtA []byte) error

func (*QueryInRouteByDenomResponse) XXX_DiscardUnknown added in v0.16.0

func (m *QueryInRouteByDenomResponse) XXX_DiscardUnknown()

func (*QueryInRouteByDenomResponse) XXX_Marshal added in v0.16.0

func (m *QueryInRouteByDenomResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryInRouteByDenomResponse) XXX_Merge added in v0.16.0

func (m *QueryInRouteByDenomResponse) XXX_Merge(src proto.Message)

func (*QueryInRouteByDenomResponse) XXX_Size added in v0.16.0

func (m *QueryInRouteByDenomResponse) XXX_Size() int

func (*QueryInRouteByDenomResponse) XXX_Unmarshal added in v0.16.0

func (m *QueryInRouteByDenomResponse) XXX_Unmarshal(b []byte) error

type QueryJoinPoolEstimationRequest added in v0.29.22

type QueryJoinPoolEstimationRequest struct {
	PoolId    uint64       `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	AmountsIn []types.Coin `protobuf:"bytes,2,rep,name=amounts_in,json=amountsIn,proto3" json:"amounts_in"`
}

func (*QueryJoinPoolEstimationRequest) Descriptor added in v0.29.22

func (*QueryJoinPoolEstimationRequest) Descriptor() ([]byte, []int)

func (*QueryJoinPoolEstimationRequest) GetAmountsIn added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) GetAmountsIn() []types.Coin

func (*QueryJoinPoolEstimationRequest) GetPoolId added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) GetPoolId() uint64

func (*QueryJoinPoolEstimationRequest) Marshal added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) Marshal() (dAtA []byte, err error)

func (*QueryJoinPoolEstimationRequest) MarshalTo added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryJoinPoolEstimationRequest) MarshalToSizedBuffer added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryJoinPoolEstimationRequest) ProtoMessage added in v0.29.22

func (*QueryJoinPoolEstimationRequest) ProtoMessage()

func (*QueryJoinPoolEstimationRequest) Reset added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) Reset()

func (*QueryJoinPoolEstimationRequest) Size added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) Size() (n int)

func (*QueryJoinPoolEstimationRequest) String added in v0.29.22

func (*QueryJoinPoolEstimationRequest) Unmarshal added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) Unmarshal(dAtA []byte) error

func (*QueryJoinPoolEstimationRequest) XXX_DiscardUnknown added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) XXX_DiscardUnknown()

func (*QueryJoinPoolEstimationRequest) XXX_Marshal added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryJoinPoolEstimationRequest) XXX_Merge added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) XXX_Merge(src proto.Message)

func (*QueryJoinPoolEstimationRequest) XXX_Size added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) XXX_Size() int

func (*QueryJoinPoolEstimationRequest) XXX_Unmarshal added in v0.29.22

func (m *QueryJoinPoolEstimationRequest) XXX_Unmarshal(b []byte) error

type QueryJoinPoolEstimationResponse added in v0.29.22

type QueryJoinPoolEstimationResponse struct {
	ShareAmountOut     types.Coin                             `protobuf:"bytes,1,opt,name=share_amount_out,json=shareAmountOut,proto3" json:"share_amount_out"`
	AmountsIn          []types.Coin                           `protobuf:"bytes,2,rep,name=amounts_in,json=amountsIn,proto3" json:"amounts_in"`
	Slippage           github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=slippage,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"slippage"`
	WeightBalanceRatio github_com_cosmos_cosmos_sdk_types.Dec `` /* 157-byte string literal not displayed */
}

func (*QueryJoinPoolEstimationResponse) Descriptor added in v0.29.22

func (*QueryJoinPoolEstimationResponse) Descriptor() ([]byte, []int)

func (*QueryJoinPoolEstimationResponse) GetAmountsIn added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) GetAmountsIn() []types.Coin

func (*QueryJoinPoolEstimationResponse) GetShareAmountOut added in v0.29.24

func (m *QueryJoinPoolEstimationResponse) GetShareAmountOut() types.Coin

func (*QueryJoinPoolEstimationResponse) Marshal added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) Marshal() (dAtA []byte, err error)

func (*QueryJoinPoolEstimationResponse) MarshalTo added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryJoinPoolEstimationResponse) MarshalToSizedBuffer added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryJoinPoolEstimationResponse) ProtoMessage added in v0.29.22

func (*QueryJoinPoolEstimationResponse) ProtoMessage()

func (*QueryJoinPoolEstimationResponse) Reset added in v0.29.22

func (*QueryJoinPoolEstimationResponse) Size added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) Size() (n int)

func (*QueryJoinPoolEstimationResponse) String added in v0.29.22

func (*QueryJoinPoolEstimationResponse) Unmarshal added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) Unmarshal(dAtA []byte) error

func (*QueryJoinPoolEstimationResponse) XXX_DiscardUnknown added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) XXX_DiscardUnknown()

func (*QueryJoinPoolEstimationResponse) XXX_Marshal added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryJoinPoolEstimationResponse) XXX_Merge added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) XXX_Merge(src proto.Message)

func (*QueryJoinPoolEstimationResponse) XXX_Size added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) XXX_Size() int

func (*QueryJoinPoolEstimationResponse) XXX_Unmarshal added in v0.29.22

func (m *QueryJoinPoolEstimationResponse) XXX_Unmarshal(b []byte) error

type QueryOutRouteByDenomRequest added in v0.16.0

type QueryOutRouteByDenomRequest struct {
	DenomOut string `protobuf:"bytes,1,opt,name=denom_out,json=denomOut,proto3" json:"denom_out,omitempty"`
	DenomIn  string `protobuf:"bytes,2,opt,name=denom_in,json=denomIn,proto3" json:"denom_in,omitempty"`
}

func (*QueryOutRouteByDenomRequest) Descriptor added in v0.16.0

func (*QueryOutRouteByDenomRequest) Descriptor() ([]byte, []int)

func (*QueryOutRouteByDenomRequest) GetDenomIn added in v0.16.0

func (m *QueryOutRouteByDenomRequest) GetDenomIn() string

func (*QueryOutRouteByDenomRequest) GetDenomOut added in v0.16.0

func (m *QueryOutRouteByDenomRequest) GetDenomOut() string

func (*QueryOutRouteByDenomRequest) Marshal added in v0.16.0

func (m *QueryOutRouteByDenomRequest) Marshal() (dAtA []byte, err error)

func (*QueryOutRouteByDenomRequest) MarshalTo added in v0.16.0

func (m *QueryOutRouteByDenomRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryOutRouteByDenomRequest) MarshalToSizedBuffer added in v0.16.0

func (m *QueryOutRouteByDenomRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryOutRouteByDenomRequest) ProtoMessage added in v0.16.0

func (*QueryOutRouteByDenomRequest) ProtoMessage()

func (*QueryOutRouteByDenomRequest) Reset added in v0.16.0

func (m *QueryOutRouteByDenomRequest) Reset()

func (*QueryOutRouteByDenomRequest) Size added in v0.16.0

func (m *QueryOutRouteByDenomRequest) Size() (n int)

func (*QueryOutRouteByDenomRequest) String added in v0.16.0

func (m *QueryOutRouteByDenomRequest) String() string

func (*QueryOutRouteByDenomRequest) Unmarshal added in v0.16.0

func (m *QueryOutRouteByDenomRequest) Unmarshal(dAtA []byte) error

func (*QueryOutRouteByDenomRequest) XXX_DiscardUnknown added in v0.16.0

func (m *QueryOutRouteByDenomRequest) XXX_DiscardUnknown()

func (*QueryOutRouteByDenomRequest) XXX_Marshal added in v0.16.0

func (m *QueryOutRouteByDenomRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryOutRouteByDenomRequest) XXX_Merge added in v0.16.0

func (m *QueryOutRouteByDenomRequest) XXX_Merge(src proto.Message)

func (*QueryOutRouteByDenomRequest) XXX_Size added in v0.16.0

func (m *QueryOutRouteByDenomRequest) XXX_Size() int

func (*QueryOutRouteByDenomRequest) XXX_Unmarshal added in v0.16.0

func (m *QueryOutRouteByDenomRequest) XXX_Unmarshal(b []byte) error

type QueryOutRouteByDenomResponse added in v0.16.0

type QueryOutRouteByDenomResponse struct {
	OutRoute []*SwapAmountOutRoute `protobuf:"bytes,1,rep,name=out_route,json=outRoute,proto3" json:"out_route,omitempty"`
}

func (*QueryOutRouteByDenomResponse) Descriptor added in v0.16.0

func (*QueryOutRouteByDenomResponse) Descriptor() ([]byte, []int)

func (*QueryOutRouteByDenomResponse) GetOutRoute added in v0.16.0

func (*QueryOutRouteByDenomResponse) Marshal added in v0.16.0

func (m *QueryOutRouteByDenomResponse) Marshal() (dAtA []byte, err error)

func (*QueryOutRouteByDenomResponse) MarshalTo added in v0.16.0

func (m *QueryOutRouteByDenomResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryOutRouteByDenomResponse) MarshalToSizedBuffer added in v0.16.0

func (m *QueryOutRouteByDenomResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryOutRouteByDenomResponse) ProtoMessage added in v0.16.0

func (*QueryOutRouteByDenomResponse) ProtoMessage()

func (*QueryOutRouteByDenomResponse) Reset added in v0.16.0

func (m *QueryOutRouteByDenomResponse) Reset()

func (*QueryOutRouteByDenomResponse) Size added in v0.16.0

func (m *QueryOutRouteByDenomResponse) Size() (n int)

func (*QueryOutRouteByDenomResponse) String added in v0.16.0

func (*QueryOutRouteByDenomResponse) Unmarshal added in v0.16.0

func (m *QueryOutRouteByDenomResponse) Unmarshal(dAtA []byte) error

func (*QueryOutRouteByDenomResponse) XXX_DiscardUnknown added in v0.16.0

func (m *QueryOutRouteByDenomResponse) XXX_DiscardUnknown()

func (*QueryOutRouteByDenomResponse) XXX_Marshal added in v0.16.0

func (m *QueryOutRouteByDenomResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryOutRouteByDenomResponse) XXX_Merge added in v0.16.0

func (m *QueryOutRouteByDenomResponse) XXX_Merge(src proto.Message)

func (*QueryOutRouteByDenomResponse) XXX_Size added in v0.16.0

func (m *QueryOutRouteByDenomResponse) XXX_Size() int

func (*QueryOutRouteByDenomResponse) XXX_Unmarshal added in v0.16.0

func (m *QueryOutRouteByDenomResponse) XXX_Unmarshal(b []byte) error

type QueryParamsRequest

type QueryParamsRequest struct {
}

QueryParamsRequest is request type for the Query/Params RPC method.

func (*QueryParamsRequest) Descriptor

func (*QueryParamsRequest) Descriptor() ([]byte, []int)

func (*QueryParamsRequest) Marshal

func (m *QueryParamsRequest) Marshal() (dAtA []byte, err error)

func (*QueryParamsRequest) MarshalTo

func (m *QueryParamsRequest) MarshalTo(dAtA []byte) (int, error)

func (*QueryParamsRequest) MarshalToSizedBuffer

func (m *QueryParamsRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

func (m *QueryParamsRequest) Size() (n int)

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

func (m *QueryParamsRequest) Unmarshal(dAtA []byte) error

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

func (m *QueryParamsRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryParamsRequest) XXX_Merge

func (m *QueryParamsRequest) XXX_Merge(src proto.Message)

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

func (m *QueryParamsRequest) XXX_Unmarshal(b []byte) error

type QueryParamsResponse

type QueryParamsResponse struct {
	// params holds all the parameters of this module.
	Params Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

QueryParamsResponse is response type for the Query/Params RPC method.

func (*QueryParamsResponse) Descriptor

func (*QueryParamsResponse) Descriptor() ([]byte, []int)

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

func (m *QueryParamsResponse) Marshal() (dAtA []byte, err error)

func (*QueryParamsResponse) MarshalTo

func (m *QueryParamsResponse) MarshalTo(dAtA []byte) (int, error)

func (*QueryParamsResponse) MarshalToSizedBuffer

func (m *QueryParamsResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

func (m *QueryParamsResponse) Size() (n int)

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

func (m *QueryParamsResponse) Unmarshal(dAtA []byte) error

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

func (m *QueryParamsResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QueryParamsResponse) XXX_Merge

func (m *QueryParamsResponse) XXX_Merge(src proto.Message)

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

func (m *QueryParamsResponse) XXX_Unmarshal(b []byte) error

type QueryServer

type QueryServer interface {
	// Parameters queries the parameters of the module.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// Queries a list of Pool items.
	Pool(context.Context, *QueryGetPoolRequest) (*QueryGetPoolResponse, error)
	PoolAll(context.Context, *QueryAllPoolRequest) (*QueryAllPoolResponse, error)
	// Queries a list of DenomLiquidity items.
	DenomLiquidity(context.Context, *QueryGetDenomLiquidityRequest) (*QueryGetDenomLiquidityResponse, error)
	DenomLiquidityAll(context.Context, *QueryAllDenomLiquidityRequest) (*QueryAllDenomLiquidityResponse, error)
	// Queries a list of SwapEstimation items.
	SwapEstimation(context.Context, *QuerySwapEstimationRequest) (*QuerySwapEstimationResponse, error)
	// Queries JoinPool estimation
	JoinPoolEstimation(context.Context, *QueryJoinPoolEstimationRequest) (*QueryJoinPoolEstimationResponse, error)
	// Queries ExistPool estimation
	ExitPoolEstimation(context.Context, *QueryExitPoolEstimationRequest) (*QueryExitPoolEstimationResponse, error)
	// Queries slippage track for a week.
	SlippageTrack(context.Context, *QuerySlippageTrackRequest) (*QuerySlippageTrackResponse, error)
	// Queries all slippage tracks for a week.
	SlippageTrackAll(context.Context, *QuerySlippageTrackAllRequest) (*QuerySlippageTrackAllResponse, error)
	// Queries a list of Balance items.
	Balance(context.Context, *QueryBalanceRequest) (*QueryBalanceResponse, error)
	// Queries a list of InRouteByDenom items.
	InRouteByDenom(context.Context, *QueryInRouteByDenomRequest) (*QueryInRouteByDenomResponse, error)
	// Queries a list of OutRouteByDenom items.
	OutRouteByDenom(context.Context, *QueryOutRouteByDenomRequest) (*QueryOutRouteByDenomResponse, error)
	// Queries a list of SwapEstimationByDenom items.
	SwapEstimationByDenom(context.Context, *QuerySwapEstimationByDenomRequest) (*QuerySwapEstimationByDenomResponse, error)
}

QueryServer is the server API for Query service.

type QuerySlippageTrackAllRequest added in v0.13.0

type QuerySlippageTrackAllRequest struct {
}

func (*QuerySlippageTrackAllRequest) Descriptor added in v0.13.0

func (*QuerySlippageTrackAllRequest) Descriptor() ([]byte, []int)

func (*QuerySlippageTrackAllRequest) Marshal added in v0.13.0

func (m *QuerySlippageTrackAllRequest) Marshal() (dAtA []byte, err error)

func (*QuerySlippageTrackAllRequest) MarshalTo added in v0.13.0

func (m *QuerySlippageTrackAllRequest) MarshalTo(dAtA []byte) (int, error)

func (*QuerySlippageTrackAllRequest) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySlippageTrackAllRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySlippageTrackAllRequest) ProtoMessage added in v0.13.0

func (*QuerySlippageTrackAllRequest) ProtoMessage()

func (*QuerySlippageTrackAllRequest) Reset added in v0.13.0

func (m *QuerySlippageTrackAllRequest) Reset()

func (*QuerySlippageTrackAllRequest) Size added in v0.13.0

func (m *QuerySlippageTrackAllRequest) Size() (n int)

func (*QuerySlippageTrackAllRequest) String added in v0.13.0

func (*QuerySlippageTrackAllRequest) Unmarshal added in v0.13.0

func (m *QuerySlippageTrackAllRequest) Unmarshal(dAtA []byte) error

func (*QuerySlippageTrackAllRequest) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySlippageTrackAllRequest) XXX_DiscardUnknown()

func (*QuerySlippageTrackAllRequest) XXX_Marshal added in v0.13.0

func (m *QuerySlippageTrackAllRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySlippageTrackAllRequest) XXX_Merge added in v0.13.0

func (m *QuerySlippageTrackAllRequest) XXX_Merge(src proto.Message)

func (*QuerySlippageTrackAllRequest) XXX_Size added in v0.13.0

func (m *QuerySlippageTrackAllRequest) XXX_Size() int

func (*QuerySlippageTrackAllRequest) XXX_Unmarshal added in v0.13.0

func (m *QuerySlippageTrackAllRequest) XXX_Unmarshal(b []byte) error

type QuerySlippageTrackAllResponse added in v0.13.0

type QuerySlippageTrackAllResponse struct {
	Tracks []OraclePoolSlippageTrack `protobuf:"bytes,1,rep,name=tracks,proto3" json:"tracks"`
}

func (*QuerySlippageTrackAllResponse) Descriptor added in v0.13.0

func (*QuerySlippageTrackAllResponse) Descriptor() ([]byte, []int)

func (*QuerySlippageTrackAllResponse) GetTracks added in v0.13.0

func (*QuerySlippageTrackAllResponse) Marshal added in v0.13.0

func (m *QuerySlippageTrackAllResponse) Marshal() (dAtA []byte, err error)

func (*QuerySlippageTrackAllResponse) MarshalTo added in v0.13.0

func (m *QuerySlippageTrackAllResponse) MarshalTo(dAtA []byte) (int, error)

func (*QuerySlippageTrackAllResponse) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySlippageTrackAllResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySlippageTrackAllResponse) ProtoMessage added in v0.13.0

func (*QuerySlippageTrackAllResponse) ProtoMessage()

func (*QuerySlippageTrackAllResponse) Reset added in v0.13.0

func (m *QuerySlippageTrackAllResponse) Reset()

func (*QuerySlippageTrackAllResponse) Size added in v0.13.0

func (m *QuerySlippageTrackAllResponse) Size() (n int)

func (*QuerySlippageTrackAllResponse) String added in v0.13.0

func (*QuerySlippageTrackAllResponse) Unmarshal added in v0.13.0

func (m *QuerySlippageTrackAllResponse) Unmarshal(dAtA []byte) error

func (*QuerySlippageTrackAllResponse) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySlippageTrackAllResponse) XXX_DiscardUnknown()

func (*QuerySlippageTrackAllResponse) XXX_Marshal added in v0.13.0

func (m *QuerySlippageTrackAllResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySlippageTrackAllResponse) XXX_Merge added in v0.13.0

func (m *QuerySlippageTrackAllResponse) XXX_Merge(src proto.Message)

func (*QuerySlippageTrackAllResponse) XXX_Size added in v0.13.0

func (m *QuerySlippageTrackAllResponse) XXX_Size() int

func (*QuerySlippageTrackAllResponse) XXX_Unmarshal added in v0.13.0

func (m *QuerySlippageTrackAllResponse) XXX_Unmarshal(b []byte) error

type QuerySlippageTrackRequest added in v0.13.0

type QuerySlippageTrackRequest struct {
	PoolId uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
}

func (*QuerySlippageTrackRequest) Descriptor added in v0.13.0

func (*QuerySlippageTrackRequest) Descriptor() ([]byte, []int)

func (*QuerySlippageTrackRequest) GetPoolId added in v0.13.0

func (m *QuerySlippageTrackRequest) GetPoolId() uint64

func (*QuerySlippageTrackRequest) Marshal added in v0.13.0

func (m *QuerySlippageTrackRequest) Marshal() (dAtA []byte, err error)

func (*QuerySlippageTrackRequest) MarshalTo added in v0.13.0

func (m *QuerySlippageTrackRequest) MarshalTo(dAtA []byte) (int, error)

func (*QuerySlippageTrackRequest) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySlippageTrackRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySlippageTrackRequest) ProtoMessage added in v0.13.0

func (*QuerySlippageTrackRequest) ProtoMessage()

func (*QuerySlippageTrackRequest) Reset added in v0.13.0

func (m *QuerySlippageTrackRequest) Reset()

func (*QuerySlippageTrackRequest) Size added in v0.13.0

func (m *QuerySlippageTrackRequest) Size() (n int)

func (*QuerySlippageTrackRequest) String added in v0.13.0

func (m *QuerySlippageTrackRequest) String() string

func (*QuerySlippageTrackRequest) Unmarshal added in v0.13.0

func (m *QuerySlippageTrackRequest) Unmarshal(dAtA []byte) error

func (*QuerySlippageTrackRequest) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySlippageTrackRequest) XXX_DiscardUnknown()

func (*QuerySlippageTrackRequest) XXX_Marshal added in v0.13.0

func (m *QuerySlippageTrackRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySlippageTrackRequest) XXX_Merge added in v0.13.0

func (m *QuerySlippageTrackRequest) XXX_Merge(src proto.Message)

func (*QuerySlippageTrackRequest) XXX_Size added in v0.13.0

func (m *QuerySlippageTrackRequest) XXX_Size() int

func (*QuerySlippageTrackRequest) XXX_Unmarshal added in v0.13.0

func (m *QuerySlippageTrackRequest) XXX_Unmarshal(b []byte) error

type QuerySlippageTrackResponse added in v0.13.0

type QuerySlippageTrackResponse struct {
	Track OraclePoolSlippageTrack `protobuf:"bytes,1,opt,name=track,proto3" json:"track"`
}

func (*QuerySlippageTrackResponse) Descriptor added in v0.13.0

func (*QuerySlippageTrackResponse) Descriptor() ([]byte, []int)

func (*QuerySlippageTrackResponse) GetTrack added in v0.13.0

func (*QuerySlippageTrackResponse) Marshal added in v0.13.0

func (m *QuerySlippageTrackResponse) Marshal() (dAtA []byte, err error)

func (*QuerySlippageTrackResponse) MarshalTo added in v0.13.0

func (m *QuerySlippageTrackResponse) MarshalTo(dAtA []byte) (int, error)

func (*QuerySlippageTrackResponse) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySlippageTrackResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySlippageTrackResponse) ProtoMessage added in v0.13.0

func (*QuerySlippageTrackResponse) ProtoMessage()

func (*QuerySlippageTrackResponse) Reset added in v0.13.0

func (m *QuerySlippageTrackResponse) Reset()

func (*QuerySlippageTrackResponse) Size added in v0.13.0

func (m *QuerySlippageTrackResponse) Size() (n int)

func (*QuerySlippageTrackResponse) String added in v0.13.0

func (m *QuerySlippageTrackResponse) String() string

func (*QuerySlippageTrackResponse) Unmarshal added in v0.13.0

func (m *QuerySlippageTrackResponse) Unmarshal(dAtA []byte) error

func (*QuerySlippageTrackResponse) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySlippageTrackResponse) XXX_DiscardUnknown()

func (*QuerySlippageTrackResponse) XXX_Marshal added in v0.13.0

func (m *QuerySlippageTrackResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySlippageTrackResponse) XXX_Merge added in v0.13.0

func (m *QuerySlippageTrackResponse) XXX_Merge(src proto.Message)

func (*QuerySlippageTrackResponse) XXX_Size added in v0.13.0

func (m *QuerySlippageTrackResponse) XXX_Size() int

func (*QuerySlippageTrackResponse) XXX_Unmarshal added in v0.13.0

func (m *QuerySlippageTrackResponse) XXX_Unmarshal(b []byte) error

type QuerySwapEstimationByDenomRequest added in v0.16.0

type QuerySwapEstimationByDenomRequest struct {
	Amount   types.Coin                             `protobuf:"bytes,1,opt,name=amount,proto3" json:"amount"`
	DenomIn  string                                 `protobuf:"bytes,2,opt,name=denom_in,json=denomIn,proto3" json:"denom_in,omitempty"`
	DenomOut string                                 `protobuf:"bytes,3,opt,name=denom_out,json=denomOut,proto3" json:"denom_out,omitempty"`
	Discount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,4,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

func (*QuerySwapEstimationByDenomRequest) Descriptor added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) Descriptor() ([]byte, []int)

func (*QuerySwapEstimationByDenomRequest) GetAmount added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) GetDenomIn added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) GetDenomIn() string

func (*QuerySwapEstimationByDenomRequest) GetDenomOut added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) GetDenomOut() string

func (*QuerySwapEstimationByDenomRequest) Marshal added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) Marshal() (dAtA []byte, err error)

func (*QuerySwapEstimationByDenomRequest) MarshalTo added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) MarshalTo(dAtA []byte) (int, error)

func (*QuerySwapEstimationByDenomRequest) MarshalToSizedBuffer added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySwapEstimationByDenomRequest) ProtoMessage added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) ProtoMessage()

func (*QuerySwapEstimationByDenomRequest) Reset added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) Size added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) Size() (n int)

func (*QuerySwapEstimationByDenomRequest) String added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) Unmarshal added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) Unmarshal(dAtA []byte) error

func (*QuerySwapEstimationByDenomRequest) XXX_DiscardUnknown added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) XXX_DiscardUnknown()

func (*QuerySwapEstimationByDenomRequest) XXX_Marshal added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySwapEstimationByDenomRequest) XXX_Merge added in v0.16.0

func (*QuerySwapEstimationByDenomRequest) XXX_Size added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) XXX_Size() int

func (*QuerySwapEstimationByDenomRequest) XXX_Unmarshal added in v0.16.0

func (m *QuerySwapEstimationByDenomRequest) XXX_Unmarshal(b []byte) error

type QuerySwapEstimationByDenomResponse added in v0.16.0

type QuerySwapEstimationByDenomResponse struct {
	InRoute            []*SwapAmountInRoute                   `protobuf:"bytes,1,rep,name=in_route,json=inRoute,proto3" json:"in_route,omitempty"`
	OutRoute           []*SwapAmountOutRoute                  `protobuf:"bytes,2,rep,name=out_route,json=outRoute,proto3" json:"out_route,omitempty"`
	SpotPrice          github_com_cosmos_cosmos_sdk_types.Dec `` /* 128-byte string literal not displayed */
	Amount             types.Coin                             `protobuf:"bytes,4,opt,name=amount,proto3" json:"amount"`
	SwapFee            github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,5,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	Discount           github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,6,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	AvailableLiquidity types.Coin                             `protobuf:"bytes,7,opt,name=available_liquidity,json=availableLiquidity,proto3" json:"available_liquidity"`
	WeightBalanceRatio github_com_cosmos_cosmos_sdk_types.Dec `` /* 157-byte string literal not displayed */
	Slippage           github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,9,opt,name=slippage,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"slippage"`
	PriceImpact        github_com_cosmos_cosmos_sdk_types.Dec `` /* 135-byte string literal not displayed */
}

func (*QuerySwapEstimationByDenomResponse) Descriptor added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) Descriptor() ([]byte, []int)

func (*QuerySwapEstimationByDenomResponse) GetAmount added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) GetAvailableLiquidity added in v0.18.0

func (m *QuerySwapEstimationByDenomResponse) GetAvailableLiquidity() types.Coin

func (*QuerySwapEstimationByDenomResponse) GetInRoute added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) GetOutRoute added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) Marshal added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) Marshal() (dAtA []byte, err error)

func (*QuerySwapEstimationByDenomResponse) MarshalTo added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) MarshalTo(dAtA []byte) (int, error)

func (*QuerySwapEstimationByDenomResponse) MarshalToSizedBuffer added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySwapEstimationByDenomResponse) ProtoMessage added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) ProtoMessage()

func (*QuerySwapEstimationByDenomResponse) Reset added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) Size added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) String added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) Unmarshal added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) Unmarshal(dAtA []byte) error

func (*QuerySwapEstimationByDenomResponse) XXX_DiscardUnknown added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) XXX_DiscardUnknown()

func (*QuerySwapEstimationByDenomResponse) XXX_Marshal added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySwapEstimationByDenomResponse) XXX_Merge added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) XXX_Size added in v0.16.0

func (*QuerySwapEstimationByDenomResponse) XXX_Unmarshal added in v0.16.0

func (m *QuerySwapEstimationByDenomResponse) XXX_Unmarshal(b []byte) error

type QuerySwapEstimationRequest added in v0.13.0

type QuerySwapEstimationRequest struct {
	Routes   []*SwapAmountInRoute                   `protobuf:"bytes,1,rep,name=routes,proto3" json:"routes,omitempty"`
	TokenIn  types.Coin                             `protobuf:"bytes,2,opt,name=token_in,json=tokenIn,proto3" json:"token_in"`
	Discount github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
}

func (*QuerySwapEstimationRequest) Descriptor added in v0.13.0

func (*QuerySwapEstimationRequest) Descriptor() ([]byte, []int)

func (*QuerySwapEstimationRequest) GetRoutes added in v0.13.0

func (*QuerySwapEstimationRequest) GetTokenIn added in v0.13.0

func (m *QuerySwapEstimationRequest) GetTokenIn() types.Coin

func (*QuerySwapEstimationRequest) Marshal added in v0.13.0

func (m *QuerySwapEstimationRequest) Marshal() (dAtA []byte, err error)

func (*QuerySwapEstimationRequest) MarshalTo added in v0.13.0

func (m *QuerySwapEstimationRequest) MarshalTo(dAtA []byte) (int, error)

func (*QuerySwapEstimationRequest) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySwapEstimationRequest) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySwapEstimationRequest) ProtoMessage added in v0.13.0

func (*QuerySwapEstimationRequest) ProtoMessage()

func (*QuerySwapEstimationRequest) Reset added in v0.13.0

func (m *QuerySwapEstimationRequest) Reset()

func (*QuerySwapEstimationRequest) Size added in v0.13.0

func (m *QuerySwapEstimationRequest) Size() (n int)

func (*QuerySwapEstimationRequest) String added in v0.13.0

func (m *QuerySwapEstimationRequest) String() string

func (*QuerySwapEstimationRequest) Unmarshal added in v0.13.0

func (m *QuerySwapEstimationRequest) Unmarshal(dAtA []byte) error

func (*QuerySwapEstimationRequest) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySwapEstimationRequest) XXX_DiscardUnknown()

func (*QuerySwapEstimationRequest) XXX_Marshal added in v0.13.0

func (m *QuerySwapEstimationRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySwapEstimationRequest) XXX_Merge added in v0.13.0

func (m *QuerySwapEstimationRequest) XXX_Merge(src proto.Message)

func (*QuerySwapEstimationRequest) XXX_Size added in v0.13.0

func (m *QuerySwapEstimationRequest) XXX_Size() int

func (*QuerySwapEstimationRequest) XXX_Unmarshal added in v0.13.0

func (m *QuerySwapEstimationRequest) XXX_Unmarshal(b []byte) error

type QuerySwapEstimationResponse added in v0.13.0

type QuerySwapEstimationResponse struct {
	SpotPrice          github_com_cosmos_cosmos_sdk_types.Dec `` /* 128-byte string literal not displayed */
	TokenOut           types.Coin                             `protobuf:"bytes,2,opt,name=token_out,json=tokenOut,proto3" json:"token_out"`
	SwapFee            github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,3,opt,name=swap_fee,json=swapFee,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"swap_fee"`
	Discount           github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,4,opt,name=discount,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"discount"`
	AvailableLiquidity types.Coin                             `protobuf:"bytes,5,opt,name=available_liquidity,json=availableLiquidity,proto3" json:"available_liquidity"`
	Slippage           github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,6,opt,name=slippage,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"slippage"`
	WeightBalanceRatio github_com_cosmos_cosmos_sdk_types.Dec `` /* 157-byte string literal not displayed */
}

func (*QuerySwapEstimationResponse) Descriptor added in v0.13.0

func (*QuerySwapEstimationResponse) Descriptor() ([]byte, []int)

func (*QuerySwapEstimationResponse) GetAvailableLiquidity added in v0.18.0

func (m *QuerySwapEstimationResponse) GetAvailableLiquidity() types.Coin

func (*QuerySwapEstimationResponse) GetTokenOut added in v0.13.0

func (m *QuerySwapEstimationResponse) GetTokenOut() types.Coin

func (*QuerySwapEstimationResponse) Marshal added in v0.13.0

func (m *QuerySwapEstimationResponse) Marshal() (dAtA []byte, err error)

func (*QuerySwapEstimationResponse) MarshalTo added in v0.13.0

func (m *QuerySwapEstimationResponse) MarshalTo(dAtA []byte) (int, error)

func (*QuerySwapEstimationResponse) MarshalToSizedBuffer added in v0.13.0

func (m *QuerySwapEstimationResponse) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*QuerySwapEstimationResponse) ProtoMessage added in v0.13.0

func (*QuerySwapEstimationResponse) ProtoMessage()

func (*QuerySwapEstimationResponse) Reset added in v0.13.0

func (m *QuerySwapEstimationResponse) Reset()

func (*QuerySwapEstimationResponse) Size added in v0.13.0

func (m *QuerySwapEstimationResponse) Size() (n int)

func (*QuerySwapEstimationResponse) String added in v0.13.0

func (m *QuerySwapEstimationResponse) String() string

func (*QuerySwapEstimationResponse) Unmarshal added in v0.13.0

func (m *QuerySwapEstimationResponse) Unmarshal(dAtA []byte) error

func (*QuerySwapEstimationResponse) XXX_DiscardUnknown added in v0.13.0

func (m *QuerySwapEstimationResponse) XXX_DiscardUnknown()

func (*QuerySwapEstimationResponse) XXX_Marshal added in v0.13.0

func (m *QuerySwapEstimationResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*QuerySwapEstimationResponse) XXX_Merge added in v0.13.0

func (m *QuerySwapEstimationResponse) XXX_Merge(src proto.Message)

func (*QuerySwapEstimationResponse) XXX_Size added in v0.13.0

func (m *QuerySwapEstimationResponse) XXX_Size() int

func (*QuerySwapEstimationResponse) XXX_Unmarshal added in v0.13.0

func (m *QuerySwapEstimationResponse) XXX_Unmarshal(b []byte) error

type SwapAmountInRoute

type SwapAmountInRoute struct {
	PoolId        uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	TokenOutDenom string `protobuf:"bytes,2,opt,name=token_out_denom,json=tokenOutDenom,proto3" json:"token_out_denom,omitempty"`
}

func (*SwapAmountInRoute) Descriptor

func (*SwapAmountInRoute) Descriptor() ([]byte, []int)

func (*SwapAmountInRoute) GetPoolId

func (m *SwapAmountInRoute) GetPoolId() uint64

func (*SwapAmountInRoute) GetTokenOutDenom

func (m *SwapAmountInRoute) GetTokenOutDenom() string

func (*SwapAmountInRoute) Marshal

func (m *SwapAmountInRoute) Marshal() (dAtA []byte, err error)

func (*SwapAmountInRoute) MarshalTo

func (m *SwapAmountInRoute) MarshalTo(dAtA []byte) (int, error)

func (*SwapAmountInRoute) MarshalToSizedBuffer

func (m *SwapAmountInRoute) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SwapAmountInRoute) ProtoMessage

func (*SwapAmountInRoute) ProtoMessage()

func (*SwapAmountInRoute) Reset

func (m *SwapAmountInRoute) Reset()

func (*SwapAmountInRoute) Size

func (m *SwapAmountInRoute) Size() (n int)

func (*SwapAmountInRoute) String

func (m *SwapAmountInRoute) String() string

func (*SwapAmountInRoute) Unmarshal

func (m *SwapAmountInRoute) Unmarshal(dAtA []byte) error

func (*SwapAmountInRoute) XXX_DiscardUnknown

func (m *SwapAmountInRoute) XXX_DiscardUnknown()

func (*SwapAmountInRoute) XXX_Marshal

func (m *SwapAmountInRoute) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SwapAmountInRoute) XXX_Merge

func (m *SwapAmountInRoute) XXX_Merge(src proto.Message)

func (*SwapAmountInRoute) XXX_Size

func (m *SwapAmountInRoute) XXX_Size() int

func (*SwapAmountInRoute) XXX_Unmarshal

func (m *SwapAmountInRoute) XXX_Unmarshal(b []byte) error

type SwapAmountInRoutes

type SwapAmountInRoutes []SwapAmountInRoute

func (SwapAmountInRoutes) IntermediateDenoms

func (routes SwapAmountInRoutes) IntermediateDenoms() []string

func (SwapAmountInRoutes) Length

func (routes SwapAmountInRoutes) Length() int

func (SwapAmountInRoutes) PoolIds

func (routes SwapAmountInRoutes) PoolIds() []uint64

func (SwapAmountInRoutes) Validate

func (routes SwapAmountInRoutes) Validate() error

type SwapAmountOutRoute

type SwapAmountOutRoute struct {
	PoolId       uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	TokenInDenom string `protobuf:"bytes,2,opt,name=token_in_denom,json=tokenInDenom,proto3" json:"token_in_denom,omitempty"`
}

func (*SwapAmountOutRoute) Descriptor

func (*SwapAmountOutRoute) Descriptor() ([]byte, []int)

func (*SwapAmountOutRoute) GetPoolId

func (m *SwapAmountOutRoute) GetPoolId() uint64

func (*SwapAmountOutRoute) GetTokenInDenom

func (m *SwapAmountOutRoute) GetTokenInDenom() string

func (*SwapAmountOutRoute) Marshal

func (m *SwapAmountOutRoute) Marshal() (dAtA []byte, err error)

func (*SwapAmountOutRoute) MarshalTo

func (m *SwapAmountOutRoute) MarshalTo(dAtA []byte) (int, error)

func (*SwapAmountOutRoute) MarshalToSizedBuffer

func (m *SwapAmountOutRoute) MarshalToSizedBuffer(dAtA []byte) (int, error)

func (*SwapAmountOutRoute) ProtoMessage

func (*SwapAmountOutRoute) ProtoMessage()

func (*SwapAmountOutRoute) Reset

func (m *SwapAmountOutRoute) Reset()

func (*SwapAmountOutRoute) Size

func (m *SwapAmountOutRoute) Size() (n int)

func (*SwapAmountOutRoute) String

func (m *SwapAmountOutRoute) String() string

func (*SwapAmountOutRoute) Unmarshal

func (m *SwapAmountOutRoute) Unmarshal(dAtA []byte) error

func (*SwapAmountOutRoute) XXX_DiscardUnknown

func (m *SwapAmountOutRoute) XXX_DiscardUnknown()

func (*SwapAmountOutRoute) XXX_Marshal

func (m *SwapAmountOutRoute) XXX_Marshal(b []byte, deterministic bool) ([]byte, error)

func (*SwapAmountOutRoute) XXX_Merge

func (m *SwapAmountOutRoute) XXX_Merge(src proto.Message)

func (*SwapAmountOutRoute) XXX_Size

func (m *SwapAmountOutRoute) XXX_Size() int

func (*SwapAmountOutRoute) XXX_Unmarshal

func (m *SwapAmountOutRoute) XXX_Unmarshal(b []byte) error

type SwapAmountOutRoutes

type SwapAmountOutRoutes []SwapAmountOutRoute

func (SwapAmountOutRoutes) IntermediateDenoms

func (routes SwapAmountOutRoutes) IntermediateDenoms() []string

func (SwapAmountOutRoutes) Length

func (routes SwapAmountOutRoutes) Length() int

func (SwapAmountOutRoutes) PoolIds

func (routes SwapAmountOutRoutes) PoolIds() []uint64

func (SwapAmountOutRoutes) Validate

func (routes SwapAmountOutRoutes) Validate() error

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) CreatePool

func (*UnimplementedMsgServer) ExitPool

func (*UnimplementedMsgServer) FeedMultipleExternalLiquidity added in v0.12.0

func (*UnimplementedMsgServer) JoinPool

func (*UnimplementedMsgServer) SwapByDenom added in v0.17.0

func (*UnimplementedMsgServer) SwapExactAmountIn

func (*UnimplementedMsgServer) SwapExactAmountOut

func (*UnimplementedMsgServer) UpdateParams added in v0.29.31

func (*UnimplementedMsgServer) UpdatePoolParams added in v0.18.0

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) Balance added in v0.14.0

func (*UnimplementedQueryServer) DenomLiquidity

func (*UnimplementedQueryServer) DenomLiquidityAll

func (*UnimplementedQueryServer) ExitPoolEstimation added in v0.29.22

func (*UnimplementedQueryServer) InRouteByDenom added in v0.16.0

func (*UnimplementedQueryServer) JoinPoolEstimation added in v0.29.22

func (*UnimplementedQueryServer) OutRouteByDenom added in v0.16.0

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) Pool

func (*UnimplementedQueryServer) PoolAll

func (*UnimplementedQueryServer) SlippageTrack added in v0.13.0

func (*UnimplementedQueryServer) SlippageTrackAll added in v0.13.0

func (*UnimplementedQueryServer) SwapEstimation added in v0.13.0

func (*UnimplementedQueryServer) SwapEstimationByDenom added in v0.16.0

Directories

Path Synopsis

Jump to

Keyboard shortcuts

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