types

package
v0.0.0-...-878d61a Latest Latest
Warning

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

Go to latest
Published: Feb 10, 2023 License: Apache-2.0 Imports: 37 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
	// Raise 10 to the power of SigFigsExponent to determine number of significant figures.
	// i.e. SigFigExponent = 8 is 10^8 which is 100000000. This gives 8 significant figures.
	SigFigsExponent       = 8
	BalancerGasFeeForSwap = 10_000

	StableswapMinScaledAmtPerAsset = 1
	// We keep this multiplier at 1, but can increase if needed in the unlikely scenario where default scaling factors of 1 cannot accommodate enough assets
	ScalingFactorMultiplier = 1

	// pools can be created with min and max number of assets defined with this constants
	MinNumOfAssetsInPool = 2
	MaxNumOfAssetsInPool = 8
)
View Source
const (
	TypeEvtPoolJoined    = "pool_joined"
	TypeEvtPoolExited    = "pool_exited"
	TypeEvtPoolCreated   = "pool_created"
	TypeEvtTokenSwapped  = "token_swapped"
	TypeEvtMigrateShares = "migrate_shares"

	AttributeValueCategory     = ModuleName
	AttributeKeyPoolId         = "pool_id"
	AttributeKeyPoolIdEntering = "pool_id_entering"
	AttributeKeyPoolIdLeaving  = "pool_id_leaving"
	AttributeKeySwapFee        = "swap_fee"
	AttributeKeyTokensIn       = "tokens_in"
	AttributeKeyTokensOut      = "tokens_out"
)
View Source
const (
	ProposalTypeUpdateMigrationRecords  = "UpdateMigrationRecords"
	ProposalTypeReplaceMigrationRecords = "ReplaceMigrationRecords"
)
View Source
const (
	ModuleName = "gamm"

	StoreKey = ModuleName

	RouterKey = ModuleName

	QuerierRoute = ModuleName
)
View Source
const (
	TypeMsgSwapExactAmountIn       = "swap_exact_amount_in"
	TypeMsgSwapExactAmountOut      = "swap_exact_amount_out"
	TypeMsgJoinPool                = "join_pool"
	TypeMsgExitPool                = "exit_pool"
	TypeMsgJoinSwapExternAmountIn  = "join_swap_extern_amount_in"
	TypeMsgJoinSwapShareAmountOut  = "join_swap_share_amount_out"
	TypeMsgExitSwapExternAmountOut = "exit_swap_extern_amount_out"
	TypeMsgExitSwapShareAmountIn   = "exit_swap_share_amount_in"
)

constants.

Variables

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

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

	// SpotPriceSigFigs is the amount of significant figures used in return value of calculate SpotPrice
	SpotPriceSigFigs = sdk.NewDec(10).Power(SigFigsExponent).TruncateInt()
	// MaxSpotPrice is the maximum supported spot price. Anything greater than this will error.
	// Internal note: Ctrl+F for MaxSpotPrice in code if ever changed.
	// Other tests depend on being equal to MaxSpotPrice,
	// but don't directly import it due to import issues.
	MaxSpotPrice = sdk.NewDec(2).Power(128).Sub(sdk.OneDec())
	// MinSpotPrice is the minimum supported spot price. Anything less than this will error.
	// It is limited by sdk.Dec's precision.
	MinSpotPrice = sdk.SmallestDec()

	// MultihopSwapFeeMultiplierForFuryPools if a swap fees multiplier for trades consists of just two FURY pools during a single transaction.
	MultihopSwapFeeMultiplierForFuryPools = sdk.NewDecWithPrec(5, 1) // 0.5

	// Maximum amount per asset after the application of scaling factors should be 10e34.
	StableswapMaxScaledAmtPerAsset = sdk.NewDec(10).Power(34).TruncateInt()
)
View Source
var (
	ErrPoolNotFound        = sdkerrors.Register(ModuleName, 1, "pool not found")
	ErrPoolAlreadyExist    = sdkerrors.Register(ModuleName, 2, "pool already exist")
	ErrPoolLocked          = sdkerrors.Register(ModuleName, 3, "pool is locked")
	ErrTooFewPoolAssets    = sdkerrors.Register(ModuleName, 4, "pool should have at least 2 assets, as they must be swapping between at least two assets")
	ErrTooManyPoolAssets   = sdkerrors.Register(ModuleName, 5, "pool has too many assets (currently capped at 8 assets for both balancer and stableswap)")
	ErrLimitMaxAmount      = sdkerrors.Register(ModuleName, 6, "calculated amount is larger than max amount")
	ErrLimitMinAmount      = sdkerrors.Register(ModuleName, 7, "calculated amount is lesser than min amount")
	ErrInvalidMathApprox   = sdkerrors.Register(ModuleName, 8, "invalid calculated result")
	ErrAlreadyInvalidPool  = sdkerrors.Register(ModuleName, 9, "destruction on already invalid pool")
	ErrInvalidPool         = sdkerrors.Register(ModuleName, 10, "attempting to create an invalid pool")
	ErrDenomNotFoundInPool = sdkerrors.Register(ModuleName, 11, "denom does not exist in pool")
	ErrDenomAlreadyInPool  = sdkerrors.Register(ModuleName, 12, "denom already exists in the pool")

	ErrEmptyRoutes              = sdkerrors.Register(ModuleName, 21, "routes not defined")
	ErrEmptyPoolAssets          = sdkerrors.Register(ModuleName, 22, "PoolAssets not defined")
	ErrNegativeSwapFee          = sdkerrors.Register(ModuleName, 23, "swap fee is negative")
	ErrNegativeExitFee          = sdkerrors.Register(ModuleName, 24, "exit fee is negative")
	ErrTooMuchSwapFee           = sdkerrors.Register(ModuleName, 25, "swap fee should be lesser than 1 (100%)")
	ErrTooMuchExitFee           = sdkerrors.Register(ModuleName, 26, "exit fee should be lesser than 1 (100%)")
	ErrNotPositiveWeight        = sdkerrors.Register(ModuleName, 27, "token weight should be greater than 0")
	ErrWeightTooLarge           = sdkerrors.Register(ModuleName, 28, "user specified token weight should be less than 2^20")
	ErrNotPositiveCriteria      = sdkerrors.Register(ModuleName, 29, "min out amount or max in amount should be positive")
	ErrNotPositiveRequireAmount = sdkerrors.Register(ModuleName, 30, "required amount should be positive")
	ErrTooManyTokensOut         = sdkerrors.Register(ModuleName, 31, "tx is trying to get more tokens out of the pool than exist")
	ErrSpotPriceOverflow        = sdkerrors.Register(ModuleName, 32, "invalid spot price (overflowed)")
	ErrSpotPriceInternal        = sdkerrors.Register(ModuleName, 33, "internal spot price error")

	ErrPoolParamsInvalidDenom     = sdkerrors.Register(ModuleName, 50, "pool params' LBP params has an invalid denomination")
	ErrPoolParamsInvalidNumDenoms = sdkerrors.Register(ModuleName, 51, "pool params' LBP doesn't have same number of params as underlying pool")

	ErrNotImplemented = sdkerrors.Register(ModuleName, 60, "function not implemented")

	ErrNotStableSwapPool          = sdkerrors.Register(ModuleName, 61, "not stableswap pool")
	ErrInvalidScalingFactorLength = sdkerrors.Register(ModuleName, 62, "pool liquidity and scaling factors must have same length")
	ErrNotScalingFactorGovernor   = sdkerrors.Register(ModuleName, 63, "not scaling factor governor")
	ErrInvalidScalingFactors      = sdkerrors.Register(ModuleName, 64, "scaling factors cannot be 0 or use more than 63 bits")
	ErrHitMaxScaledAssets         = sdkerrors.Register(ModuleName, 65, "post-scaled pool assets can not exceed 10^34")
	ErrHitMinScaledAssets         = sdkerrors.Register(ModuleName, 66, "post-scaled pool assets can not be less than 1")
)

x/gamm 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 (
	ErrInvalidLengthGov        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGov          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGov = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// KeyNextGlobalPoolId defines key to store the next Pool ID to be used.
	KeyNextGlobalPoolId = []byte{0x01}
	// KeyPrefixPools defines prefix to store pools.
	KeyPrefixPools = []byte{0x02}
	// KeyTotalLiquidity defines key to store total liquidity.
	KeyTotalLiquidity = []byte{0x03}
	KeyMigrationInfo  = []byte{0x04}
)
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 (
	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 (
	KeyPoolCreationFee = []byte("PoolCreationFee")
)

Parameter store keys.

View Source
var (

	// ModuleCdc references the global x/bank module codec. Note, the codec should
	// ONLY be used in certain instances of tests and for JSON encoding as Amino is
	// still used for that purpose.
	//
	// The actual codec used for serialization should be provided to x/staking and
	// defined at the application level.
	ModuleCdc = codec.NewAminoCodec(amino)
)

Functions

func GetDenomPrefix

func GetDenomPrefix(denom string) []byte

func GetKeyPrefixPools

func GetKeyPrefixPools(poolId uint64) []byte

func GetPoolShareDenom

func GetPoolShareDenom(poolId uint64) string

func MustGetPoolIdFromShareDenom

func MustGetPoolIdFromShareDenom(denom string) uint64

func NewPoolAddress

func NewPoolAddress(poolId uint64) sdk.AccAddress

TODO: move to poolmanager

func NewReplaceMigrationRecordsProposal

func NewReplaceMigrationRecordsProposal(title, description string, records []BalancerToConcentratedPoolLink) govtypes.Content

NewReplacePoolIncentivesProposal returns a new instance of a replace migration record's proposal struct.

func NewUpdatePoolIncentivesProposal

func NewUpdatePoolIncentivesProposal(title, description string, records []BalancerToConcentratedPoolLink) govtypes.Content

NewReplacePoolIncentivesProposal returns a new instance of a replace migration record's proposal struct.

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamTable for gamm module.

func RegisterInterfaces

func RegisterInterfaces(registry types.InterfaceRegistry)

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

RegisterLegacyAminoCodec registers the necessary x/gamm interfaces and concrete types on the provided LegacyAmino codec. These types are used for Amino JSON serialization.

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 to stop working. Consider using RegisterQueryHandlerFromEndpoint instead.

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ValidateFutureGovernor

func ValidateFutureGovernor(governor string) error

func ValidatePoolShareDenom

func ValidatePoolShareDenom(denom string) error

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)

	GetModuleAddressAndPermissions(moduleName string) (addr sdk.AccAddress, permissions []string)
}

AccountKeeper defines the account contract that must be fulfilled when creating a x/gamm keeper.

type BalancerToConcentratedPoolLink struct {
	BalancerPoolId uint64 `protobuf:"varint,1,opt,name=balancer_pool_id,json=balancerPoolId,proto3" json:"balancer_pool_id,omitempty"`
	ClPoolId       uint64 `protobuf:"varint,2,opt,name=cl_pool_id,json=clPoolId,proto3" json:"cl_pool_id,omitempty"`
}

BalancerToConcentratedPoolLink defines a single link between a single balancer pool and a single concentrated liquidity pool. This link is used to allow a balancer pool to migrate to a single canonical full range concentrated liquidity pool position A balancer pool can be linked to a maximum of one cl pool, and a cl pool can be linked to a maximum of one balancer pool.

func (*BalancerToConcentratedPoolLink) Descriptor

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

func (*BalancerToConcentratedPoolLink) Equal

func (this *BalancerToConcentratedPoolLink) Equal(that interface{}) bool

func (*BalancerToConcentratedPoolLink) GetBalancerPoolId

func (m *BalancerToConcentratedPoolLink) GetBalancerPoolId() uint64

func (*BalancerToConcentratedPoolLink) GetClPoolId

func (m *BalancerToConcentratedPoolLink) GetClPoolId() uint64

func (*BalancerToConcentratedPoolLink) Marshal

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

func (*BalancerToConcentratedPoolLink) MarshalTo

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

func (*BalancerToConcentratedPoolLink) MarshalToSizedBuffer

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

func (*BalancerToConcentratedPoolLink) ProtoMessage

func (*BalancerToConcentratedPoolLink) ProtoMessage()

func (*BalancerToConcentratedPoolLink) Reset

func (m *BalancerToConcentratedPoolLink) Reset()

func (*BalancerToConcentratedPoolLink) Size

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

func (*BalancerToConcentratedPoolLink) String

func (*BalancerToConcentratedPoolLink) Unmarshal

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

func (*BalancerToConcentratedPoolLink) XXX_DiscardUnknown

func (m *BalancerToConcentratedPoolLink) XXX_DiscardUnknown()

func (*BalancerToConcentratedPoolLink) XXX_Marshal

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

func (*BalancerToConcentratedPoolLink) XXX_Merge

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

func (*BalancerToConcentratedPoolLink) XXX_Size

func (m *BalancerToConcentratedPoolLink) XXX_Size() int

func (*BalancerToConcentratedPoolLink) XXX_Unmarshal

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

type BankKeeper

type BankKeeper interface {
	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

	SendCoins(ctx sdk.Context, fromAddr sdk.AccAddress, toAddr sdk.AccAddress, amt sdk.Coins) error

	MintCoins(ctx sdk.Context, moduleName string, amt sdk.Coins) error
	BurnCoins(ctx sdk.Context, name string, amt sdk.Coins) error

	SetDenomMetaData(ctx sdk.Context, denomMetaData banktypes.Metadata)

	// Only needed for simulation interface matching
	// TODO: Look into golang syntax to make this "Everything in stakingtypes.bankkeeper + extra funcs"
	// I think it has to do with listing another interface as the first line here?
	GetAllBalances(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
}

BankKeeper defines the banking contract that must be fulfilled when creating a x/gamm keeper.

type CFMMPoolI

type CFMMPoolI interface {
	poolmanagertypes.PoolI

	// JoinPool joins the pool using all of the tokensIn provided.
	// The AMM swaps to the correct internal ratio should be and returns the number of shares created.
	// This function is mutative and updates the pool's internal state if there is no error.
	// It is up to pool implementation if they support LP'ing at arbitrary ratios, or a subset of ratios.
	// Pools are expected to guarantee LP'ing at the exact ratio, and single sided LP'ing.
	JoinPool(ctx sdk.Context, tokensIn sdk.Coins, swapFee sdk.Dec) (numShares sdk.Int, err error)
	// JoinPoolNoSwap joins the pool with an all-asset join using the maximum amount possible given the tokensIn provided.
	// This function is mutative and updates the pool's internal state if there is no error.
	// Pools are expected to guarantee LP'ing at the exact ratio.
	JoinPoolNoSwap(ctx sdk.Context, tokensIn sdk.Coins, swapFee sdk.Dec) (numShares sdk.Int, err error)

	// ExitPool exits #numShares LP shares from the pool, decreases its internal liquidity & LP share totals,
	// and returns the number of coins that are being returned.
	// This mutates the pool and state.
	ExitPool(ctx sdk.Context, numShares sdk.Int, exitFee sdk.Dec) (exitedCoins sdk.Coins, err error)
	// CalcJoinPoolNoSwapShares returns how many LP shares JoinPoolNoSwap would return on these arguments.
	// This does not mutate the pool, or state.
	CalcJoinPoolNoSwapShares(ctx sdk.Context, tokensIn sdk.Coins, swapFee sdk.Dec) (numShares sdk.Int, newLiquidity sdk.Coins, err error)
	// CalcExitPoolCoinsFromShares returns how many coins ExitPool would return on these arguments.
	// This does not mutate the pool, or state.
	CalcExitPoolCoinsFromShares(ctx sdk.Context, numShares sdk.Int, exitFee sdk.Dec) (exitedCoins sdk.Coins, err error)
	// CalcJoinPoolShares returns how many LP shares JoinPool would return on these arguments.
	// This does not mutate the pool, or state.
	CalcJoinPoolShares(ctx sdk.Context, tokensIn sdk.Coins, swapFee sdk.Dec) (numShares sdk.Int, newLiquidity sdk.Coins, err error)
	// SwapOutAmtGivenIn swaps 'tokenIn' against the pool, for tokenOutDenom, with the provided swapFee charged.
	// Balance transfers are done in the keeper, but this method updates the internal pool state.
	SwapOutAmtGivenIn(ctx sdk.Context, tokenIn sdk.Coins, tokenOutDenom string, swapFee sdk.Dec) (tokenOut sdk.Coin, err error)
	// CalcOutAmtGivenIn returns how many coins SwapOutAmtGivenIn would return on these arguments.
	// This does not mutate the pool, or state.
	CalcOutAmtGivenIn(ctx sdk.Context, tokenIn sdk.Coins, tokenOutDenom string, swapFee sdk.Dec) (tokenOut sdk.Coin, err error)

	// SwapInAmtGivenOut swaps exactly enough tokensIn against the pool, to get the provided tokenOut amount out of the pool.
	// Balance transfers are done in the keeper, but this method updates the internal pool state.
	SwapInAmtGivenOut(ctx sdk.Context, tokenOut sdk.Coins, tokenInDenom string, swapFee sdk.Dec) (tokenIn sdk.Coin, err error)
	// CalcInAmtGivenOut returns how many coins SwapInAmtGivenOut would return on these arguments.
	// This does not mutate the pool, or state.
	CalcInAmtGivenOut(ctx sdk.Context, tokenOut sdk.Coins, tokenInDenom string, swapFee sdk.Dec) (tokenIn sdk.Coin, err error)
}

CFMMPoolI defines an interface for pools representing constant function AMM.

type CLKeeper

type CLKeeper interface {
	CreatePosition(ctx sdk.Context, poolId uint64, owner sdk.AccAddress, amount0Desired, amount1Desired, amount0Min, amount1Min sdk.Int, lowerTick, upperTick int64, frozenUntil time.Time) (sdk.Int, sdk.Int, sdk.Dec, error)
	GetPool(ctx sdk.Context, poolId uint64) (poolmanagertypes.PoolI, error)
}

CLKeeper defines the contract needed to be fulfilled for the concentrated liquidity keeper.

type CommunityPoolKeeper

type CommunityPoolKeeper interface {
	FundCommunityPool(ctx sdk.Context, amount sdk.Coins, sender sdk.AccAddress) error
}

CommunityPoolKeeper defines the contract needed to be fulfilled for distribution keeper.

type GammHooks

type GammHooks interface {
	// AfterPoolCreated is called after CreatePool
	AfterPoolCreated(ctx sdk.Context, sender sdk.AccAddress, poolId uint64)

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

	// AfterExitPool is called after ExitPool, ExitSwapShareAmountIn, and ExitSwapExternAmountOut
	AfterExitPool(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, shareInAmount sdk.Int, exitCoins sdk.Coins)

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

type GenesisState

type GenesisState struct {
	Pools []*types1.Any `protobuf:"bytes,1,rep,name=pools,proto3" json:"pools,omitempty"`
	// will be renamed to next_pool_id in an upcoming version
	NextPoolNumber   uint64            `protobuf:"varint,2,opt,name=next_pool_number,json=nextPoolNumber,proto3" json:"next_pool_number,omitempty"`
	Params           Params            `protobuf:"bytes,3,opt,name=params,proto3" json:"params"`
	MigrationRecords *MigrationRecords `protobuf:"bytes,4,opt,name=migration_records,json=migrationRecords,proto3" json:"migration_records,omitempty"`
}

GenesisState defines the gamm module's genesis state.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis creates a default GenesisState object.

func (*GenesisState) Descriptor

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

func (*GenesisState) GetMigrationRecords

func (m *GenesisState) GetMigrationRecords() *MigrationRecords

func (*GenesisState) GetNextPoolNumber

func (m *GenesisState) GetNextPoolNumber() uint64

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPools

func (m *GenesisState) GetPools() []*types1.Any

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 InvalidPoolMigrationLinkError

type InvalidPoolMigrationLinkError struct {
	PoolIdEntering uint64
	CanonicalId    uint64
}

func (InvalidPoolMigrationLinkError) Error

type LiquidityAndScalingFactorCountMismatchError

type LiquidityAndScalingFactorCountMismatchError struct {
	LiquidityCount     int
	ScalingFactorCount int
}

func (LiquidityAndScalingFactorCountMismatchError) Error

type LiquidityChangeMsg

type LiquidityChangeMsg interface {
	LiquidityChangeType() LiquidityChangeType
}

LiquidityChangeMsg defines a simple interface for determining if an LP msg is removing or adding liquidity.

type LiquidityChangeType

type LiquidityChangeType int
const (
	AddLiquidity LiquidityChangeType = iota
	RemoveLiquidity
)

type MigrationRecords

type MigrationRecords struct {
	BalancerToConcentratedPoolLinks []BalancerToConcentratedPoolLink `` /* 150-byte string literal not displayed */
}

MigrationRecords contains all the links between balancer and concentrated pools

func (*MigrationRecords) Descriptor

func (*MigrationRecords) Descriptor() ([]byte, []int)
func (m *MigrationRecords) GetBalancerToConcentratedPoolLinks() []BalancerToConcentratedPoolLink

func (*MigrationRecords) Marshal

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

func (*MigrationRecords) MarshalTo

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

func (*MigrationRecords) MarshalToSizedBuffer

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

func (*MigrationRecords) ProtoMessage

func (*MigrationRecords) ProtoMessage()

func (*MigrationRecords) Reset

func (m *MigrationRecords) Reset()

func (*MigrationRecords) Size

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

func (*MigrationRecords) String

func (m *MigrationRecords) String() string

func (*MigrationRecords) Unmarshal

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

func (*MigrationRecords) XXX_DiscardUnknown

func (m *MigrationRecords) XXX_DiscardUnknown()

func (*MigrationRecords) XXX_Marshal

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

func (*MigrationRecords) XXX_Merge

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

func (*MigrationRecords) XXX_Size

func (m *MigrationRecords) XXX_Size() int

func (*MigrationRecords) XXX_Unmarshal

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

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 MsgExitPool

type MsgExitPool struct {
	Sender        string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId        uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	ShareInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 165-byte string literal not displayed */
	TokenOutMins  []types.Coin                           `protobuf:"bytes,4,rep,name=token_out_mins,json=tokenOutMins,proto3" json:"token_out_mins" yaml:"token_out_min_amounts"`
}

===================== MsgExitPool

func (*MsgExitPool) Descriptor

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

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) GetTokenOutMins

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

func (MsgExitPool) LiquidityChangeType

func (msg MsgExitPool) LiquidityChangeType() LiquidityChangeType

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,1,rep,name=token_out,json=tokenOut,proto3" json:"token_out" yaml:"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 MsgExitSwapExternAmountOut

type MsgExitSwapExternAmountOut struct {
	Sender           string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId           uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokenOut         types.Coin                             `protobuf:"bytes,3,opt,name=token_out,json=tokenOut,proto3" json:"token_out" yaml:"token_out"`
	ShareInMaxAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 180-byte string literal not displayed */
}

===================== MsgExitSwapExternAmountOut

func (*MsgExitSwapExternAmountOut) Descriptor

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

func (*MsgExitSwapExternAmountOut) GetPoolId

func (m *MsgExitSwapExternAmountOut) GetPoolId() uint64

func (*MsgExitSwapExternAmountOut) GetSender

func (m *MsgExitSwapExternAmountOut) GetSender() string

func (MsgExitSwapExternAmountOut) GetSignBytes

func (msg MsgExitSwapExternAmountOut) GetSignBytes() []byte

func (MsgExitSwapExternAmountOut) GetSigners

func (msg MsgExitSwapExternAmountOut) GetSigners() []sdk.AccAddress

func (*MsgExitSwapExternAmountOut) GetTokenOut

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

func (MsgExitSwapExternAmountOut) LiquidityChangeType

func (msg MsgExitSwapExternAmountOut) LiquidityChangeType() LiquidityChangeType

func (*MsgExitSwapExternAmountOut) Marshal

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

func (*MsgExitSwapExternAmountOut) MarshalTo

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

func (*MsgExitSwapExternAmountOut) MarshalToSizedBuffer

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

func (*MsgExitSwapExternAmountOut) ProtoMessage

func (*MsgExitSwapExternAmountOut) ProtoMessage()

func (*MsgExitSwapExternAmountOut) Reset

func (m *MsgExitSwapExternAmountOut) Reset()

func (MsgExitSwapExternAmountOut) Route

func (msg MsgExitSwapExternAmountOut) Route() string

func (*MsgExitSwapExternAmountOut) Size

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

func (*MsgExitSwapExternAmountOut) String

func (m *MsgExitSwapExternAmountOut) String() string

func (MsgExitSwapExternAmountOut) Type

func (*MsgExitSwapExternAmountOut) Unmarshal

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

func (MsgExitSwapExternAmountOut) ValidateBasic

func (msg MsgExitSwapExternAmountOut) ValidateBasic() error

func (*MsgExitSwapExternAmountOut) XXX_DiscardUnknown

func (m *MsgExitSwapExternAmountOut) XXX_DiscardUnknown()

func (*MsgExitSwapExternAmountOut) XXX_Marshal

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

func (*MsgExitSwapExternAmountOut) XXX_Merge

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

func (*MsgExitSwapExternAmountOut) XXX_Size

func (m *MsgExitSwapExternAmountOut) XXX_Size() int

func (*MsgExitSwapExternAmountOut) XXX_Unmarshal

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

type MsgExitSwapExternAmountOutResponse

type MsgExitSwapExternAmountOutResponse struct {
	ShareInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 165-byte string literal not displayed */
}

func (*MsgExitSwapExternAmountOutResponse) Descriptor

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

func (*MsgExitSwapExternAmountOutResponse) Marshal

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

func (*MsgExitSwapExternAmountOutResponse) MarshalTo

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

func (*MsgExitSwapExternAmountOutResponse) MarshalToSizedBuffer

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

func (*MsgExitSwapExternAmountOutResponse) ProtoMessage

func (*MsgExitSwapExternAmountOutResponse) ProtoMessage()

func (*MsgExitSwapExternAmountOutResponse) Reset

func (*MsgExitSwapExternAmountOutResponse) Size

func (*MsgExitSwapExternAmountOutResponse) String

func (*MsgExitSwapExternAmountOutResponse) Unmarshal

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

func (*MsgExitSwapExternAmountOutResponse) XXX_DiscardUnknown

func (m *MsgExitSwapExternAmountOutResponse) XXX_DiscardUnknown()

func (*MsgExitSwapExternAmountOutResponse) XXX_Marshal

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

func (*MsgExitSwapExternAmountOutResponse) XXX_Merge

func (*MsgExitSwapExternAmountOutResponse) XXX_Size

func (*MsgExitSwapExternAmountOutResponse) XXX_Unmarshal

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

type MsgExitSwapShareAmountIn

type MsgExitSwapShareAmountIn struct {
	Sender            string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId            uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokenOutDenom     string                                 `protobuf:"bytes,3,opt,name=token_out_denom,json=tokenOutDenom,proto3" json:"token_out_denom,omitempty" yaml:"token_out_denom"`
	ShareInAmount     github_com_cosmos_cosmos_sdk_types.Int `` /* 165-byte string literal not displayed */
	TokenOutMinAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 184-byte string literal not displayed */
}

===================== MsgExitSwapShareAmountIn

func (*MsgExitSwapShareAmountIn) Descriptor

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

func (*MsgExitSwapShareAmountIn) GetPoolId

func (m *MsgExitSwapShareAmountIn) GetPoolId() uint64

func (*MsgExitSwapShareAmountIn) GetSender

func (m *MsgExitSwapShareAmountIn) GetSender() string

func (MsgExitSwapShareAmountIn) GetSignBytes

func (msg MsgExitSwapShareAmountIn) GetSignBytes() []byte

func (MsgExitSwapShareAmountIn) GetSigners

func (msg MsgExitSwapShareAmountIn) GetSigners() []sdk.AccAddress

func (*MsgExitSwapShareAmountIn) GetTokenOutDenom

func (m *MsgExitSwapShareAmountIn) GetTokenOutDenom() string

func (MsgExitSwapShareAmountIn) LiquidityChangeType

func (msg MsgExitSwapShareAmountIn) LiquidityChangeType() LiquidityChangeType

func (*MsgExitSwapShareAmountIn) Marshal

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

func (*MsgExitSwapShareAmountIn) MarshalTo

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

func (*MsgExitSwapShareAmountIn) MarshalToSizedBuffer

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

func (*MsgExitSwapShareAmountIn) ProtoMessage

func (*MsgExitSwapShareAmountIn) ProtoMessage()

func (*MsgExitSwapShareAmountIn) Reset

func (m *MsgExitSwapShareAmountIn) Reset()

func (MsgExitSwapShareAmountIn) Route

func (msg MsgExitSwapShareAmountIn) Route() string

func (*MsgExitSwapShareAmountIn) Size

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

func (*MsgExitSwapShareAmountIn) String

func (m *MsgExitSwapShareAmountIn) String() string

func (MsgExitSwapShareAmountIn) Type

func (msg MsgExitSwapShareAmountIn) Type() string

func (*MsgExitSwapShareAmountIn) Unmarshal

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

func (MsgExitSwapShareAmountIn) ValidateBasic

func (msg MsgExitSwapShareAmountIn) ValidateBasic() error

func (*MsgExitSwapShareAmountIn) XXX_DiscardUnknown

func (m *MsgExitSwapShareAmountIn) XXX_DiscardUnknown()

func (*MsgExitSwapShareAmountIn) XXX_Marshal

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

func (*MsgExitSwapShareAmountIn) XXX_Merge

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

func (*MsgExitSwapShareAmountIn) XXX_Size

func (m *MsgExitSwapShareAmountIn) XXX_Size() int

func (*MsgExitSwapShareAmountIn) XXX_Unmarshal

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

type MsgExitSwapShareAmountInResponse

type MsgExitSwapShareAmountInResponse struct {
	TokenOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 169-byte string literal not displayed */
}

func (*MsgExitSwapShareAmountInResponse) Descriptor

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

func (*MsgExitSwapShareAmountInResponse) Marshal

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

func (*MsgExitSwapShareAmountInResponse) MarshalTo

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

func (*MsgExitSwapShareAmountInResponse) MarshalToSizedBuffer

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

func (*MsgExitSwapShareAmountInResponse) ProtoMessage

func (*MsgExitSwapShareAmountInResponse) ProtoMessage()

func (*MsgExitSwapShareAmountInResponse) Reset

func (*MsgExitSwapShareAmountInResponse) Size

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

func (*MsgExitSwapShareAmountInResponse) String

func (*MsgExitSwapShareAmountInResponse) Unmarshal

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

func (*MsgExitSwapShareAmountInResponse) XXX_DiscardUnknown

func (m *MsgExitSwapShareAmountInResponse) XXX_DiscardUnknown()

func (*MsgExitSwapShareAmountInResponse) XXX_Marshal

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

func (*MsgExitSwapShareAmountInResponse) XXX_Merge

func (*MsgExitSwapShareAmountInResponse) XXX_Size

func (m *MsgExitSwapShareAmountInResponse) XXX_Size() int

func (*MsgExitSwapShareAmountInResponse) XXX_Unmarshal

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

type MsgJoinPool

type MsgJoinPool struct {
	Sender         string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId         uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	ShareOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 168-byte string literal not displayed */
	TokenInMaxs    []types.Coin                           `protobuf:"bytes,4,rep,name=token_in_maxs,json=tokenInMaxs,proto3" json:"token_in_maxs" yaml:"token_in_max_amounts"`
}

===================== MsgJoinPool This is really MsgJoinPoolNoSwap

func (*MsgJoinPool) Descriptor

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

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) GetTokenInMaxs

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

func (MsgJoinPool) LiquidityChangeType

func (msg MsgJoinPool) LiquidityChangeType() LiquidityChangeType

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 {
	ShareOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 169-byte string literal not displayed */
	TokenIn        []types.Coin                           `protobuf:"bytes,2,rep,name=token_in,json=tokenIn,proto3" json:"token_in" yaml:"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 MsgJoinSwapExternAmountIn

type MsgJoinSwapExternAmountIn struct {
	Sender            string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId            uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokenIn           types.Coin                             `protobuf:"bytes,3,opt,name=token_in,json=tokenIn,proto3" json:"token_in" yaml:"token_in"`
	ShareOutMinAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 184-byte string literal not displayed */
}

===================== MsgJoinSwapExternAmountIn TODO: Rename to MsgJoinSwapExactAmountIn

func (*MsgJoinSwapExternAmountIn) Descriptor

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

func (*MsgJoinSwapExternAmountIn) GetPoolId

func (m *MsgJoinSwapExternAmountIn) GetPoolId() uint64

func (*MsgJoinSwapExternAmountIn) GetSender

func (m *MsgJoinSwapExternAmountIn) GetSender() string

func (MsgJoinSwapExternAmountIn) GetSignBytes

func (msg MsgJoinSwapExternAmountIn) GetSignBytes() []byte

func (MsgJoinSwapExternAmountIn) GetSigners

func (msg MsgJoinSwapExternAmountIn) GetSigners() []sdk.AccAddress

func (*MsgJoinSwapExternAmountIn) GetTokenIn

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

func (MsgJoinSwapExternAmountIn) LiquidityChangeType

func (msg MsgJoinSwapExternAmountIn) LiquidityChangeType() LiquidityChangeType

func (*MsgJoinSwapExternAmountIn) Marshal

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

func (*MsgJoinSwapExternAmountIn) MarshalTo

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

func (*MsgJoinSwapExternAmountIn) MarshalToSizedBuffer

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

func (*MsgJoinSwapExternAmountIn) ProtoMessage

func (*MsgJoinSwapExternAmountIn) ProtoMessage()

func (*MsgJoinSwapExternAmountIn) Reset

func (m *MsgJoinSwapExternAmountIn) Reset()

func (MsgJoinSwapExternAmountIn) Route

func (msg MsgJoinSwapExternAmountIn) Route() string

func (*MsgJoinSwapExternAmountIn) Size

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

func (*MsgJoinSwapExternAmountIn) String

func (m *MsgJoinSwapExternAmountIn) String() string

func (MsgJoinSwapExternAmountIn) Type

func (msg MsgJoinSwapExternAmountIn) Type() string

func (*MsgJoinSwapExternAmountIn) Unmarshal

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

func (MsgJoinSwapExternAmountIn) ValidateBasic

func (msg MsgJoinSwapExternAmountIn) ValidateBasic() error

func (*MsgJoinSwapExternAmountIn) XXX_DiscardUnknown

func (m *MsgJoinSwapExternAmountIn) XXX_DiscardUnknown()

func (*MsgJoinSwapExternAmountIn) XXX_Marshal

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

func (*MsgJoinSwapExternAmountIn) XXX_Merge

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

func (*MsgJoinSwapExternAmountIn) XXX_Size

func (m *MsgJoinSwapExternAmountIn) XXX_Size() int

func (*MsgJoinSwapExternAmountIn) XXX_Unmarshal

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

type MsgJoinSwapExternAmountInResponse

type MsgJoinSwapExternAmountInResponse struct {
	ShareOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 169-byte string literal not displayed */
}

func (*MsgJoinSwapExternAmountInResponse) Descriptor

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

func (*MsgJoinSwapExternAmountInResponse) Marshal

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

func (*MsgJoinSwapExternAmountInResponse) MarshalTo

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

func (*MsgJoinSwapExternAmountInResponse) MarshalToSizedBuffer

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

func (*MsgJoinSwapExternAmountInResponse) ProtoMessage

func (*MsgJoinSwapExternAmountInResponse) ProtoMessage()

func (*MsgJoinSwapExternAmountInResponse) Reset

func (*MsgJoinSwapExternAmountInResponse) Size

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

func (*MsgJoinSwapExternAmountInResponse) String

func (*MsgJoinSwapExternAmountInResponse) Unmarshal

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

func (*MsgJoinSwapExternAmountInResponse) XXX_DiscardUnknown

func (m *MsgJoinSwapExternAmountInResponse) XXX_DiscardUnknown()

func (*MsgJoinSwapExternAmountInResponse) XXX_Marshal

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

func (*MsgJoinSwapExternAmountInResponse) XXX_Merge

func (*MsgJoinSwapExternAmountInResponse) XXX_Size

func (m *MsgJoinSwapExternAmountInResponse) XXX_Size() int

func (*MsgJoinSwapExternAmountInResponse) XXX_Unmarshal

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

type MsgJoinSwapShareAmountOut

type MsgJoinSwapShareAmountOut struct {
	Sender           string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId           uint64                                 `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokenInDenom     string                                 `protobuf:"bytes,3,opt,name=token_in_denom,json=tokenInDenom,proto3" json:"token_in_denom,omitempty" yaml:"token_in_denom"`
	ShareOutAmount   github_com_cosmos_cosmos_sdk_types.Int `` /* 169-byte string literal not displayed */
	TokenInMaxAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 180-byte string literal not displayed */
}

===================== MsgJoinSwapShareAmountOut

func (*MsgJoinSwapShareAmountOut) Descriptor

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

func (*MsgJoinSwapShareAmountOut) GetPoolId

func (m *MsgJoinSwapShareAmountOut) GetPoolId() uint64

func (*MsgJoinSwapShareAmountOut) GetSender

func (m *MsgJoinSwapShareAmountOut) GetSender() string

func (MsgJoinSwapShareAmountOut) GetSignBytes

func (msg MsgJoinSwapShareAmountOut) GetSignBytes() []byte

func (MsgJoinSwapShareAmountOut) GetSigners

func (msg MsgJoinSwapShareAmountOut) GetSigners() []sdk.AccAddress

func (*MsgJoinSwapShareAmountOut) GetTokenInDenom

func (m *MsgJoinSwapShareAmountOut) GetTokenInDenom() string

func (MsgJoinSwapShareAmountOut) LiquidityChangeType

func (msg MsgJoinSwapShareAmountOut) LiquidityChangeType() LiquidityChangeType

func (*MsgJoinSwapShareAmountOut) Marshal

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

func (*MsgJoinSwapShareAmountOut) MarshalTo

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

func (*MsgJoinSwapShareAmountOut) MarshalToSizedBuffer

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

func (*MsgJoinSwapShareAmountOut) ProtoMessage

func (*MsgJoinSwapShareAmountOut) ProtoMessage()

func (*MsgJoinSwapShareAmountOut) Reset

func (m *MsgJoinSwapShareAmountOut) Reset()

func (MsgJoinSwapShareAmountOut) Route

func (msg MsgJoinSwapShareAmountOut) Route() string

func (*MsgJoinSwapShareAmountOut) Size

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

func (*MsgJoinSwapShareAmountOut) String

func (m *MsgJoinSwapShareAmountOut) String() string

func (MsgJoinSwapShareAmountOut) Type

func (msg MsgJoinSwapShareAmountOut) Type() string

func (*MsgJoinSwapShareAmountOut) Unmarshal

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

func (MsgJoinSwapShareAmountOut) ValidateBasic

func (msg MsgJoinSwapShareAmountOut) ValidateBasic() error

func (*MsgJoinSwapShareAmountOut) XXX_DiscardUnknown

func (m *MsgJoinSwapShareAmountOut) XXX_DiscardUnknown()

func (*MsgJoinSwapShareAmountOut) XXX_Marshal

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

func (*MsgJoinSwapShareAmountOut) XXX_Merge

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

func (*MsgJoinSwapShareAmountOut) XXX_Size

func (m *MsgJoinSwapShareAmountOut) XXX_Size() int

func (*MsgJoinSwapShareAmountOut) XXX_Unmarshal

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

type MsgJoinSwapShareAmountOutResponse

type MsgJoinSwapShareAmountOutResponse struct {
	TokenInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 165-byte string literal not displayed */
}

func (*MsgJoinSwapShareAmountOutResponse) Descriptor

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

func (*MsgJoinSwapShareAmountOutResponse) Marshal

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

func (*MsgJoinSwapShareAmountOutResponse) MarshalTo

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

func (*MsgJoinSwapShareAmountOutResponse) MarshalToSizedBuffer

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

func (*MsgJoinSwapShareAmountOutResponse) ProtoMessage

func (*MsgJoinSwapShareAmountOutResponse) ProtoMessage()

func (*MsgJoinSwapShareAmountOutResponse) Reset

func (*MsgJoinSwapShareAmountOutResponse) Size

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

func (*MsgJoinSwapShareAmountOutResponse) String

func (*MsgJoinSwapShareAmountOutResponse) Unmarshal

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

func (*MsgJoinSwapShareAmountOutResponse) XXX_DiscardUnknown

func (m *MsgJoinSwapShareAmountOutResponse) XXX_DiscardUnknown()

func (*MsgJoinSwapShareAmountOutResponse) XXX_Marshal

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

func (*MsgJoinSwapShareAmountOutResponse) XXX_Merge

func (*MsgJoinSwapShareAmountOutResponse) XXX_Size

func (m *MsgJoinSwapShareAmountOutResponse) XXX_Size() int

func (*MsgJoinSwapShareAmountOutResponse) XXX_Unmarshal

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

type MsgSwapExactAmountIn

type MsgSwapExactAmountIn struct {
	Sender            string                                 `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	Routes            []types1.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" yaml:"token_in"`
	TokenOutMinAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 184-byte string literal not displayed */
}

===================== MsgSwapExactAmountIn

func (*MsgSwapExactAmountIn) Descriptor

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

func (*MsgSwapExactAmountIn) GetRoutes

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) TokenDenomsOnPath

func (msg MsgSwapExactAmountIn) TokenDenomsOnPath() []string

func (MsgSwapExactAmountIn) TokenInDenom

func (msg MsgSwapExactAmountIn) TokenInDenom() string

func (MsgSwapExactAmountIn) TokenOutDenom

func (msg MsgSwapExactAmountIn) TokenOutDenom() 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 `` /* 169-byte string literal not displayed */
}

func (*MsgSwapExactAmountInResponse) Descriptor

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

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" yaml:"sender"`
	Routes           []types1.SwapAmountOutRoute            `protobuf:"bytes,2,rep,name=routes,proto3" json:"routes"`
	TokenInMaxAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 180-byte string literal not displayed */
	TokenOut         types.Coin                             `protobuf:"bytes,4,opt,name=token_out,json=tokenOut,proto3" json:"token_out" yaml:"token_out"`
}

func (*MsgSwapExactAmountOut) Descriptor

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

func (*MsgSwapExactAmountOut) GetRoutes

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) TokenDenomsOnPath

func (msg MsgSwapExactAmountOut) TokenDenomsOnPath() []string

func (MsgSwapExactAmountOut) TokenInDenom

func (msg MsgSwapExactAmountOut) TokenInDenom() string

func (MsgSwapExactAmountOut) TokenOutDenom

func (msg MsgSwapExactAmountOut) TokenOutDenom() 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 `` /* 165-byte string literal not displayed */
}

func (*MsgSwapExactAmountOutResponse) Descriptor

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

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 MultiGammHooks

type MultiGammHooks []GammHooks

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

func NewMultiGammHooks

func NewMultiGammHooks(hooks ...GammHooks) MultiGammHooks

Creates hooks for the Gamm Module.

func (MultiGammHooks) AfterExitPool

func (h MultiGammHooks) AfterExitPool(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, shareInAmount sdk.Int, exitCoins sdk.Coins)

func (MultiGammHooks) AfterJoinPool

func (h MultiGammHooks) AfterJoinPool(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, enterCoins sdk.Coins, shareOutAmount sdk.Int)

func (MultiGammHooks) AfterPoolCreated

func (h MultiGammHooks) AfterPoolCreated(ctx sdk.Context, sender sdk.AccAddress, poolId uint64)

func (MultiGammHooks) AfterSwap

func (h MultiGammHooks) AfterSwap(ctx sdk.Context, sender sdk.AccAddress, poolId uint64, input sdk.Coins, output sdk.Coins)

type MultihopRoute

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

type Params

type Params struct {
	PoolCreationFee github_com_cosmos_cosmos_sdk_types.Coins `` /* 177-byte string literal not displayed */
}

Params holds parameters for the incentives module

func DefaultParams

func DefaultParams() Params

default gamm module parameters.

func NewParams

func NewParams(poolCreationFee sdk.Coins) Params

func (*Params) Descriptor

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

func (*Params) GetPoolCreationFee

func (m *Params) GetPoolCreationFee() github_com_cosmos_cosmos_sdk_types.Coins

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) ParamSetPairs

func (p *Params) ParamSetPairs() paramtypes.ParamSetPairs

Implements params.ParamSet.

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 (m *Params) String() string

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

validate 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 PoolAmountOutExtension

type PoolAmountOutExtension interface {
	CFMMPoolI

	// CalcTokenInShareAmountOut returns the number of tokenInDenom tokens
	// that would be returned if swapped for an exact number of shares (shareOutAmount).
	// Returns error if tokenInDenom is not in the pool or if fails to approximate
	// given the shareOutAmount.
	// This method does not mutate the pool
	CalcTokenInShareAmountOut(
		ctx sdk.Context,
		tokenInDenom string,
		shareOutAmount sdk.Int,
		swapFee sdk.Dec,
	) (tokenInAmount sdk.Int, err error)

	// JoinPoolTokenInMaxShareAmountOut add liquidity to a specified pool with a maximum amount of tokens in (tokenInMaxAmount)
	// and swaps to an exact number of shares (shareOutAmount).
	JoinPoolTokenInMaxShareAmountOut(
		ctx sdk.Context,
		tokenInDenom string,
		shareOutAmount sdk.Int,
	) (tokenInAmount sdk.Int, err error)

	// ExitSwapExactAmountOut removes liquidity from a specified pool with a maximum amount of LP shares (shareInMaxAmount)
	// and swaps to an exact amount of one of the token pairs (tokenOut).
	ExitSwapExactAmountOut(
		ctx sdk.Context,
		tokenOut sdk.Coin,
		shareInMaxAmount sdk.Int,
	) (shareInAmount sdk.Int, err error)

	// IncreaseLiquidity increases the pool's liquidity by the specified sharesOut and coinsIn.
	IncreaseLiquidity(sharesOut sdk.Int, coinsIn sdk.Coins)
}

PoolAmountOutExtension is an extension of the PoolI interface definiting an abstraction for pools that hold tokens. In addition, it supports JoinSwapShareAmountOut and ExitSwapExactAmountOut methods that allow joining with the exact amount of shares to get out, and exiting with exact amount of coins to get out. See definitions below.

type PoolDoesNotExistError

type PoolDoesNotExistError struct {
	PoolId uint64
}

func (PoolDoesNotExistError) Error

func (e PoolDoesNotExistError) Error() string

type PoolManager

type PoolManager interface {
	CreatePool(ctx sdk.Context, msg poolmanagertypes.CreatePoolMsg) (uint64, error)

	GetNextPoolId(ctx sdk.Context) uint64

	RouteExactAmountIn(
		ctx sdk.Context,
		sender sdk.AccAddress,
		routes []poolmanagertypes.SwapAmountInRoute,
		tokenIn sdk.Coin,
		tokenOutMinAmount sdk.Int) (tokenOutAmount sdk.Int, err error)

	RouteExactAmountOut(ctx sdk.Context,
		sender sdk.AccAddress,
		routes []poolmanagertypes.SwapAmountOutRoute,
		tokenInMaxAmount sdk.Int,
		tokenOut sdk.Coin,
	) (tokenInAmount sdk.Int, err error)

	MultihopEstimateOutGivenExactAmountIn(
		ctx sdk.Context,
		routes []poolmanagertypes.SwapAmountInRoute,
		tokenIn sdk.Coin,
	) (tokenOutAmount sdk.Int, err error)

	MultihopEstimateInGivenExactAmountOut(
		ctx sdk.Context,
		routes []poolmanagertypes.SwapAmountOutRoute,
		tokenOut sdk.Coin) (tokenInAmount sdk.Int, err error)

	GetPoolModule(ctx sdk.Context, poolId uint64) (poolmanagertypes.SwapI, error)
}

PoolManager defines the interface needed to be fulfilled for the pool manger.

type PoolMigrationLinkNotFoundError

type PoolMigrationLinkNotFoundError struct {
	PoolIdLeaving uint64
}

func (PoolMigrationLinkNotFoundError) Error

type QueryCalcExitPoolCoinsFromSharesRequest

type QueryCalcExitPoolCoinsFromSharesRequest struct {
	PoolId        uint64                                 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty"`
	ShareInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 142-byte string literal not displayed */
}

=============================== CalcExitPoolCoinsFromShares

func (*QueryCalcExitPoolCoinsFromSharesRequest) Descriptor

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) GetPoolId

func (*QueryCalcExitPoolCoinsFromSharesRequest) Marshal

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) MarshalTo

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) MarshalToSizedBuffer

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) ProtoMessage

func (*QueryCalcExitPoolCoinsFromSharesRequest) Reset

func (*QueryCalcExitPoolCoinsFromSharesRequest) Size

func (*QueryCalcExitPoolCoinsFromSharesRequest) String

func (*QueryCalcExitPoolCoinsFromSharesRequest) Unmarshal

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) XXX_DiscardUnknown

func (m *QueryCalcExitPoolCoinsFromSharesRequest) XXX_DiscardUnknown()

func (*QueryCalcExitPoolCoinsFromSharesRequest) XXX_Marshal

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

func (*QueryCalcExitPoolCoinsFromSharesRequest) XXX_Merge

func (*QueryCalcExitPoolCoinsFromSharesRequest) XXX_Size

func (*QueryCalcExitPoolCoinsFromSharesRequest) XXX_Unmarshal

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

type QueryCalcExitPoolCoinsFromSharesResponse

type QueryCalcExitPoolCoinsFromSharesResponse struct {
	TokensOut github_com_cosmos_cosmos_sdk_types.Coins `` /* 132-byte string literal not displayed */
}

func (*QueryCalcExitPoolCoinsFromSharesResponse) Descriptor

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

func (*QueryCalcExitPoolCoinsFromSharesResponse) GetTokensOut

func (*QueryCalcExitPoolCoinsFromSharesResponse) Marshal

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

func (*QueryCalcExitPoolCoinsFromSharesResponse) MarshalTo

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

func (*QueryCalcExitPoolCoinsFromSharesResponse) MarshalToSizedBuffer

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

func (*QueryCalcExitPoolCoinsFromSharesResponse) ProtoMessage

func (*QueryCalcExitPoolCoinsFromSharesResponse) Reset

func (*QueryCalcExitPoolCoinsFromSharesResponse) Size

func (*QueryCalcExitPoolCoinsFromSharesResponse) String

func (*QueryCalcExitPoolCoinsFromSharesResponse) Unmarshal

func (*QueryCalcExitPoolCoinsFromSharesResponse) XXX_DiscardUnknown

func (m *QueryCalcExitPoolCoinsFromSharesResponse) XXX_DiscardUnknown()

func (*QueryCalcExitPoolCoinsFromSharesResponse) XXX_Marshal

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

func (*QueryCalcExitPoolCoinsFromSharesResponse) XXX_Merge

func (*QueryCalcExitPoolCoinsFromSharesResponse) XXX_Size

func (*QueryCalcExitPoolCoinsFromSharesResponse) XXX_Unmarshal

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

type QueryCalcJoinPoolNoSwapSharesRequest

type QueryCalcJoinPoolNoSwapSharesRequest struct {
	PoolId   uint64                                   `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokensIn github_com_cosmos_cosmos_sdk_types.Coins `` /* 129-byte string literal not displayed */
}

=============================== CalcJoinPoolNoSwapShares

func (*QueryCalcJoinPoolNoSwapSharesRequest) Descriptor

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) GetPoolId

func (*QueryCalcJoinPoolNoSwapSharesRequest) GetTokensIn

func (*QueryCalcJoinPoolNoSwapSharesRequest) Marshal

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) MarshalTo

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) MarshalToSizedBuffer

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) ProtoMessage

func (*QueryCalcJoinPoolNoSwapSharesRequest) ProtoMessage()

func (*QueryCalcJoinPoolNoSwapSharesRequest) Reset

func (*QueryCalcJoinPoolNoSwapSharesRequest) Size

func (*QueryCalcJoinPoolNoSwapSharesRequest) String

func (*QueryCalcJoinPoolNoSwapSharesRequest) Unmarshal

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) XXX_DiscardUnknown

func (m *QueryCalcJoinPoolNoSwapSharesRequest) XXX_DiscardUnknown()

func (*QueryCalcJoinPoolNoSwapSharesRequest) XXX_Marshal

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

func (*QueryCalcJoinPoolNoSwapSharesRequest) XXX_Merge

func (*QueryCalcJoinPoolNoSwapSharesRequest) XXX_Size

func (*QueryCalcJoinPoolNoSwapSharesRequest) XXX_Unmarshal

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

type QueryCalcJoinPoolNoSwapSharesResponse

type QueryCalcJoinPoolNoSwapSharesResponse struct {
	TokensOut github_com_cosmos_cosmos_sdk_types.Coins `` /* 150-byte string literal not displayed */
	SharesOut github_com_cosmos_cosmos_sdk_types.Int   `` /* 128-byte string literal not displayed */
}

func (*QueryCalcJoinPoolNoSwapSharesResponse) Descriptor

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) GetTokensOut

func (*QueryCalcJoinPoolNoSwapSharesResponse) Marshal

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) MarshalTo

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) MarshalToSizedBuffer

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) ProtoMessage

func (*QueryCalcJoinPoolNoSwapSharesResponse) ProtoMessage()

func (*QueryCalcJoinPoolNoSwapSharesResponse) Reset

func (*QueryCalcJoinPoolNoSwapSharesResponse) Size

func (*QueryCalcJoinPoolNoSwapSharesResponse) String

func (*QueryCalcJoinPoolNoSwapSharesResponse) Unmarshal

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) XXX_DiscardUnknown

func (m *QueryCalcJoinPoolNoSwapSharesResponse) XXX_DiscardUnknown()

func (*QueryCalcJoinPoolNoSwapSharesResponse) XXX_Marshal

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

func (*QueryCalcJoinPoolNoSwapSharesResponse) XXX_Merge

func (*QueryCalcJoinPoolNoSwapSharesResponse) XXX_Size

func (*QueryCalcJoinPoolNoSwapSharesResponse) XXX_Unmarshal

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

type QueryCalcJoinPoolSharesRequest

type QueryCalcJoinPoolSharesRequest struct {
	PoolId   uint64                                   `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokensIn github_com_cosmos_cosmos_sdk_types.Coins `` /* 129-byte string literal not displayed */
}

=============================== CalcJoinPoolShares

func (*QueryCalcJoinPoolSharesRequest) Descriptor

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

func (*QueryCalcJoinPoolSharesRequest) GetPoolId

func (m *QueryCalcJoinPoolSharesRequest) GetPoolId() uint64

func (*QueryCalcJoinPoolSharesRequest) GetTokensIn

func (*QueryCalcJoinPoolSharesRequest) Marshal

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

func (*QueryCalcJoinPoolSharesRequest) MarshalTo

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

func (*QueryCalcJoinPoolSharesRequest) MarshalToSizedBuffer

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

func (*QueryCalcJoinPoolSharesRequest) ProtoMessage

func (*QueryCalcJoinPoolSharesRequest) ProtoMessage()

func (*QueryCalcJoinPoolSharesRequest) Reset

func (m *QueryCalcJoinPoolSharesRequest) Reset()

func (*QueryCalcJoinPoolSharesRequest) Size

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

func (*QueryCalcJoinPoolSharesRequest) String

func (*QueryCalcJoinPoolSharesRequest) Unmarshal

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

func (*QueryCalcJoinPoolSharesRequest) XXX_DiscardUnknown

func (m *QueryCalcJoinPoolSharesRequest) XXX_DiscardUnknown()

func (*QueryCalcJoinPoolSharesRequest) XXX_Marshal

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

func (*QueryCalcJoinPoolSharesRequest) XXX_Merge

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

func (*QueryCalcJoinPoolSharesRequest) XXX_Size

func (m *QueryCalcJoinPoolSharesRequest) XXX_Size() int

func (*QueryCalcJoinPoolSharesRequest) XXX_Unmarshal

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

type QueryCalcJoinPoolSharesResponse

type QueryCalcJoinPoolSharesResponse struct {
	ShareOutAmount github_com_cosmos_cosmos_sdk_types.Int   `` /* 169-byte string literal not displayed */
	TokensOut      github_com_cosmos_cosmos_sdk_types.Coins `` /* 132-byte string literal not displayed */
}

func (*QueryCalcJoinPoolSharesResponse) Descriptor

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

func (*QueryCalcJoinPoolSharesResponse) GetTokensOut

func (*QueryCalcJoinPoolSharesResponse) Marshal

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

func (*QueryCalcJoinPoolSharesResponse) MarshalTo

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

func (*QueryCalcJoinPoolSharesResponse) MarshalToSizedBuffer

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

func (*QueryCalcJoinPoolSharesResponse) ProtoMessage

func (*QueryCalcJoinPoolSharesResponse) ProtoMessage()

func (*QueryCalcJoinPoolSharesResponse) Reset

func (*QueryCalcJoinPoolSharesResponse) Size

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

func (*QueryCalcJoinPoolSharesResponse) String

func (*QueryCalcJoinPoolSharesResponse) Unmarshal

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

func (*QueryCalcJoinPoolSharesResponse) XXX_DiscardUnknown

func (m *QueryCalcJoinPoolSharesResponse) XXX_DiscardUnknown()

func (*QueryCalcJoinPoolSharesResponse) XXX_Marshal

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

func (*QueryCalcJoinPoolSharesResponse) XXX_Merge

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

func (*QueryCalcJoinPoolSharesResponse) XXX_Size

func (m *QueryCalcJoinPoolSharesResponse) XXX_Size() int

func (*QueryCalcJoinPoolSharesResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	Pools(ctx context.Context, in *QueryPoolsRequest, opts ...grpc.CallOption) (*QueryPoolsResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	NumPools(ctx context.Context, in *QueryNumPoolsRequest, opts ...grpc.CallOption) (*QueryNumPoolsResponse, error)
	TotalLiquidity(ctx context.Context, in *QueryTotalLiquidityRequest, opts ...grpc.CallOption) (*QueryTotalLiquidityResponse, error)
	// PoolsWithFilter allows you to query specific pools with requested
	// parameters
	PoolsWithFilter(ctx context.Context, in *QueryPoolsWithFilterRequest, opts ...grpc.CallOption) (*QueryPoolsWithFilterResponse, error)
	// Per Pool gRPC Endpoints
	Pool(ctx context.Context, in *QueryPoolRequest, opts ...grpc.CallOption) (*QueryPoolResponse, error)
	// PoolType returns the type of the pool.
	// Returns "Balancer" as a string literal when the pool is a balancer pool.
	// Errors if the pool is failed to be type caseted.
	PoolType(ctx context.Context, in *QueryPoolTypeRequest, opts ...grpc.CallOption) (*QueryPoolTypeResponse, error)
	// Simulates joining pool without a swap. Returns the amount of shares you'd
	// get and tokens needed to provide
	CalcJoinPoolNoSwapShares(ctx context.Context, in *QueryCalcJoinPoolNoSwapSharesRequest, opts ...grpc.CallOption) (*QueryCalcJoinPoolNoSwapSharesResponse, error)
	CalcJoinPoolShares(ctx context.Context, in *QueryCalcJoinPoolSharesRequest, opts ...grpc.CallOption) (*QueryCalcJoinPoolSharesResponse, error)
	CalcExitPoolCoinsFromShares(ctx context.Context, in *QueryCalcExitPoolCoinsFromSharesRequest, opts ...grpc.CallOption) (*QueryCalcExitPoolCoinsFromSharesResponse, error)
	PoolParams(ctx context.Context, in *QueryPoolParamsRequest, opts ...grpc.CallOption) (*QueryPoolParamsResponse, error)
	TotalPoolLiquidity(ctx context.Context, in *QueryTotalPoolLiquidityRequest, opts ...grpc.CallOption) (*QueryTotalPoolLiquidityResponse, error)
	TotalShares(ctx context.Context, in *QueryTotalSharesRequest, opts ...grpc.CallOption) (*QueryTotalSharesResponse, error)
	// SpotPrice defines a gRPC query handler that returns the spot price given
	// a base denomination and a quote denomination.
	SpotPrice(ctx context.Context, in *QuerySpotPriceRequest, opts ...grpc.CallOption) (*QuerySpotPriceResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	EstimateSwapExactAmountIn(ctx context.Context, in *QuerySwapExactAmountInRequest, opts ...grpc.CallOption) (*QuerySwapExactAmountInResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	EstimateSwapExactAmountOut(ctx context.Context, in *QuerySwapExactAmountOutRequest, opts ...grpc.CallOption) (*QuerySwapExactAmountOutResponse, 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 QueryNumPoolsRequest deprecated

type QueryNumPoolsRequest struct {
}

=============================== NumPools

Deprecated: Do not use.

func (*QueryNumPoolsRequest) Descriptor

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

func (*QueryNumPoolsRequest) Marshal

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

func (*QueryNumPoolsRequest) MarshalTo

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

func (*QueryNumPoolsRequest) MarshalToSizedBuffer

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

func (*QueryNumPoolsRequest) ProtoMessage

func (*QueryNumPoolsRequest) ProtoMessage()

func (*QueryNumPoolsRequest) Reset

func (m *QueryNumPoolsRequest) Reset()

func (*QueryNumPoolsRequest) Size

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

func (*QueryNumPoolsRequest) String

func (m *QueryNumPoolsRequest) String() string

func (*QueryNumPoolsRequest) Unmarshal

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

func (*QueryNumPoolsRequest) XXX_DiscardUnknown

func (m *QueryNumPoolsRequest) XXX_DiscardUnknown()

func (*QueryNumPoolsRequest) XXX_Marshal

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

func (*QueryNumPoolsRequest) XXX_Merge

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

func (*QueryNumPoolsRequest) XXX_Size

func (m *QueryNumPoolsRequest) XXX_Size() int

func (*QueryNumPoolsRequest) XXX_Unmarshal

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

type QueryNumPoolsResponse deprecated

type QueryNumPoolsResponse struct {
	NumPools uint64 `protobuf:"varint,1,opt,name=num_pools,json=numPools,proto3" json:"num_pools,omitempty" yaml:"num_pools"`
}

Deprecated: Do not use.

func (*QueryNumPoolsResponse) Descriptor

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

func (*QueryNumPoolsResponse) GetNumPools

func (m *QueryNumPoolsResponse) GetNumPools() uint64

func (*QueryNumPoolsResponse) Marshal

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

func (*QueryNumPoolsResponse) MarshalTo

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

func (*QueryNumPoolsResponse) MarshalToSizedBuffer

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

func (*QueryNumPoolsResponse) ProtoMessage

func (*QueryNumPoolsResponse) ProtoMessage()

func (*QueryNumPoolsResponse) Reset

func (m *QueryNumPoolsResponse) Reset()

func (*QueryNumPoolsResponse) Size

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

func (*QueryNumPoolsResponse) String

func (m *QueryNumPoolsResponse) String() string

func (*QueryNumPoolsResponse) Unmarshal

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

func (*QueryNumPoolsResponse) XXX_DiscardUnknown

func (m *QueryNumPoolsResponse) XXX_DiscardUnknown()

func (*QueryNumPoolsResponse) XXX_Marshal

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

func (*QueryNumPoolsResponse) XXX_Merge

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

func (*QueryNumPoolsResponse) XXX_Size

func (m *QueryNumPoolsResponse) XXX_Size() int

func (*QueryNumPoolsResponse) XXX_Unmarshal

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

type QueryPoolParamsRequest

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

=============================== PoolParams

func (*QueryPoolParamsRequest) Descriptor

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

func (*QueryPoolParamsRequest) GetPoolId

func (m *QueryPoolParamsRequest) GetPoolId() uint64

func (*QueryPoolParamsRequest) Marshal

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

func (*QueryPoolParamsRequest) MarshalTo

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

func (*QueryPoolParamsRequest) MarshalToSizedBuffer

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

func (*QueryPoolParamsRequest) ProtoMessage

func (*QueryPoolParamsRequest) ProtoMessage()

func (*QueryPoolParamsRequest) Reset

func (m *QueryPoolParamsRequest) Reset()

func (*QueryPoolParamsRequest) Size

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

func (*QueryPoolParamsRequest) String

func (m *QueryPoolParamsRequest) String() string

func (*QueryPoolParamsRequest) Unmarshal

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

func (*QueryPoolParamsRequest) XXX_DiscardUnknown

func (m *QueryPoolParamsRequest) XXX_DiscardUnknown()

func (*QueryPoolParamsRequest) XXX_Marshal

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

func (*QueryPoolParamsRequest) XXX_Merge

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

func (*QueryPoolParamsRequest) XXX_Size

func (m *QueryPoolParamsRequest) XXX_Size() int

func (*QueryPoolParamsRequest) XXX_Unmarshal

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

type QueryPoolParamsResponse

type QueryPoolParamsResponse struct {
	Params *types.Any `protobuf:"bytes,1,opt,name=params,proto3" json:"params,omitempty"`
}

func (*QueryPoolParamsResponse) Descriptor

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

func (*QueryPoolParamsResponse) GetParams

func (m *QueryPoolParamsResponse) GetParams() *types.Any

func (*QueryPoolParamsResponse) Marshal

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

func (*QueryPoolParamsResponse) MarshalTo

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

func (*QueryPoolParamsResponse) MarshalToSizedBuffer

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

func (*QueryPoolParamsResponse) ProtoMessage

func (*QueryPoolParamsResponse) ProtoMessage()

func (*QueryPoolParamsResponse) Reset

func (m *QueryPoolParamsResponse) Reset()

func (*QueryPoolParamsResponse) Size

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

func (*QueryPoolParamsResponse) String

func (m *QueryPoolParamsResponse) String() string

func (*QueryPoolParamsResponse) Unmarshal

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

func (*QueryPoolParamsResponse) XXX_DiscardUnknown

func (m *QueryPoolParamsResponse) XXX_DiscardUnknown()

func (*QueryPoolParamsResponse) XXX_Marshal

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

func (*QueryPoolParamsResponse) XXX_Merge

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

func (*QueryPoolParamsResponse) XXX_Size

func (m *QueryPoolParamsResponse) XXX_Size() int

func (*QueryPoolParamsResponse) XXX_Unmarshal

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

type QueryPoolRequest

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

=============================== Pool

func (*QueryPoolRequest) Descriptor

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

func (*QueryPoolRequest) GetPoolId

func (m *QueryPoolRequest) GetPoolId() uint64

func (*QueryPoolRequest) Marshal

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

func (*QueryPoolRequest) MarshalTo

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

func (*QueryPoolRequest) MarshalToSizedBuffer

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

func (*QueryPoolRequest) ProtoMessage

func (*QueryPoolRequest) ProtoMessage()

func (*QueryPoolRequest) Reset

func (m *QueryPoolRequest) Reset()

func (*QueryPoolRequest) Size

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

func (*QueryPoolRequest) String

func (m *QueryPoolRequest) String() string

func (*QueryPoolRequest) Unmarshal

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

func (*QueryPoolRequest) XXX_DiscardUnknown

func (m *QueryPoolRequest) XXX_DiscardUnknown()

func (*QueryPoolRequest) XXX_Marshal

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

func (*QueryPoolRequest) XXX_Merge

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

func (*QueryPoolRequest) XXX_Size

func (m *QueryPoolRequest) XXX_Size() int

func (*QueryPoolRequest) XXX_Unmarshal

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

type QueryPoolResponse

type QueryPoolResponse struct {
	Pool *types.Any `protobuf:"bytes,1,opt,name=pool,proto3" json:"pool,omitempty"`
}

func (*QueryPoolResponse) Descriptor

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

func (*QueryPoolResponse) GetPool

func (m *QueryPoolResponse) GetPool() *types.Any

func (*QueryPoolResponse) Marshal

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

func (*QueryPoolResponse) MarshalTo

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

func (*QueryPoolResponse) MarshalToSizedBuffer

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

func (*QueryPoolResponse) ProtoMessage

func (*QueryPoolResponse) ProtoMessage()

func (*QueryPoolResponse) Reset

func (m *QueryPoolResponse) Reset()

func (*QueryPoolResponse) Size

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

func (*QueryPoolResponse) String

func (m *QueryPoolResponse) String() string

func (*QueryPoolResponse) Unmarshal

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

func (*QueryPoolResponse) XXX_DiscardUnknown

func (m *QueryPoolResponse) XXX_DiscardUnknown()

func (*QueryPoolResponse) XXX_Marshal

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

func (*QueryPoolResponse) XXX_Merge

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

func (*QueryPoolResponse) XXX_Size

func (m *QueryPoolResponse) XXX_Size() int

func (*QueryPoolResponse) XXX_Unmarshal

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

type QueryPoolTypeRequest

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

=============================== PoolType

func (*QueryPoolTypeRequest) Descriptor

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

func (*QueryPoolTypeRequest) GetPoolId

func (m *QueryPoolTypeRequest) GetPoolId() uint64

func (*QueryPoolTypeRequest) Marshal

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

func (*QueryPoolTypeRequest) MarshalTo

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

func (*QueryPoolTypeRequest) MarshalToSizedBuffer

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

func (*QueryPoolTypeRequest) ProtoMessage

func (*QueryPoolTypeRequest) ProtoMessage()

func (*QueryPoolTypeRequest) Reset

func (m *QueryPoolTypeRequest) Reset()

func (*QueryPoolTypeRequest) Size

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

func (*QueryPoolTypeRequest) String

func (m *QueryPoolTypeRequest) String() string

func (*QueryPoolTypeRequest) Unmarshal

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

func (*QueryPoolTypeRequest) XXX_DiscardUnknown

func (m *QueryPoolTypeRequest) XXX_DiscardUnknown()

func (*QueryPoolTypeRequest) XXX_Marshal

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

func (*QueryPoolTypeRequest) XXX_Merge

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

func (*QueryPoolTypeRequest) XXX_Size

func (m *QueryPoolTypeRequest) XXX_Size() int

func (*QueryPoolTypeRequest) XXX_Unmarshal

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

type QueryPoolTypeResponse

type QueryPoolTypeResponse struct {
	PoolType string `protobuf:"bytes,1,opt,name=pool_type,json=poolType,proto3" json:"pool_type,omitempty" yaml:"pool_type"`
}

func (*QueryPoolTypeResponse) Descriptor

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

func (*QueryPoolTypeResponse) GetPoolType

func (m *QueryPoolTypeResponse) GetPoolType() string

func (*QueryPoolTypeResponse) Marshal

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

func (*QueryPoolTypeResponse) MarshalTo

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

func (*QueryPoolTypeResponse) MarshalToSizedBuffer

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

func (*QueryPoolTypeResponse) ProtoMessage

func (*QueryPoolTypeResponse) ProtoMessage()

func (*QueryPoolTypeResponse) Reset

func (m *QueryPoolTypeResponse) Reset()

func (*QueryPoolTypeResponse) Size

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

func (*QueryPoolTypeResponse) String

func (m *QueryPoolTypeResponse) String() string

func (*QueryPoolTypeResponse) Unmarshal

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

func (*QueryPoolTypeResponse) XXX_DiscardUnknown

func (m *QueryPoolTypeResponse) XXX_DiscardUnknown()

func (*QueryPoolTypeResponse) XXX_Marshal

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

func (*QueryPoolTypeResponse) XXX_Merge

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

func (*QueryPoolTypeResponse) XXX_Size

func (m *QueryPoolTypeResponse) XXX_Size() int

func (*QueryPoolTypeResponse) XXX_Unmarshal

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

type QueryPoolsRequest

type QueryPoolsRequest struct {
	// pagination defines an optional pagination for the request.
	Pagination *query.PageRequest `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

=============================== Pools

func (*QueryPoolsRequest) Descriptor

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

func (*QueryPoolsRequest) GetPagination

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

func (*QueryPoolsRequest) Marshal

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

func (*QueryPoolsRequest) MarshalTo

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

func (*QueryPoolsRequest) MarshalToSizedBuffer

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

func (*QueryPoolsRequest) ProtoMessage

func (*QueryPoolsRequest) ProtoMessage()

func (*QueryPoolsRequest) Reset

func (m *QueryPoolsRequest) Reset()

func (*QueryPoolsRequest) Size

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

func (*QueryPoolsRequest) String

func (m *QueryPoolsRequest) String() string

func (*QueryPoolsRequest) Unmarshal

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

func (*QueryPoolsRequest) XXX_DiscardUnknown

func (m *QueryPoolsRequest) XXX_DiscardUnknown()

func (*QueryPoolsRequest) XXX_Marshal

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

func (*QueryPoolsRequest) XXX_Merge

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

func (*QueryPoolsRequest) XXX_Size

func (m *QueryPoolsRequest) XXX_Size() int

func (*QueryPoolsRequest) XXX_Unmarshal

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

type QueryPoolsResponse

type QueryPoolsResponse struct {
	Pools []*types.Any `protobuf:"bytes,1,rep,name=pools,proto3" json:"pools,omitempty"`
	// pagination defines the pagination in the response.
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryPoolsResponse) Descriptor

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

func (*QueryPoolsResponse) GetPagination

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

func (*QueryPoolsResponse) GetPools

func (m *QueryPoolsResponse) GetPools() []*types.Any

func (*QueryPoolsResponse) Marshal

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

func (*QueryPoolsResponse) MarshalTo

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

func (*QueryPoolsResponse) MarshalToSizedBuffer

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

func (*QueryPoolsResponse) ProtoMessage

func (*QueryPoolsResponse) ProtoMessage()

func (*QueryPoolsResponse) Reset

func (m *QueryPoolsResponse) Reset()

func (*QueryPoolsResponse) Size

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

func (*QueryPoolsResponse) String

func (m *QueryPoolsResponse) String() string

func (*QueryPoolsResponse) Unmarshal

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

func (*QueryPoolsResponse) XXX_DiscardUnknown

func (m *QueryPoolsResponse) XXX_DiscardUnknown()

func (*QueryPoolsResponse) XXX_Marshal

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

func (*QueryPoolsResponse) XXX_Merge

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

func (*QueryPoolsResponse) XXX_Size

func (m *QueryPoolsResponse) XXX_Size() int

func (*QueryPoolsResponse) XXX_Unmarshal

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

type QueryPoolsWithFilterRequest

type QueryPoolsWithFilterRequest struct {
	// String of the coins in single string seperated by comma. Ex)
	// 10uatom,100ufury
	MinLiquidity string             `protobuf:"bytes,1,opt,name=min_liquidity,json=minLiquidity,proto3" json:"min_liquidity,omitempty" yaml:"min_liquidity"`
	PoolType     string             `protobuf:"bytes,2,opt,name=pool_type,json=poolType,proto3" json:"pool_type,omitempty"`
	Pagination   *query.PageRequest `protobuf:"bytes,3,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryPoolsWithFilterRequest) Descriptor

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

func (*QueryPoolsWithFilterRequest) GetMinLiquidity

func (m *QueryPoolsWithFilterRequest) GetMinLiquidity() string

func (*QueryPoolsWithFilterRequest) GetPagination

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

func (*QueryPoolsWithFilterRequest) GetPoolType

func (m *QueryPoolsWithFilterRequest) GetPoolType() string

func (*QueryPoolsWithFilterRequest) Marshal

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

func (*QueryPoolsWithFilterRequest) MarshalTo

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

func (*QueryPoolsWithFilterRequest) MarshalToSizedBuffer

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

func (*QueryPoolsWithFilterRequest) ProtoMessage

func (*QueryPoolsWithFilterRequest) ProtoMessage()

func (*QueryPoolsWithFilterRequest) Reset

func (m *QueryPoolsWithFilterRequest) Reset()

func (*QueryPoolsWithFilterRequest) Size

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

func (*QueryPoolsWithFilterRequest) String

func (m *QueryPoolsWithFilterRequest) String() string

func (*QueryPoolsWithFilterRequest) Unmarshal

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

func (*QueryPoolsWithFilterRequest) XXX_DiscardUnknown

func (m *QueryPoolsWithFilterRequest) XXX_DiscardUnknown()

func (*QueryPoolsWithFilterRequest) XXX_Marshal

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

func (*QueryPoolsWithFilterRequest) XXX_Merge

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

func (*QueryPoolsWithFilterRequest) XXX_Size

func (m *QueryPoolsWithFilterRequest) XXX_Size() int

func (*QueryPoolsWithFilterRequest) XXX_Unmarshal

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

type QueryPoolsWithFilterResponse

type QueryPoolsWithFilterResponse struct {
	Pools []*types.Any `protobuf:"bytes,1,rep,name=pools,proto3" json:"pools,omitempty"`
	// pagination defines the pagination in the response.
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryPoolsWithFilterResponse) Descriptor

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

func (*QueryPoolsWithFilterResponse) GetPagination

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

func (*QueryPoolsWithFilterResponse) GetPools

func (m *QueryPoolsWithFilterResponse) GetPools() []*types.Any

func (*QueryPoolsWithFilterResponse) Marshal

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

func (*QueryPoolsWithFilterResponse) MarshalTo

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

func (*QueryPoolsWithFilterResponse) MarshalToSizedBuffer

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

func (*QueryPoolsWithFilterResponse) ProtoMessage

func (*QueryPoolsWithFilterResponse) ProtoMessage()

func (*QueryPoolsWithFilterResponse) Reset

func (m *QueryPoolsWithFilterResponse) Reset()

func (*QueryPoolsWithFilterResponse) Size

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

func (*QueryPoolsWithFilterResponse) String

func (*QueryPoolsWithFilterResponse) Unmarshal

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

func (*QueryPoolsWithFilterResponse) XXX_DiscardUnknown

func (m *QueryPoolsWithFilterResponse) XXX_DiscardUnknown()

func (*QueryPoolsWithFilterResponse) XXX_Marshal

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

func (*QueryPoolsWithFilterResponse) XXX_Merge

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

func (*QueryPoolsWithFilterResponse) XXX_Size

func (m *QueryPoolsWithFilterResponse) XXX_Size() int

func (*QueryPoolsWithFilterResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	Pools(context.Context, *QueryPoolsRequest) (*QueryPoolsResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	NumPools(context.Context, *QueryNumPoolsRequest) (*QueryNumPoolsResponse, error)
	TotalLiquidity(context.Context, *QueryTotalLiquidityRequest) (*QueryTotalLiquidityResponse, error)
	// PoolsWithFilter allows you to query specific pools with requested
	// parameters
	PoolsWithFilter(context.Context, *QueryPoolsWithFilterRequest) (*QueryPoolsWithFilterResponse, error)
	// Per Pool gRPC Endpoints
	Pool(context.Context, *QueryPoolRequest) (*QueryPoolResponse, error)
	// PoolType returns the type of the pool.
	// Returns "Balancer" as a string literal when the pool is a balancer pool.
	// Errors if the pool is failed to be type caseted.
	PoolType(context.Context, *QueryPoolTypeRequest) (*QueryPoolTypeResponse, error)
	// Simulates joining pool without a swap. Returns the amount of shares you'd
	// get and tokens needed to provide
	CalcJoinPoolNoSwapShares(context.Context, *QueryCalcJoinPoolNoSwapSharesRequest) (*QueryCalcJoinPoolNoSwapSharesResponse, error)
	CalcJoinPoolShares(context.Context, *QueryCalcJoinPoolSharesRequest) (*QueryCalcJoinPoolSharesResponse, error)
	CalcExitPoolCoinsFromShares(context.Context, *QueryCalcExitPoolCoinsFromSharesRequest) (*QueryCalcExitPoolCoinsFromSharesResponse, error)
	PoolParams(context.Context, *QueryPoolParamsRequest) (*QueryPoolParamsResponse, error)
	TotalPoolLiquidity(context.Context, *QueryTotalPoolLiquidityRequest) (*QueryTotalPoolLiquidityResponse, error)
	TotalShares(context.Context, *QueryTotalSharesRequest) (*QueryTotalSharesResponse, error)
	// SpotPrice defines a gRPC query handler that returns the spot price given
	// a base denomination and a quote denomination.
	SpotPrice(context.Context, *QuerySpotPriceRequest) (*QuerySpotPriceResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	EstimateSwapExactAmountIn(context.Context, *QuerySwapExactAmountInRequest) (*QuerySwapExactAmountInResponse, error)
	// Deprecated: please use the alternative in x/poolmanager
	EstimateSwapExactAmountOut(context.Context, *QuerySwapExactAmountOutRequest) (*QuerySwapExactAmountOutResponse, error)
}

QueryServer is the server API for Query service.

type QuerySpotPriceRequest deprecated

type QuerySpotPriceRequest struct {
	PoolId          uint64 `protobuf:"varint,1,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	BaseAssetDenom  string `` /* 129-byte string literal not displayed */
	QuoteAssetDenom string `` /* 133-byte string literal not displayed */
}

QuerySpotPriceRequest defines the gRPC request structure for a SpotPrice query.

Deprecated: Do not use.

func (*QuerySpotPriceRequest) Descriptor

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

func (*QuerySpotPriceRequest) GetBaseAssetDenom

func (m *QuerySpotPriceRequest) GetBaseAssetDenom() string

func (*QuerySpotPriceRequest) GetPoolId

func (m *QuerySpotPriceRequest) GetPoolId() uint64

func (*QuerySpotPriceRequest) GetQuoteAssetDenom

func (m *QuerySpotPriceRequest) GetQuoteAssetDenom() string

func (*QuerySpotPriceRequest) Marshal

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

func (*QuerySpotPriceRequest) MarshalTo

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

func (*QuerySpotPriceRequest) MarshalToSizedBuffer

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

func (*QuerySpotPriceRequest) ProtoMessage

func (*QuerySpotPriceRequest) ProtoMessage()

func (*QuerySpotPriceRequest) Reset

func (m *QuerySpotPriceRequest) Reset()

func (*QuerySpotPriceRequest) Size

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

func (*QuerySpotPriceRequest) String

func (m *QuerySpotPriceRequest) String() string

func (*QuerySpotPriceRequest) Unmarshal

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

func (*QuerySpotPriceRequest) XXX_DiscardUnknown

func (m *QuerySpotPriceRequest) XXX_DiscardUnknown()

func (*QuerySpotPriceRequest) XXX_Marshal

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

func (*QuerySpotPriceRequest) XXX_Merge

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

func (*QuerySpotPriceRequest) XXX_Size

func (m *QuerySpotPriceRequest) XXX_Size() int

func (*QuerySpotPriceRequest) XXX_Unmarshal

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

type QuerySpotPriceResponse deprecated

type QuerySpotPriceResponse struct {
	// String of the Dec. Ex) 10.203uatom
	SpotPrice string `protobuf:"bytes,1,opt,name=spot_price,json=spotPrice,proto3" json:"spot_price,omitempty" yaml:"spot_price"`
}

QuerySpotPriceResponse defines the gRPC response structure for a SpotPrice query.

Deprecated: Do not use.

func (*QuerySpotPriceResponse) Descriptor

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

func (*QuerySpotPriceResponse) GetSpotPrice

func (m *QuerySpotPriceResponse) GetSpotPrice() string

func (*QuerySpotPriceResponse) Marshal

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

func (*QuerySpotPriceResponse) MarshalTo

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

func (*QuerySpotPriceResponse) MarshalToSizedBuffer

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

func (*QuerySpotPriceResponse) ProtoMessage

func (*QuerySpotPriceResponse) ProtoMessage()

func (*QuerySpotPriceResponse) Reset

func (m *QuerySpotPriceResponse) Reset()

func (*QuerySpotPriceResponse) Size

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

func (*QuerySpotPriceResponse) String

func (m *QuerySpotPriceResponse) String() string

func (*QuerySpotPriceResponse) Unmarshal

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

func (*QuerySpotPriceResponse) XXX_DiscardUnknown

func (m *QuerySpotPriceResponse) XXX_DiscardUnknown()

func (*QuerySpotPriceResponse) XXX_Marshal

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

func (*QuerySpotPriceResponse) XXX_Merge

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

func (*QuerySpotPriceResponse) XXX_Size

func (m *QuerySpotPriceResponse) XXX_Size() int

func (*QuerySpotPriceResponse) XXX_Unmarshal

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

type QuerySwapExactAmountInRequest deprecated

type QuerySwapExactAmountInRequest struct {
	Sender  string                     `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId  uint64                     `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	TokenIn string                     `protobuf:"bytes,3,opt,name=token_in,json=tokenIn,proto3" json:"token_in,omitempty" yaml:"token_in"`
	Routes  []types2.SwapAmountInRoute `protobuf:"bytes,4,rep,name=routes,proto3" json:"routes" yaml:"routes"`
}

=============================== EstimateSwapExactAmountIn

Deprecated: Do not use.

func (*QuerySwapExactAmountInRequest) Descriptor

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

func (*QuerySwapExactAmountInRequest) GetPoolId

func (m *QuerySwapExactAmountInRequest) GetPoolId() uint64

func (*QuerySwapExactAmountInRequest) GetRoutes

func (*QuerySwapExactAmountInRequest) GetSender

func (m *QuerySwapExactAmountInRequest) GetSender() string

func (*QuerySwapExactAmountInRequest) GetTokenIn

func (m *QuerySwapExactAmountInRequest) GetTokenIn() string

func (*QuerySwapExactAmountInRequest) Marshal

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

func (*QuerySwapExactAmountInRequest) MarshalTo

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

func (*QuerySwapExactAmountInRequest) MarshalToSizedBuffer

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

func (*QuerySwapExactAmountInRequest) ProtoMessage

func (*QuerySwapExactAmountInRequest) ProtoMessage()

func (*QuerySwapExactAmountInRequest) Reset

func (m *QuerySwapExactAmountInRequest) Reset()

func (*QuerySwapExactAmountInRequest) Size

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

func (*QuerySwapExactAmountInRequest) String

func (*QuerySwapExactAmountInRequest) Unmarshal

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

func (*QuerySwapExactAmountInRequest) XXX_DiscardUnknown

func (m *QuerySwapExactAmountInRequest) XXX_DiscardUnknown()

func (*QuerySwapExactAmountInRequest) XXX_Marshal

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

func (*QuerySwapExactAmountInRequest) XXX_Merge

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

func (*QuerySwapExactAmountInRequest) XXX_Size

func (m *QuerySwapExactAmountInRequest) XXX_Size() int

func (*QuerySwapExactAmountInRequest) XXX_Unmarshal

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

type QuerySwapExactAmountInResponse deprecated

type QuerySwapExactAmountInResponse struct {
	TokenOutAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 169-byte string literal not displayed */
}

Deprecated: Do not use.

func (*QuerySwapExactAmountInResponse) Descriptor

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

func (*QuerySwapExactAmountInResponse) Marshal

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

func (*QuerySwapExactAmountInResponse) MarshalTo

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

func (*QuerySwapExactAmountInResponse) MarshalToSizedBuffer

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

func (*QuerySwapExactAmountInResponse) ProtoMessage

func (*QuerySwapExactAmountInResponse) ProtoMessage()

func (*QuerySwapExactAmountInResponse) Reset

func (m *QuerySwapExactAmountInResponse) Reset()

func (*QuerySwapExactAmountInResponse) Size

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

func (*QuerySwapExactAmountInResponse) String

func (*QuerySwapExactAmountInResponse) Unmarshal

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

func (*QuerySwapExactAmountInResponse) XXX_DiscardUnknown

func (m *QuerySwapExactAmountInResponse) XXX_DiscardUnknown()

func (*QuerySwapExactAmountInResponse) XXX_Marshal

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

func (*QuerySwapExactAmountInResponse) XXX_Merge

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

func (*QuerySwapExactAmountInResponse) XXX_Size

func (m *QuerySwapExactAmountInResponse) XXX_Size() int

func (*QuerySwapExactAmountInResponse) XXX_Unmarshal

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

type QuerySwapExactAmountOutRequest deprecated

type QuerySwapExactAmountOutRequest struct {
	Sender   string                      `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	PoolId   uint64                      `protobuf:"varint,2,opt,name=pool_id,json=poolId,proto3" json:"pool_id,omitempty" yaml:"pool_id"`
	Routes   []types2.SwapAmountOutRoute `protobuf:"bytes,3,rep,name=routes,proto3" json:"routes" yaml:"routes"`
	TokenOut string                      `protobuf:"bytes,4,opt,name=token_out,json=tokenOut,proto3" json:"token_out,omitempty" yaml:"token_out"`
}

=============================== EstimateSwapExactAmountOut

Deprecated: Do not use.

func (*QuerySwapExactAmountOutRequest) Descriptor

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

func (*QuerySwapExactAmountOutRequest) GetPoolId

func (m *QuerySwapExactAmountOutRequest) GetPoolId() uint64

func (*QuerySwapExactAmountOutRequest) GetRoutes

func (*QuerySwapExactAmountOutRequest) GetSender

func (m *QuerySwapExactAmountOutRequest) GetSender() string

func (*QuerySwapExactAmountOutRequest) GetTokenOut

func (m *QuerySwapExactAmountOutRequest) GetTokenOut() string

func (*QuerySwapExactAmountOutRequest) Marshal

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

func (*QuerySwapExactAmountOutRequest) MarshalTo

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

func (*QuerySwapExactAmountOutRequest) MarshalToSizedBuffer

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

func (*QuerySwapExactAmountOutRequest) ProtoMessage

func (*QuerySwapExactAmountOutRequest) ProtoMessage()

func (*QuerySwapExactAmountOutRequest) Reset

func (m *QuerySwapExactAmountOutRequest) Reset()

func (*QuerySwapExactAmountOutRequest) Size

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

func (*QuerySwapExactAmountOutRequest) String

func (*QuerySwapExactAmountOutRequest) Unmarshal

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

func (*QuerySwapExactAmountOutRequest) XXX_DiscardUnknown

func (m *QuerySwapExactAmountOutRequest) XXX_DiscardUnknown()

func (*QuerySwapExactAmountOutRequest) XXX_Marshal

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

func (*QuerySwapExactAmountOutRequest) XXX_Merge

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

func (*QuerySwapExactAmountOutRequest) XXX_Size

func (m *QuerySwapExactAmountOutRequest) XXX_Size() int

func (*QuerySwapExactAmountOutRequest) XXX_Unmarshal

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

type QuerySwapExactAmountOutResponse deprecated

type QuerySwapExactAmountOutResponse struct {
	TokenInAmount github_com_cosmos_cosmos_sdk_types.Int `` /* 165-byte string literal not displayed */
}

Deprecated: Do not use.

func (*QuerySwapExactAmountOutResponse) Descriptor

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

func (*QuerySwapExactAmountOutResponse) Marshal

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

func (*QuerySwapExactAmountOutResponse) MarshalTo

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

func (*QuerySwapExactAmountOutResponse) MarshalToSizedBuffer

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

func (*QuerySwapExactAmountOutResponse) ProtoMessage

func (*QuerySwapExactAmountOutResponse) ProtoMessage()

func (*QuerySwapExactAmountOutResponse) Reset

func (*QuerySwapExactAmountOutResponse) Size

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

func (*QuerySwapExactAmountOutResponse) String

func (*QuerySwapExactAmountOutResponse) Unmarshal

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

func (*QuerySwapExactAmountOutResponse) XXX_DiscardUnknown

func (m *QuerySwapExactAmountOutResponse) XXX_DiscardUnknown()

func (*QuerySwapExactAmountOutResponse) XXX_Marshal

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

func (*QuerySwapExactAmountOutResponse) XXX_Merge

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

func (*QuerySwapExactAmountOutResponse) XXX_Size

func (m *QuerySwapExactAmountOutResponse) XXX_Size() int

func (*QuerySwapExactAmountOutResponse) XXX_Unmarshal

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

type QueryTotalLiquidityRequest

type QueryTotalLiquidityRequest struct {
}

func (*QueryTotalLiquidityRequest) Descriptor

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

func (*QueryTotalLiquidityRequest) Marshal

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

func (*QueryTotalLiquidityRequest) MarshalTo

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

func (*QueryTotalLiquidityRequest) MarshalToSizedBuffer

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

func (*QueryTotalLiquidityRequest) ProtoMessage

func (*QueryTotalLiquidityRequest) ProtoMessage()

func (*QueryTotalLiquidityRequest) Reset

func (m *QueryTotalLiquidityRequest) Reset()

func (*QueryTotalLiquidityRequest) Size

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

func (*QueryTotalLiquidityRequest) String

func (m *QueryTotalLiquidityRequest) String() string

func (*QueryTotalLiquidityRequest) Unmarshal

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

func (*QueryTotalLiquidityRequest) XXX_DiscardUnknown

func (m *QueryTotalLiquidityRequest) XXX_DiscardUnknown()

func (*QueryTotalLiquidityRequest) XXX_Marshal

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

func (*QueryTotalLiquidityRequest) XXX_Merge

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

func (*QueryTotalLiquidityRequest) XXX_Size

func (m *QueryTotalLiquidityRequest) XXX_Size() int

func (*QueryTotalLiquidityRequest) XXX_Unmarshal

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

type QueryTotalLiquidityResponse

type QueryTotalLiquidityResponse struct {
	Liquidity github_com_cosmos_cosmos_sdk_types.Coins `` /* 132-byte string literal not displayed */
}

func (*QueryTotalLiquidityResponse) Descriptor

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

func (*QueryTotalLiquidityResponse) GetLiquidity

func (*QueryTotalLiquidityResponse) Marshal

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

func (*QueryTotalLiquidityResponse) MarshalTo

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

func (*QueryTotalLiquidityResponse) MarshalToSizedBuffer

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

func (*QueryTotalLiquidityResponse) ProtoMessage

func (*QueryTotalLiquidityResponse) ProtoMessage()

func (*QueryTotalLiquidityResponse) Reset

func (m *QueryTotalLiquidityResponse) Reset()

func (*QueryTotalLiquidityResponse) Size

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

func (*QueryTotalLiquidityResponse) String

func (m *QueryTotalLiquidityResponse) String() string

func (*QueryTotalLiquidityResponse) Unmarshal

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

func (*QueryTotalLiquidityResponse) XXX_DiscardUnknown

func (m *QueryTotalLiquidityResponse) XXX_DiscardUnknown()

func (*QueryTotalLiquidityResponse) XXX_Marshal

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

func (*QueryTotalLiquidityResponse) XXX_Merge

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

func (*QueryTotalLiquidityResponse) XXX_Size

func (m *QueryTotalLiquidityResponse) XXX_Size() int

func (*QueryTotalLiquidityResponse) XXX_Unmarshal

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

type QueryTotalPoolLiquidityRequest

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

=============================== PoolLiquidity

func (*QueryTotalPoolLiquidityRequest) Descriptor

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

func (*QueryTotalPoolLiquidityRequest) GetPoolId

func (m *QueryTotalPoolLiquidityRequest) GetPoolId() uint64

func (*QueryTotalPoolLiquidityRequest) Marshal

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

func (*QueryTotalPoolLiquidityRequest) MarshalTo

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

func (*QueryTotalPoolLiquidityRequest) MarshalToSizedBuffer

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

func (*QueryTotalPoolLiquidityRequest) ProtoMessage

func (*QueryTotalPoolLiquidityRequest) ProtoMessage()

func (*QueryTotalPoolLiquidityRequest) Reset

func (m *QueryTotalPoolLiquidityRequest) Reset()

func (*QueryTotalPoolLiquidityRequest) Size

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

func (*QueryTotalPoolLiquidityRequest) String

func (*QueryTotalPoolLiquidityRequest) Unmarshal

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

func (*QueryTotalPoolLiquidityRequest) XXX_DiscardUnknown

func (m *QueryTotalPoolLiquidityRequest) XXX_DiscardUnknown()

func (*QueryTotalPoolLiquidityRequest) XXX_Marshal

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

func (*QueryTotalPoolLiquidityRequest) XXX_Merge

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

func (*QueryTotalPoolLiquidityRequest) XXX_Size

func (m *QueryTotalPoolLiquidityRequest) XXX_Size() int

func (*QueryTotalPoolLiquidityRequest) XXX_Unmarshal

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

type QueryTotalPoolLiquidityResponse

type QueryTotalPoolLiquidityResponse struct {
	Liquidity github_com_cosmos_cosmos_sdk_types.Coins `` /* 132-byte string literal not displayed */
}

func (*QueryTotalPoolLiquidityResponse) Descriptor

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

func (*QueryTotalPoolLiquidityResponse) GetLiquidity

func (*QueryTotalPoolLiquidityResponse) Marshal

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

func (*QueryTotalPoolLiquidityResponse) MarshalTo

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

func (*QueryTotalPoolLiquidityResponse) MarshalToSizedBuffer

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

func (*QueryTotalPoolLiquidityResponse) ProtoMessage

func (*QueryTotalPoolLiquidityResponse) ProtoMessage()

func (*QueryTotalPoolLiquidityResponse) Reset

func (*QueryTotalPoolLiquidityResponse) Size

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

func (*QueryTotalPoolLiquidityResponse) String

func (*QueryTotalPoolLiquidityResponse) Unmarshal

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

func (*QueryTotalPoolLiquidityResponse) XXX_DiscardUnknown

func (m *QueryTotalPoolLiquidityResponse) XXX_DiscardUnknown()

func (*QueryTotalPoolLiquidityResponse) XXX_Marshal

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

func (*QueryTotalPoolLiquidityResponse) XXX_Merge

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

func (*QueryTotalPoolLiquidityResponse) XXX_Size

func (m *QueryTotalPoolLiquidityResponse) XXX_Size() int

func (*QueryTotalPoolLiquidityResponse) XXX_Unmarshal

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

type QueryTotalSharesRequest

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

=============================== TotalShares

func (*QueryTotalSharesRequest) Descriptor

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

func (*QueryTotalSharesRequest) GetPoolId

func (m *QueryTotalSharesRequest) GetPoolId() uint64

func (*QueryTotalSharesRequest) Marshal

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

func (*QueryTotalSharesRequest) MarshalTo

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

func (*QueryTotalSharesRequest) MarshalToSizedBuffer

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

func (*QueryTotalSharesRequest) ProtoMessage

func (*QueryTotalSharesRequest) ProtoMessage()

func (*QueryTotalSharesRequest) Reset

func (m *QueryTotalSharesRequest) Reset()

func (*QueryTotalSharesRequest) Size

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

func (*QueryTotalSharesRequest) String

func (m *QueryTotalSharesRequest) String() string

func (*QueryTotalSharesRequest) Unmarshal

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

func (*QueryTotalSharesRequest) XXX_DiscardUnknown

func (m *QueryTotalSharesRequest) XXX_DiscardUnknown()

func (*QueryTotalSharesRequest) XXX_Marshal

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

func (*QueryTotalSharesRequest) XXX_Merge

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

func (*QueryTotalSharesRequest) XXX_Size

func (m *QueryTotalSharesRequest) XXX_Size() int

func (*QueryTotalSharesRequest) XXX_Unmarshal

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

type QueryTotalSharesResponse

type QueryTotalSharesResponse struct {
	TotalShares types1.Coin `protobuf:"bytes,1,opt,name=total_shares,json=totalShares,proto3" json:"total_shares" yaml:"total_shares"`
}

func (*QueryTotalSharesResponse) Descriptor

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

func (*QueryTotalSharesResponse) GetTotalShares

func (m *QueryTotalSharesResponse) GetTotalShares() types1.Coin

func (*QueryTotalSharesResponse) Marshal

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

func (*QueryTotalSharesResponse) MarshalTo

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

func (*QueryTotalSharesResponse) MarshalToSizedBuffer

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

func (*QueryTotalSharesResponse) ProtoMessage

func (*QueryTotalSharesResponse) ProtoMessage()

func (*QueryTotalSharesResponse) Reset

func (m *QueryTotalSharesResponse) Reset()

func (*QueryTotalSharesResponse) Size

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

func (*QueryTotalSharesResponse) String

func (m *QueryTotalSharesResponse) String() string

func (*QueryTotalSharesResponse) Unmarshal

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

func (*QueryTotalSharesResponse) XXX_DiscardUnknown

func (m *QueryTotalSharesResponse) XXX_DiscardUnknown()

func (*QueryTotalSharesResponse) XXX_Marshal

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

func (*QueryTotalSharesResponse) XXX_Merge

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

func (*QueryTotalSharesResponse) XXX_Size

func (m *QueryTotalSharesResponse) XXX_Size() int

func (*QueryTotalSharesResponse) XXX_Unmarshal

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

type ReplaceMigrationRecordsProposal

type ReplaceMigrationRecordsProposal 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"`
	Records     []BalancerToConcentratedPoolLink `protobuf:"bytes,3,rep,name=records,proto3" json:"records"`
}

ReplaceMigrationRecordsProposal is a gov Content type for updating the migration records. If a ReplaceMigrationRecordsProposal passes, the proposal’s records override the existing MigrationRecords set in the module. Each record specifies a single connection between a single balancer pool and a single concentrated pool.

func (*ReplaceMigrationRecordsProposal) Descriptor

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

func (*ReplaceMigrationRecordsProposal) Equal

func (this *ReplaceMigrationRecordsProposal) Equal(that interface{}) bool

func (*ReplaceMigrationRecordsProposal) GetDescription

func (p *ReplaceMigrationRecordsProposal) GetDescription() string

GetDescription gets the description of the proposal

func (*ReplaceMigrationRecordsProposal) GetTitle

GetTitle gets the title of the proposal

func (*ReplaceMigrationRecordsProposal) Marshal

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

func (*ReplaceMigrationRecordsProposal) MarshalTo

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

func (*ReplaceMigrationRecordsProposal) MarshalToSizedBuffer

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

func (*ReplaceMigrationRecordsProposal) ProposalRoute

func (p *ReplaceMigrationRecordsProposal) ProposalRoute() string

ProposalRoute returns the router key for the proposal

func (*ReplaceMigrationRecordsProposal) ProposalType

func (p *ReplaceMigrationRecordsProposal) ProposalType() string

ProposalType returns the type of the proposal

func (*ReplaceMigrationRecordsProposal) ProtoMessage

func (*ReplaceMigrationRecordsProposal) ProtoMessage()

func (*ReplaceMigrationRecordsProposal) Reset

func (*ReplaceMigrationRecordsProposal) Size

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

func (ReplaceMigrationRecordsProposal) String

String returns a string containing the migration record's proposal.

func (*ReplaceMigrationRecordsProposal) Unmarshal

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

func (*ReplaceMigrationRecordsProposal) ValidateBasic

func (p *ReplaceMigrationRecordsProposal) ValidateBasic() error

ValidateBasic validates a governance proposal's abstract and basic contents

func (*ReplaceMigrationRecordsProposal) XXX_DiscardUnknown

func (m *ReplaceMigrationRecordsProposal) XXX_DiscardUnknown()

func (*ReplaceMigrationRecordsProposal) XXX_Marshal

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

func (*ReplaceMigrationRecordsProposal) XXX_Merge

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

func (*ReplaceMigrationRecordsProposal) XXX_Size

func (m *ReplaceMigrationRecordsProposal) XXX_Size() int

func (*ReplaceMigrationRecordsProposal) XXX_Unmarshal

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

type SwapAmountInRoutes

type SwapAmountInRoutes []poolmanagertypes.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 SwapAmountOutRoutes

type SwapAmountOutRoutes []poolmanagertypes.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 SwapMsgRoute

type SwapMsgRoute interface {
	TokenInDenom() string
	TokenOutDenom() string
	TokenDenomsOnPath() []string
}

SwapMsg defines a simple interface for getting the token denoms on a swap message route.

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) ExitPool

func (*UnimplementedMsgServer) ExitSwapExternAmountOut

func (*UnimplementedMsgServer) ExitSwapShareAmountIn

func (*UnimplementedMsgServer) JoinPool

func (*UnimplementedMsgServer) JoinSwapExternAmountIn

func (*UnimplementedMsgServer) JoinSwapShareAmountOut

func (*UnimplementedMsgServer) SwapExactAmountIn

func (*UnimplementedMsgServer) SwapExactAmountOut

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) CalcJoinPoolShares

func (*UnimplementedQueryServer) EstimateSwapExactAmountIn

func (*UnimplementedQueryServer) EstimateSwapExactAmountOut

func (*UnimplementedQueryServer) NumPools

func (*UnimplementedQueryServer) Pool

func (*UnimplementedQueryServer) PoolParams

func (*UnimplementedQueryServer) PoolType

func (*UnimplementedQueryServer) Pools

func (*UnimplementedQueryServer) PoolsWithFilter

func (*UnimplementedQueryServer) SpotPrice

func (*UnimplementedQueryServer) TotalLiquidity

func (*UnimplementedQueryServer) TotalPoolLiquidity

func (*UnimplementedQueryServer) TotalShares

type UnsortedPoolLiqError

type UnsortedPoolLiqError struct {
	ActualLiquidity sdk.Coins
}

func (UnsortedPoolLiqError) Error

func (e UnsortedPoolLiqError) Error() string

type UpdateMigrationRecordsProposal

type UpdateMigrationRecordsProposal 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"`
	Records     []BalancerToConcentratedPoolLink `protobuf:"bytes,3,rep,name=records,proto3" json:"records"`
}

For example: if the existing DistrRecords were: [(Balancer 1, CL 5), (Balancer 2, CL 6), (Balancer 3, CL 7)] And an UpdateMigrationRecordsProposal includes [(Balancer 2, CL 0), (Balancer 3, CL 4), (Balancer 4, CL 10)] This would leave Balancer 1 record, delete Balancer 2 record, Edit Balancer 3 record, and Add Balancer 4 record The result MigrationRecords in state would be: [(Balancer 1, CL 5), (Balancer 3, CL 4), (Balancer 4, CL 10)]

func (*UpdateMigrationRecordsProposal) Descriptor

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

func (*UpdateMigrationRecordsProposal) Equal

func (this *UpdateMigrationRecordsProposal) Equal(that interface{}) bool

func (*UpdateMigrationRecordsProposal) GetDescription

func (p *UpdateMigrationRecordsProposal) GetDescription() string

GetDescription gets the description of the proposal

func (*UpdateMigrationRecordsProposal) GetTitle

func (p *UpdateMigrationRecordsProposal) GetTitle() string

GetTitle gets the title of the proposal

func (*UpdateMigrationRecordsProposal) Marshal

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

func (*UpdateMigrationRecordsProposal) MarshalTo

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

func (*UpdateMigrationRecordsProposal) MarshalToSizedBuffer

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

func (*UpdateMigrationRecordsProposal) ProposalRoute

func (p *UpdateMigrationRecordsProposal) ProposalRoute() string

ProposalRoute returns the router key for the proposal

func (*UpdateMigrationRecordsProposal) ProposalType

func (p *UpdateMigrationRecordsProposal) ProposalType() string

ProposalType returns the type of the proposal

func (*UpdateMigrationRecordsProposal) ProtoMessage

func (*UpdateMigrationRecordsProposal) ProtoMessage()

func (*UpdateMigrationRecordsProposal) Reset

func (m *UpdateMigrationRecordsProposal) Reset()

func (*UpdateMigrationRecordsProposal) Size

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

func (UpdateMigrationRecordsProposal) String

String returns a string containing the migration record's proposal.

func (*UpdateMigrationRecordsProposal) Unmarshal

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

func (*UpdateMigrationRecordsProposal) ValidateBasic

func (p *UpdateMigrationRecordsProposal) ValidateBasic() error

ValidateBasic validates a governance proposal's abstract and basic contents.

func (*UpdateMigrationRecordsProposal) XXX_DiscardUnknown

func (m *UpdateMigrationRecordsProposal) XXX_DiscardUnknown()

func (*UpdateMigrationRecordsProposal) XXX_Marshal

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

func (*UpdateMigrationRecordsProposal) XXX_Merge

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

func (*UpdateMigrationRecordsProposal) XXX_Size

func (m *UpdateMigrationRecordsProposal) XXX_Size() int

func (*UpdateMigrationRecordsProposal) XXX_Unmarshal

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

type WeightedPoolExtension

type WeightedPoolExtension interface {
	CFMMPoolI

	// PokePool determines if a pool's weights need to be updated and updates
	// them if so.
	PokePool(blockTime time.Time)

	// GetTokenWeight returns the weight of the specified token in the pool.
	GetTokenWeight(denom string) (sdk.Int, error)
}

WeightedPoolExtension is an extension of the PoolI interface That defines an additional API for handling the pool's weights.

Jump to

Keyboard shortcuts

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