types

package
v0.5.20 Latest Latest
Warning

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

Go to latest
Published: May 13, 2022 License: Apache-2.0 Imports: 44 Imported by: 14

Documentation

Overview

noalias

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	EventTypeStoreCode           = "store_code"
	EventTypeMigrateCode         = "migrate_code"
	EventTypeInstantiateContract = "instantiate_contract"
	EventTypeExecuteContract     = "execute_contract"
	EventTypeMigrateContract     = "migrate_contract"
	EventTypeUpdateContractAdmin = "update_contract_admin"
	EventTypeClearContractAdmin  = "clear_contract_admin"
	EventTypeWasmPrefix          = "wasm"

	// Deprecated
	EventTypeFromContract = "from_contract"

	AttributeKeySender          = "sender"
	AttributeKeyCodeID          = "code_id"
	AttributeKeyContractAddress = "contract_address"
	AttributeKeyContractID      = "contract_id"
	AttributeKeyAdmin           = "admin"
	AttributeKeyCreator         = "creator"

	AttributeValueCategory = ModuleName
)

Wasm module event types

View Source
const (
	GasMultiplier = uint64(100) // Please note that all gas prices returned to the wasmVM engine should have this multiplied

	// HumanizeWasmGasCost humanize cost in wasm gas unit
	HumanizeWasmGasCost = humanizeCost * GasMultiplier
	// CanonicalizeWasmGasCost canonicalize cost in wasm gas unit
	CanonicalizeWasmGasCost = canonicalizeCost * GasMultiplier
)

Constant gas parameters

View Source
const (
	// ModuleName is the name of the wasm module
	ModuleName = "wasm"

	// StoreKey is the string store representation
	StoreKey = ModuleName

	// TStoreKey is the string transient store representation
	TStoreKey = "transient_" + ModuleName

	// QuerierRoute is the querier route for the wasm module
	QuerierRoute = ModuleName

	// RouterKey is the msg router key for the wasm module
	RouterKey = ModuleName

	// WasmVMQueryDepthContextKey context key to keep query depth
	WasmVMQueryDepthContextKey = "wasmvm-query-depth"
)
View Source
const (
	WasmMsgParserRouteBank         = "bank"
	WasmMsgParserRouteStaking      = "staking"
	WasmMsgParserRouteDistribution = "distribution"
	WasmMsgParserRouteGov          = "gov"
	WasmMsgParserRouteMarket       = "market"
	WasmMsgParserRouteWasm         = "wasm"
)

Routes of pre-determined wasm querier

View Source
const (
	TypeMsgStoreCode           = "store_code"
	TypeMsgMigrateCode         = "migrate_code"
	TypeMsgInstantiateContract = "instantiate_contract"
	TypeMsgExecuteContract     = "execute_contract"
	TypeMsgMigrateContract     = "migrate_contract"
	TypeMsgUpdateContractAdmin = "update_contract_admin"
	TypeMsgClearContractAdmin  = "clear_contract_admin"
)

wasm message types

View Source
const (
	EnforcedMaxContractSize    = uint64(3000 * 1024) // 3MB
	EnforcedMaxContractGas     = uint64(100_000_000) // 100,000,000
	EnforcedMaxContractMsgSize = uint64(20 * 1024)   // 10KB
)

Max params for static check

View Source
const (
	DefaultMaxContractSize    = uint64(600 * 1024) // 600 KB
	DefaultMaxContractGas     = uint64(20_000_000) // 20,000,000
	DefaultMaxContractMsgSize = uint64(4 * 1024)   // 4KB

	// ContractMemoryLimit is the memory limit of each contract execution (in MiB)
	// constant value so all nodes run with the same limit.
	ContractMemoryLimit = uint32(32)
)

Default parameter values

View Source
const (
	QueryGetByteCode     = "bytecode"
	QueryGetCodeInfo     = "codeInfo"
	QueryGetContractInfo = "contractInfo"
	QueryRawStore        = "rawStore"
	QueryContractStore   = "contractStore"
	QueryParameters      = "parameters"
)

query endpoints supported by the wasm Querier

View Source
const (
	WasmQueryRouteBank     = "bank"
	WasmQueryRouteStaking  = "staking"
	WasmQueryRouteMarket   = "market"
	WasmQueryRouteOracle   = "oracle"
	WasmQueryRouteTreasury = "treasury"
	WasmQueryRouteWasm     = "wasm"
)

Routes of pre-determined wasm querier

View Source
const ContractMaxQueryDepth = 20

ContractMaxQueryDepth maximum recursive query depth allowed

View Source
const DefaultFeatures = "stargate,staking,terra"

DefaultFeatures - Cosmwasm feature

Variables

View Source
var (
	ErrAccountExists             = sdkerrors.Register(ModuleName, 2, "contract account already exists")
	ErrInstantiateFailed         = sdkerrors.Register(ModuleName, 3, "instantiate wasm contract failed")
	ErrExecuteFailed             = sdkerrors.Register(ModuleName, 4, "execute wasm contract failed")
	ErrGasLimit                  = sdkerrors.Register(ModuleName, 5, "insufficient gas")
	ErrInvalidGenesis            = sdkerrors.Register(ModuleName, 6, "invalid genesis")
	ErrNotFound                  = sdkerrors.Register(ModuleName, 7, "not found")
	ErrInvalidMsg                = sdkerrors.Register(ModuleName, 8, "invalid Msg from the contract")
	ErrNoRegisteredQuerier       = sdkerrors.Register(ModuleName, 9, "failed to find querier for route")
	ErrNoRegisteredParser        = sdkerrors.Register(ModuleName, 10, "failed to find parser for route")
	ErrMigrationFailed           = sdkerrors.Register(ModuleName, 11, "migrate wasm contract failed")
	ErrNotMigratable             = sdkerrors.Register(ModuleName, 12, "the contract is not migratable ")
	ErrStoreCodeFailed           = sdkerrors.Register(ModuleName, 13, "store wasm contract failed")
	ErrContractQueryFailed       = sdkerrors.Register(ModuleName, 14, "contract query failed")
	ErrExceedMaxContractSize     = sdkerrors.Register(ModuleName, 15, "exceeds max contract size limit")
	ErrExceedMaxContractMsgSize  = sdkerrors.Register(ModuleName, 16, "exceeds max contract msg size limit")
	ErrExceedMaxContractDataSize = sdkerrors.Register(ModuleName, 17, "exceeds max contract data size limit")
	ErrReplyFailed               = sdkerrors.Register(ModuleName, 18, "reply wasm contract failed")
	ErrExceedMaxQueryDepth       = sdkerrors.Register(ModuleName, 19, "exceed max query depth")
)

Wasm 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 (
	LastCodeIDKey     = []byte{0x01}
	LastInstanceIDKey = []byte{0x02}
	CodeKey           = []byte{0x03}
	ContractInfoKey   = []byte{0x04}
	ContractStoreKey  = []byte{0x05}
)

Keys for wasm store Items are stored with the following key: values

- 0x01: uint64

- 0x02: uint64

- 0x03<uint64>: CodeInfo

- 0x04<accAddress_Bytes>: ContractInfo

- 0x05<accAddress_Bytes>: KVStore for contract

View Source
var (
	KeyMaxContractSize    = []byte("MaxContractSize")
	KeyMaxContractGas     = []byte("MaxContractGas")
	KeyMaxContractMsgSize = []byte("MaxContractMsgSize")
)

Parameter keys

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 (
	ErrInvalidLengthWasm        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowWasm          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupWasm = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// JSONDeserializationWasmGasCost json deserialization cost in wasm gas unit
	JSONDeserializationWasmGasCost = wasmvmtypes.UFraction{
		Numerator:   deserializationCostPerByte * GasMultiplier,
		Denominator: 1,
	}
)
View Source
var (

	// ModuleCdc references the global x/market 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 CompileCosts

func CompileCosts(byteLength int) sdk.Gas

CompileCosts costs to persist and "compile" a new wasm contract

func EncodeSdkCoin

func EncodeSdkCoin(coin sdk.Coin) wasmvmtypes.Coin

EncodeSdkCoin - encode sdk coin to wasm coin

func EncodeSdkCoins

func EncodeSdkCoins(coins sdk.Coins) wasmvmtypes.Coins

EncodeSdkCoins - encode sdk coins to wasm coins

func EncodeSdkEvents

func EncodeSdkEvents(events []sdk.Event) []wasmvmtypes.Event

EncodeSdkEvents - encode sdk events to wasm events Deprecated `from_contract` will be excluded from the events

func EventCosts

func EventCosts(attrs []wasmvmtypes.EventAttribute, events wasmvmtypes.Events) sdk.Gas

EventCosts costs to persist an event

func FromWasmVMGas

func FromWasmVMGas(source uint64) sdk.Gas

FromWasmVMGas converts from wasmvm gas to sdk gas

func GenerateContractAddress

func GenerateContractAddress(codeID uint64, instanceID uint64) sdk.AccAddress

GenerateContractAddress generates a contract address from codeID + instanceID and increases last instanceID

func GetCodeInfoKey

func GetCodeInfoKey(codeID uint64) []byte

GetCodeInfoKey constructs the key of the WASM code info for the ID

func GetContractInfoKey

func GetContractInfoKey(addr sdk.AccAddress) []byte

GetContractInfoKey returns the key of the WASM contract info for the contract address

func GetContractStoreKey

func GetContractStoreKey(addr sdk.AccAddress) []byte

GetContractStoreKey returns the store prefix for the WASM contract store

func InstantiateContractCosts

func InstantiateContractCosts(msgLen int) sdk.Gas

InstantiateContractCosts costs when interacting with a wasm contract

func KVStore added in v0.5.16

func KVStore(ctx sdk.Context, key sdk.StoreKey) types.KVStore

KVStore return new gas KVStore which fixed https://github.com/cosmos/cosmos-sdk/issues/10243

func NewEnv

func NewEnv(ctx sdk.Context, contractAddr sdk.AccAddress) wasmvmtypes.Env

NewEnv initializes the environment for a contract instance

func NewInfo

func NewInfo(creator sdk.AccAddress, deposit sdk.Coins) wasmvmtypes.MessageInfo

NewInfo initializes the MessageInfo for a contract instance

func NewWasmCoins

func NewWasmCoins(cosmosCoins sdk.Coins) (wasmCoins []wasmvmtypes.Coin)

NewWasmCoins translates between Cosmos SDK coins and Wasm coins

func ParamKeyTable

func ParamKeyTable() paramstypes.KeyTable

ParamKeyTable returns the parameter key table.

func ParseEvents

func ParseEvents(
	contractAddr sdk.AccAddress,
	attributes wasmvmtypes.EventAttributes,
	events wasmvmtypes.Events,
) (sdk.Events, error)

ParseEvents converts wasm EventAttributes and Events into an sdk.Events

func ParseToCoin

func ParseToCoin(wasmCoin wasmvmtypes.Coin) (coin sdk.Coin, err error)

ParseToCoin converts wasm coin to sdk.Coin

func ParseToCoins

func ParseToCoins(wasmCoins []wasmvmtypes.Coin) (coins sdk.Coins, err error)

ParseToCoins converts wasm coins to sdk.Coins

func RegisterContractCosts

func RegisterContractCosts() sdk.Gas

RegisterContractCosts costs when registering a new contract to the store

func RegisterInterfaces

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

RegisterInterfaces registers the x/market interfaces types with the interface registry

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

RegisterLegacyAminoCodec registers the wasm types and interface

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ReplyCosts

func ReplyCosts(reply wasmvmtypes.Reply) sdk.Gas

ReplyCosts costs to to handle a message reply

func ToWasmVMGas

func ToWasmVMGas(source sdk.Gas) uint64

ToWasmVMGas converts from sdk gas to wasmvm gas

func ValidateGenesis

func ValidateGenesis(data *GenesisState) error

ValidateGenesis performs basic validation of wasm genesis data returning an error for any failed validation criteria.

Types

type AccountKeeper

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

AccountKeeper - expected account keeper

type BankKeeper

type BankKeeper interface {
	SendCoins(ctx sdk.Context, fromAddr sdk.AccAddress, toAddr sdk.AccAddress, amt sdk.Coins) error

	// used to deduct tax
	SendCoinsFromAccountToModule(ctx sdk.Context, senderAddr sdk.AccAddress, recipientModule string, amt sdk.Coins) error

	// used for simulation
	SpendableCoins(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	GetBalance(ctx sdk.Context, addr sdk.AccAddress, denom string) sdk.Coin
	GetAllBalances(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	IsSendEnabledCoin(ctx sdk.Context, coin sdk.Coin) bool
	IsSendEnabledCoins(ctx sdk.Context, coins ...sdk.Coin) error
}

BankKeeper - expected bank keeper

type CapabilityKeeper

type CapabilityKeeper interface {
	GetCapability(ctx sdk.Context, name string) (*capabilitytypes.Capability, bool)
	ClaimCapability(ctx sdk.Context, cap *capabilitytypes.Capability, name string) error
	AuthenticateCapability(ctx sdk.Context, capability *capabilitytypes.Capability, name string) bool
}

CapabilityKeeper defined the expected IBC capability keeper

type ChannelKeeper

type ChannelKeeper interface {
	GetChannel(ctx sdk.Context, srcPort, srcChan string) (channel channeltypes.Channel, found bool)
	GetNextSequenceSend(ctx sdk.Context, portID, channelID string) (uint64, bool)
	SendPacket(ctx sdk.Context, channelCap *capabilitytypes.Capability, packet ibcexported.PacketI) error
	ChanCloseInit(ctx sdk.Context, portID, channelID string, chanCap *capabilitytypes.Capability) error
	GetAllChannels(ctx sdk.Context) (channels []channeltypes.IdentifiedChannel)
	IterateChannels(ctx sdk.Context, cb func(channeltypes.IdentifiedChannel) bool)
}

ChannelKeeper defines the expected IBC channel keeper

type ClientKeeper

type ClientKeeper interface {
	GetClientConsensusState(ctx sdk.Context, clientID string) (connection ibcexported.ConsensusState, found bool)
}

ClientKeeper defines the expected IBC client keeper

type Code

type Code struct {
	CodeInfo  CodeInfo `protobuf:"bytes,1,opt,name=code_info,json=codeInfo,proto3" json:"code_info"`
	CodeBytes []byte   `protobuf:"bytes,2,opt,name=code_bytes,json=codeBytes,proto3" json:"code_bytes,omitempty"`
}

Code struct encompasses CodeInfo and CodeBytes

func (*Code) Descriptor

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

func (*Code) GetCodeBytes

func (m *Code) GetCodeBytes() []byte

func (*Code) GetCodeInfo

func (m *Code) GetCodeInfo() CodeInfo

func (*Code) Marshal

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

func (*Code) MarshalTo

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

func (*Code) MarshalToSizedBuffer

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

func (*Code) ProtoMessage

func (*Code) ProtoMessage()

func (*Code) Reset

func (m *Code) Reset()

func (*Code) Size

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

func (*Code) String

func (m *Code) String() string

func (*Code) Unmarshal

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

func (*Code) XXX_DiscardUnknown

func (m *Code) XXX_DiscardUnknown()

func (*Code) XXX_Marshal

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

func (*Code) XXX_Merge

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

func (*Code) XXX_Size

func (m *Code) XXX_Size() int

func (*Code) XXX_Unmarshal

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

type CodeInfo

type CodeInfo struct {
	// CodeID is the sequentially increasing unique identifier
	CodeID uint64 `protobuf:"varint,1,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty" yaml:"code_id"`
	// CodeHash is the unique identifier created by wasmvm
	CodeHash []byte `protobuf:"bytes,2,opt,name=code_hash,json=codeHash,proto3" json:"code_hash,omitempty" yaml:"code_hash"`
	// Creator address who initially stored the code
	Creator string `protobuf:"bytes,3,opt,name=creator,proto3" json:"creator,omitempty" yaml:"creator"`
}

CodeInfo is data for the uploaded contract WASM code

func NewCodeInfo

func NewCodeInfo(codeID uint64, codeHash []byte, creator sdk.AccAddress) CodeInfo

NewCodeInfo fills a new Contract struct

func (*CodeInfo) Descriptor

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

func (*CodeInfo) GetCodeHash

func (m *CodeInfo) GetCodeHash() []byte

func (*CodeInfo) GetCodeID

func (m *CodeInfo) GetCodeID() uint64

func (*CodeInfo) GetCreator

func (m *CodeInfo) GetCreator() string

func (*CodeInfo) Marshal

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

func (*CodeInfo) MarshalTo

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

func (*CodeInfo) MarshalToSizedBuffer

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

func (*CodeInfo) ProtoMessage

func (*CodeInfo) ProtoMessage()

func (*CodeInfo) Reset

func (m *CodeInfo) Reset()

func (*CodeInfo) Size

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

func (*CodeInfo) String

func (m *CodeInfo) String() string

func (*CodeInfo) Unmarshal

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

func (*CodeInfo) XXX_DiscardUnknown

func (m *CodeInfo) XXX_DiscardUnknown()

func (*CodeInfo) XXX_Marshal

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

func (*CodeInfo) XXX_Merge

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

func (*CodeInfo) XXX_Size

func (m *CodeInfo) XXX_Size() int

func (*CodeInfo) XXX_Unmarshal

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

type ConnectionKeeper

type ConnectionKeeper interface {
	GetConnection(ctx sdk.Context, connectionID string) (connection connectiontypes.ConnectionEnd, found bool)
}

ConnectionKeeper defines the expected IBC connection keeper

type Contract

type Contract struct {
	ContractInfo  ContractInfo `protobuf:"bytes,1,opt,name=contract_info,json=contractInfo,proto3" json:"contract_info"`
	ContractStore []Model      `protobuf:"bytes,2,rep,name=contract_store,json=contractStore,proto3" json:"contract_store"`
}

Contract struct encompasses ContractAddress, ContractInfo, and ContractState

func (*Contract) Descriptor

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

func (*Contract) GetContractInfo

func (m *Contract) GetContractInfo() ContractInfo

func (*Contract) GetContractStore

func (m *Contract) GetContractStore() []Model

func (*Contract) Marshal

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

func (*Contract) MarshalTo

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

func (*Contract) MarshalToSizedBuffer

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

func (*Contract) ProtoMessage

func (*Contract) ProtoMessage()

func (*Contract) Reset

func (m *Contract) Reset()

func (*Contract) Size

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

func (*Contract) String

func (m *Contract) String() string

func (*Contract) Unmarshal

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

func (*Contract) XXX_DiscardUnknown

func (m *Contract) XXX_DiscardUnknown()

func (*Contract) XXX_Marshal

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

func (*Contract) XXX_Merge

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

func (*Contract) XXX_Size

func (m *Contract) XXX_Size() int

func (*Contract) XXX_Unmarshal

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

type ContractInfo

type ContractInfo struct {
	// Address is the address of the contract
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty" yaml:"address"`
	// Creator is the contract creator address
	Creator string `protobuf:"bytes,2,opt,name=creator,proto3" json:"creator,omitempty" yaml:"creator"`
	// Admin is who can execute the contract migration
	Admin string `protobuf:"bytes,3,opt,name=admin,proto3" json:"admin,omitempty" yaml:"admin"`
	// CodeID is the reference to the stored Wasm code
	CodeID uint64 `protobuf:"varint,4,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty" yaml:"code_id"`
	// InitMsg is the raw message used when instantiating a contract
	InitMsg encoding_json.RawMessage `` /* 132-byte string literal not displayed */
}

ContractInfo stores a WASM contract instance

func NewContractInfo

func NewContractInfo(codeID uint64, address, creator, admin sdk.AccAddress, initMsg []byte) ContractInfo

NewContractInfo creates a new instance of a given WASM contract info

func (*ContractInfo) Descriptor

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

func (*ContractInfo) Equal

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

func (*ContractInfo) GetAddress

func (m *ContractInfo) GetAddress() string

func (*ContractInfo) GetAdmin

func (m *ContractInfo) GetAdmin() string

func (*ContractInfo) GetCodeID

func (m *ContractInfo) GetCodeID() uint64

func (*ContractInfo) GetCreator

func (m *ContractInfo) GetCreator() string

func (*ContractInfo) GetInitMsg

func (m *ContractInfo) GetInitMsg() encoding_json.RawMessage

func (*ContractInfo) Marshal

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

func (*ContractInfo) MarshalTo

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

func (*ContractInfo) MarshalToSizedBuffer

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

func (*ContractInfo) ProtoMessage

func (*ContractInfo) ProtoMessage()

func (*ContractInfo) Reset

func (m *ContractInfo) Reset()

func (*ContractInfo) Size

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

func (*ContractInfo) String

func (m *ContractInfo) String() string

func (*ContractInfo) Unmarshal

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

func (*ContractInfo) XXX_DiscardUnknown

func (m *ContractInfo) XXX_DiscardUnknown()

func (*ContractInfo) XXX_Marshal

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

func (*ContractInfo) XXX_Merge

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

func (*ContractInfo) XXX_Size

func (m *ContractInfo) XXX_Size() int

func (*ContractInfo) XXX_Unmarshal

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

type GRPCQueryHandler

type GRPCQueryHandler = func(ctx sdk.Context, req abci.RequestQuery) (abci.ResponseQuery, error)

GRPCQueryHandler defines a function type which handles ABCI Query requests using gRPC

type GRPCQueryRouter

type GRPCQueryRouter interface {
	Route(path string) GRPCQueryHandler
}

GRPCQueryRouter expected GRPCQueryRouter interface

type GenesisState

type GenesisState struct {
	Params         Params     `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	LastCodeID     uint64     `protobuf:"varint,2,opt,name=last_code_id,json=lastCodeId,proto3" json:"last_code_id,omitempty"`
	LastInstanceID uint64     `protobuf:"varint,3,opt,name=last_instance_id,json=lastInstanceId,proto3" json:"last_instance_id,omitempty"`
	Codes          []Code     `protobuf:"bytes,4,rep,name=codes,proto3" json:"codes"`
	Contracts      []Contract `protobuf:"bytes,5,rep,name=contracts,proto3" json:"contracts"`
}

GenesisState defines the oracle module's genesis state.

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

DefaultGenesisState gets raw genesis raw message for testing

func GetGenesisStateFromAppState

func GetGenesisStateFromAppState(cdc codec.JSONCodec, appState map[string]json.RawMessage) *GenesisState

GetGenesisStateFromAppState returns x/market GenesisState given raw application genesis state.

func NewGenesisState

func NewGenesisState(params Params, lastCodeID, lastInstanceID uint64, codes []Code, contracts []Contract) *GenesisState

NewGenesisState creates a new GenesisState object

func (*GenesisState) Descriptor

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

func (*GenesisState) GetCodes

func (m *GenesisState) GetCodes() []Code

func (*GenesisState) GetContracts

func (m *GenesisState) GetContracts() []Contract

func (*GenesisState) GetLastCodeID

func (m *GenesisState) GetLastCodeID() uint64

func (*GenesisState) GetLastInstanceID

func (m *GenesisState) GetLastInstanceID() uint64

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

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

type ICS20TransferPortSource interface {
	GetPort(ctx sdk.Context) string
}

ICS20TransferPortSource is a subset of the ibc transfer keeper.

type Model

type Model struct {
	Key   []byte `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value []byte `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
}

Model is a struct that holds a KV pair

func (*Model) Descriptor

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

func (*Model) GetKey

func (m *Model) GetKey() []byte

func (*Model) GetValue

func (m *Model) GetValue() []byte

func (*Model) Marshal

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

func (*Model) MarshalTo

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

func (*Model) MarshalToSizedBuffer

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

func (*Model) ProtoMessage

func (*Model) ProtoMessage()

func (*Model) Reset

func (m *Model) Reset()

func (*Model) Size

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

func (*Model) String

func (m *Model) String() string

func (*Model) Unmarshal

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

func (*Model) XXX_DiscardUnknown

func (m *Model) XXX_DiscardUnknown()

func (*Model) XXX_Marshal

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

func (*Model) XXX_Merge

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

func (*Model) XXX_Size

func (m *Model) XXX_Size() int

func (*Model) XXX_Unmarshal

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

type MsgClearContractAdmin

type MsgClearContractAdmin struct {
	// Admin is the current contract admin
	Admin string `protobuf:"bytes,1,opt,name=admin,proto3" json:"admin,omitempty" yaml:"admin"`
	// Contract is the address of the smart contract
	Contract string `protobuf:"bytes,2,opt,name=contract,proto3" json:"contract,omitempty" yaml:"contract"`
}

MsgClearContractAdmin represents a message to clear admin address from a smart contract

func NewMsgClearContractAdmin

func NewMsgClearContractAdmin(admin, contract sdk.AccAddress) *MsgClearContractAdmin

NewMsgClearContractAdmin creates a MsgClearContractAdmin instance

func (*MsgClearContractAdmin) Descriptor

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

func (MsgClearContractAdmin) GetSignBytes

func (msg MsgClearContractAdmin) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgClearContractAdmin) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgClearContractAdmin) Marshal

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

func (*MsgClearContractAdmin) MarshalTo

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

func (*MsgClearContractAdmin) MarshalToSizedBuffer

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

func (*MsgClearContractAdmin) ProtoMessage

func (*MsgClearContractAdmin) ProtoMessage()

func (*MsgClearContractAdmin) Reset

func (m *MsgClearContractAdmin) Reset()

func (MsgClearContractAdmin) Route

func (msg MsgClearContractAdmin) Route() string

Route implements sdk.Msg

func (*MsgClearContractAdmin) Size

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

func (*MsgClearContractAdmin) String

func (m *MsgClearContractAdmin) String() string

func (MsgClearContractAdmin) Type

func (msg MsgClearContractAdmin) Type() string

Type implements sdk.Msg

func (*MsgClearContractAdmin) Unmarshal

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

func (MsgClearContractAdmin) ValidateBasic

func (msg MsgClearContractAdmin) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgClearContractAdmin) XXX_DiscardUnknown

func (m *MsgClearContractAdmin) XXX_DiscardUnknown()

func (*MsgClearContractAdmin) XXX_Marshal

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

func (*MsgClearContractAdmin) XXX_Merge

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

func (*MsgClearContractAdmin) XXX_Size

func (m *MsgClearContractAdmin) XXX_Size() int

func (*MsgClearContractAdmin) XXX_Unmarshal

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

type MsgClearContractAdminResponse

type MsgClearContractAdminResponse struct {
}

MsgClearContractAdminResponse defines the Msg/ClearContractAdmin response type.

func (*MsgClearContractAdminResponse) Descriptor

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

func (*MsgClearContractAdminResponse) Marshal

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

func (*MsgClearContractAdminResponse) MarshalTo

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

func (*MsgClearContractAdminResponse) MarshalToSizedBuffer

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

func (*MsgClearContractAdminResponse) ProtoMessage

func (*MsgClearContractAdminResponse) ProtoMessage()

func (*MsgClearContractAdminResponse) Reset

func (m *MsgClearContractAdminResponse) Reset()

func (*MsgClearContractAdminResponse) Size

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

func (*MsgClearContractAdminResponse) String

func (*MsgClearContractAdminResponse) Unmarshal

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

func (*MsgClearContractAdminResponse) XXX_DiscardUnknown

func (m *MsgClearContractAdminResponse) XXX_DiscardUnknown()

func (*MsgClearContractAdminResponse) XXX_Marshal

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

func (*MsgClearContractAdminResponse) XXX_Merge

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

func (*MsgClearContractAdminResponse) XXX_Size

func (m *MsgClearContractAdminResponse) XXX_Size() int

func (*MsgClearContractAdminResponse) XXX_Unmarshal

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

type MsgClient

type MsgClient interface {
	// StoreCode to submit Wasm code to the system
	StoreCode(ctx context.Context, in *MsgStoreCode, opts ...grpc.CallOption) (*MsgStoreCodeResponse, error)
	// MigrateCode to submit new version Wasm code to the system
	MigrateCode(ctx context.Context, in *MsgMigrateCode, opts ...grpc.CallOption) (*MsgMigrateCodeResponse, error)
	//  Instantiate creates a new smart contract instance for the given code id.
	InstantiateContract(ctx context.Context, in *MsgInstantiateContract, opts ...grpc.CallOption) (*MsgInstantiateContractResponse, error)
	// Execute submits the given message data to a smart contract
	ExecuteContract(ctx context.Context, in *MsgExecuteContract, opts ...grpc.CallOption) (*MsgExecuteContractResponse, error)
	// Migrate runs a code upgrade/ downgrade for a smart contract
	MigrateContract(ctx context.Context, in *MsgMigrateContract, opts ...grpc.CallOption) (*MsgMigrateContractResponse, error)
	// UpdateContractAdmin sets a new admin for a smart contract
	UpdateContractAdmin(ctx context.Context, in *MsgUpdateContractAdmin, opts ...grpc.CallOption) (*MsgUpdateContractAdminResponse, error)
	// ClearContractAdmin remove admin flag from a smart contract
	ClearContractAdmin(ctx context.Context, in *MsgClearContractAdmin, opts ...grpc.CallOption) (*MsgClearContractAdminResponse, error)
}

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 MsgExecuteContract

type MsgExecuteContract struct {
	// Sender is the that actor that signed the messages
	Sender string `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	// Contract is the address of the smart contract
	Contract string `protobuf:"bytes,2,opt,name=contract,proto3" json:"contract,omitempty" yaml:"contract"`
	// ExecuteMsg json encoded message to be passed to the contract
	ExecuteMsg encoding_json.RawMessage `` /* 144-byte string literal not displayed */
	// Coins that are transferred to the contract on execution
	Coins github_com_cosmos_cosmos_sdk_types.Coins `protobuf:"bytes,5,rep,name=coins,proto3,castrepeated=github.com/cosmos/cosmos-sdk/types.Coins" json:"coins" yaml:"coins"`
}

MsgExecuteContract represents a message to submits the given message data to a smart contract.

func NewMsgExecuteContract

func NewMsgExecuteContract(sender sdk.AccAddress, contract sdk.AccAddress, execMsg []byte, coins sdk.Coins) *MsgExecuteContract

NewMsgExecuteContract creates a NewMsgExecuteContract instance

func (*MsgExecuteContract) Descriptor

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

func (MsgExecuteContract) GetSignBytes

func (msg MsgExecuteContract) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgExecuteContract) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgExecuteContract) Marshal

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

func (*MsgExecuteContract) MarshalTo

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

func (*MsgExecuteContract) MarshalToSizedBuffer

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

func (*MsgExecuteContract) ProtoMessage

func (*MsgExecuteContract) ProtoMessage()

func (*MsgExecuteContract) Reset

func (m *MsgExecuteContract) Reset()

func (MsgExecuteContract) Route

func (msg MsgExecuteContract) Route() string

Route implements sdk.Msg

func (*MsgExecuteContract) Size

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

func (*MsgExecuteContract) String

func (m *MsgExecuteContract) String() string

func (MsgExecuteContract) Type

func (msg MsgExecuteContract) Type() string

Type implements sdk.Msg

func (*MsgExecuteContract) Unmarshal

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

func (MsgExecuteContract) ValidateBasic

func (msg MsgExecuteContract) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgExecuteContract) XXX_DiscardUnknown

func (m *MsgExecuteContract) XXX_DiscardUnknown()

func (*MsgExecuteContract) XXX_Marshal

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

func (*MsgExecuteContract) XXX_Merge

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

func (*MsgExecuteContract) XXX_Size

func (m *MsgExecuteContract) XXX_Size() int

func (*MsgExecuteContract) XXX_Unmarshal

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

type MsgExecuteContractResponse

type MsgExecuteContractResponse struct {
	// Data contains base64-encoded bytes to returned from the contract
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty" yaml:"data"`
}

MsgExecuteContractResponse defines the Msg/ExecuteContract response type.

func (*MsgExecuteContractResponse) Descriptor

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

func (*MsgExecuteContractResponse) GetData

func (m *MsgExecuteContractResponse) GetData() []byte

func (*MsgExecuteContractResponse) Marshal

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

func (*MsgExecuteContractResponse) MarshalTo

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

func (*MsgExecuteContractResponse) MarshalToSizedBuffer

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

func (*MsgExecuteContractResponse) ProtoMessage

func (*MsgExecuteContractResponse) ProtoMessage()

func (*MsgExecuteContractResponse) Reset

func (m *MsgExecuteContractResponse) Reset()

func (*MsgExecuteContractResponse) Size

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

func (*MsgExecuteContractResponse) String

func (m *MsgExecuteContractResponse) String() string

func (*MsgExecuteContractResponse) Unmarshal

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

func (*MsgExecuteContractResponse) XXX_DiscardUnknown

func (m *MsgExecuteContractResponse) XXX_DiscardUnknown()

func (*MsgExecuteContractResponse) XXX_Marshal

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

func (*MsgExecuteContractResponse) XXX_Merge

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

func (*MsgExecuteContractResponse) XXX_Size

func (m *MsgExecuteContractResponse) XXX_Size() int

func (*MsgExecuteContractResponse) XXX_Unmarshal

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

type MsgInstantiateContract

type MsgInstantiateContract struct {
	// Sender is an sender address
	Sender string `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	// Admin is an optional admin address who can migrate the contract
	Admin string `protobuf:"bytes,2,opt,name=admin,proto3" json:"admin,omitempty" yaml:"admin"`
	// CodeID is the reference to the stored WASM code
	CodeID uint64 `protobuf:"varint,3,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty" yaml:"code_id"`
	// InitMsg json encoded message to be passed to the contract on instantiation
	InitMsg encoding_json.RawMessage `` /* 132-byte string literal not displayed */
	// InitCoins that are transferred to the contract on execution
	InitCoins github_com_cosmos_cosmos_sdk_types.Coins `` /* 150-byte string literal not displayed */
}

MsgInstantiateContract represents a message to create a new smart contract instance for the given code id.

func NewMsgInstantiateContract

func NewMsgInstantiateContract(sender, admin sdk.AccAddress, codeID uint64, initMsg []byte, initCoins sdk.Coins) *MsgInstantiateContract

NewMsgInstantiateContract creates a MsgInstantiateContract instance

func (*MsgInstantiateContract) Descriptor

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

func (MsgInstantiateContract) GetSignBytes

func (msg MsgInstantiateContract) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgInstantiateContract) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgInstantiateContract) Marshal

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

func (*MsgInstantiateContract) MarshalTo

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

func (*MsgInstantiateContract) MarshalToSizedBuffer

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

func (*MsgInstantiateContract) ProtoMessage

func (*MsgInstantiateContract) ProtoMessage()

func (*MsgInstantiateContract) Reset

func (m *MsgInstantiateContract) Reset()

func (MsgInstantiateContract) Route

func (msg MsgInstantiateContract) Route() string

Route implements sdk.Msg

func (*MsgInstantiateContract) Size

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

func (*MsgInstantiateContract) String

func (m *MsgInstantiateContract) String() string

func (MsgInstantiateContract) Type

func (msg MsgInstantiateContract) Type() string

Type implements sdk.Msg

func (*MsgInstantiateContract) Unmarshal

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

func (MsgInstantiateContract) ValidateBasic

func (msg MsgInstantiateContract) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgInstantiateContract) XXX_DiscardUnknown

func (m *MsgInstantiateContract) XXX_DiscardUnknown()

func (*MsgInstantiateContract) XXX_Marshal

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

func (*MsgInstantiateContract) XXX_Merge

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

func (*MsgInstantiateContract) XXX_Size

func (m *MsgInstantiateContract) XXX_Size() int

func (*MsgInstantiateContract) XXX_Unmarshal

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

type MsgInstantiateContractResponse

type MsgInstantiateContractResponse struct {
	// ContractAddress is the bech32 address of the new contract instance.
	ContractAddress string `` /* 130-byte string literal not displayed */
	// Data contains base64-encoded bytes to returned from the contract
	Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty" yaml:"data"`
}

MsgInstantiateContractResponse defines the Msg/InstantiateContract response type.

func (*MsgInstantiateContractResponse) Descriptor

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

func (*MsgInstantiateContractResponse) GetContractAddress

func (m *MsgInstantiateContractResponse) GetContractAddress() string

func (*MsgInstantiateContractResponse) GetData

func (m *MsgInstantiateContractResponse) GetData() []byte

func (*MsgInstantiateContractResponse) Marshal

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

func (*MsgInstantiateContractResponse) MarshalTo

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

func (*MsgInstantiateContractResponse) MarshalToSizedBuffer

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

func (*MsgInstantiateContractResponse) ProtoMessage

func (*MsgInstantiateContractResponse) ProtoMessage()

func (*MsgInstantiateContractResponse) Reset

func (m *MsgInstantiateContractResponse) Reset()

func (*MsgInstantiateContractResponse) Size

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

func (*MsgInstantiateContractResponse) String

func (*MsgInstantiateContractResponse) Unmarshal

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

func (*MsgInstantiateContractResponse) XXX_DiscardUnknown

func (m *MsgInstantiateContractResponse) XXX_DiscardUnknown()

func (*MsgInstantiateContractResponse) XXX_Marshal

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

func (*MsgInstantiateContractResponse) XXX_Merge

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

func (*MsgInstantiateContractResponse) XXX_Size

func (m *MsgInstantiateContractResponse) XXX_Size() int

func (*MsgInstantiateContractResponse) XXX_Unmarshal

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

type MsgMigrateCode

type MsgMigrateCode struct {
	// CodeID is the migration target code id
	CodeID uint64 `protobuf:"varint,1,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty" yaml:"code_id"`
	// Sender is the that actor that signed the messages
	Sender string `protobuf:"bytes,2,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	// WASMByteCode can be raw or gzip compressed
	WASMByteCode []byte `protobuf:"bytes,3,opt,name=wasm_byte_code,json=wasmByteCode,proto3" json:"wasm_byte_code,omitempty" yaml:"wasm_byte_code"`
}

MsgMigrateCode represents a message to submit Wasm code to the system

func NewMsgMigrateCode

func NewMsgMigrateCode(codeID uint64, sender sdk.AccAddress, wasmByteCode []byte) *MsgMigrateCode

NewMsgMigrateCode creates a MsgMigrateCode instance TODO - remove after columbus-5 update

func (*MsgMigrateCode) Descriptor

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

func (MsgMigrateCode) GetSignBytes

func (msg MsgMigrateCode) GetSignBytes() []byte

GetSignBytes Implements Msg

func (MsgMigrateCode) GetSigners

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

GetSigners Implements Msg

func (*MsgMigrateCode) Marshal

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

func (*MsgMigrateCode) MarshalTo

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

func (*MsgMigrateCode) MarshalToSizedBuffer

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

func (*MsgMigrateCode) ProtoMessage

func (*MsgMigrateCode) ProtoMessage()

func (*MsgMigrateCode) Reset

func (m *MsgMigrateCode) Reset()

func (MsgMigrateCode) Route

func (msg MsgMigrateCode) Route() string

Route implements sdk.Msg

func (*MsgMigrateCode) Size

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

func (*MsgMigrateCode) String

func (m *MsgMigrateCode) String() string

func (MsgMigrateCode) Type

func (msg MsgMigrateCode) Type() string

Type implements sdk.Msg

func (*MsgMigrateCode) Unmarshal

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

func (MsgMigrateCode) ValidateBasic

func (msg MsgMigrateCode) ValidateBasic() error

ValidateBasic Implements sdk.Msg

func (*MsgMigrateCode) XXX_DiscardUnknown

func (m *MsgMigrateCode) XXX_DiscardUnknown()

func (*MsgMigrateCode) XXX_Marshal

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

func (*MsgMigrateCode) XXX_Merge

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

func (*MsgMigrateCode) XXX_Size

func (m *MsgMigrateCode) XXX_Size() int

func (*MsgMigrateCode) XXX_Unmarshal

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

type MsgMigrateCodeResponse

type MsgMigrateCodeResponse struct {
}

MsgMigrateCodeResponse defines the Msg/MigrateCode response type.

func (*MsgMigrateCodeResponse) Descriptor

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

func (*MsgMigrateCodeResponse) Marshal

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

func (*MsgMigrateCodeResponse) MarshalTo

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

func (*MsgMigrateCodeResponse) MarshalToSizedBuffer

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

func (*MsgMigrateCodeResponse) ProtoMessage

func (*MsgMigrateCodeResponse) ProtoMessage()

func (*MsgMigrateCodeResponse) Reset

func (m *MsgMigrateCodeResponse) Reset()

func (*MsgMigrateCodeResponse) Size

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

func (*MsgMigrateCodeResponse) String

func (m *MsgMigrateCodeResponse) String() string

func (*MsgMigrateCodeResponse) Unmarshal

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

func (*MsgMigrateCodeResponse) XXX_DiscardUnknown

func (m *MsgMigrateCodeResponse) XXX_DiscardUnknown()

func (*MsgMigrateCodeResponse) XXX_Marshal

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

func (*MsgMigrateCodeResponse) XXX_Merge

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

func (*MsgMigrateCodeResponse) XXX_Size

func (m *MsgMigrateCodeResponse) XXX_Size() int

func (*MsgMigrateCodeResponse) XXX_Unmarshal

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

type MsgMigrateContract

type MsgMigrateContract struct {
	// Admin is the current contract admin
	Admin string `protobuf:"bytes,1,opt,name=admin,proto3" json:"admin,omitempty" yaml:"admin"`
	// Contract is the address of the smart contract
	Contract string `protobuf:"bytes,2,opt,name=contract,proto3" json:"contract,omitempty" yaml:"contract"`
	// NewCodeID references the new WASM code
	NewCodeID uint64 `protobuf:"varint,3,opt,name=new_code_id,json=newCodeId,proto3" json:"new_code_id,omitempty" yaml:"new_code_id"`
	// MigrateMsg is json encoded message to be passed to the contract on migration
	MigrateMsg encoding_json.RawMessage `` /* 144-byte string literal not displayed */
}

MsgMigrateContract represents a message to runs a code upgrade/ downgrade for a smart contract

func NewMsgMigrateContract

func NewMsgMigrateContract(admin, contract sdk.AccAddress, newCodeID uint64, migrateMsg json.RawMessage) *MsgMigrateContract

NewMsgMigrateContract creates a MsgMigrateContract instance

func (*MsgMigrateContract) Descriptor

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

func (MsgMigrateContract) GetSignBytes

func (msg MsgMigrateContract) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgMigrateContract) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgMigrateContract) Marshal

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

func (*MsgMigrateContract) MarshalTo

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

func (*MsgMigrateContract) MarshalToSizedBuffer

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

func (*MsgMigrateContract) ProtoMessage

func (*MsgMigrateContract) ProtoMessage()

func (*MsgMigrateContract) Reset

func (m *MsgMigrateContract) Reset()

func (MsgMigrateContract) Route

func (msg MsgMigrateContract) Route() string

Route implements sdk.Msg

func (*MsgMigrateContract) Size

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

func (*MsgMigrateContract) String

func (m *MsgMigrateContract) String() string

func (MsgMigrateContract) Type

func (msg MsgMigrateContract) Type() string

Type implements sdk.Msg

func (*MsgMigrateContract) Unmarshal

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

func (MsgMigrateContract) ValidateBasic

func (msg MsgMigrateContract) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgMigrateContract) XXX_DiscardUnknown

func (m *MsgMigrateContract) XXX_DiscardUnknown()

func (*MsgMigrateContract) XXX_Marshal

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

func (*MsgMigrateContract) XXX_Merge

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

func (*MsgMigrateContract) XXX_Size

func (m *MsgMigrateContract) XXX_Size() int

func (*MsgMigrateContract) XXX_Unmarshal

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

type MsgMigrateContractResponse

type MsgMigrateContractResponse struct {
	// Data contains base64-encoded bytes to returned from the contract
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty" yaml:"data"`
}

MsgMigrateContractResponse defines the Msg/MigrateContract response type.

func (*MsgMigrateContractResponse) Descriptor

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

func (*MsgMigrateContractResponse) GetData

func (m *MsgMigrateContractResponse) GetData() []byte

func (*MsgMigrateContractResponse) Marshal

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

func (*MsgMigrateContractResponse) MarshalTo

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

func (*MsgMigrateContractResponse) MarshalToSizedBuffer

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

func (*MsgMigrateContractResponse) ProtoMessage

func (*MsgMigrateContractResponse) ProtoMessage()

func (*MsgMigrateContractResponse) Reset

func (m *MsgMigrateContractResponse) Reset()

func (*MsgMigrateContractResponse) Size

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

func (*MsgMigrateContractResponse) String

func (m *MsgMigrateContractResponse) String() string

func (*MsgMigrateContractResponse) Unmarshal

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

func (*MsgMigrateContractResponse) XXX_DiscardUnknown

func (m *MsgMigrateContractResponse) XXX_DiscardUnknown()

func (*MsgMigrateContractResponse) XXX_Marshal

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

func (*MsgMigrateContractResponse) XXX_Merge

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

func (*MsgMigrateContractResponse) XXX_Size

func (m *MsgMigrateContractResponse) XXX_Size() int

func (*MsgMigrateContractResponse) XXX_Unmarshal

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

type MsgParser

type MsgParser struct {
	Parsers        map[string]WasmMsgParserInterface
	StargateParser StargateWasmMsgParserInterface
}

MsgParser - holds multiple module msg parsers

func NewWasmMsgParser

func NewWasmMsgParser() MsgParser

NewWasmMsgParser returns wasm msg parser

func (MsgParser) Parse

func (p MsgParser) Parse(ctx sdk.Context, contractAddr sdk.AccAddress, msg wasmvmtypes.CosmosMsg) (sdk.Msg, error)

Parse convert Wasm raw msg to chain msg

type MsgServer

type MsgServer interface {
	// StoreCode to submit Wasm code to the system
	StoreCode(context.Context, *MsgStoreCode) (*MsgStoreCodeResponse, error)
	// MigrateCode to submit new version Wasm code to the system
	MigrateCode(context.Context, *MsgMigrateCode) (*MsgMigrateCodeResponse, error)
	//  Instantiate creates a new smart contract instance for the given code id.
	InstantiateContract(context.Context, *MsgInstantiateContract) (*MsgInstantiateContractResponse, error)
	// Execute submits the given message data to a smart contract
	ExecuteContract(context.Context, *MsgExecuteContract) (*MsgExecuteContractResponse, error)
	// Migrate runs a code upgrade/ downgrade for a smart contract
	MigrateContract(context.Context, *MsgMigrateContract) (*MsgMigrateContractResponse, error)
	// UpdateContractAdmin sets a new admin for a smart contract
	UpdateContractAdmin(context.Context, *MsgUpdateContractAdmin) (*MsgUpdateContractAdminResponse, error)
	// ClearContractAdmin remove admin flag from a smart contract
	ClearContractAdmin(context.Context, *MsgClearContractAdmin) (*MsgClearContractAdminResponse, error)
}

MsgServer is the server API for Msg service.

type MsgServiceRouter

type MsgServiceRouter interface {
	Handler(msg sdk.Msg) baseapp.MsgServiceHandler
}

MsgServiceRouter expected MsgServiceRouter interface

type MsgStoreCode

type MsgStoreCode struct {
	// Sender is the that actor that signed the messages
	Sender string `protobuf:"bytes,1,opt,name=sender,proto3" json:"sender,omitempty" yaml:"sender"`
	// WASMByteCode can be raw or gzip compressed
	WASMByteCode []byte `protobuf:"bytes,2,opt,name=wasm_byte_code,json=wasmByteCode,proto3" json:"wasm_byte_code,omitempty" yaml:"wasm_byte_code"`
}

MsgStoreCode represents a message to submit Wasm code to the system

func NewMsgStoreCode

func NewMsgStoreCode(sender sdk.AccAddress, wasmByteCode []byte) *MsgStoreCode

NewMsgStoreCode creates a MsgStoreCode instance

func (*MsgStoreCode) Descriptor

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

func (MsgStoreCode) GetSignBytes

func (msg MsgStoreCode) GetSignBytes() []byte

GetSignBytes Implements Msg

func (MsgStoreCode) GetSigners

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

GetSigners Implements Msg

func (*MsgStoreCode) Marshal

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

func (*MsgStoreCode) MarshalTo

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

func (*MsgStoreCode) MarshalToSizedBuffer

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

func (*MsgStoreCode) ProtoMessage

func (*MsgStoreCode) ProtoMessage()

func (*MsgStoreCode) Reset

func (m *MsgStoreCode) Reset()

func (MsgStoreCode) Route

func (msg MsgStoreCode) Route() string

Route implements sdk.Msg

func (*MsgStoreCode) Size

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

func (*MsgStoreCode) String

func (m *MsgStoreCode) String() string

func (MsgStoreCode) Type

func (msg MsgStoreCode) Type() string

Type implements sdk.Msg

func (*MsgStoreCode) Unmarshal

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

func (MsgStoreCode) ValidateBasic

func (msg MsgStoreCode) ValidateBasic() error

ValidateBasic Implements sdk.Msg

func (*MsgStoreCode) XXX_DiscardUnknown

func (m *MsgStoreCode) XXX_DiscardUnknown()

func (*MsgStoreCode) XXX_Marshal

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

func (*MsgStoreCode) XXX_Merge

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

func (*MsgStoreCode) XXX_Size

func (m *MsgStoreCode) XXX_Size() int

func (*MsgStoreCode) XXX_Unmarshal

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

type MsgStoreCodeResponse

type MsgStoreCodeResponse struct {
	// CodeID is the reference to the stored WASM code
	CodeID uint64 `protobuf:"varint,1,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty" yaml:"code_id"`
}

MsgStoreCodeResponse defines the Msg/StoreCode response type.

func (*MsgStoreCodeResponse) Descriptor

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

func (*MsgStoreCodeResponse) GetCodeID

func (m *MsgStoreCodeResponse) GetCodeID() uint64

func (*MsgStoreCodeResponse) Marshal

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

func (*MsgStoreCodeResponse) MarshalTo

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

func (*MsgStoreCodeResponse) MarshalToSizedBuffer

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

func (*MsgStoreCodeResponse) ProtoMessage

func (*MsgStoreCodeResponse) ProtoMessage()

func (*MsgStoreCodeResponse) Reset

func (m *MsgStoreCodeResponse) Reset()

func (*MsgStoreCodeResponse) Size

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

func (*MsgStoreCodeResponse) String

func (m *MsgStoreCodeResponse) String() string

func (*MsgStoreCodeResponse) Unmarshal

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

func (*MsgStoreCodeResponse) XXX_DiscardUnknown

func (m *MsgStoreCodeResponse) XXX_DiscardUnknown()

func (*MsgStoreCodeResponse) XXX_Marshal

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

func (*MsgStoreCodeResponse) XXX_Merge

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

func (*MsgStoreCodeResponse) XXX_Size

func (m *MsgStoreCodeResponse) XXX_Size() int

func (*MsgStoreCodeResponse) XXX_Unmarshal

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

type MsgUpdateContractAdmin

type MsgUpdateContractAdmin struct {
	// Admin is the current contract admin
	Admin string `protobuf:"bytes,1,opt,name=admin,proto3" json:"admin,omitempty" yaml:"admin"`
	// NewAdmin is the new contract admin
	NewAdmin string `protobuf:"bytes,2,opt,name=new_admin,json=newAdmin,proto3" json:"new_admin,omitempty" yaml:"new_admin"`
	// Contract is the address of the smart contract
	Contract string `protobuf:"bytes,3,opt,name=contract,proto3" json:"contract,omitempty" yaml:"contract"`
}

MsgUpdateContractAdmin represents a message to sets a new admin for a smart contract

func NewMsgUpdateContractAdmin

func NewMsgUpdateContractAdmin(admin, newAdmin, contract sdk.AccAddress) *MsgUpdateContractAdmin

NewMsgUpdateContractAdmin creates a MsgUpdateContractAdmin instance

func (*MsgUpdateContractAdmin) Descriptor

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

func (MsgUpdateContractAdmin) GetSignBytes

func (msg MsgUpdateContractAdmin) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgUpdateContractAdmin) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgUpdateContractAdmin) Marshal

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

func (*MsgUpdateContractAdmin) MarshalTo

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

func (*MsgUpdateContractAdmin) MarshalToSizedBuffer

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

func (*MsgUpdateContractAdmin) ProtoMessage

func (*MsgUpdateContractAdmin) ProtoMessage()

func (*MsgUpdateContractAdmin) Reset

func (m *MsgUpdateContractAdmin) Reset()

func (MsgUpdateContractAdmin) Route

func (msg MsgUpdateContractAdmin) Route() string

Route implements sdk.Msg

func (*MsgUpdateContractAdmin) Size

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

func (*MsgUpdateContractAdmin) String

func (m *MsgUpdateContractAdmin) String() string

func (MsgUpdateContractAdmin) Type

func (msg MsgUpdateContractAdmin) Type() string

Type implements sdk.Msg

func (*MsgUpdateContractAdmin) Unmarshal

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

func (MsgUpdateContractAdmin) ValidateBasic

func (msg MsgUpdateContractAdmin) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgUpdateContractAdmin) XXX_DiscardUnknown

func (m *MsgUpdateContractAdmin) XXX_DiscardUnknown()

func (*MsgUpdateContractAdmin) XXX_Marshal

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

func (*MsgUpdateContractAdmin) XXX_Merge

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

func (*MsgUpdateContractAdmin) XXX_Size

func (m *MsgUpdateContractAdmin) XXX_Size() int

func (*MsgUpdateContractAdmin) XXX_Unmarshal

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

type MsgUpdateContractAdminResponse

type MsgUpdateContractAdminResponse struct {
}

MsgUpdateContractAdminResponse defines the Msg/UpdateContractAdmin response type.

func (*MsgUpdateContractAdminResponse) Descriptor

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

func (*MsgUpdateContractAdminResponse) Marshal

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

func (*MsgUpdateContractAdminResponse) MarshalTo

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

func (*MsgUpdateContractAdminResponse) MarshalToSizedBuffer

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

func (*MsgUpdateContractAdminResponse) ProtoMessage

func (*MsgUpdateContractAdminResponse) ProtoMessage()

func (*MsgUpdateContractAdminResponse) Reset

func (m *MsgUpdateContractAdminResponse) Reset()

func (*MsgUpdateContractAdminResponse) Size

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

func (*MsgUpdateContractAdminResponse) String

func (*MsgUpdateContractAdminResponse) Unmarshal

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

func (*MsgUpdateContractAdminResponse) XXX_DiscardUnknown

func (m *MsgUpdateContractAdminResponse) XXX_DiscardUnknown()

func (*MsgUpdateContractAdminResponse) XXX_Marshal

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

func (*MsgUpdateContractAdminResponse) XXX_Merge

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

func (*MsgUpdateContractAdminResponse) XXX_Size

func (m *MsgUpdateContractAdminResponse) XXX_Size() int

func (*MsgUpdateContractAdminResponse) XXX_Unmarshal

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

type Params

type Params struct {
	MaxContractSize    uint64 `` /* 134-byte string literal not displayed */
	MaxContractGas     uint64 `` /* 130-byte string literal not displayed */
	MaxContractMsgSize uint64 `` /* 149-byte string literal not displayed */
}

Params defines the parameters for the wasm module.

func DefaultParams

func DefaultParams() Params

DefaultParams creates default treasury module parameters

func (*Params) Descriptor

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

func (*Params) Equal

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

func (*Params) GetMaxContractGas

func (m *Params) GetMaxContractGas() uint64

func (*Params) GetMaxContractMsgSize

func (m *Params) GetMaxContractMsgSize() uint64

func (*Params) GetMaxContractSize

func (m *Params) GetMaxContractSize() uint64

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

ParamSetPairs implements the ParamSet interface and returns all the key/value pairs pairs of treasury module's parameters. nolint

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

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

func (Params) String

func (p Params) String() string

String implements fmt.Stringer interface

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 PortKeeper

type PortKeeper interface {
	BindPort(ctx sdk.Context, portID string) *capabilitytypes.Capability
}

PortKeeper defines the expected IBC port keeper

type Querier

type Querier struct {
	Ctx             sdk.Context
	ContractAddr    sdk.AccAddress
	Queriers        map[string]WasmQuerierInterface
	StargateQuerier StargateWasmQuerierInterface
}

Querier - wasm query handler

func NewWasmQuerier

func NewWasmQuerier() Querier

NewWasmQuerier return wasm querier

func (Querier) GasConsumed

func (q Querier) GasConsumed() uint64

GasConsumed consume gas in the current context

func (Querier) Query

func (q Querier) Query(request wasmvmtypes.QueryRequest, gasLimit uint64) ([]byte, error)

Query - interface for wasmvmtypes.Querier

func (Querier) WithContractAddr

func (q Querier) WithContractAddr(contractAddr sdk.AccAddress) Querier

WithContractAddr returns new querier with contractAddr

func (Querier) WithCtx

func (q Querier) WithCtx(ctx sdk.Context) Querier

WithCtx returns new querier with context

type QueryByteCodeRequest

type QueryByteCodeRequest struct {
	// grpc-gateway_out does not support Go style CodID
	CodeId uint64 `protobuf:"varint,1,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty"`
}

QueryByteCodeRequest is the request type for the QueryyByteCode RPC method.

func (*QueryByteCodeRequest) Descriptor

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

func (*QueryByteCodeRequest) Marshal

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

func (*QueryByteCodeRequest) MarshalTo

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

func (*QueryByteCodeRequest) MarshalToSizedBuffer

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

func (*QueryByteCodeRequest) ProtoMessage

func (*QueryByteCodeRequest) ProtoMessage()

func (*QueryByteCodeRequest) Reset

func (m *QueryByteCodeRequest) Reset()

func (*QueryByteCodeRequest) Size

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

func (*QueryByteCodeRequest) String

func (m *QueryByteCodeRequest) String() string

func (*QueryByteCodeRequest) Unmarshal

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

func (*QueryByteCodeRequest) XXX_DiscardUnknown

func (m *QueryByteCodeRequest) XXX_DiscardUnknown()

func (*QueryByteCodeRequest) XXX_Marshal

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

func (*QueryByteCodeRequest) XXX_Merge

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

func (*QueryByteCodeRequest) XXX_Size

func (m *QueryByteCodeRequest) XXX_Size() int

func (*QueryByteCodeRequest) XXX_Unmarshal

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

type QueryByteCodeResponse

type QueryByteCodeResponse struct {
	ByteCode []byte `protobuf:"bytes,1,opt,name=byte_code,json=byteCode,proto3" json:"byte_code,omitempty"`
}

QueryByteCodeResponse is response type for the QueryyByteCode RPC method.

func (*QueryByteCodeResponse) Descriptor

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

func (*QueryByteCodeResponse) GetByteCode

func (m *QueryByteCodeResponse) GetByteCode() []byte

func (*QueryByteCodeResponse) Marshal

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

func (*QueryByteCodeResponse) MarshalTo

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

func (*QueryByteCodeResponse) MarshalToSizedBuffer

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

func (*QueryByteCodeResponse) ProtoMessage

func (*QueryByteCodeResponse) ProtoMessage()

func (*QueryByteCodeResponse) Reset

func (m *QueryByteCodeResponse) Reset()

func (*QueryByteCodeResponse) Size

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

func (*QueryByteCodeResponse) String

func (m *QueryByteCodeResponse) String() string

func (*QueryByteCodeResponse) Unmarshal

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

func (*QueryByteCodeResponse) XXX_DiscardUnknown

func (m *QueryByteCodeResponse) XXX_DiscardUnknown()

func (*QueryByteCodeResponse) XXX_Marshal

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

func (*QueryByteCodeResponse) XXX_Merge

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

func (*QueryByteCodeResponse) XXX_Size

func (m *QueryByteCodeResponse) XXX_Size() int

func (*QueryByteCodeResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	// CodeInfo returns the stored code info
	CodeInfo(ctx context.Context, in *QueryCodeInfoRequest, opts ...grpc.CallOption) (*QueryCodeInfoResponse, error)
	// ByteCode returns the stored byte code
	ByteCode(ctx context.Context, in *QueryByteCodeRequest, opts ...grpc.CallOption) (*QueryByteCodeResponse, error)
	// ContractInfo returns the stored contract info
	ContractInfo(ctx context.Context, in *QueryContractInfoRequest, opts ...grpc.CallOption) (*QueryContractInfoResponse, error)
	// ContractStore return smart query result from the contract
	ContractStore(ctx context.Context, in *QueryContractStoreRequest, opts ...grpc.CallOption) (*QueryContractStoreResponse, error)
	// RawStore return single key from the raw store data of a contract
	RawStore(ctx context.Context, in *QueryRawStoreRequest, opts ...grpc.CallOption) (*QueryRawStoreResponse, error)
	// Params queries all parameters.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, 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 QueryCodeIDParams

type QueryCodeIDParams struct {
	CodeID uint64
}

QueryCodeIDParams defines the params for the following queries: - 'custom/wasm/codeInfo - 'custom/wasm/bytecode

func NewQueryCodeIDParams

func NewQueryCodeIDParams(codeID uint64) QueryCodeIDParams

NewQueryCodeIDParams returns QueryCodeIDParams instance

type QueryCodeInfoRequest

type QueryCodeInfoRequest struct {
	// grpc-gateway_out does not support Go style CodID
	CodeId uint64 `protobuf:"varint,1,opt,name=code_id,json=codeId,proto3" json:"code_id,omitempty"`
}

QueryCodeInfoRequest is the request type for the QueryyCodeInfo RPC method.

func (*QueryCodeInfoRequest) Descriptor

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

func (*QueryCodeInfoRequest) Marshal

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

func (*QueryCodeInfoRequest) MarshalTo

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

func (*QueryCodeInfoRequest) MarshalToSizedBuffer

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

func (*QueryCodeInfoRequest) ProtoMessage

func (*QueryCodeInfoRequest) ProtoMessage()

func (*QueryCodeInfoRequest) Reset

func (m *QueryCodeInfoRequest) Reset()

func (*QueryCodeInfoRequest) Size

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

func (*QueryCodeInfoRequest) String

func (m *QueryCodeInfoRequest) String() string

func (*QueryCodeInfoRequest) Unmarshal

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

func (*QueryCodeInfoRequest) XXX_DiscardUnknown

func (m *QueryCodeInfoRequest) XXX_DiscardUnknown()

func (*QueryCodeInfoRequest) XXX_Marshal

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

func (*QueryCodeInfoRequest) XXX_Merge

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

func (*QueryCodeInfoRequest) XXX_Size

func (m *QueryCodeInfoRequest) XXX_Size() int

func (*QueryCodeInfoRequest) XXX_Unmarshal

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

type QueryCodeInfoResponse

type QueryCodeInfoResponse struct {
	CodeInfo CodeInfo `protobuf:"bytes,1,opt,name=code_info,json=codeInfo,proto3" json:"code_info"`
}

QueryCodeInfoResponse is response type for the QueryyCodeInfo RPC method.

func (*QueryCodeInfoResponse) Descriptor

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

func (*QueryCodeInfoResponse) GetCodeInfo

func (m *QueryCodeInfoResponse) GetCodeInfo() CodeInfo

func (*QueryCodeInfoResponse) Marshal

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

func (*QueryCodeInfoResponse) MarshalTo

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

func (*QueryCodeInfoResponse) MarshalToSizedBuffer

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

func (*QueryCodeInfoResponse) ProtoMessage

func (*QueryCodeInfoResponse) ProtoMessage()

func (*QueryCodeInfoResponse) Reset

func (m *QueryCodeInfoResponse) Reset()

func (*QueryCodeInfoResponse) Size

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

func (*QueryCodeInfoResponse) String

func (m *QueryCodeInfoResponse) String() string

func (*QueryCodeInfoResponse) Unmarshal

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

func (*QueryCodeInfoResponse) XXX_DiscardUnknown

func (m *QueryCodeInfoResponse) XXX_DiscardUnknown()

func (*QueryCodeInfoResponse) XXX_Marshal

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

func (*QueryCodeInfoResponse) XXX_Merge

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

func (*QueryCodeInfoResponse) XXX_Size

func (m *QueryCodeInfoResponse) XXX_Size() int

func (*QueryCodeInfoResponse) XXX_Unmarshal

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

type QueryContractAddressParams

type QueryContractAddressParams struct {
	ContractAddress sdk.AccAddress
}

QueryContractAddressParams defines the params for the following queries: - 'custom/wasm/contractInfo

func NewQueryContractAddressParams

func NewQueryContractAddressParams(contractAddress sdk.AccAddress) QueryContractAddressParams

NewQueryContractAddressParams returns QueryContractAddressParams instance

type QueryContractInfoRequest

type QueryContractInfoRequest struct {
	ContractAddress string `protobuf:"bytes,1,opt,name=contract_address,json=contractAddress,proto3" json:"contract_address,omitempty"`
}

QueryContractInfoRequest is the request type for the Query/ContractInfo RPC method.

func (*QueryContractInfoRequest) Descriptor

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

func (*QueryContractInfoRequest) Marshal

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

func (*QueryContractInfoRequest) MarshalTo

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

func (*QueryContractInfoRequest) MarshalToSizedBuffer

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

func (*QueryContractInfoRequest) ProtoMessage

func (*QueryContractInfoRequest) ProtoMessage()

func (*QueryContractInfoRequest) Reset

func (m *QueryContractInfoRequest) Reset()

func (*QueryContractInfoRequest) Size

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

func (*QueryContractInfoRequest) String

func (m *QueryContractInfoRequest) String() string

func (*QueryContractInfoRequest) Unmarshal

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

func (*QueryContractInfoRequest) XXX_DiscardUnknown

func (m *QueryContractInfoRequest) XXX_DiscardUnknown()

func (*QueryContractInfoRequest) XXX_Marshal

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

func (*QueryContractInfoRequest) XXX_Merge

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

func (*QueryContractInfoRequest) XXX_Size

func (m *QueryContractInfoRequest) XXX_Size() int

func (*QueryContractInfoRequest) XXX_Unmarshal

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

type QueryContractInfoResponse

type QueryContractInfoResponse struct {
	ContractInfo ContractInfo `protobuf:"bytes,1,opt,name=contract_info,json=contractInfo,proto3" json:"contract_info"`
}

QueryContractInfoResponse is response type for the Query/ContractInfo RPC method.

func (*QueryContractInfoResponse) Descriptor

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

func (*QueryContractInfoResponse) GetContractInfo

func (m *QueryContractInfoResponse) GetContractInfo() ContractInfo

func (*QueryContractInfoResponse) Marshal

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

func (*QueryContractInfoResponse) MarshalTo

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

func (*QueryContractInfoResponse) MarshalToSizedBuffer

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

func (*QueryContractInfoResponse) ProtoMessage

func (*QueryContractInfoResponse) ProtoMessage()

func (*QueryContractInfoResponse) Reset

func (m *QueryContractInfoResponse) Reset()

func (*QueryContractInfoResponse) Size

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

func (*QueryContractInfoResponse) String

func (m *QueryContractInfoResponse) String() string

func (*QueryContractInfoResponse) Unmarshal

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

func (*QueryContractInfoResponse) XXX_DiscardUnknown

func (m *QueryContractInfoResponse) XXX_DiscardUnknown()

func (*QueryContractInfoResponse) XXX_Marshal

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

func (*QueryContractInfoResponse) XXX_Merge

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

func (*QueryContractInfoResponse) XXX_Size

func (m *QueryContractInfoResponse) XXX_Size() int

func (*QueryContractInfoResponse) XXX_Unmarshal

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

type QueryContractParams

type QueryContractParams struct {
	ContractAddress sdk.AccAddress
	Msg             []byte
}

QueryContractParams defines the params for the following queries: - 'custom/wasm/contractStore'

func NewQueryContractParams

func NewQueryContractParams(contractAddress sdk.AccAddress, msg []byte) QueryContractParams

NewQueryContractParams returns QueryContractParams instance

type QueryContractStoreRequest

type QueryContractStoreRequest struct {
	ContractAddress string                   `protobuf:"bytes,1,opt,name=contract_address,json=contractAddress,proto3" json:"contract_address,omitempty"`
	QueryMsg        encoding_json.RawMessage `protobuf:"bytes,2,opt,name=query_msg,json=queryMsg,proto3,casttype=encoding/json.RawMessage" json:"query_msg,omitempty"`
}

QueryContractStoreRequest is the request type for the Query/ContractStore RPC method.

func (*QueryContractStoreRequest) Descriptor

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

func (*QueryContractStoreRequest) Marshal

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

func (*QueryContractStoreRequest) MarshalTo

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

func (*QueryContractStoreRequest) MarshalToSizedBuffer

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

func (*QueryContractStoreRequest) ProtoMessage

func (*QueryContractStoreRequest) ProtoMessage()

func (*QueryContractStoreRequest) Reset

func (m *QueryContractStoreRequest) Reset()

func (*QueryContractStoreRequest) Size

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

func (*QueryContractStoreRequest) String

func (m *QueryContractStoreRequest) String() string

func (*QueryContractStoreRequest) Unmarshal

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

func (*QueryContractStoreRequest) XXX_DiscardUnknown

func (m *QueryContractStoreRequest) XXX_DiscardUnknown()

func (*QueryContractStoreRequest) XXX_Marshal

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

func (*QueryContractStoreRequest) XXX_Merge

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

func (*QueryContractStoreRequest) XXX_Size

func (m *QueryContractStoreRequest) XXX_Size() int

func (*QueryContractStoreRequest) XXX_Unmarshal

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

type QueryContractStoreResponse

type QueryContractStoreResponse struct {
	QueryResult encoding_json.RawMessage `` /* 128-byte string literal not displayed */
}

QueryContractStoreResponse is response type for the Query/ContractStore RPC method.

func (*QueryContractStoreResponse) Descriptor

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

func (*QueryContractStoreResponse) GetQueryResult

func (*QueryContractStoreResponse) Marshal

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

func (*QueryContractStoreResponse) MarshalTo

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

func (*QueryContractStoreResponse) MarshalToSizedBuffer

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

func (*QueryContractStoreResponse) ProtoMessage

func (*QueryContractStoreResponse) ProtoMessage()

func (*QueryContractStoreResponse) Reset

func (m *QueryContractStoreResponse) Reset()

func (*QueryContractStoreResponse) Size

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

func (*QueryContractStoreResponse) String

func (m *QueryContractStoreResponse) String() string

func (*QueryContractStoreResponse) Unmarshal

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

func (*QueryContractStoreResponse) XXX_DiscardUnknown

func (m *QueryContractStoreResponse) XXX_DiscardUnknown()

func (*QueryContractStoreResponse) XXX_Marshal

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

func (*QueryContractStoreResponse) XXX_Merge

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

func (*QueryContractStoreResponse) XXX_Size

func (m *QueryContractStoreResponse) XXX_Size() int

func (*QueryContractStoreResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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

func (*QueryParamsRequest) Descriptor

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

func (*QueryParamsRequest) Marshal

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

func (*QueryParamsRequest) MarshalTo

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

func (*QueryParamsRequest) MarshalToSizedBuffer

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

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

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

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

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

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

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

func (*QueryParamsRequest) XXX_Merge

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

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

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

type QueryParamsResponse

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

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

func (*QueryParamsResponse) Descriptor

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

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

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

func (*QueryParamsResponse) MarshalTo

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

func (*QueryParamsResponse) MarshalToSizedBuffer

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

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

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

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

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

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

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

func (*QueryParamsResponse) XXX_Merge

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

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

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

type QueryRawStoreParams

type QueryRawStoreParams struct {
	ContractAddress sdk.AccAddress
	Key             []byte
}

QueryRawStoreParams defines the params for the following queries: - 'custom/wasm/rawStore'

func NewQueryRawStoreParams

func NewQueryRawStoreParams(contractAddress sdk.AccAddress, key []byte) QueryRawStoreParams

NewQueryRawStoreParams returns QueryRawStoreParams instance

type QueryRawStoreRequest

type QueryRawStoreRequest struct {
	ContractAddress string `protobuf:"bytes,1,opt,name=contract_address,json=contractAddress,proto3" json:"contract_address,omitempty"`
	Key             []byte `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"`
}

QueryRawStoreRequest is the request type for the Query/RawStore RPC method.

func (*QueryRawStoreRequest) Descriptor

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

func (*QueryRawStoreRequest) Marshal

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

func (*QueryRawStoreRequest) MarshalTo

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

func (*QueryRawStoreRequest) MarshalToSizedBuffer

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

func (*QueryRawStoreRequest) ProtoMessage

func (*QueryRawStoreRequest) ProtoMessage()

func (*QueryRawStoreRequest) Reset

func (m *QueryRawStoreRequest) Reset()

func (*QueryRawStoreRequest) Size

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

func (*QueryRawStoreRequest) String

func (m *QueryRawStoreRequest) String() string

func (*QueryRawStoreRequest) Unmarshal

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

func (*QueryRawStoreRequest) XXX_DiscardUnknown

func (m *QueryRawStoreRequest) XXX_DiscardUnknown()

func (*QueryRawStoreRequest) XXX_Marshal

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

func (*QueryRawStoreRequest) XXX_Merge

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

func (*QueryRawStoreRequest) XXX_Size

func (m *QueryRawStoreRequest) XXX_Size() int

func (*QueryRawStoreRequest) XXX_Unmarshal

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

type QueryRawStoreResponse

type QueryRawStoreResponse struct {
	// Data contains the raw store data
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
}

QueryRawStoreResponse is response type for the Query/RawStore RPC method.

func (*QueryRawStoreResponse) Descriptor

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

func (*QueryRawStoreResponse) GetData

func (m *QueryRawStoreResponse) GetData() []byte

func (*QueryRawStoreResponse) Marshal

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

func (*QueryRawStoreResponse) MarshalTo

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

func (*QueryRawStoreResponse) MarshalToSizedBuffer

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

func (*QueryRawStoreResponse) ProtoMessage

func (*QueryRawStoreResponse) ProtoMessage()

func (*QueryRawStoreResponse) Reset

func (m *QueryRawStoreResponse) Reset()

func (*QueryRawStoreResponse) Size

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

func (*QueryRawStoreResponse) String

func (m *QueryRawStoreResponse) String() string

func (*QueryRawStoreResponse) Unmarshal

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

func (*QueryRawStoreResponse) XXX_DiscardUnknown

func (m *QueryRawStoreResponse) XXX_DiscardUnknown()

func (*QueryRawStoreResponse) XXX_Marshal

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

func (*QueryRawStoreResponse) XXX_Merge

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

func (*QueryRawStoreResponse) XXX_Size

func (m *QueryRawStoreResponse) XXX_Size() int

func (*QueryRawStoreResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	// CodeInfo returns the stored code info
	CodeInfo(context.Context, *QueryCodeInfoRequest) (*QueryCodeInfoResponse, error)
	// ByteCode returns the stored byte code
	ByteCode(context.Context, *QueryByteCodeRequest) (*QueryByteCodeResponse, error)
	// ContractInfo returns the stored contract info
	ContractInfo(context.Context, *QueryContractInfoRequest) (*QueryContractInfoResponse, error)
	// ContractStore return smart query result from the contract
	ContractStore(context.Context, *QueryContractStoreRequest) (*QueryContractStoreResponse, error)
	// RawStore return single key from the raw store data of a contract
	RawStore(context.Context, *QueryRawStoreRequest) (*QueryRawStoreResponse, error)
	// Params queries all parameters.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
}

QueryServer is the server API for Query service.

type StargateWasmMsgParserInterface

type StargateWasmMsgParserInterface interface {
	Parse(msg wasmvmtypes.CosmosMsg) (sdk.Msg, error)
}

StargateWasmMsgParserInterface - stargate msg parsers

type StargateWasmQuerierInterface

type StargateWasmQuerierInterface interface {
	Query(ctx sdk.Context, request wasmvmtypes.QueryRequest) ([]byte, error)
}

StargateWasmQuerierInterface - query registration interface for stargate querier

type Store added in v0.5.16

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

Store applies gas tracking to an underlying KVStore. It implements the KVStore interface.

func NewStore added in v0.5.16

func NewStore(parent types.KVStore, gasMeter types.GasMeter, gasConfig types.GasConfig) *Store

NewStore returns a reference to a new GasKVStore.

func (*Store) CacheWrap added in v0.5.16

func (gs *Store) CacheWrap() types.CacheWrap

CacheWrap implements KVStore.

func (*Store) CacheWrapWithListeners added in v0.5.16

func (gs *Store) CacheWrapWithListeners(_ types.StoreKey, _ []types.WriteListener) types.CacheWrap

CacheWrapWithListeners implements the CacheWrapper interface.

func (*Store) CacheWrapWithTrace added in v0.5.16

func (gs *Store) CacheWrapWithTrace(_ io.Writer, _ types.TraceContext) types.CacheWrap

CacheWrapWithTrace implements the KVStore interface.

func (*Store) Delete added in v0.5.16

func (gs *Store) Delete(key []byte)

Delete implements KVStore.

func (*Store) Get added in v0.5.16

func (gs *Store) Get(key []byte) (value []byte)

Get implements KVStore.

func (*Store) GetStoreType added in v0.5.16

func (gs *Store) GetStoreType() types.StoreType

GetStoreType implements Store.

func (*Store) Has added in v0.5.16

func (gs *Store) Has(key []byte) bool

Has implements KVStore.

func (*Store) Iterator added in v0.5.16

func (gs *Store) Iterator(start, end []byte) types.Iterator

Iterator implements the KVStore interface. It returns an iterator which incurs a flat gas cost for seeking to the first key/value pair and a variable gas cost based on the current value's length if the iterator is valid.

func (*Store) ReverseIterator added in v0.5.16

func (gs *Store) ReverseIterator(start, end []byte) types.Iterator

ReverseIterator implements the KVStore interface. It returns a reverse iterator which incurs a flat gas cost for seeking to the first key/value pair and a variable gas cost based on the current value's length if the iterator is valid.

func (*Store) Set added in v0.5.16

func (gs *Store) Set(key []byte, value []byte)

Set implements KVStore.

type TreasuryKeeper

type TreasuryKeeper interface {
	RecordEpochTaxProceeds(ctx sdk.Context, delta sdk.Coins)
	GetTaxRate(ctx sdk.Context) (taxRate sdk.Dec)
	GetTaxCap(ctx sdk.Context, denom string) (taxCap sdk.Int)
}

TreasuryKeeper - expected treasury keeper

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) ClearContractAdmin

func (*UnimplementedMsgServer) ExecuteContract

func (*UnimplementedMsgServer) InstantiateContract

func (*UnimplementedMsgServer) MigrateCode

func (*UnimplementedMsgServer) MigrateContract

func (*UnimplementedMsgServer) StoreCode

func (*UnimplementedMsgServer) UpdateContractAdmin

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) ByteCode

func (*UnimplementedQueryServer) CodeInfo

func (*UnimplementedQueryServer) ContractInfo

func (*UnimplementedQueryServer) ContractStore

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) RawStore

type WasmCustomMsg

type WasmCustomMsg struct {
	Route   string          `json:"route"`
	MsgData json.RawMessage `json:"msg_data"`
}

WasmCustomMsg - wasm custom msg parser

type WasmCustomQuery

type WasmCustomQuery struct {
	Route     string          `json:"route"`
	QueryData json.RawMessage `json:"query_data"`
}

WasmCustomQuery - wasm custom query

type WasmMsgParserInterface

type WasmMsgParserInterface interface {
	Parse(contractAddr sdk.AccAddress, msg wasmvmtypes.CosmosMsg) (sdk.Msg, error)
	ParseCustom(contractAddr sdk.AccAddress, data json.RawMessage) (sdk.Msg, error)
}

WasmMsgParserInterface - msg parsers of each module

type WasmQuerierInterface

type WasmQuerierInterface interface {
	Query(ctx sdk.Context, request wasmvmtypes.QueryRequest) ([]byte, error)
	QueryCustom(ctx sdk.Context, data json.RawMessage) ([]byte, error)
}

WasmQuerierInterface - query registration interface for other modules

type WasmerEngine

type WasmerEngine interface {

	// Create will compile the wasm code, and store the resulting pre-compile
	// as well as the original code. Both can be referenced later via CodeID
	// This must be done one time for given code, after which it can be
	// instantiated many times, and each instance called many times.
	//
	// For example, the code for all ERC-20 contracts should be the same.
	// This function stores the code for that contract only once, but it can
	// be instantiated with custom inputs in the future.
	Create(code wasmvm.WasmCode) (wasmvm.Checksum, error)

	// AnalyzeCode will statically analyze the code.
	// Reports if it exposes all IBC entry points and required features.
	AnalyzeCode(checksum wasmvm.Checksum) (*wasmvmtypes.AnalysisReport, error)

	// Instantiate will create a new contract based on the given codeID.
	// We can set the initMsg (contract "genesis") here, and it then receives
	// an account and address and can be invoked (Execute) many times.
	//
	// Storage should be set with a PrefixedKVStore that this code can safely access.
	//
	// Under the hood, we may recompile the wasm, use a cached native compile, or even use a cached instance
	// for performance.
	Instantiate(
		code wasmvm.Checksum,
		env wasmvmtypes.Env,
		info wasmvmtypes.MessageInfo,
		initMsg []byte,
		store wasmvm.KVStore,
		goapi wasmvm.GoAPI,
		querier wasmvm.Querier,
		gasMeter wasmvm.GasMeter,
		gasLimit uint64,
		deserializeCost wasmvmtypes.UFraction,
	) (*wasmvmtypes.Response, uint64, error)

	// Execute calls a given contract. Since the only difference between contracts with the same CodeID is the
	// data in their local storage, and their address in the outside world, we need no ContractID here.
	// (That is a detail for the external, sdk-facing, side).
	//
	// The caller is responsible for passing the correct `store` (which must have been initialized exactly once),
	// and setting the env with relevant info on this instance (address, balance, etc)
	Execute(
		code wasmvm.Checksum,
		env wasmvmtypes.Env,
		info wasmvmtypes.MessageInfo,
		executeMsg []byte,
		store wasmvm.KVStore,
		goapi wasmvm.GoAPI,
		querier wasmvm.Querier,
		gasMeter wasmvm.GasMeter,
		gasLimit uint64,
		deserializeCost wasmvmtypes.UFraction,
	) (*wasmvmtypes.Response, uint64, error)

	// Query allows a client to execute a contract-specific query. If the result is not empty, it should be
	// valid json-encoded data to return to the client.
	// The meaning of path and data can be determined by the code. Path is the suffix of the abci.QueryRequest.Path
	Query(
		code wasmvm.Checksum,
		env wasmvmtypes.Env,
		queryMsg []byte,
		store wasmvm.KVStore,
		goapi wasmvm.GoAPI,
		querier wasmvm.Querier,
		gasMeter wasmvm.GasMeter,
		gasLimit uint64,
		deserializeCost wasmvmtypes.UFraction,
	) ([]byte, uint64, error)

	// Migrate will migrate an existing contract to a new code binary.
	// This takes storage of the data from the original contract and the CodeID of the new contract that should
	// replace it. This allows it to run a migration step if needed, or return an error if unable to migrate
	// the given data.
	//
	// MigrateMsg has some data on how to perform the migration.
	Migrate(
		codeID wasmvm.Checksum,
		env wasmvmtypes.Env,
		migrateMsg []byte,
		store wasmvm.KVStore,
		goapi wasmvm.GoAPI,
		querier wasmvm.Querier,
		gasMeter wasmvm.GasMeter,
		gasLimit uint64,
		deserializeCost wasmvmtypes.UFraction,
	) (*wasmvmtypes.Response, uint64, error)

	// Reply is called on the original dispatching contract after running a submessage
	Reply(
		codeID wasmvm.Checksum,
		env wasmvmtypes.Env,
		reply wasmvmtypes.Reply,
		store wasmvm.KVStore,
		goapi wasmvm.GoAPI,
		querier wasmvm.Querier,
		gasMeter wasmvm.GasMeter,
		gasLimit uint64,
		deserializeCost wasmvmtypes.UFraction,
	) (*wasmvmtypes.Response, uint64, error)

	// GetCode will load the original wasm code for the given code id.
	// This will only succeed if that code id was previously returned from
	// a call to Create.
	//
	// This can be used so that the (short) code id (hash) is stored in the iavl tree
	// and the larger binary blobs (wasm and pre-compiles) are all managed by the
	// rust library
	GetCode(code wasmvm.Checksum) (wasmvm.WasmCode, error)

	// Cleanup should be called when no longer using this to free resources on the rust-side
	Cleanup()
}

WasmerEngine defines the WASM contract runtime engine.

Jump to

Keyboard shortcuts

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