types

package
v0.5.0 Latest Latest
Warning

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

Go to latest
Published: Mar 26, 2024 License: Apache-2.0 Imports: 47 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	EventTypeTimeout                   = "timeout"
	EventTypeRequestAggrKeysharePacket = "requestAggrKeyshare_packet"
	EventTypeGetAggrKeysharePacket     = "getAggrKeyshare_packet"
	EventTypeAggrKeyshareDataPacket    = "aggrKeyshareData_packet"

	AttributeKeyAckSuccess = "success"
	AttributeKeyAck        = "acknowledgement"
	AttributeKeyAckError   = "error"

	AttributeKeyAckIdentity = "identity"
	AttributeKeyAckPubkey   = "pubkey"
)

IBC events

View Source
const (
	// AggregatedKeyShareKeyPrefix is the prefix to retrieve all AggregatedKeyShare
	AggregatedKeyShareKeyPrefix    = "AggregatedKeyShare/value/"
	AggregatedKeyShareLengthPrefix = "AggregatedKeyShare/length/"
)
View Source
const (
	// AuthorizedAddressKeyPrefix is the prefix to retrieve all AuthorizedAddress
	AuthorizedAddressKeyPrefix = "AuthorizedAddress/value/"

	AuthorizedCountKeyPrefix = "AuthorizedCount/value/"
)
View Source
const (
	// ActiveCommitmentsPrefix is the prefix to retrieve the active Commitments
	ActiveCommitmentsPrefix = "ActiveCommitments/value/"

	// QueuedCommitmentsPrefix is the prefix to retrieve the queued Commitments
	QueuedCommitmentsPrefix = "QueuedCommitments/value/"
)
View Source
const (
	// ActivePubKeyPrefix is the prefix to retrieve the active Public Key
	ActivePubKeyPrefix = "ActivePubKey/value/"

	QueuedPubKeyPrefix = "QueuedPubKey/value/"
)
View Source
const (
	// ModuleName defines the module name
	ModuleName = "keyshare"

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

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

	// MemStoreKey defines the in-memory store key
	MemStoreKey = "mem_keyshare"

	// Version defines the current version the IBC module supports
	Version = "keyshare-1"

	// PortID is the default port id that module binds to
	PortID = "keyshare"

	// ChannelID is the default channel id that module will use to transmit IBC packets.
	ChannelID = "channel-0"
)
View Source
const (
	KeyAggregationThresholdNumerator   = 2
	KeyAggregationThresholdDenominator = 3
)
View Source
const (
	RegisteredValidatorEventType    = "new-validator-registered"
	RegisteredValidatorEventCreator = "creator"
)
View Source
const (
	DeRegisteredValidatorEventType    = "validator-deregistered"
	DeRegisteredValidatorEventCreator = "creator"
)
View Source
const (
	SendKeyshareEventType                = "keyshare-sent"
	SendKeyshareEventValidator           = "validator"
	SendKeyshareEventKeyshareBlockHeight = "keyshare-height"
	SendKeyshareEventReceivedBlockHeight = "received-height"
	SendKeyshareEventMessage             = "message"
	SendKeyshareEventIndex               = "index"
)
View Source
const (
	StartSendGeneralKeyShareEventType     = "start-send-general-keyshare"
	StartSendGeneralKeyShareEventIdentity = "identity"
)
View Source
const (
	SendGeneralKeyshareEventType                = "keyshare-sent"
	SendGeneralKeyshareEventValidator           = "validator"
	SendGeneralKeyshareEventReceivedBlockHeight = "received-height"
	SendGeneralKeyshareEventMessage             = "message"
	SendGeneralKeyshareEventIDType              = "id-type"
	SendGeneralKeyshareEventIdValue             = "id-value"
	SendGeneralKeyshareEventIndex               = "index"
)
View Source
const (
	KeyShareAggregatedEventType        = "keyshare-aggregated"
	KeyShareAggregatedEventBlockHeight = "height"
	KeyShareAggregatedEventData        = "data"
	KeyShareAggregatedEventPubKey      = "pubkey"
)
View Source
const (
	GeneralKeyShareAggregatedEventType    = "general-keyshare-aggregated"
	GeneralKeyShareAggregatedEventIDValue = "id-value"
	GeneralKeyShareAggregatedEventIDType  = "id-type"
	GeneralKeyShareAggregatedEventData    = "data"
	GeneralKeyShareAggregatedEventPubKey  = "pubkey"
)
View Source
const (
	QueuedPubKeyCreatedEventType                     = "queued-pubkey-created"
	QueuedPubKeyCreatedEventActivePubkeyExpiryHeight = "active-pubkey-expiry-height"
	QueuedPubKeyCreatedEventExpiryHeight             = "expiry-height"
	QueuedPubKeyCreatedEventCreator                  = "creator"
	QueuedPubKeyCreatedEventPubkey                   = "pubkey"
	QueuedPubKeyCreatedEventNumberOfValidators       = "number-of-validators"
	QueuedPubKeyCreatedEventEncryptedShares          = "encrypted-shares"
)
View Source
const (
	PubKeyOverrodeEventType                     = "pubkey-overrode"
	PubKeyOverrodeEventActivePubkeyExpiryHeight = "active-pubkey-expiry-height"
	PubKeyOverrodeEventExpiryHeight             = "expiry-height"
	PubKeyOverrodeEventCreator                  = "creator"
	PubKeyOverrodeEventPubkey                   = "pubkey"
	PubKeyOverrodeEventNumberOfValidators       = "number-of-validators"
	PubKeyOverrodeEventEncryptedShares          = "encrypted-shares"
)
View Source
const (
	KeyTotalIdleValSlashed           = "total_idle_validator_slashed"
	KeyTotalValidKeyShareSubmitted   = "total_valid_key_share"
	KeyTotalInvalidKeyShareSubmitted = "total_invalid_key_share"
)
View Source
const (
	TypeMsgSendKeyshare = "send_keyshare"
	KeyShareHexLen      = 192
)
View Source
const (
	TypeMsgCreateAuthorizedAddress = "create_authorized_address"
	TypeMsgUpdateAuthorizedAddress = "update_authorized_address"
	TypeMsgDeleteAuthorizedAddress = "delete_authorized_address"
)
View Source
const (
	TypeMsgCreateLatestPubKeyID = "create_latest_pub_key"
	PubKeyHexLength             = 96
	CommitmentHexLength         = 96
)
View Source
const DefaultIndex uint64 = 1

DefaultIndex is the default global index

View Source
const (
	// GeneralKeyShareKeyPrefix is the prefix to retrieve all GeneralKeyShare
	GeneralKeyShareKeyPrefix = "GeneralKeyShare/value/"
)
View Source
const (
	// KeyLastSubmittedHeightPrefix is the prefix to retrieve all LastSubmittedHeight
	KeyLastSubmittedHeightPrefix = "LastSubmittedHeight/value/"
)
View Source
const (
	// KeyShareKeyPrefix is the prefix to retrieve all KeyShare
	KeyShareKeyPrefix = "KeyShare/value/"
)
View Source
const (
	// KeyShareRequestKeyPrefix is the prefix to retrieve all Keyshare requests
	KeyShareRequestKeyPrefix = "KeyshareRequest/value/"
)
View Source
const (
	SlashPower int64 = 100
)
View Source
const (
	TypeMsgCreateGeneralKeyShare = "create_general_key_share"
)
View Source
const TypeMsgDeRegisterValidator = "deregister_validator"
View Source
const (
	TypeMsgOverrideLatestPubKeyID = "override_latest_pub_key"
)
View Source
const TypeMsgRegisterValidator = "register_validator"
View Source
const (
	// ValidatorSetKeyPrefix is the prefix to retrieve all ValidatorSet
	ValidatorSetKeyPrefix = "ValidatorSet/value/"
)

Variables

View Source
var (
	ErrInvalidLengthAggregatedKeyShare        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowAggregatedKeyShare          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupAggregatedKeyShare = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthAuthorizedAddress        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowAuthorizedAddress          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupAuthorizedAddress = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthCommitments        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowCommitments          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupCommitments = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrValidatorAlreadyRegistered      = sdkerrors.Register(ModuleName, 1101, "validator already registered")
	ErrValidatorNotRegistered          = sdkerrors.Register(ModuleName, 1102, "validator not registered")
	ErrInvalidBlockHeight              = sdkerrors.Register(ModuleName, 1103, "invalid block height")
	ErrDecodingKeyShare                = sdkerrors.Register(ModuleName, 1104, "error decoding keyshare")
	ErrUnmarshallingKeyShare           = sdkerrors.Register(ModuleName, 1105, "error unmarshalling keyshare")
	ErrDecodingCommitment              = sdkerrors.Register(ModuleName, 1106, "error decoding commitment")
	ErrUnmarshallingCommitment         = sdkerrors.Register(ModuleName, 1107, "error unmarhsalling commitment")
	ErrUnableToVerifyShare             = sdkerrors.Register(ModuleName, 1108, "unable to verify share")
	ErrInvalidShare                    = sdkerrors.Register(ModuleName, 1109, "invalid share / commitment")
	ErrPubKeyNotFound                  = sdkerrors.Register(ModuleName, 1110, "Public key does not exists now")
	ErrQueuedKeyAlreadyExists          = sdkerrors.Register(ModuleName, 1111, "a queued key already exists")
	ErrAccountNotStaking               = sdkerrors.Register(ModuleName, 1112, "account is not staking")
	ErrAddressNotTrusted               = sdkerrors.Register(ModuleName, 1113, "address is not trusted")
	ErrInsufficientBondedAmount        = sdkerrors.Register(ModuleName, 1114, "insufficient bonded amount to be a validator")
	ErrEmptyCommitments                = sdkerrors.Register(ModuleName, 1115, "provided commitments are empty")
	ErrCommitmentsNotFound             = sdkerrors.Register(ModuleName, 1116, "commitments not found")
	ErrInvalidKeyShareIndex            = sdkerrors.Register(ModuleName, 1117, "invalid KeyShare index")
	ErrInvalidKeyShareLength           = sdkerrors.Register(ModuleName, 1118, "invalid KeyShare length")
	ErrInvalidPubKeyLength             = sdkerrors.Register(ModuleName, 1119, "invalid PubKey length")
	ErrInvalidPubKey                   = sdkerrors.Register(ModuleName, 1120, "invalid PubKey")
	ErrInvalidCommitment               = sdkerrors.Register(ModuleName, 1121, "invalid commitment")
	ErrInvalidCommitmentLength         = sdkerrors.Register(ModuleName, 1122, "invalid commitment length")
	ErrInvalidVersion                  = sdkerrors.Register(ModuleName, 1123, "invalid version")
	ErrRequestNotFound                 = sdkerrors.Register(ModuleName, 1124, "no request found with this identity")
	ErrInvalidNumberOfValidators       = sdkerrors.Register(ModuleName, 1125, "invalid number of validators")
	ErrAuthorizedAnotherAddr           = sdkerrors.Register(ModuleName, 1126, "validator authorized another address, please remove authorized address before deregistering")
	ErrEmptyEncryptedShares            = sdkerrors.Register(ModuleName, 1127, "provided encrypted key shares are empty")
	ErrNotMatchNumOfCommits            = sdkerrors.Register(ModuleName, 1128, "provided number of commitments does not match number of validators")
	ErrNotMatchNumOfEncryptedKeyShares = sdkerrors.Register(ModuleName, 1129, "provided number of commitments does not match number of encrypted key shares")
	ErrInvalidEncryptedShareData       = sdkerrors.Register(ModuleName, 1130, "invalid encrypted share data")
	ErrQueuedKeyNotFound               = sdkerrors.Register(ModuleName, 1131, "Queued public key not found")
	ErrAddressAlreadyAuthorized        = sdkerrors.Register(ModuleName, 1900, "address is already authorized")
	ErrAuthorizedAddrNotFound          = sdkerrors.Register(ModuleName, 1901, "target authorized address not found")
	ErrNotAuthorizedAddrCreator        = sdkerrors.Register(ModuleName, 1902, "sender is not the creator of target authorized address")
	ErrNotTargetOrAuthAddrCreator      = sdkerrors.Register(ModuleName, 1903, "only the authorized address / the creator can delete authorized address")
	ErrAddrIsNotValidatorOrAuthorized  = sdkerrors.Register(ModuleName, 1904, "sender is not validator / authorized address to submit key share")
	ErrAuthorizerIsNotValidator        = sdkerrors.Register(ModuleName, 1905, "address authorized you is not a validator")
	ErrOnlyValidatorCanAuthorizeAddr   = sdkerrors.Register(ModuleName, 1906, "only validator can authorize address to submit key share")
	ErrExceedMaxAuthAddr               = sdkerrors.Register(ModuleName, 1907, "each validator can only authorize max 1 address to submit key share")
	ErrAuthorizeSelfAddress            = sdkerrors.Register(ModuleName, 1908, "unable to authorize sender own address")
	ErrAuthorizedAnotherAddress        = sdkerrors.Register(ModuleName, 1909, "validator authorized another address to submit key share is not allow to submit key share")
	ErrUnsupportedIDType               = sdkerrors.Register(ModuleName, 1910, "id type provided in general key share message is not supported")
	ErrKeyShareRequestNotFound         = sdkerrors.Register(ModuleName, 1911, "key share request for the given identity not found")
	ErrAggKeyAlreadyExists             = sdkerrors.Register(ModuleName, 1912, "aggregated key already exists for the given identity")
)

x/keyshare module sentinel errors

View Source
var (
	ErrInvalidLengthGeneralKeyShare        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGeneralKeyShare          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGeneralKeyShare = fmt.Errorf("proto: unexpected end of group")
)
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 (
	ErrInvalidLengthKeyShare        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowKeyShare          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupKeyShare = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// PortKey defines the key to store the port ID in store
	PortKey          = KeyPrefix("keyshare-port-")
	ChannelKey       = KeyPrefix("keyshare-channel-")
	RequestsCountKey = KeyPrefix("keyshare-request-count-")
)
View Source
var (
	ErrInvalidLengthPacket        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPacket          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPacket = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	KeyMinimumBonded            = []byte("MinimumBonded")
	DefaultMinimumBonded uint64 = 10000000000
)
View Source
var (
	KeyKeyExpiry            = []byte("KeyExpiry")
	DefaultKeyExpiry uint64 = 100
)
View Source
var (
	KeyTrustedAddresses     = []byte("TrustedAddresses")
	DefaultTrustedAddresses []string
)
View Source
var (
	KeySlashFractionNoKeyShare     = []byte("KeyNoShareSlashFraction")
	DefaultSlashFractionNoKeyShare = sdk.NewDecWithPrec(5, 1) // 0.5
)
View Source
var (
	KeySlashFractionWrongKeyShare     = []byte("KeyWrongShareSlashFraction")
	DefaultSlashFractionWrongKeyShare = sdk.NewDecWithPrec(5, 1) // 0.5
)
View Source
var (
	KeyMaxIdledBlock            = []byte("KeyMaxIdledBlock")
	DefaultMaxIdledBlock uint64 = 10
)
View Source
var (
	ErrInvalidLengthParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupParams = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthPubKey        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPubKey          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPubKey = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthQuery        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowQuery          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupQuery = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthRequestedKeyshare        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowRequestedKeyshare          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupRequestedKeyshare = 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 (
	ErrInvalidLengthValidatorSet        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowValidatorSet          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupValidatorSet = fmt.Errorf("proto: unexpected end of group")
)

Functions

func AggregatedKeyShareKey

func AggregatedKeyShareKey(
	height uint64,
) []byte

AggregatedKeyShareKey returns the store key to retrieve a AggregatedKeyShare from the index fields

func AuthorizedAddressKey

func AuthorizedAddressKey(
	target string,
) []byte

AuthorizedAddressKey returns the store key to retrieve a AuthorizedAddress from the index fields

func AuthorizedCountKey

func AuthorizedCountKey(
	creator string,
) []byte

func GeneralKeyShareKey

func GeneralKeyShareKey(
	validator string,
	idType string,
	idValue string,
) []byte

GeneralKeyShareKey returns the store key to retrieve a GeneralKeyShare from the index fields

func IdentityFromRequestCount

func IdentityFromRequestCount(
	reqCount uint64,
) string

func KeyPrefix

func KeyPrefix(p string) []byte

func KeyShareKey

func KeyShareKey(
	validator string,
	blockHeight uint64,
) []byte

KeyShareKey returns the store key to retrieve a KeyShare from the index fields

func LastSubmittedHeightKey

func LastSubmittedHeightKey(
	validator string,
) []byte

LastSubmittedHeightKey returns the store key to retrieve a LastSubmittedHeight from the index fields

func MustProtoMarshalJSON

func MustProtoMarshalJSON(msg proto.Message) []byte

mustProtoMarshalJSON provides an auxiliary function to return Proto3 JSON encoded bytes of a message. NOTE: Copied from https://github.com/cosmos/cosmos-sdk/blob/971c542453e0972ef1dfc5a80159ad5049c7211c/codec/json.go and modified in order to allow `EmitDefaults` to be set to false for ics20 packet marshalling. This allows for the introduction of the memo field to be backwards compatible.

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable the param key table for launch module

func RegisterCodec

func RegisterCodec(cdc *codec.LegacyAmino)

func RegisterInterfaces

func RegisterInterfaces(registry cdctypes.InterfaceRegistry)

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func RequestCountFromIdentity

func RequestCountFromIdentity(
	identity string,
) uint64

func ValidatorSetKey

func ValidatorSetKey(
	index string,
) []byte

ValidatorSetKey returns the store key to retrieve a ValidatorSet from the index fields

Types

type AccountKeeper

type AccountKeeper interface {
	GetAccount(ctx sdk.Context, addr sdk.AccAddress) types.AccountI
}

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

type ActivePubKey

type ActivePubKey struct {
	PublicKey          string               `protobuf:"bytes,1,opt,name=publicKey,proto3" json:"publicKey,omitempty"`
	Creator            string               `protobuf:"bytes,2,opt,name=creator,proto3" json:"creator,omitempty"`
	Expiry             uint64               `protobuf:"varint,3,opt,name=expiry,proto3" json:"expiry,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=numberOfValidators,proto3" json:"numberOfValidators,omitempty"`
	EncryptedKeyShares []*EncryptedKeyShare `protobuf:"bytes,5,rep,name=encryptedKeyShares,proto3" json:"encryptedKeyShares,omitempty"`
}

func (*ActivePubKey) Descriptor

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

func (*ActivePubKey) GetCreator

func (m *ActivePubKey) GetCreator() string

func (*ActivePubKey) GetEncryptedKeyShares added in v0.5.0

func (m *ActivePubKey) GetEncryptedKeyShares() []*EncryptedKeyShare

func (*ActivePubKey) GetExpiry

func (m *ActivePubKey) GetExpiry() uint64

func (*ActivePubKey) GetNumberOfValidators added in v0.5.0

func (m *ActivePubKey) GetNumberOfValidators() uint64

func (*ActivePubKey) GetPublicKey

func (m *ActivePubKey) GetPublicKey() string

func (*ActivePubKey) Marshal

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

func (*ActivePubKey) MarshalTo

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

func (*ActivePubKey) MarshalToSizedBuffer

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

func (*ActivePubKey) ProtoMessage

func (*ActivePubKey) ProtoMessage()

func (*ActivePubKey) Reset

func (m *ActivePubKey) Reset()

func (*ActivePubKey) Size

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

func (*ActivePubKey) String

func (m *ActivePubKey) String() string

func (*ActivePubKey) Unmarshal

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

func (*ActivePubKey) XXX_DiscardUnknown

func (m *ActivePubKey) XXX_DiscardUnknown()

func (*ActivePubKey) XXX_Marshal

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

func (*ActivePubKey) XXX_Merge

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

func (*ActivePubKey) XXX_Size

func (m *ActivePubKey) XXX_Size() int

func (*ActivePubKey) XXX_Unmarshal

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

type AggrKeyshareDataPacketAck

type AggrKeyshareDataPacketAck struct {
}

AggrKeyshareDataPacketAck defines a struct for the packet acknowledgment

func (*AggrKeyshareDataPacketAck) Descriptor

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

func (*AggrKeyshareDataPacketAck) Marshal

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

func (*AggrKeyshareDataPacketAck) MarshalTo

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

func (*AggrKeyshareDataPacketAck) MarshalToSizedBuffer

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

func (*AggrKeyshareDataPacketAck) ProtoMessage

func (*AggrKeyshareDataPacketAck) ProtoMessage()

func (*AggrKeyshareDataPacketAck) Reset

func (m *AggrKeyshareDataPacketAck) Reset()

func (*AggrKeyshareDataPacketAck) Size

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

func (*AggrKeyshareDataPacketAck) String

func (m *AggrKeyshareDataPacketAck) String() string

func (*AggrKeyshareDataPacketAck) Unmarshal

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

func (*AggrKeyshareDataPacketAck) XXX_DiscardUnknown

func (m *AggrKeyshareDataPacketAck) XXX_DiscardUnknown()

func (*AggrKeyshareDataPacketAck) XXX_Marshal

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

func (*AggrKeyshareDataPacketAck) XXX_Merge

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

func (*AggrKeyshareDataPacketAck) XXX_Size

func (m *AggrKeyshareDataPacketAck) XXX_Size() int

func (*AggrKeyshareDataPacketAck) XXX_Unmarshal

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

type AggrKeyshareDataPacketData

type AggrKeyshareDataPacketData struct {
	Identity     string `protobuf:"bytes,1,opt,name=identity,proto3" json:"identity,omitempty"`
	Pubkey       string `protobuf:"bytes,2,opt,name=pubkey,proto3" json:"pubkey,omitempty"`
	AggrKeyshare string `protobuf:"bytes,3,opt,name=aggr_keyshare,json=aggrKeyshare,proto3" json:"aggr_keyshare,omitempty"`
	AggrHeight   string `protobuf:"bytes,4,opt,name=aggr_height,json=aggrHeight,proto3" json:"aggr_height,omitempty"`
	ProposalId   string `protobuf:"bytes,5,opt,name=proposal_id,json=proposalId,proto3" json:"proposal_id,omitempty"`
	RequestId    string `protobuf:"bytes,6,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"`
	Retries      uint64 `protobuf:"varint,7,opt,name=retries,proto3" json:"retries,omitempty"`
}

AggrKeyshareDataPacketData defines a struct for the packet payload

func (*AggrKeyshareDataPacketData) Descriptor

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

func (*AggrKeyshareDataPacketData) GetAggrHeight

func (m *AggrKeyshareDataPacketData) GetAggrHeight() string

func (*AggrKeyshareDataPacketData) GetAggrKeyshare

func (m *AggrKeyshareDataPacketData) GetAggrKeyshare() string

func (AggrKeyshareDataPacketData) GetBytes

func (p AggrKeyshareDataPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*AggrKeyshareDataPacketData) GetIdentity

func (m *AggrKeyshareDataPacketData) GetIdentity() string

func (*AggrKeyshareDataPacketData) GetProposalId

func (m *AggrKeyshareDataPacketData) GetProposalId() string

func (*AggrKeyshareDataPacketData) GetPubkey

func (m *AggrKeyshareDataPacketData) GetPubkey() string

func (*AggrKeyshareDataPacketData) GetRequestId added in v0.4.0

func (m *AggrKeyshareDataPacketData) GetRequestId() string

func (*AggrKeyshareDataPacketData) GetRetries

func (m *AggrKeyshareDataPacketData) GetRetries() uint64

func (*AggrKeyshareDataPacketData) Marshal

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

func (*AggrKeyshareDataPacketData) MarshalTo

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

func (*AggrKeyshareDataPacketData) MarshalToSizedBuffer

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

func (*AggrKeyshareDataPacketData) ProtoMessage

func (*AggrKeyshareDataPacketData) ProtoMessage()

func (*AggrKeyshareDataPacketData) Reset

func (m *AggrKeyshareDataPacketData) Reset()

func (*AggrKeyshareDataPacketData) Size

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

func (*AggrKeyshareDataPacketData) String

func (m *AggrKeyshareDataPacketData) String() string

func (*AggrKeyshareDataPacketData) Unmarshal

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

func (AggrKeyshareDataPacketData) ValidateBasic

func (p AggrKeyshareDataPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*AggrKeyshareDataPacketData) XXX_DiscardUnknown

func (m *AggrKeyshareDataPacketData) XXX_DiscardUnknown()

func (*AggrKeyshareDataPacketData) XXX_Marshal

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

func (*AggrKeyshareDataPacketData) XXX_Merge

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

func (*AggrKeyshareDataPacketData) XXX_Size

func (m *AggrKeyshareDataPacketData) XXX_Size() int

func (*AggrKeyshareDataPacketData) XXX_Unmarshal

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

type AggregatedKeyShare

type AggregatedKeyShare struct {
	Height uint64 `protobuf:"varint,1,opt,name=height,proto3" json:"height,omitempty"`
	Data   string `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"`
}

func (*AggregatedKeyShare) Descriptor

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

func (*AggregatedKeyShare) GetData

func (m *AggregatedKeyShare) GetData() string

func (*AggregatedKeyShare) GetHeight

func (m *AggregatedKeyShare) GetHeight() uint64

func (*AggregatedKeyShare) Marshal

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

func (*AggregatedKeyShare) MarshalTo

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

func (*AggregatedKeyShare) MarshalToSizedBuffer

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

func (*AggregatedKeyShare) ProtoMessage

func (*AggregatedKeyShare) ProtoMessage()

func (*AggregatedKeyShare) Reset

func (m *AggregatedKeyShare) Reset()

func (*AggregatedKeyShare) Size

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

func (*AggregatedKeyShare) String

func (m *AggregatedKeyShare) String() string

func (*AggregatedKeyShare) Unmarshal

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

func (*AggregatedKeyShare) XXX_DiscardUnknown

func (m *AggregatedKeyShare) XXX_DiscardUnknown()

func (*AggregatedKeyShare) XXX_Marshal

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

func (*AggregatedKeyShare) XXX_Merge

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

func (*AggregatedKeyShare) XXX_Size

func (m *AggregatedKeyShare) XXX_Size() int

func (*AggregatedKeyShare) XXX_Unmarshal

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

type AuthorizedAddress

type AuthorizedAddress struct {
	Target       string `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	IsAuthorized bool   `protobuf:"varint,2,opt,name=isAuthorized,proto3" json:"isAuthorized,omitempty"`
	AuthorizedBy string `protobuf:"bytes,3,opt,name=authorizedBy,proto3" json:"authorizedBy,omitempty"`
}

func (*AuthorizedAddress) Descriptor

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

func (*AuthorizedAddress) GetAuthorizedBy

func (m *AuthorizedAddress) GetAuthorizedBy() string

func (*AuthorizedAddress) GetIsAuthorized

func (m *AuthorizedAddress) GetIsAuthorized() bool

func (*AuthorizedAddress) GetTarget

func (m *AuthorizedAddress) GetTarget() string

func (*AuthorizedAddress) Marshal

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

func (*AuthorizedAddress) MarshalTo

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

func (*AuthorizedAddress) MarshalToSizedBuffer

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

func (*AuthorizedAddress) ProtoMessage

func (*AuthorizedAddress) ProtoMessage()

func (*AuthorizedAddress) Reset

func (m *AuthorizedAddress) Reset()

func (*AuthorizedAddress) Size

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

func (*AuthorizedAddress) String

func (m *AuthorizedAddress) String() string

func (*AuthorizedAddress) Unmarshal

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

func (*AuthorizedAddress) XXX_DiscardUnknown

func (m *AuthorizedAddress) XXX_DiscardUnknown()

func (*AuthorizedAddress) XXX_Marshal

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

func (*AuthorizedAddress) XXX_Merge

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

func (*AuthorizedAddress) XXX_Size

func (m *AuthorizedAddress) XXX_Size() int

func (*AuthorizedAddress) XXX_Unmarshal

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

type BankKeeper

type BankKeeper interface {
	SpendableCoins(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
}

BankKeeper defines the expected interface needed to retrieve account balances.

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,
		sourcePort string,
		sourceChannel string,
		timeoutHeight clienttypes.Height,
		timeoutTimestamp uint64,
		data []byte,
	) (uint64, error)
	ChanCloseInit(ctx sdk.Context, portID, channelID string, chanCap *capabilitytypes.Capability) error
}

ChannelKeeper defines the expected IBC channel keeper

type Commitments

type Commitments struct {
	Commitments []string `protobuf:"bytes,1,rep,name=commitments,proto3" json:"commitments,omitempty"`
}

func (*Commitments) Descriptor

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

func (*Commitments) GetCommitments

func (m *Commitments) GetCommitments() []string

func (*Commitments) Marshal

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

func (*Commitments) MarshalTo

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

func (*Commitments) MarshalToSizedBuffer

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

func (*Commitments) ProtoMessage

func (*Commitments) ProtoMessage()

func (*Commitments) Reset

func (m *Commitments) Reset()

func (*Commitments) Size

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

func (*Commitments) String

func (m *Commitments) String() string

func (*Commitments) Unmarshal

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

func (*Commitments) XXX_DiscardUnknown

func (m *Commitments) XXX_DiscardUnknown()

func (*Commitments) XXX_Marshal

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

func (*Commitments) XXX_Merge

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

func (*Commitments) XXX_Size

func (m *Commitments) XXX_Size() int

func (*Commitments) XXX_Unmarshal

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

type ConnectionKeeper

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

ConnectionKeeper defines the expected interfaces needed to retrieve connection info

type CounterPartyIBCInfo

type CounterPartyIBCInfo struct {
	ClientID     string `protobuf:"bytes,1,opt,name=ClientID,proto3" json:"ClientID,omitempty"`
	ConnectionID string `protobuf:"bytes,2,opt,name=ConnectionID,proto3" json:"ConnectionID,omitempty"`
	ChannelID    string `protobuf:"bytes,3,opt,name=ChannelID,proto3" json:"ChannelID,omitempty"`
	PortID       string `protobuf:"bytes,4,opt,name=PortID,proto3" json:"PortID,omitempty"`
}

func (*CounterPartyIBCInfo) Descriptor

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

func (*CounterPartyIBCInfo) GetChannelID

func (m *CounterPartyIBCInfo) GetChannelID() string

func (*CounterPartyIBCInfo) GetClientID

func (m *CounterPartyIBCInfo) GetClientID() string

func (*CounterPartyIBCInfo) GetConnectionID

func (m *CounterPartyIBCInfo) GetConnectionID() string

func (*CounterPartyIBCInfo) GetPortID

func (m *CounterPartyIBCInfo) GetPortID() string

func (*CounterPartyIBCInfo) Marshal

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

func (*CounterPartyIBCInfo) MarshalTo

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

func (*CounterPartyIBCInfo) MarshalToSizedBuffer

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

func (*CounterPartyIBCInfo) ProtoMessage

func (*CounterPartyIBCInfo) ProtoMessage()

func (*CounterPartyIBCInfo) Reset

func (m *CounterPartyIBCInfo) Reset()

func (*CounterPartyIBCInfo) Size

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

func (*CounterPartyIBCInfo) String

func (m *CounterPartyIBCInfo) String() string

func (*CounterPartyIBCInfo) Unmarshal

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

func (*CounterPartyIBCInfo) XXX_DiscardUnknown

func (m *CounterPartyIBCInfo) XXX_DiscardUnknown()

func (*CounterPartyIBCInfo) XXX_Marshal

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

func (*CounterPartyIBCInfo) XXX_Merge

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

func (*CounterPartyIBCInfo) XXX_Size

func (m *CounterPartyIBCInfo) XXX_Size() int

func (*CounterPartyIBCInfo) XXX_Unmarshal

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

type EncryptedKeyShare added in v0.5.0

type EncryptedKeyShare struct {
	Data      string `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"`
}

func (*EncryptedKeyShare) Descriptor added in v0.5.0

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

func (*EncryptedKeyShare) GetData added in v0.5.0

func (m *EncryptedKeyShare) GetData() string

func (*EncryptedKeyShare) GetValidator added in v0.5.0

func (m *EncryptedKeyShare) GetValidator() string

func (*EncryptedKeyShare) Marshal added in v0.5.0

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

func (*EncryptedKeyShare) MarshalTo added in v0.5.0

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

func (*EncryptedKeyShare) MarshalToSizedBuffer added in v0.5.0

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

func (*EncryptedKeyShare) ProtoMessage added in v0.5.0

func (*EncryptedKeyShare) ProtoMessage()

func (*EncryptedKeyShare) Reset added in v0.5.0

func (m *EncryptedKeyShare) Reset()

func (*EncryptedKeyShare) Size added in v0.5.0

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

func (*EncryptedKeyShare) String added in v0.5.0

func (m *EncryptedKeyShare) String() string

func (*EncryptedKeyShare) Unmarshal added in v0.5.0

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

func (*EncryptedKeyShare) XXX_DiscardUnknown added in v0.5.0

func (m *EncryptedKeyShare) XXX_DiscardUnknown()

func (*EncryptedKeyShare) XXX_Marshal added in v0.5.0

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

func (*EncryptedKeyShare) XXX_Merge added in v0.5.0

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

func (*EncryptedKeyShare) XXX_Size added in v0.5.0

func (m *EncryptedKeyShare) XXX_Size() int

func (*EncryptedKeyShare) XXX_Unmarshal added in v0.5.0

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

type GeneralKeyShare

type GeneralKeyShare struct {
	Validator           string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=idType,proto3" json:"idType,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=idValue,proto3" json:"idValue,omitempty"`
	KeyShare            string `protobuf:"bytes,4,opt,name=keyShare,proto3" json:"keyShare,omitempty"`
	KeyShareIndex       uint64 `protobuf:"varint,5,opt,name=keyShareIndex,proto3" json:"keyShareIndex,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,6,opt,name=receivedTimestamp,proto3" json:"receivedTimestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,7,opt,name=receivedBlockHeight,proto3" json:"receivedBlockHeight,omitempty"`
}

func (*GeneralKeyShare) Descriptor

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

func (*GeneralKeyShare) GetIdType

func (m *GeneralKeyShare) GetIdType() string

func (*GeneralKeyShare) GetIdValue

func (m *GeneralKeyShare) GetIdValue() string

func (*GeneralKeyShare) GetKeyShare

func (m *GeneralKeyShare) GetKeyShare() string

func (*GeneralKeyShare) GetKeyShareIndex

func (m *GeneralKeyShare) GetKeyShareIndex() uint64

func (*GeneralKeyShare) GetReceivedBlockHeight

func (m *GeneralKeyShare) GetReceivedBlockHeight() uint64

func (*GeneralKeyShare) GetReceivedTimestamp

func (m *GeneralKeyShare) GetReceivedTimestamp() uint64

func (*GeneralKeyShare) GetValidator

func (m *GeneralKeyShare) GetValidator() string

func (*GeneralKeyShare) Marshal

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

func (*GeneralKeyShare) MarshalTo

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

func (*GeneralKeyShare) MarshalToSizedBuffer

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

func (*GeneralKeyShare) ProtoMessage

func (*GeneralKeyShare) ProtoMessage()

func (*GeneralKeyShare) Reset

func (m *GeneralKeyShare) Reset()

func (*GeneralKeyShare) Size

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

func (*GeneralKeyShare) String

func (m *GeneralKeyShare) String() string

func (*GeneralKeyShare) Unmarshal

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

func (*GeneralKeyShare) XXX_DiscardUnknown

func (m *GeneralKeyShare) XXX_DiscardUnknown()

func (*GeneralKeyShare) XXX_Marshal

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

func (*GeneralKeyShare) XXX_Merge

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

func (*GeneralKeyShare) XXX_Size

func (m *GeneralKeyShare) XXX_Size() int

func (*GeneralKeyShare) XXX_Unmarshal

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

type GenesisState

type GenesisState struct {
	Params           Params         `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	PortId           string         `protobuf:"bytes,2,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
	ValidatorSetList []ValidatorSet `protobuf:"bytes,3,rep,name=validatorSetList,proto3" json:"validatorSetList"`
	KeyShareList     []KeyShare     `protobuf:"bytes,4,rep,name=keyShareList,proto3" json:"keyShareList"`
	// this line is used by starport scaffolding # genesis/proto/state
	AggregatedKeyShareList []AggregatedKeyShare `protobuf:"bytes,5,rep,name=aggregatedKeyShareList,proto3" json:"aggregatedKeyShareList"`
	ActivePubKey           ActivePubKey         `protobuf:"bytes,6,opt,name=activePubKey,proto3" json:"activePubKey"`
	QueuedPubKey           QueuedPubKey         `protobuf:"bytes,7,opt,name=queuedPubKey,proto3" json:"queuedPubKey"`
	AuthorizedAddressList  []AuthorizedAddress  `protobuf:"bytes,8,rep,name=authorizedAddressList,proto3" json:"authorizedAddressList"`
	RequestCount           uint64               `protobuf:"varint,9,opt,name=request_count,json=requestCount,proto3" json:"request_count,omitempty"`
	GeneralKeyShareList    []GeneralKeyShare    `protobuf:"bytes,10,rep,name=generalKeyShareList,proto3" json:"generalKeyShareList"`
}

GenesisState defines the keyshare module's genesis state.

func DefaultGenesis

func DefaultGenesis() *GenesisState

DefaultGenesis returns the default genesis state

func (*GenesisState) Descriptor

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

func (*GenesisState) GetActivePubKey

func (m *GenesisState) GetActivePubKey() ActivePubKey

func (*GenesisState) GetAggregatedKeyShareList

func (m *GenesisState) GetAggregatedKeyShareList() []AggregatedKeyShare

func (*GenesisState) GetAuthorizedAddressList

func (m *GenesisState) GetAuthorizedAddressList() []AuthorizedAddress

func (*GenesisState) GetGeneralKeyShareList

func (m *GenesisState) GetGeneralKeyShareList() []GeneralKeyShare

func (*GenesisState) GetKeyShareList

func (m *GenesisState) GetKeyShareList() []KeyShare

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPortId

func (m *GenesisState) GetPortId() string

func (*GenesisState) GetQueuedPubKey

func (m *GenesisState) GetQueuedPubKey() QueuedPubKey

func (*GenesisState) GetRequestCount

func (m *GenesisState) GetRequestCount() uint64

func (*GenesisState) GetValidatorSetList

func (m *GenesisState) GetValidatorSetList() []ValidatorSet

func (*GenesisState) Marshal

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

func (*GenesisState) MarshalTo

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

func (*GenesisState) MarshalToSizedBuffer

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

func (*GenesisState) ProtoMessage

func (*GenesisState) ProtoMessage()

func (*GenesisState) Reset

func (m *GenesisState) Reset()

func (*GenesisState) Size

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

func (*GenesisState) String

func (m *GenesisState) String() string

func (*GenesisState) Unmarshal

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

func (GenesisState) Validate

func (gs GenesisState) Validate() error

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

func (*GenesisState) XXX_DiscardUnknown

func (m *GenesisState) XXX_DiscardUnknown()

func (*GenesisState) XXX_Marshal

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

func (*GenesisState) XXX_Merge

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

func (*GenesisState) XXX_Size

func (m *GenesisState) XXX_Size() int

func (*GenesisState) XXX_Unmarshal

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

type GetAggrKeysharePacketAck

type GetAggrKeysharePacketAck struct {
}

GetAggrKeysharePacketAck defines a struct for the packet acknowledgment

func (*GetAggrKeysharePacketAck) Descriptor

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

func (*GetAggrKeysharePacketAck) Marshal

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

func (*GetAggrKeysharePacketAck) MarshalTo

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

func (*GetAggrKeysharePacketAck) MarshalToSizedBuffer

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

func (*GetAggrKeysharePacketAck) ProtoMessage

func (*GetAggrKeysharePacketAck) ProtoMessage()

func (*GetAggrKeysharePacketAck) Reset

func (m *GetAggrKeysharePacketAck) Reset()

func (*GetAggrKeysharePacketAck) Size

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

func (*GetAggrKeysharePacketAck) String

func (m *GetAggrKeysharePacketAck) String() string

func (*GetAggrKeysharePacketAck) Unmarshal

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

func (*GetAggrKeysharePacketAck) XXX_DiscardUnknown

func (m *GetAggrKeysharePacketAck) XXX_DiscardUnknown()

func (*GetAggrKeysharePacketAck) XXX_Marshal

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

func (*GetAggrKeysharePacketAck) XXX_Merge

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

func (*GetAggrKeysharePacketAck) XXX_Size

func (m *GetAggrKeysharePacketAck) XXX_Size() int

func (*GetAggrKeysharePacketAck) XXX_Unmarshal

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

type GetAggrKeysharePacketData

type GetAggrKeysharePacketData struct {
	Identity string `protobuf:"bytes,1,opt,name=identity,proto3" json:"identity,omitempty"`
}

GetAggrKeysharePacketData defines a struct for the packet payload

func (*GetAggrKeysharePacketData) Descriptor

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

func (GetAggrKeysharePacketData) GetBytes

func (p GetAggrKeysharePacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*GetAggrKeysharePacketData) GetIdentity

func (m *GetAggrKeysharePacketData) GetIdentity() string

func (*GetAggrKeysharePacketData) Marshal

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

func (*GetAggrKeysharePacketData) MarshalTo

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

func (*GetAggrKeysharePacketData) MarshalToSizedBuffer

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

func (*GetAggrKeysharePacketData) ProtoMessage

func (*GetAggrKeysharePacketData) ProtoMessage()

func (*GetAggrKeysharePacketData) Reset

func (m *GetAggrKeysharePacketData) Reset()

func (*GetAggrKeysharePacketData) Size

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

func (*GetAggrKeysharePacketData) String

func (m *GetAggrKeysharePacketData) String() string

func (*GetAggrKeysharePacketData) Unmarshal

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

func (GetAggrKeysharePacketData) ValidateBasic

func (p GetAggrKeysharePacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*GetAggrKeysharePacketData) XXX_DiscardUnknown

func (m *GetAggrKeysharePacketData) XXX_DiscardUnknown()

func (*GetAggrKeysharePacketData) XXX_Marshal

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

func (*GetAggrKeysharePacketData) XXX_Merge

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

func (*GetAggrKeysharePacketData) XXX_Size

func (m *GetAggrKeysharePacketData) XXX_Size() int

func (*GetAggrKeysharePacketData) XXX_Unmarshal

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

type GovKeeper added in v0.4.0

type GovKeeper interface {
	ProcessAggrKeyshare(ctx sdk.Context, pID string, aggrKeyshare string) error
}

type IBCInfo

type IBCInfo struct {
	ClientID     string `protobuf:"bytes,1,opt,name=ClientID,proto3" json:"ClientID,omitempty"`
	ConnectionID string `protobuf:"bytes,2,opt,name=ConnectionID,proto3" json:"ConnectionID,omitempty"`
	ChannelID    string `protobuf:"bytes,3,opt,name=ChannelID,proto3" json:"ChannelID,omitempty"`
	PortID       string `protobuf:"bytes,4,opt,name=PortID,proto3" json:"PortID,omitempty"`
}

func (*IBCInfo) Descriptor

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

func (*IBCInfo) GetChannelID

func (m *IBCInfo) GetChannelID() string

func (*IBCInfo) GetClientID

func (m *IBCInfo) GetClientID() string

func (*IBCInfo) GetConnectionID

func (m *IBCInfo) GetConnectionID() string

func (*IBCInfo) GetPortID

func (m *IBCInfo) GetPortID() string

func (*IBCInfo) Marshal

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

func (*IBCInfo) MarshalTo

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

func (*IBCInfo) MarshalToSizedBuffer

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

func (*IBCInfo) ProtoMessage

func (*IBCInfo) ProtoMessage()

func (*IBCInfo) Reset

func (m *IBCInfo) Reset()

func (*IBCInfo) Size

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

func (*IBCInfo) String

func (m *IBCInfo) String() string

func (*IBCInfo) Unmarshal

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

func (*IBCInfo) XXX_DiscardUnknown

func (m *IBCInfo) XXX_DiscardUnknown()

func (*IBCInfo) XXX_Marshal

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

func (*IBCInfo) XXX_Merge

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

func (*IBCInfo) XXX_Size

func (m *IBCInfo) XXX_Size() int

func (*IBCInfo) XXX_Unmarshal

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

type IBCKeeper

type IBCKeeper struct {
	ChannelKeeper ChannelKeeper
	PortKeeper    PortKeeper
	ScopedKeeper  ScopedKeeper
	// contains filtered or unexported fields
}

IBCKeeper defines the IBC Keeper

func NewIBCKeeper

func NewIBCKeeper(
	portKey []byte,
	storeKey storetypes.StoreKey,
	channelKeeper ChannelKeeper,
	portKeeper PortKeeper,
	scopedKeeper ScopedKeeper,
) *IBCKeeper

NewKeeper create an IBC Keeper

func (IBCKeeper) AuthenticateCapability

func (k IBCKeeper) AuthenticateCapability(ctx sdk.Context, cap *capabilitytypes.Capability, name string) bool

AuthenticateCapability wraps the scopedKeeper's AuthenticateCapability function

func (IBCKeeper) BindPort

func (k IBCKeeper) BindPort(ctx sdk.Context, portID string) error

BindPort defines a wrapper function for the ort Keeper's function in order to expose it to module's InitGenesis function

func (IBCKeeper) ChanCloseInit

func (k IBCKeeper) ChanCloseInit(ctx sdk.Context, portID, channelID string) error

ChanCloseInit defines a wrapper function for the channel Keeper's function

func (IBCKeeper) ClaimCapability

func (k IBCKeeper) ClaimCapability(ctx sdk.Context, cap *capabilitytypes.Capability, name string) error

ClaimCapability allows the module that can claim a capability that IBC module passes to it

func (IBCKeeper) GetPort

func (k IBCKeeper) GetPort(ctx sdk.Context) string

GetPort returns the portID for the module. Used in ExportGenesis

func (IBCKeeper) IsBound

func (k IBCKeeper) IsBound(ctx sdk.Context, portID string) bool

IsBound checks if the module is already bound to the desired port

func (IBCKeeper) SetPort

func (k IBCKeeper) SetPort(ctx sdk.Context, portID string)

SetPort sets the portID for the module. Used in InitGenesis

type KeyShare

type KeyShare struct {
	Validator           string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	BlockHeight         uint64 `protobuf:"varint,2,opt,name=blockHeight,proto3" json:"blockHeight,omitempty"`
	KeyShare            string `protobuf:"bytes,3,opt,name=keyShare,proto3" json:"keyShare,omitempty"`
	KeyShareIndex       uint64 `protobuf:"varint,4,opt,name=keyShareIndex,proto3" json:"keyShareIndex,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,5,opt,name=receivedTimestamp,proto3" json:"receivedTimestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=receivedBlockHeight,proto3" json:"receivedBlockHeight,omitempty"`
}

func (*KeyShare) Descriptor

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

func (*KeyShare) GetBlockHeight

func (m *KeyShare) GetBlockHeight() uint64

func (*KeyShare) GetKeyShare

func (m *KeyShare) GetKeyShare() string

func (*KeyShare) GetKeyShareIndex

func (m *KeyShare) GetKeyShareIndex() uint64

func (*KeyShare) GetReceivedBlockHeight

func (m *KeyShare) GetReceivedBlockHeight() uint64

func (*KeyShare) GetReceivedTimestamp

func (m *KeyShare) GetReceivedTimestamp() uint64

func (*KeyShare) GetValidator

func (m *KeyShare) GetValidator() string

func (*KeyShare) Marshal

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

func (*KeyShare) MarshalTo

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

func (*KeyShare) MarshalToSizedBuffer

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

func (*KeyShare) ProtoMessage

func (*KeyShare) ProtoMessage()

func (*KeyShare) Reset

func (m *KeyShare) Reset()

func (*KeyShare) Size

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

func (*KeyShare) String

func (m *KeyShare) String() string

func (*KeyShare) Unmarshal

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

func (*KeyShare) XXX_DiscardUnknown

func (m *KeyShare) XXX_DiscardUnknown()

func (*KeyShare) XXX_Marshal

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

func (*KeyShare) XXX_Merge

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

func (*KeyShare) XXX_Size

func (m *KeyShare) XXX_Size() int

func (*KeyShare) XXX_Unmarshal

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

type KeyShareRequest

type KeyShareRequest struct {
	Identity     string               `protobuf:"bytes,1,opt,name=identity,proto3" json:"identity,omitempty"`
	Pubkey       string               `protobuf:"bytes,2,opt,name=pubkey,proto3" json:"pubkey,omitempty"`
	IbcInfo      *IBCInfo             `protobuf:"bytes,3,opt,name=ibc_info,json=ibcInfo,proto3" json:"ibc_info,omitempty"`
	Counterparty *CounterPartyIBCInfo `protobuf:"bytes,4,opt,name=counterparty,proto3" json:"counterparty,omitempty"`
	AggrKeyshare string               `protobuf:"bytes,5,opt,name=aggr_keyshare,json=aggrKeyshare,proto3" json:"aggr_keyshare,omitempty"`
	ProposalId   string               `protobuf:"bytes,6,opt,name=proposal_id,json=proposalId,proto3" json:"proposal_id,omitempty"`
	RequestId    string               `protobuf:"bytes,7,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"`
	Sent         bool                 `protobuf:"varint,8,opt,name=sent,proto3" json:"sent,omitempty"`
}

func (*KeyShareRequest) Descriptor

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

func (*KeyShareRequest) GetAggrKeyshare

func (m *KeyShareRequest) GetAggrKeyshare() string

func (*KeyShareRequest) GetCounterparty

func (m *KeyShareRequest) GetCounterparty() *CounterPartyIBCInfo

func (*KeyShareRequest) GetIbcInfo

func (m *KeyShareRequest) GetIbcInfo() *IBCInfo

func (*KeyShareRequest) GetIdentity

func (m *KeyShareRequest) GetIdentity() string

func (*KeyShareRequest) GetProposalId

func (m *KeyShareRequest) GetProposalId() string

func (*KeyShareRequest) GetPubkey

func (m *KeyShareRequest) GetPubkey() string

func (*KeyShareRequest) GetRequestId added in v0.4.0

func (m *KeyShareRequest) GetRequestId() string

func (*KeyShareRequest) GetSent

func (m *KeyShareRequest) GetSent() bool

func (*KeyShareRequest) Marshal

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

func (*KeyShareRequest) MarshalTo

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

func (*KeyShareRequest) MarshalToSizedBuffer

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

func (*KeyShareRequest) ProtoMessage

func (*KeyShareRequest) ProtoMessage()

func (*KeyShareRequest) Reset

func (m *KeyShareRequest) Reset()

func (*KeyShareRequest) Size

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

func (*KeyShareRequest) String

func (m *KeyShareRequest) String() string

func (*KeyShareRequest) Unmarshal

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

func (*KeyShareRequest) XXX_DiscardUnknown

func (m *KeyShareRequest) XXX_DiscardUnknown()

func (*KeyShareRequest) XXX_Marshal

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

func (*KeyShareRequest) XXX_Merge

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

func (*KeyShareRequest) XXX_Size

func (m *KeyShareRequest) XXX_Size() int

func (*KeyShareRequest) XXX_Unmarshal

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

type KeysharePacketData

type KeysharePacketData struct {
	// Types that are valid to be assigned to Packet:
	//
	//	*KeysharePacketData_NoData
	//	*KeysharePacketData_RequestAggrKeysharePacket
	//	*KeysharePacketData_GetAggrKeysharePacket
	//	*KeysharePacketData_AggrKeyshareDataPacket
	Packet isKeysharePacketData_Packet `protobuf_oneof:"packet"`
}

func (*KeysharePacketData) Descriptor

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

func (*KeysharePacketData) GetAggrKeyshareDataPacket

func (m *KeysharePacketData) GetAggrKeyshareDataPacket() *AggrKeyshareDataPacketData

func (*KeysharePacketData) GetGetAggrKeysharePacket

func (m *KeysharePacketData) GetGetAggrKeysharePacket() *GetAggrKeysharePacketData

func (*KeysharePacketData) GetNoData

func (m *KeysharePacketData) GetNoData() *NoData

func (*KeysharePacketData) GetPacket

func (m *KeysharePacketData) GetPacket() isKeysharePacketData_Packet

func (*KeysharePacketData) GetRequestAggrKeysharePacket

func (m *KeysharePacketData) GetRequestAggrKeysharePacket() *RequestAggrKeysharePacketData

func (*KeysharePacketData) Marshal

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

func (*KeysharePacketData) MarshalTo

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

func (*KeysharePacketData) MarshalToSizedBuffer

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

func (*KeysharePacketData) ProtoMessage

func (*KeysharePacketData) ProtoMessage()

func (*KeysharePacketData) Reset

func (m *KeysharePacketData) Reset()

func (*KeysharePacketData) Size

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

func (*KeysharePacketData) String

func (m *KeysharePacketData) String() string

func (*KeysharePacketData) Unmarshal

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

func (*KeysharePacketData) XXX_DiscardUnknown

func (m *KeysharePacketData) XXX_DiscardUnknown()

func (*KeysharePacketData) XXX_Marshal

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

func (*KeysharePacketData) XXX_Merge

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

func (*KeysharePacketData) XXX_OneofWrappers

func (*KeysharePacketData) XXX_OneofWrappers() []interface{}

XXX_OneofWrappers is for the internal use of the proto package.

func (*KeysharePacketData) XXX_Size

func (m *KeysharePacketData) XXX_Size() int

func (*KeysharePacketData) XXX_Unmarshal

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

type KeysharePacketData_AggrKeyshareDataPacket

type KeysharePacketData_AggrKeyshareDataPacket struct {
	AggrKeyshareDataPacket *AggrKeyshareDataPacketData `protobuf:"bytes,4,opt,name=aggrKeyshareDataPacket,proto3,oneof" json:"aggrKeyshareDataPacket,omitempty"`
}

func (*KeysharePacketData_AggrKeyshareDataPacket) MarshalTo

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

func (*KeysharePacketData_AggrKeyshareDataPacket) MarshalToSizedBuffer

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

func (*KeysharePacketData_AggrKeyshareDataPacket) Size

type KeysharePacketData_GetAggrKeysharePacket

type KeysharePacketData_GetAggrKeysharePacket struct {
	GetAggrKeysharePacket *GetAggrKeysharePacketData `protobuf:"bytes,3,opt,name=getAggrKeysharePacket,proto3,oneof" json:"getAggrKeysharePacket,omitempty"`
}

func (*KeysharePacketData_GetAggrKeysharePacket) MarshalTo

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

func (*KeysharePacketData_GetAggrKeysharePacket) MarshalToSizedBuffer

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

func (*KeysharePacketData_GetAggrKeysharePacket) Size

type KeysharePacketData_NoData

type KeysharePacketData_NoData struct {
	NoData *NoData `protobuf:"bytes,1,opt,name=noData,proto3,oneof" json:"noData,omitempty"`
}

func (*KeysharePacketData_NoData) MarshalTo

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

func (*KeysharePacketData_NoData) MarshalToSizedBuffer

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

func (*KeysharePacketData_NoData) Size

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

type KeysharePacketData_RequestAggrKeysharePacket

type KeysharePacketData_RequestAggrKeysharePacket struct {
	RequestAggrKeysharePacket *RequestAggrKeysharePacketData `protobuf:"bytes,2,opt,name=requestAggrKeysharePacket,proto3,oneof" json:"requestAggrKeysharePacket,omitempty"`
}

func (*KeysharePacketData_RequestAggrKeysharePacket) MarshalTo

func (*KeysharePacketData_RequestAggrKeysharePacket) MarshalToSizedBuffer

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

func (*KeysharePacketData_RequestAggrKeysharePacket) Size

type MsgClient

type MsgClient interface {
	RegisterValidator(ctx context.Context, in *MsgRegisterValidator, opts ...grpc.CallOption) (*MsgRegisterValidatorResponse, error)
	DeRegisterValidator(ctx context.Context, in *MsgDeRegisterValidator, opts ...grpc.CallOption) (*MsgDeRegisterValidatorResponse, error)
	SendKeyshare(ctx context.Context, in *MsgSendKeyshare, opts ...grpc.CallOption) (*MsgSendKeyshareResponse, error)
	// this line is used by starport scaffolding # proto/tx/rpc
	CreateLatestPubKey(ctx context.Context, in *MsgCreateLatestPubKey, opts ...grpc.CallOption) (*MsgCreateLatestPubKeyResponse, error)
	OverrideLatestPubKey(ctx context.Context, in *MsgOverrideLatestPubKey, opts ...grpc.CallOption) (*MsgOverrideLatestPubKeyResponse, error)
	CreateAuthorizedAddress(ctx context.Context, in *MsgCreateAuthorizedAddress, opts ...grpc.CallOption) (*MsgCreateAuthorizedAddressResponse, error)
	UpdateAuthorizedAddress(ctx context.Context, in *MsgUpdateAuthorizedAddress, opts ...grpc.CallOption) (*MsgUpdateAuthorizedAddressResponse, error)
	DeleteAuthorizedAddress(ctx context.Context, in *MsgDeleteAuthorizedAddress, opts ...grpc.CallOption) (*MsgDeleteAuthorizedAddressResponse, error)
	CreateGeneralKeyShare(ctx context.Context, in *MsgCreateGeneralKeyShare, opts ...grpc.CallOption) (*MsgCreateGeneralKeyShareResponse, 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 MsgCreateAuthorizedAddress

type MsgCreateAuthorizedAddress struct {
	Target  string `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	Creator string `protobuf:"bytes,2,opt,name=creator,proto3" json:"creator,omitempty"`
}

func NewMsgCreateAuthorizedAddress

func NewMsgCreateAuthorizedAddress(
	creator string,
	target string,

) *MsgCreateAuthorizedAddress

func (*MsgCreateAuthorizedAddress) Descriptor

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

func (*MsgCreateAuthorizedAddress) GetCreator

func (m *MsgCreateAuthorizedAddress) GetCreator() string

func (*MsgCreateAuthorizedAddress) GetSignBytes

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

func (*MsgCreateAuthorizedAddress) GetSigners

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

func (*MsgCreateAuthorizedAddress) GetTarget

func (m *MsgCreateAuthorizedAddress) GetTarget() string

func (*MsgCreateAuthorizedAddress) Marshal

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

func (*MsgCreateAuthorizedAddress) MarshalTo

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

func (*MsgCreateAuthorizedAddress) MarshalToSizedBuffer

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

func (*MsgCreateAuthorizedAddress) ProtoMessage

func (*MsgCreateAuthorizedAddress) ProtoMessage()

func (*MsgCreateAuthorizedAddress) Reset

func (m *MsgCreateAuthorizedAddress) Reset()

func (*MsgCreateAuthorizedAddress) Route

func (msg *MsgCreateAuthorizedAddress) Route() string

func (*MsgCreateAuthorizedAddress) Size

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

func (*MsgCreateAuthorizedAddress) String

func (m *MsgCreateAuthorizedAddress) String() string

func (*MsgCreateAuthorizedAddress) Type

func (msg *MsgCreateAuthorizedAddress) Type() string

func (*MsgCreateAuthorizedAddress) Unmarshal

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

func (*MsgCreateAuthorizedAddress) ValidateBasic

func (msg *MsgCreateAuthorizedAddress) ValidateBasic() error

func (*MsgCreateAuthorizedAddress) XXX_DiscardUnknown

func (m *MsgCreateAuthorizedAddress) XXX_DiscardUnknown()

func (*MsgCreateAuthorizedAddress) XXX_Marshal

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

func (*MsgCreateAuthorizedAddress) XXX_Merge

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

func (*MsgCreateAuthorizedAddress) XXX_Size

func (m *MsgCreateAuthorizedAddress) XXX_Size() int

func (*MsgCreateAuthorizedAddress) XXX_Unmarshal

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

type MsgCreateAuthorizedAddressResponse

type MsgCreateAuthorizedAddressResponse struct {
}

func (*MsgCreateAuthorizedAddressResponse) Descriptor

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

func (*MsgCreateAuthorizedAddressResponse) Marshal

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

func (*MsgCreateAuthorizedAddressResponse) MarshalTo

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

func (*MsgCreateAuthorizedAddressResponse) MarshalToSizedBuffer

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

func (*MsgCreateAuthorizedAddressResponse) ProtoMessage

func (*MsgCreateAuthorizedAddressResponse) ProtoMessage()

func (*MsgCreateAuthorizedAddressResponse) Reset

func (*MsgCreateAuthorizedAddressResponse) Size

func (*MsgCreateAuthorizedAddressResponse) String

func (*MsgCreateAuthorizedAddressResponse) Unmarshal

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

func (*MsgCreateAuthorizedAddressResponse) XXX_DiscardUnknown

func (m *MsgCreateAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*MsgCreateAuthorizedAddressResponse) XXX_Marshal

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

func (*MsgCreateAuthorizedAddressResponse) XXX_Merge

func (*MsgCreateAuthorizedAddressResponse) XXX_Size

func (*MsgCreateAuthorizedAddressResponse) XXX_Unmarshal

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

type MsgCreateGeneralKeyShare

type MsgCreateGeneralKeyShare struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=idType,proto3" json:"idType,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=idValue,proto3" json:"idValue,omitempty"`
	KeyShare            string `protobuf:"bytes,4,opt,name=keyShare,proto3" json:"keyShare,omitempty"`
	KeyShareIndex       uint64 `protobuf:"varint,5,opt,name=keyShareIndex,proto3" json:"keyShareIndex,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,6,opt,name=receivedTimestamp,proto3" json:"receivedTimestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,7,opt,name=receivedBlockHeight,proto3" json:"receivedBlockHeight,omitempty"`
}

func NewMsgCreateGeneralKeyShare

func NewMsgCreateGeneralKeyShare(
	creator string,
	idType string,
	idValue string,
	keyShare string,
	keyShareIndex uint64,

) *MsgCreateGeneralKeyShare

func (*MsgCreateGeneralKeyShare) Descriptor

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

func (*MsgCreateGeneralKeyShare) GetCreator

func (m *MsgCreateGeneralKeyShare) GetCreator() string

func (*MsgCreateGeneralKeyShare) GetIdType

func (m *MsgCreateGeneralKeyShare) GetIdType() string

func (*MsgCreateGeneralKeyShare) GetIdValue

func (m *MsgCreateGeneralKeyShare) GetIdValue() string

func (*MsgCreateGeneralKeyShare) GetKeyShare

func (m *MsgCreateGeneralKeyShare) GetKeyShare() string

func (*MsgCreateGeneralKeyShare) GetKeyShareIndex

func (m *MsgCreateGeneralKeyShare) GetKeyShareIndex() uint64

func (*MsgCreateGeneralKeyShare) GetReceivedBlockHeight

func (m *MsgCreateGeneralKeyShare) GetReceivedBlockHeight() uint64

func (*MsgCreateGeneralKeyShare) GetReceivedTimestamp

func (m *MsgCreateGeneralKeyShare) GetReceivedTimestamp() uint64

func (*MsgCreateGeneralKeyShare) GetSignBytes

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

func (*MsgCreateGeneralKeyShare) GetSigners

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

func (*MsgCreateGeneralKeyShare) Marshal

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

func (*MsgCreateGeneralKeyShare) MarshalTo

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

func (*MsgCreateGeneralKeyShare) MarshalToSizedBuffer

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

func (*MsgCreateGeneralKeyShare) ProtoMessage

func (*MsgCreateGeneralKeyShare) ProtoMessage()

func (*MsgCreateGeneralKeyShare) Reset

func (m *MsgCreateGeneralKeyShare) Reset()

func (*MsgCreateGeneralKeyShare) Route

func (msg *MsgCreateGeneralKeyShare) Route() string

func (*MsgCreateGeneralKeyShare) Size

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

func (*MsgCreateGeneralKeyShare) String

func (m *MsgCreateGeneralKeyShare) String() string

func (*MsgCreateGeneralKeyShare) Type

func (msg *MsgCreateGeneralKeyShare) Type() string

func (*MsgCreateGeneralKeyShare) Unmarshal

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

func (*MsgCreateGeneralKeyShare) ValidateBasic

func (msg *MsgCreateGeneralKeyShare) ValidateBasic() error

func (*MsgCreateGeneralKeyShare) XXX_DiscardUnknown

func (m *MsgCreateGeneralKeyShare) XXX_DiscardUnknown()

func (*MsgCreateGeneralKeyShare) XXX_Marshal

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

func (*MsgCreateGeneralKeyShare) XXX_Merge

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

func (*MsgCreateGeneralKeyShare) XXX_Size

func (m *MsgCreateGeneralKeyShare) XXX_Size() int

func (*MsgCreateGeneralKeyShare) XXX_Unmarshal

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

type MsgCreateGeneralKeyShareResponse

type MsgCreateGeneralKeyShareResponse struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=idType,proto3" json:"idType,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=idValue,proto3" json:"idValue,omitempty"`
	KeyShare            string `protobuf:"bytes,4,opt,name=keyShare,proto3" json:"keyShare,omitempty"`
	KeyShareIndex       uint64 `protobuf:"varint,5,opt,name=keyShareIndex,proto3" json:"keyShareIndex,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=receivedBlockHeight,proto3" json:"receivedBlockHeight,omitempty"`
	Success             bool   `protobuf:"varint,7,opt,name=success,proto3" json:"success,omitempty"`
	ErrorMessage        string `protobuf:"bytes,8,opt,name=errorMessage,proto3" json:"errorMessage,omitempty"`
}

func (*MsgCreateGeneralKeyShareResponse) Descriptor

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

func (*MsgCreateGeneralKeyShareResponse) GetCreator

func (m *MsgCreateGeneralKeyShareResponse) GetCreator() string

func (*MsgCreateGeneralKeyShareResponse) GetErrorMessage

func (m *MsgCreateGeneralKeyShareResponse) GetErrorMessage() string

func (*MsgCreateGeneralKeyShareResponse) GetIdType

func (*MsgCreateGeneralKeyShareResponse) GetIdValue

func (m *MsgCreateGeneralKeyShareResponse) GetIdValue() string

func (*MsgCreateGeneralKeyShareResponse) GetKeyShare

func (m *MsgCreateGeneralKeyShareResponse) GetKeyShare() string

func (*MsgCreateGeneralKeyShareResponse) GetKeyShareIndex

func (m *MsgCreateGeneralKeyShareResponse) GetKeyShareIndex() uint64

func (*MsgCreateGeneralKeyShareResponse) GetReceivedBlockHeight

func (m *MsgCreateGeneralKeyShareResponse) GetReceivedBlockHeight() uint64

func (*MsgCreateGeneralKeyShareResponse) GetSuccess

func (m *MsgCreateGeneralKeyShareResponse) GetSuccess() bool

func (*MsgCreateGeneralKeyShareResponse) Marshal

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

func (*MsgCreateGeneralKeyShareResponse) MarshalTo

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

func (*MsgCreateGeneralKeyShareResponse) MarshalToSizedBuffer

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

func (*MsgCreateGeneralKeyShareResponse) ProtoMessage

func (*MsgCreateGeneralKeyShareResponse) ProtoMessage()

func (*MsgCreateGeneralKeyShareResponse) Reset

func (*MsgCreateGeneralKeyShareResponse) Size

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

func (*MsgCreateGeneralKeyShareResponse) String

func (*MsgCreateGeneralKeyShareResponse) Unmarshal

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

func (*MsgCreateGeneralKeyShareResponse) XXX_DiscardUnknown

func (m *MsgCreateGeneralKeyShareResponse) XXX_DiscardUnknown()

func (*MsgCreateGeneralKeyShareResponse) XXX_Marshal

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

func (*MsgCreateGeneralKeyShareResponse) XXX_Merge

func (*MsgCreateGeneralKeyShareResponse) XXX_Size

func (m *MsgCreateGeneralKeyShareResponse) XXX_Size() int

func (*MsgCreateGeneralKeyShareResponse) XXX_Unmarshal

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

type MsgCreateLatestPubKey

type MsgCreateLatestPubKey struct {
	Creator            string               `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	PublicKey          string               `protobuf:"bytes,2,opt,name=publicKey,proto3" json:"publicKey,omitempty"`
	Commitments        []string             `protobuf:"bytes,3,rep,name=commitments,proto3" json:"commitments,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=numberOfValidators,proto3" json:"numberOfValidators,omitempty"`
	EncryptedKeyShares []*EncryptedKeyShare `protobuf:"bytes,5,rep,name=encryptedKeyShares,proto3" json:"encryptedKeyShares,omitempty"`
}

this line is used by starport scaffolding # proto/tx/message

func NewMsgCreateLatestPubKey

func NewMsgCreateLatestPubKey(
	creator string,
	publicKey string,
	commitments []string,
	numberOfValidators uint64,
	encryptedKeyShares []*EncryptedKeyShare,
) *MsgCreateLatestPubKey

func (*MsgCreateLatestPubKey) Descriptor

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

func (*MsgCreateLatestPubKey) GetCommitments

func (m *MsgCreateLatestPubKey) GetCommitments() []string

func (*MsgCreateLatestPubKey) GetCreator

func (m *MsgCreateLatestPubKey) GetCreator() string

func (*MsgCreateLatestPubKey) GetEncryptedKeyShares added in v0.5.0

func (m *MsgCreateLatestPubKey) GetEncryptedKeyShares() []*EncryptedKeyShare

func (*MsgCreateLatestPubKey) GetNumberOfValidators added in v0.5.0

func (m *MsgCreateLatestPubKey) GetNumberOfValidators() uint64

func (*MsgCreateLatestPubKey) GetPublicKey

func (m *MsgCreateLatestPubKey) GetPublicKey() string

func (*MsgCreateLatestPubKey) GetSignBytes

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

func (*MsgCreateLatestPubKey) GetSigners

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

func (*MsgCreateLatestPubKey) Marshal

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

func (*MsgCreateLatestPubKey) MarshalTo

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

func (*MsgCreateLatestPubKey) MarshalToSizedBuffer

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

func (*MsgCreateLatestPubKey) ProtoMessage

func (*MsgCreateLatestPubKey) ProtoMessage()

func (*MsgCreateLatestPubKey) Reset

func (m *MsgCreateLatestPubKey) Reset()

func (*MsgCreateLatestPubKey) Route

func (msg *MsgCreateLatestPubKey) Route() string

func (*MsgCreateLatestPubKey) Size

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

func (*MsgCreateLatestPubKey) String

func (m *MsgCreateLatestPubKey) String() string

func (*MsgCreateLatestPubKey) Type

func (msg *MsgCreateLatestPubKey) Type() string

func (*MsgCreateLatestPubKey) Unmarshal

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

func (*MsgCreateLatestPubKey) ValidateBasic

func (msg *MsgCreateLatestPubKey) ValidateBasic() error

func (*MsgCreateLatestPubKey) XXX_DiscardUnknown

func (m *MsgCreateLatestPubKey) XXX_DiscardUnknown()

func (*MsgCreateLatestPubKey) XXX_Marshal

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

func (*MsgCreateLatestPubKey) XXX_Merge

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

func (*MsgCreateLatestPubKey) XXX_Size

func (m *MsgCreateLatestPubKey) XXX_Size() int

func (*MsgCreateLatestPubKey) XXX_Unmarshal

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

type MsgCreateLatestPubKeyResponse

type MsgCreateLatestPubKeyResponse struct {
}

func (*MsgCreateLatestPubKeyResponse) Descriptor

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

func (*MsgCreateLatestPubKeyResponse) Marshal

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

func (*MsgCreateLatestPubKeyResponse) MarshalTo

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

func (*MsgCreateLatestPubKeyResponse) MarshalToSizedBuffer

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

func (*MsgCreateLatestPubKeyResponse) ProtoMessage

func (*MsgCreateLatestPubKeyResponse) ProtoMessage()

func (*MsgCreateLatestPubKeyResponse) Reset

func (m *MsgCreateLatestPubKeyResponse) Reset()

func (*MsgCreateLatestPubKeyResponse) Size

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

func (*MsgCreateLatestPubKeyResponse) String

func (*MsgCreateLatestPubKeyResponse) Unmarshal

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

func (*MsgCreateLatestPubKeyResponse) XXX_DiscardUnknown

func (m *MsgCreateLatestPubKeyResponse) XXX_DiscardUnknown()

func (*MsgCreateLatestPubKeyResponse) XXX_Marshal

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

func (*MsgCreateLatestPubKeyResponse) XXX_Merge

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

func (*MsgCreateLatestPubKeyResponse) XXX_Size

func (m *MsgCreateLatestPubKeyResponse) XXX_Size() int

func (*MsgCreateLatestPubKeyResponse) XXX_Unmarshal

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

type MsgDeRegisterValidator added in v0.5.0

type MsgDeRegisterValidator struct {
	Creator string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
}

func NewMsgDeRegisterValidator added in v0.5.0

func NewMsgDeRegisterValidator(creator string) *MsgDeRegisterValidator

func (*MsgDeRegisterValidator) Descriptor added in v0.5.0

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

func (*MsgDeRegisterValidator) GetCreator added in v0.5.0

func (m *MsgDeRegisterValidator) GetCreator() string

func (*MsgDeRegisterValidator) GetSignBytes added in v0.5.0

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

func (*MsgDeRegisterValidator) GetSigners added in v0.5.0

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

func (*MsgDeRegisterValidator) Marshal added in v0.5.0

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

func (*MsgDeRegisterValidator) MarshalTo added in v0.5.0

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

func (*MsgDeRegisterValidator) MarshalToSizedBuffer added in v0.5.0

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

func (*MsgDeRegisterValidator) ProtoMessage added in v0.5.0

func (*MsgDeRegisterValidator) ProtoMessage()

func (*MsgDeRegisterValidator) Reset added in v0.5.0

func (m *MsgDeRegisterValidator) Reset()

func (*MsgDeRegisterValidator) Route added in v0.5.0

func (msg *MsgDeRegisterValidator) Route() string

func (*MsgDeRegisterValidator) Size added in v0.5.0

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

func (*MsgDeRegisterValidator) String added in v0.5.0

func (m *MsgDeRegisterValidator) String() string

func (*MsgDeRegisterValidator) Type added in v0.5.0

func (msg *MsgDeRegisterValidator) Type() string

func (*MsgDeRegisterValidator) Unmarshal added in v0.5.0

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

func (*MsgDeRegisterValidator) ValidateBasic added in v0.5.0

func (msg *MsgDeRegisterValidator) ValidateBasic() error

func (*MsgDeRegisterValidator) XXX_DiscardUnknown added in v0.5.0

func (m *MsgDeRegisterValidator) XXX_DiscardUnknown()

func (*MsgDeRegisterValidator) XXX_Marshal added in v0.5.0

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

func (*MsgDeRegisterValidator) XXX_Merge added in v0.5.0

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

func (*MsgDeRegisterValidator) XXX_Size added in v0.5.0

func (m *MsgDeRegisterValidator) XXX_Size() int

func (*MsgDeRegisterValidator) XXX_Unmarshal added in v0.5.0

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

type MsgDeRegisterValidatorResponse added in v0.5.0

type MsgDeRegisterValidatorResponse struct {
	Creator string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
}

func (*MsgDeRegisterValidatorResponse) Descriptor added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) GetCreator added in v0.5.0

func (m *MsgDeRegisterValidatorResponse) GetCreator() string

func (*MsgDeRegisterValidatorResponse) Marshal added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) MarshalTo added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) MarshalToSizedBuffer added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) ProtoMessage added in v0.5.0

func (*MsgDeRegisterValidatorResponse) ProtoMessage()

func (*MsgDeRegisterValidatorResponse) Reset added in v0.5.0

func (m *MsgDeRegisterValidatorResponse) Reset()

func (*MsgDeRegisterValidatorResponse) Size added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) String added in v0.5.0

func (*MsgDeRegisterValidatorResponse) Unmarshal added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) XXX_DiscardUnknown added in v0.5.0

func (m *MsgDeRegisterValidatorResponse) XXX_DiscardUnknown()

func (*MsgDeRegisterValidatorResponse) XXX_Marshal added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) XXX_Merge added in v0.5.0

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

func (*MsgDeRegisterValidatorResponse) XXX_Size added in v0.5.0

func (m *MsgDeRegisterValidatorResponse) XXX_Size() int

func (*MsgDeRegisterValidatorResponse) XXX_Unmarshal added in v0.5.0

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

type MsgDeleteAuthorizedAddress

type MsgDeleteAuthorizedAddress struct {
	Target  string `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	Creator string `protobuf:"bytes,2,opt,name=creator,proto3" json:"creator,omitempty"`
}

func NewMsgDeleteAuthorizedAddress

func NewMsgDeleteAuthorizedAddress(
	creator string,
	target string,

) *MsgDeleteAuthorizedAddress

func (*MsgDeleteAuthorizedAddress) Descriptor

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

func (*MsgDeleteAuthorizedAddress) GetCreator

func (m *MsgDeleteAuthorizedAddress) GetCreator() string

func (*MsgDeleteAuthorizedAddress) GetSignBytes

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

func (*MsgDeleteAuthorizedAddress) GetSigners

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

func (*MsgDeleteAuthorizedAddress) GetTarget

func (m *MsgDeleteAuthorizedAddress) GetTarget() string

func (*MsgDeleteAuthorizedAddress) Marshal

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

func (*MsgDeleteAuthorizedAddress) MarshalTo

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

func (*MsgDeleteAuthorizedAddress) MarshalToSizedBuffer

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

func (*MsgDeleteAuthorizedAddress) ProtoMessage

func (*MsgDeleteAuthorizedAddress) ProtoMessage()

func (*MsgDeleteAuthorizedAddress) Reset

func (m *MsgDeleteAuthorizedAddress) Reset()

func (*MsgDeleteAuthorizedAddress) Route

func (msg *MsgDeleteAuthorizedAddress) Route() string

func (*MsgDeleteAuthorizedAddress) Size

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

func (*MsgDeleteAuthorizedAddress) String

func (m *MsgDeleteAuthorizedAddress) String() string

func (*MsgDeleteAuthorizedAddress) Type

func (msg *MsgDeleteAuthorizedAddress) Type() string

func (*MsgDeleteAuthorizedAddress) Unmarshal

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

func (*MsgDeleteAuthorizedAddress) ValidateBasic

func (msg *MsgDeleteAuthorizedAddress) ValidateBasic() error

func (*MsgDeleteAuthorizedAddress) XXX_DiscardUnknown

func (m *MsgDeleteAuthorizedAddress) XXX_DiscardUnknown()

func (*MsgDeleteAuthorizedAddress) XXX_Marshal

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

func (*MsgDeleteAuthorizedAddress) XXX_Merge

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

func (*MsgDeleteAuthorizedAddress) XXX_Size

func (m *MsgDeleteAuthorizedAddress) XXX_Size() int

func (*MsgDeleteAuthorizedAddress) XXX_Unmarshal

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

type MsgDeleteAuthorizedAddressResponse

type MsgDeleteAuthorizedAddressResponse struct {
}

func (*MsgDeleteAuthorizedAddressResponse) Descriptor

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

func (*MsgDeleteAuthorizedAddressResponse) Marshal

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

func (*MsgDeleteAuthorizedAddressResponse) MarshalTo

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

func (*MsgDeleteAuthorizedAddressResponse) MarshalToSizedBuffer

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

func (*MsgDeleteAuthorizedAddressResponse) ProtoMessage

func (*MsgDeleteAuthorizedAddressResponse) ProtoMessage()

func (*MsgDeleteAuthorizedAddressResponse) Reset

func (*MsgDeleteAuthorizedAddressResponse) Size

func (*MsgDeleteAuthorizedAddressResponse) String

func (*MsgDeleteAuthorizedAddressResponse) Unmarshal

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

func (*MsgDeleteAuthorizedAddressResponse) XXX_DiscardUnknown

func (m *MsgDeleteAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*MsgDeleteAuthorizedAddressResponse) XXX_Marshal

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

func (*MsgDeleteAuthorizedAddressResponse) XXX_Merge

func (*MsgDeleteAuthorizedAddressResponse) XXX_Size

func (*MsgDeleteAuthorizedAddressResponse) XXX_Unmarshal

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

type MsgOverrideLatestPubKey added in v0.5.0

type MsgOverrideLatestPubKey struct {
	Creator            string               `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	PublicKey          string               `protobuf:"bytes,2,opt,name=publicKey,proto3" json:"publicKey,omitempty"`
	Commitments        []string             `protobuf:"bytes,3,rep,name=commitments,proto3" json:"commitments,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=numberOfValidators,proto3" json:"numberOfValidators,omitempty"`
	EncryptedKeyShares []*EncryptedKeyShare `protobuf:"bytes,5,rep,name=encryptedKeyShares,proto3" json:"encryptedKeyShares,omitempty"`
}

func NewMsgOverrideLatestPubKey added in v0.5.0

func NewMsgOverrideLatestPubKey(
	creator string,
	publicKey string,
	commitments []string,
	numberOfValidators uint64,
	encryptedKeyShares []*EncryptedKeyShare,
) *MsgOverrideLatestPubKey

func (*MsgOverrideLatestPubKey) Descriptor added in v0.5.0

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

func (*MsgOverrideLatestPubKey) GetCommitments added in v0.5.0

func (m *MsgOverrideLatestPubKey) GetCommitments() []string

func (*MsgOverrideLatestPubKey) GetCreator added in v0.5.0

func (m *MsgOverrideLatestPubKey) GetCreator() string

func (*MsgOverrideLatestPubKey) GetEncryptedKeyShares added in v0.5.0

func (m *MsgOverrideLatestPubKey) GetEncryptedKeyShares() []*EncryptedKeyShare

func (*MsgOverrideLatestPubKey) GetNumberOfValidators added in v0.5.0

func (m *MsgOverrideLatestPubKey) GetNumberOfValidators() uint64

func (*MsgOverrideLatestPubKey) GetPublicKey added in v0.5.0

func (m *MsgOverrideLatestPubKey) GetPublicKey() string

func (*MsgOverrideLatestPubKey) GetSignBytes added in v0.5.0

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

func (*MsgOverrideLatestPubKey) GetSigners added in v0.5.0

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

func (*MsgOverrideLatestPubKey) Marshal added in v0.5.0

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

func (*MsgOverrideLatestPubKey) MarshalTo added in v0.5.0

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

func (*MsgOverrideLatestPubKey) MarshalToSizedBuffer added in v0.5.0

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

func (*MsgOverrideLatestPubKey) ProtoMessage added in v0.5.0

func (*MsgOverrideLatestPubKey) ProtoMessage()

func (*MsgOverrideLatestPubKey) Reset added in v0.5.0

func (m *MsgOverrideLatestPubKey) Reset()

func (*MsgOverrideLatestPubKey) Route added in v0.5.0

func (msg *MsgOverrideLatestPubKey) Route() string

func (*MsgOverrideLatestPubKey) Size added in v0.5.0

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

func (*MsgOverrideLatestPubKey) String added in v0.5.0

func (m *MsgOverrideLatestPubKey) String() string

func (*MsgOverrideLatestPubKey) Type added in v0.5.0

func (msg *MsgOverrideLatestPubKey) Type() string

func (*MsgOverrideLatestPubKey) Unmarshal added in v0.5.0

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

func (*MsgOverrideLatestPubKey) ValidateBasic added in v0.5.0

func (msg *MsgOverrideLatestPubKey) ValidateBasic() error

func (*MsgOverrideLatestPubKey) XXX_DiscardUnknown added in v0.5.0

func (m *MsgOverrideLatestPubKey) XXX_DiscardUnknown()

func (*MsgOverrideLatestPubKey) XXX_Marshal added in v0.5.0

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

func (*MsgOverrideLatestPubKey) XXX_Merge added in v0.5.0

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

func (*MsgOverrideLatestPubKey) XXX_Size added in v0.5.0

func (m *MsgOverrideLatestPubKey) XXX_Size() int

func (*MsgOverrideLatestPubKey) XXX_Unmarshal added in v0.5.0

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

type MsgOverrideLatestPubKeyResponse added in v0.5.0

type MsgOverrideLatestPubKeyResponse struct {
}

func (*MsgOverrideLatestPubKeyResponse) Descriptor added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) Marshal added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) MarshalTo added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) MarshalToSizedBuffer added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) ProtoMessage added in v0.5.0

func (*MsgOverrideLatestPubKeyResponse) ProtoMessage()

func (*MsgOverrideLatestPubKeyResponse) Reset added in v0.5.0

func (*MsgOverrideLatestPubKeyResponse) Size added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) String added in v0.5.0

func (*MsgOverrideLatestPubKeyResponse) Unmarshal added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) XXX_DiscardUnknown added in v0.5.0

func (m *MsgOverrideLatestPubKeyResponse) XXX_DiscardUnknown()

func (*MsgOverrideLatestPubKeyResponse) XXX_Marshal added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) XXX_Merge added in v0.5.0

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

func (*MsgOverrideLatestPubKeyResponse) XXX_Size added in v0.5.0

func (m *MsgOverrideLatestPubKeyResponse) XXX_Size() int

func (*MsgOverrideLatestPubKeyResponse) XXX_Unmarshal added in v0.5.0

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

type MsgRegisterValidator

type MsgRegisterValidator struct {
	Creator string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
}

func NewMsgRegisterValidator

func NewMsgRegisterValidator(creator string) *MsgRegisterValidator

func (*MsgRegisterValidator) Descriptor

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

func (*MsgRegisterValidator) GetCreator

func (m *MsgRegisterValidator) GetCreator() string

func (*MsgRegisterValidator) GetSignBytes

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

func (*MsgRegisterValidator) GetSigners

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

func (*MsgRegisterValidator) Marshal

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

func (*MsgRegisterValidator) MarshalTo

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

func (*MsgRegisterValidator) MarshalToSizedBuffer

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

func (*MsgRegisterValidator) ProtoMessage

func (*MsgRegisterValidator) ProtoMessage()

func (*MsgRegisterValidator) Reset

func (m *MsgRegisterValidator) Reset()

func (*MsgRegisterValidator) Route

func (msg *MsgRegisterValidator) Route() string

func (*MsgRegisterValidator) Size

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

func (*MsgRegisterValidator) String

func (m *MsgRegisterValidator) String() string

func (*MsgRegisterValidator) Type

func (msg *MsgRegisterValidator) Type() string

func (*MsgRegisterValidator) Unmarshal

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

func (*MsgRegisterValidator) ValidateBasic

func (msg *MsgRegisterValidator) ValidateBasic() error

func (*MsgRegisterValidator) XXX_DiscardUnknown

func (m *MsgRegisterValidator) XXX_DiscardUnknown()

func (*MsgRegisterValidator) XXX_Marshal

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

func (*MsgRegisterValidator) XXX_Merge

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

func (*MsgRegisterValidator) XXX_Size

func (m *MsgRegisterValidator) XXX_Size() int

func (*MsgRegisterValidator) XXX_Unmarshal

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

type MsgRegisterValidatorResponse

type MsgRegisterValidatorResponse struct {
	Creator string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
}

func (*MsgRegisterValidatorResponse) Descriptor

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

func (*MsgRegisterValidatorResponse) GetCreator

func (m *MsgRegisterValidatorResponse) GetCreator() string

func (*MsgRegisterValidatorResponse) Marshal

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

func (*MsgRegisterValidatorResponse) MarshalTo

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

func (*MsgRegisterValidatorResponse) MarshalToSizedBuffer

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

func (*MsgRegisterValidatorResponse) ProtoMessage

func (*MsgRegisterValidatorResponse) ProtoMessage()

func (*MsgRegisterValidatorResponse) Reset

func (m *MsgRegisterValidatorResponse) Reset()

func (*MsgRegisterValidatorResponse) Size

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

func (*MsgRegisterValidatorResponse) String

func (*MsgRegisterValidatorResponse) Unmarshal

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

func (*MsgRegisterValidatorResponse) XXX_DiscardUnknown

func (m *MsgRegisterValidatorResponse) XXX_DiscardUnknown()

func (*MsgRegisterValidatorResponse) XXX_Marshal

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

func (*MsgRegisterValidatorResponse) XXX_Merge

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

func (*MsgRegisterValidatorResponse) XXX_Size

func (m *MsgRegisterValidatorResponse) XXX_Size() int

func (*MsgRegisterValidatorResponse) XXX_Unmarshal

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

type MsgSendKeyshare

type MsgSendKeyshare struct {
	Creator       string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	Message       string `protobuf:"bytes,2,opt,name=message,proto3" json:"message,omitempty"`
	KeyShareIndex uint64 `protobuf:"varint,3,opt,name=keyShareIndex,proto3" json:"keyShareIndex,omitempty"`
	BlockHeight   uint64 `protobuf:"varint,4,opt,name=blockHeight,proto3" json:"blockHeight,omitempty"`
}

func NewMsgSendKeyshare

func NewMsgSendKeyshare(creator string, message string, keyShareIndex uint64, blockHeight uint64) *MsgSendKeyshare

func (*MsgSendKeyshare) Descriptor

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

func (*MsgSendKeyshare) GetBlockHeight

func (m *MsgSendKeyshare) GetBlockHeight() uint64

func (*MsgSendKeyshare) GetCreator

func (m *MsgSendKeyshare) GetCreator() string

func (*MsgSendKeyshare) GetKeyShareIndex

func (m *MsgSendKeyshare) GetKeyShareIndex() uint64

func (*MsgSendKeyshare) GetMessage

func (m *MsgSendKeyshare) GetMessage() string

func (*MsgSendKeyshare) GetSignBytes

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

func (*MsgSendKeyshare) GetSigners

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

func (*MsgSendKeyshare) Marshal

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

func (*MsgSendKeyshare) MarshalTo

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

func (*MsgSendKeyshare) MarshalToSizedBuffer

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

func (*MsgSendKeyshare) ProtoMessage

func (*MsgSendKeyshare) ProtoMessage()

func (*MsgSendKeyshare) Reset

func (m *MsgSendKeyshare) Reset()

func (*MsgSendKeyshare) Route

func (msg *MsgSendKeyshare) Route() string

func (*MsgSendKeyshare) Size

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

func (*MsgSendKeyshare) String

func (m *MsgSendKeyshare) String() string

func (*MsgSendKeyshare) Type

func (msg *MsgSendKeyshare) Type() string

func (*MsgSendKeyshare) Unmarshal

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

func (*MsgSendKeyshare) ValidateBasic

func (msg *MsgSendKeyshare) ValidateBasic() error

func (*MsgSendKeyshare) XXX_DiscardUnknown

func (m *MsgSendKeyshare) XXX_DiscardUnknown()

func (*MsgSendKeyshare) XXX_Marshal

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

func (*MsgSendKeyshare) XXX_Merge

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

func (*MsgSendKeyshare) XXX_Size

func (m *MsgSendKeyshare) XXX_Size() int

func (*MsgSendKeyshare) XXX_Unmarshal

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

type MsgSendKeyshareResponse

type MsgSendKeyshareResponse struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	Keyshare            string `protobuf:"bytes,2,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,3,opt,name=keyshareIndex,proto3" json:"keyshareIndex,omitempty"`
	BlockHeight         uint64 `protobuf:"varint,4,opt,name=blockHeight,proto3" json:"blockHeight,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,5,opt,name=receivedBlockHeight,proto3" json:"receivedBlockHeight,omitempty"`
	Success             bool   `protobuf:"varint,6,opt,name=success,proto3" json:"success,omitempty"`
	ErrorMessage        string `protobuf:"bytes,7,opt,name=errorMessage,proto3" json:"errorMessage,omitempty"`
}

func (*MsgSendKeyshareResponse) Descriptor

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

func (*MsgSendKeyshareResponse) GetBlockHeight

func (m *MsgSendKeyshareResponse) GetBlockHeight() uint64

func (*MsgSendKeyshareResponse) GetCreator

func (m *MsgSendKeyshareResponse) GetCreator() string

func (*MsgSendKeyshareResponse) GetErrorMessage

func (m *MsgSendKeyshareResponse) GetErrorMessage() string

func (*MsgSendKeyshareResponse) GetKeyshare

func (m *MsgSendKeyshareResponse) GetKeyshare() string

func (*MsgSendKeyshareResponse) GetKeyshareIndex

func (m *MsgSendKeyshareResponse) GetKeyshareIndex() uint64

func (*MsgSendKeyshareResponse) GetReceivedBlockHeight

func (m *MsgSendKeyshareResponse) GetReceivedBlockHeight() uint64

func (*MsgSendKeyshareResponse) GetSuccess

func (m *MsgSendKeyshareResponse) GetSuccess() bool

func (*MsgSendKeyshareResponse) Marshal

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

func (*MsgSendKeyshareResponse) MarshalTo

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

func (*MsgSendKeyshareResponse) MarshalToSizedBuffer

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

func (*MsgSendKeyshareResponse) ProtoMessage

func (*MsgSendKeyshareResponse) ProtoMessage()

func (*MsgSendKeyshareResponse) Reset

func (m *MsgSendKeyshareResponse) Reset()

func (*MsgSendKeyshareResponse) Size

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

func (*MsgSendKeyshareResponse) String

func (m *MsgSendKeyshareResponse) String() string

func (*MsgSendKeyshareResponse) Unmarshal

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

func (*MsgSendKeyshareResponse) XXX_DiscardUnknown

func (m *MsgSendKeyshareResponse) XXX_DiscardUnknown()

func (*MsgSendKeyshareResponse) XXX_Marshal

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

func (*MsgSendKeyshareResponse) XXX_Merge

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

func (*MsgSendKeyshareResponse) XXX_Size

func (m *MsgSendKeyshareResponse) XXX_Size() int

func (*MsgSendKeyshareResponse) XXX_Unmarshal

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

type MsgUpdateAuthorizedAddress

type MsgUpdateAuthorizedAddress struct {
	Target       string `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
	IsAuthorized bool   `protobuf:"varint,2,opt,name=isAuthorized,proto3" json:"isAuthorized,omitempty"`
	Creator      string `protobuf:"bytes,3,opt,name=creator,proto3" json:"creator,omitempty"`
}

func NewMsgUpdateAuthorizedAddress

func NewMsgUpdateAuthorizedAddress(
	creator string,
	target string,
	isAuthorized bool,
) *MsgUpdateAuthorizedAddress

func (*MsgUpdateAuthorizedAddress) Descriptor

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

func (*MsgUpdateAuthorizedAddress) GetCreator

func (m *MsgUpdateAuthorizedAddress) GetCreator() string

func (*MsgUpdateAuthorizedAddress) GetIsAuthorized

func (m *MsgUpdateAuthorizedAddress) GetIsAuthorized() bool

func (*MsgUpdateAuthorizedAddress) GetSignBytes

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

func (*MsgUpdateAuthorizedAddress) GetSigners

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

func (*MsgUpdateAuthorizedAddress) GetTarget

func (m *MsgUpdateAuthorizedAddress) GetTarget() string

func (*MsgUpdateAuthorizedAddress) Marshal

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

func (*MsgUpdateAuthorizedAddress) MarshalTo

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

func (*MsgUpdateAuthorizedAddress) MarshalToSizedBuffer

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

func (*MsgUpdateAuthorizedAddress) ProtoMessage

func (*MsgUpdateAuthorizedAddress) ProtoMessage()

func (*MsgUpdateAuthorizedAddress) Reset

func (m *MsgUpdateAuthorizedAddress) Reset()

func (*MsgUpdateAuthorizedAddress) Route

func (msg *MsgUpdateAuthorizedAddress) Route() string

func (*MsgUpdateAuthorizedAddress) Size

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

func (*MsgUpdateAuthorizedAddress) String

func (m *MsgUpdateAuthorizedAddress) String() string

func (*MsgUpdateAuthorizedAddress) Type

func (msg *MsgUpdateAuthorizedAddress) Type() string

func (*MsgUpdateAuthorizedAddress) Unmarshal

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

func (*MsgUpdateAuthorizedAddress) ValidateBasic

func (msg *MsgUpdateAuthorizedAddress) ValidateBasic() error

func (*MsgUpdateAuthorizedAddress) XXX_DiscardUnknown

func (m *MsgUpdateAuthorizedAddress) XXX_DiscardUnknown()

func (*MsgUpdateAuthorizedAddress) XXX_Marshal

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

func (*MsgUpdateAuthorizedAddress) XXX_Merge

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

func (*MsgUpdateAuthorizedAddress) XXX_Size

func (m *MsgUpdateAuthorizedAddress) XXX_Size() int

func (*MsgUpdateAuthorizedAddress) XXX_Unmarshal

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

type MsgUpdateAuthorizedAddressResponse

type MsgUpdateAuthorizedAddressResponse struct {
}

func (*MsgUpdateAuthorizedAddressResponse) Descriptor

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

func (*MsgUpdateAuthorizedAddressResponse) Marshal

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

func (*MsgUpdateAuthorizedAddressResponse) MarshalTo

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

func (*MsgUpdateAuthorizedAddressResponse) MarshalToSizedBuffer

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

func (*MsgUpdateAuthorizedAddressResponse) ProtoMessage

func (*MsgUpdateAuthorizedAddressResponse) ProtoMessage()

func (*MsgUpdateAuthorizedAddressResponse) Reset

func (*MsgUpdateAuthorizedAddressResponse) Size

func (*MsgUpdateAuthorizedAddressResponse) String

func (*MsgUpdateAuthorizedAddressResponse) Unmarshal

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

func (*MsgUpdateAuthorizedAddressResponse) XXX_DiscardUnknown

func (m *MsgUpdateAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*MsgUpdateAuthorizedAddressResponse) XXX_Marshal

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

func (*MsgUpdateAuthorizedAddressResponse) XXX_Merge

func (*MsgUpdateAuthorizedAddressResponse) XXX_Size

func (*MsgUpdateAuthorizedAddressResponse) XXX_Unmarshal

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

type NoData

type NoData struct {
}

func (*NoData) Descriptor

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

func (*NoData) Marshal

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

func (*NoData) MarshalTo

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

func (*NoData) MarshalToSizedBuffer

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

func (*NoData) ProtoMessage

func (*NoData) ProtoMessage()

func (*NoData) Reset

func (m *NoData) Reset()

func (*NoData) Size

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

func (*NoData) String

func (m *NoData) String() string

func (*NoData) Unmarshal

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

func (*NoData) XXX_DiscardUnknown

func (m *NoData) XXX_DiscardUnknown()

func (*NoData) XXX_Marshal

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

func (*NoData) XXX_Merge

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

func (*NoData) XXX_Size

func (m *NoData) XXX_Size() int

func (*NoData) XXX_Unmarshal

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

type Params

type Params struct {
	KeyExpiry                  uint64                                 `protobuf:"varint,1,opt,name=key_expiry,json=keyExpiry,proto3" json:"key_expiry,omitempty"`
	TrustedAddresses           []string                               `protobuf:"bytes,2,rep,name=trusted_addresses,json=trustedAddresses,proto3" json:"trusted_addresses,omitempty"`
	SlashFractionNoKeyshare    github_com_cosmos_cosmos_sdk_types.Dec `` /* 174-byte string literal not displayed */
	SlashFractionWrongKeyshare github_com_cosmos_cosmos_sdk_types.Dec `` /* 183-byte string literal not displayed */
	MinimumBonded              uint64                                 `protobuf:"varint,5,opt,name=minimum_bonded,json=minimumBonded,proto3" json:"minimum_bonded,omitempty"`
	MaxIdledBlock              uint64                                 `protobuf:"varint,6,opt,name=max_idled_block,json=maxIdledBlock,proto3" json:"max_idled_block,omitempty"`
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams(
	keyExp uint64,
	trAddrs []string,
	minimumBonded uint64,
	noKeyShareFraction sdk.Dec,
	wrongKeyShareFraction sdk.Dec,
	maxIdledBlock uint64,
) Params

NewParams creates a new Params instance

func (*Params) Descriptor

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

func (*Params) GetKeyExpiry

func (m *Params) GetKeyExpiry() uint64

func (*Params) GetMaxIdledBlock

func (m *Params) GetMaxIdledBlock() uint64

func (*Params) GetMinimumBonded

func (m *Params) GetMinimumBonded() uint64

func (*Params) GetTrustedAddresses

func (m *Params) GetTrustedAddresses() []string

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

ParamSetPairs get the params.ParamSet

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

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

func (Params) String

func (p Params) String() string

String implements the Stringer interface.

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

Validate validates the set of params

func (*Params) XXX_DiscardUnknown

func (m *Params) XXX_DiscardUnknown()

func (*Params) XXX_Marshal

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

func (*Params) XXX_Merge

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

func (*Params) XXX_Size

func (m *Params) XXX_Size() int

func (*Params) XXX_Unmarshal

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

type PepKeeper

type PepKeeper interface {
	SetActivePubKey(ctx sdk.Context, activePubKey peptypes.ActivePubKey)
	SetQueuedPubKey(ctx sdk.Context, queuedPubKey peptypes.QueuedPubKey)
	GetActivePubKey(ctx sdk.Context) (val peptypes.ActivePubKey, found bool)
	GetQueuedPubKey(ctx sdk.Context) (val peptypes.QueuedPubKey, found bool)
	DeleteActivePubKey(ctx sdk.Context)
	DeleteQueuedPubKey(ctx sdk.Context)
}

PepKeeper defines the expected interface needed to get and set active and queued public keys

type PortKeeper

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

PortKeeper defines the expected IBC port keeper

type QueryAllAggregatedKeyShareRequest

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

func (*QueryAllAggregatedKeyShareRequest) Descriptor

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

func (*QueryAllAggregatedKeyShareRequest) GetPagination

func (*QueryAllAggregatedKeyShareRequest) Marshal

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

func (*QueryAllAggregatedKeyShareRequest) MarshalTo

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

func (*QueryAllAggregatedKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryAllAggregatedKeyShareRequest) ProtoMessage

func (*QueryAllAggregatedKeyShareRequest) ProtoMessage()

func (*QueryAllAggregatedKeyShareRequest) Reset

func (*QueryAllAggregatedKeyShareRequest) Size

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

func (*QueryAllAggregatedKeyShareRequest) String

func (*QueryAllAggregatedKeyShareRequest) Unmarshal

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

func (*QueryAllAggregatedKeyShareRequest) XXX_DiscardUnknown

func (m *QueryAllAggregatedKeyShareRequest) XXX_DiscardUnknown()

func (*QueryAllAggregatedKeyShareRequest) XXX_Marshal

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

func (*QueryAllAggregatedKeyShareRequest) XXX_Merge

func (*QueryAllAggregatedKeyShareRequest) XXX_Size

func (m *QueryAllAggregatedKeyShareRequest) XXX_Size() int

func (*QueryAllAggregatedKeyShareRequest) XXX_Unmarshal

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

type QueryAllAggregatedKeyShareResponse

type QueryAllAggregatedKeyShareResponse struct {
	AggregatedKeyShare []AggregatedKeyShare `protobuf:"bytes,1,rep,name=aggregatedKeyShare,proto3" json:"aggregatedKeyShare"`
	Pagination         *query.PageResponse  `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllAggregatedKeyShareResponse) Descriptor

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

func (*QueryAllAggregatedKeyShareResponse) GetAggregatedKeyShare

func (m *QueryAllAggregatedKeyShareResponse) GetAggregatedKeyShare() []AggregatedKeyShare

func (*QueryAllAggregatedKeyShareResponse) GetPagination

func (*QueryAllAggregatedKeyShareResponse) Marshal

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

func (*QueryAllAggregatedKeyShareResponse) MarshalTo

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

func (*QueryAllAggregatedKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryAllAggregatedKeyShareResponse) ProtoMessage

func (*QueryAllAggregatedKeyShareResponse) ProtoMessage()

func (*QueryAllAggregatedKeyShareResponse) Reset

func (*QueryAllAggregatedKeyShareResponse) Size

func (*QueryAllAggregatedKeyShareResponse) String

func (*QueryAllAggregatedKeyShareResponse) Unmarshal

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

func (*QueryAllAggregatedKeyShareResponse) XXX_DiscardUnknown

func (m *QueryAllAggregatedKeyShareResponse) XXX_DiscardUnknown()

func (*QueryAllAggregatedKeyShareResponse) XXX_Marshal

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

func (*QueryAllAggregatedKeyShareResponse) XXX_Merge

func (*QueryAllAggregatedKeyShareResponse) XXX_Size

func (*QueryAllAggregatedKeyShareResponse) XXX_Unmarshal

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

type QueryAllAuthorizedAddressRequest

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

func (*QueryAllAuthorizedAddressRequest) Descriptor

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

func (*QueryAllAuthorizedAddressRequest) GetPagination

func (*QueryAllAuthorizedAddressRequest) Marshal

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

func (*QueryAllAuthorizedAddressRequest) MarshalTo

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

func (*QueryAllAuthorizedAddressRequest) MarshalToSizedBuffer

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

func (*QueryAllAuthorizedAddressRequest) ProtoMessage

func (*QueryAllAuthorizedAddressRequest) ProtoMessage()

func (*QueryAllAuthorizedAddressRequest) Reset

func (*QueryAllAuthorizedAddressRequest) Size

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

func (*QueryAllAuthorizedAddressRequest) String

func (*QueryAllAuthorizedAddressRequest) Unmarshal

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

func (*QueryAllAuthorizedAddressRequest) XXX_DiscardUnknown

func (m *QueryAllAuthorizedAddressRequest) XXX_DiscardUnknown()

func (*QueryAllAuthorizedAddressRequest) XXX_Marshal

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

func (*QueryAllAuthorizedAddressRequest) XXX_Merge

func (*QueryAllAuthorizedAddressRequest) XXX_Size

func (m *QueryAllAuthorizedAddressRequest) XXX_Size() int

func (*QueryAllAuthorizedAddressRequest) XXX_Unmarshal

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

type QueryAllAuthorizedAddressResponse

type QueryAllAuthorizedAddressResponse struct {
	AuthorizedAddress []AuthorizedAddress `protobuf:"bytes,1,rep,name=authorizedAddress,proto3" json:"authorizedAddress"`
	Pagination        *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllAuthorizedAddressResponse) Descriptor

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

func (*QueryAllAuthorizedAddressResponse) GetAuthorizedAddress

func (m *QueryAllAuthorizedAddressResponse) GetAuthorizedAddress() []AuthorizedAddress

func (*QueryAllAuthorizedAddressResponse) GetPagination

func (*QueryAllAuthorizedAddressResponse) Marshal

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

func (*QueryAllAuthorizedAddressResponse) MarshalTo

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

func (*QueryAllAuthorizedAddressResponse) MarshalToSizedBuffer

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

func (*QueryAllAuthorizedAddressResponse) ProtoMessage

func (*QueryAllAuthorizedAddressResponse) ProtoMessage()

func (*QueryAllAuthorizedAddressResponse) Reset

func (*QueryAllAuthorizedAddressResponse) Size

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

func (*QueryAllAuthorizedAddressResponse) String

func (*QueryAllAuthorizedAddressResponse) Unmarshal

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

func (*QueryAllAuthorizedAddressResponse) XXX_DiscardUnknown

func (m *QueryAllAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*QueryAllAuthorizedAddressResponse) XXX_Marshal

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

func (*QueryAllAuthorizedAddressResponse) XXX_Merge

func (*QueryAllAuthorizedAddressResponse) XXX_Size

func (m *QueryAllAuthorizedAddressResponse) XXX_Size() int

func (*QueryAllAuthorizedAddressResponse) XXX_Unmarshal

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

type QueryAllGeneralKeyShareRequest

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

func (*QueryAllGeneralKeyShareRequest) Descriptor

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

func (*QueryAllGeneralKeyShareRequest) GetPagination

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

func (*QueryAllGeneralKeyShareRequest) Marshal

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

func (*QueryAllGeneralKeyShareRequest) MarshalTo

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

func (*QueryAllGeneralKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryAllGeneralKeyShareRequest) ProtoMessage

func (*QueryAllGeneralKeyShareRequest) ProtoMessage()

func (*QueryAllGeneralKeyShareRequest) Reset

func (m *QueryAllGeneralKeyShareRequest) Reset()

func (*QueryAllGeneralKeyShareRequest) Size

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

func (*QueryAllGeneralKeyShareRequest) String

func (*QueryAllGeneralKeyShareRequest) Unmarshal

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

func (*QueryAllGeneralKeyShareRequest) XXX_DiscardUnknown

func (m *QueryAllGeneralKeyShareRequest) XXX_DiscardUnknown()

func (*QueryAllGeneralKeyShareRequest) XXX_Marshal

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

func (*QueryAllGeneralKeyShareRequest) XXX_Merge

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

func (*QueryAllGeneralKeyShareRequest) XXX_Size

func (m *QueryAllGeneralKeyShareRequest) XXX_Size() int

func (*QueryAllGeneralKeyShareRequest) XXX_Unmarshal

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

type QueryAllGeneralKeyShareResponse

type QueryAllGeneralKeyShareResponse struct {
	GeneralKeyShare []GeneralKeyShare   `protobuf:"bytes,1,rep,name=generalKeyShare,proto3" json:"generalKeyShare"`
	Pagination      *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllGeneralKeyShareResponse) Descriptor

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

func (*QueryAllGeneralKeyShareResponse) GetGeneralKeyShare

func (m *QueryAllGeneralKeyShareResponse) GetGeneralKeyShare() []GeneralKeyShare

func (*QueryAllGeneralKeyShareResponse) GetPagination

func (*QueryAllGeneralKeyShareResponse) Marshal

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

func (*QueryAllGeneralKeyShareResponse) MarshalTo

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

func (*QueryAllGeneralKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryAllGeneralKeyShareResponse) ProtoMessage

func (*QueryAllGeneralKeyShareResponse) ProtoMessage()

func (*QueryAllGeneralKeyShareResponse) Reset

func (*QueryAllGeneralKeyShareResponse) Size

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

func (*QueryAllGeneralKeyShareResponse) String

func (*QueryAllGeneralKeyShareResponse) Unmarshal

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

func (*QueryAllGeneralKeyShareResponse) XXX_DiscardUnknown

func (m *QueryAllGeneralKeyShareResponse) XXX_DiscardUnknown()

func (*QueryAllGeneralKeyShareResponse) XXX_Marshal

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

func (*QueryAllGeneralKeyShareResponse) XXX_Merge

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

func (*QueryAllGeneralKeyShareResponse) XXX_Size

func (m *QueryAllGeneralKeyShareResponse) XXX_Size() int

func (*QueryAllGeneralKeyShareResponse) XXX_Unmarshal

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

type QueryAllKeyShareRequest

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

func (*QueryAllKeyShareRequest) Descriptor

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

func (*QueryAllKeyShareRequest) GetPagination

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

func (*QueryAllKeyShareRequest) Marshal

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

func (*QueryAllKeyShareRequest) MarshalTo

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

func (*QueryAllKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryAllKeyShareRequest) ProtoMessage

func (*QueryAllKeyShareRequest) ProtoMessage()

func (*QueryAllKeyShareRequest) Reset

func (m *QueryAllKeyShareRequest) Reset()

func (*QueryAllKeyShareRequest) Size

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

func (*QueryAllKeyShareRequest) String

func (m *QueryAllKeyShareRequest) String() string

func (*QueryAllKeyShareRequest) Unmarshal

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

func (*QueryAllKeyShareRequest) XXX_DiscardUnknown

func (m *QueryAllKeyShareRequest) XXX_DiscardUnknown()

func (*QueryAllKeyShareRequest) XXX_Marshal

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

func (*QueryAllKeyShareRequest) XXX_Merge

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

func (*QueryAllKeyShareRequest) XXX_Size

func (m *QueryAllKeyShareRequest) XXX_Size() int

func (*QueryAllKeyShareRequest) XXX_Unmarshal

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

type QueryAllKeyShareResponse

type QueryAllKeyShareResponse struct {
	KeyShare   []KeyShare          `protobuf:"bytes,1,rep,name=keyShare,proto3" json:"keyShare"`
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllKeyShareResponse) Descriptor

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

func (*QueryAllKeyShareResponse) GetKeyShare

func (m *QueryAllKeyShareResponse) GetKeyShare() []KeyShare

func (*QueryAllKeyShareResponse) GetPagination

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

func (*QueryAllKeyShareResponse) Marshal

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

func (*QueryAllKeyShareResponse) MarshalTo

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

func (*QueryAllKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryAllKeyShareResponse) ProtoMessage

func (*QueryAllKeyShareResponse) ProtoMessage()

func (*QueryAllKeyShareResponse) Reset

func (m *QueryAllKeyShareResponse) Reset()

func (*QueryAllKeyShareResponse) Size

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

func (*QueryAllKeyShareResponse) String

func (m *QueryAllKeyShareResponse) String() string

func (*QueryAllKeyShareResponse) Unmarshal

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

func (*QueryAllKeyShareResponse) XXX_DiscardUnknown

func (m *QueryAllKeyShareResponse) XXX_DiscardUnknown()

func (*QueryAllKeyShareResponse) XXX_Marshal

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

func (*QueryAllKeyShareResponse) XXX_Merge

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

func (*QueryAllKeyShareResponse) XXX_Size

func (m *QueryAllKeyShareResponse) XXX_Size() int

func (*QueryAllKeyShareResponse) XXX_Unmarshal

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

type QueryAllValidatorSetRequest

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

func (*QueryAllValidatorSetRequest) Descriptor

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

func (*QueryAllValidatorSetRequest) GetPagination

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

func (*QueryAllValidatorSetRequest) Marshal

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

func (*QueryAllValidatorSetRequest) MarshalTo

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

func (*QueryAllValidatorSetRequest) MarshalToSizedBuffer

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

func (*QueryAllValidatorSetRequest) ProtoMessage

func (*QueryAllValidatorSetRequest) ProtoMessage()

func (*QueryAllValidatorSetRequest) Reset

func (m *QueryAllValidatorSetRequest) Reset()

func (*QueryAllValidatorSetRequest) Size

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

func (*QueryAllValidatorSetRequest) String

func (m *QueryAllValidatorSetRequest) String() string

func (*QueryAllValidatorSetRequest) Unmarshal

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

func (*QueryAllValidatorSetRequest) XXX_DiscardUnknown

func (m *QueryAllValidatorSetRequest) XXX_DiscardUnknown()

func (*QueryAllValidatorSetRequest) XXX_Marshal

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

func (*QueryAllValidatorSetRequest) XXX_Merge

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

func (*QueryAllValidatorSetRequest) XXX_Size

func (m *QueryAllValidatorSetRequest) XXX_Size() int

func (*QueryAllValidatorSetRequest) XXX_Unmarshal

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

type QueryAllValidatorSetResponse

type QueryAllValidatorSetResponse struct {
	ValidatorSet []ValidatorSet      `protobuf:"bytes,1,rep,name=validatorSet,proto3" json:"validatorSet"`
	Pagination   *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

func (*QueryAllValidatorSetResponse) Descriptor

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

func (*QueryAllValidatorSetResponse) GetPagination

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

func (*QueryAllValidatorSetResponse) GetValidatorSet

func (m *QueryAllValidatorSetResponse) GetValidatorSet() []ValidatorSet

func (*QueryAllValidatorSetResponse) Marshal

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

func (*QueryAllValidatorSetResponse) MarshalTo

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

func (*QueryAllValidatorSetResponse) MarshalToSizedBuffer

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

func (*QueryAllValidatorSetResponse) ProtoMessage

func (*QueryAllValidatorSetResponse) ProtoMessage()

func (*QueryAllValidatorSetResponse) Reset

func (m *QueryAllValidatorSetResponse) Reset()

func (*QueryAllValidatorSetResponse) Size

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

func (*QueryAllValidatorSetResponse) String

func (*QueryAllValidatorSetResponse) Unmarshal

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

func (*QueryAllValidatorSetResponse) XXX_DiscardUnknown

func (m *QueryAllValidatorSetResponse) XXX_DiscardUnknown()

func (*QueryAllValidatorSetResponse) XXX_Marshal

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

func (*QueryAllValidatorSetResponse) XXX_Merge

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

func (*QueryAllValidatorSetResponse) XXX_Size

func (m *QueryAllValidatorSetResponse) XXX_Size() int

func (*QueryAllValidatorSetResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	Commitments(ctx context.Context, in *QueryCommitmentsRequest, opts ...grpc.CallOption) (*QueryCommitmentsResponse, error)
	// Parameters queries the parameters of the module.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// Queries a ValidatorSet by index.
	ValidatorSet(ctx context.Context, in *QueryGetValidatorSetRequest, opts ...grpc.CallOption) (*QueryGetValidatorSetResponse, error)
	// Queries a list of ValidatorSet items.
	ValidatorSetAll(ctx context.Context, in *QueryAllValidatorSetRequest, opts ...grpc.CallOption) (*QueryAllValidatorSetResponse, error)
	// Queries a KeyShare by index.
	KeyShare(ctx context.Context, in *QueryGetKeyShareRequest, opts ...grpc.CallOption) (*QueryGetKeyShareResponse, error)
	// Queries a list of KeyShare items.
	KeyShareAll(ctx context.Context, in *QueryAllKeyShareRequest, opts ...grpc.CallOption) (*QueryAllKeyShareResponse, error)
	// Queries a list of AggregatedKeyShare items.
	AggregatedKeyShare(ctx context.Context, in *QueryGetAggregatedKeyShareRequest, opts ...grpc.CallOption) (*QueryGetAggregatedKeyShareResponse, error)
	AggregatedKeyShareAll(ctx context.Context, in *QueryAllAggregatedKeyShareRequest, opts ...grpc.CallOption) (*QueryAllAggregatedKeyShareResponse, error)
	// Queries the public keys
	PubKey(ctx context.Context, in *QueryPubKeyRequest, opts ...grpc.CallOption) (*QueryPubKeyResponse, error)
	// Queries a list of AuthorizedAddress items.
	AuthorizedAddress(ctx context.Context, in *QueryGetAuthorizedAddressRequest, opts ...grpc.CallOption) (*QueryGetAuthorizedAddressResponse, error)
	AuthorizedAddressAll(ctx context.Context, in *QueryAllAuthorizedAddressRequest, opts ...grpc.CallOption) (*QueryAllAuthorizedAddressResponse, error)
	// Queries a list of GeneralKeyShare items.
	GeneralKeyShare(ctx context.Context, in *QueryGetGeneralKeyShareRequest, opts ...grpc.CallOption) (*QueryGetGeneralKeyShareResponse, error)
	GeneralKeyShareAll(ctx context.Context, in *QueryAllGeneralKeyShareRequest, opts ...grpc.CallOption) (*QueryAllGeneralKeyShareResponse, 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 QueryCommitmentsRequest

type QueryCommitmentsRequest struct {
}

func (*QueryCommitmentsRequest) Descriptor

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

func (*QueryCommitmentsRequest) Marshal

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

func (*QueryCommitmentsRequest) MarshalTo

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

func (*QueryCommitmentsRequest) MarshalToSizedBuffer

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

func (*QueryCommitmentsRequest) ProtoMessage

func (*QueryCommitmentsRequest) ProtoMessage()

func (*QueryCommitmentsRequest) Reset

func (m *QueryCommitmentsRequest) Reset()

func (*QueryCommitmentsRequest) Size

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

func (*QueryCommitmentsRequest) String

func (m *QueryCommitmentsRequest) String() string

func (*QueryCommitmentsRequest) Unmarshal

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

func (*QueryCommitmentsRequest) XXX_DiscardUnknown

func (m *QueryCommitmentsRequest) XXX_DiscardUnknown()

func (*QueryCommitmentsRequest) XXX_Marshal

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

func (*QueryCommitmentsRequest) XXX_Merge

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

func (*QueryCommitmentsRequest) XXX_Size

func (m *QueryCommitmentsRequest) XXX_Size() int

func (*QueryCommitmentsRequest) XXX_Unmarshal

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

type QueryCommitmentsResponse

type QueryCommitmentsResponse struct {
	ActiveCommitments *Commitments `protobuf:"bytes,1,opt,name=activeCommitments,proto3" json:"activeCommitments,omitempty"`
	QueuedCommitments *Commitments `protobuf:"bytes,2,opt,name=queuedCommitments,proto3" json:"queuedCommitments,omitempty"`
}

func (*QueryCommitmentsResponse) Descriptor

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

func (*QueryCommitmentsResponse) GetActiveCommitments

func (m *QueryCommitmentsResponse) GetActiveCommitments() *Commitments

func (*QueryCommitmentsResponse) GetQueuedCommitments

func (m *QueryCommitmentsResponse) GetQueuedCommitments() *Commitments

func (*QueryCommitmentsResponse) Marshal

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

func (*QueryCommitmentsResponse) MarshalTo

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

func (*QueryCommitmentsResponse) MarshalToSizedBuffer

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

func (*QueryCommitmentsResponse) ProtoMessage

func (*QueryCommitmentsResponse) ProtoMessage()

func (*QueryCommitmentsResponse) Reset

func (m *QueryCommitmentsResponse) Reset()

func (*QueryCommitmentsResponse) Size

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

func (*QueryCommitmentsResponse) String

func (m *QueryCommitmentsResponse) String() string

func (*QueryCommitmentsResponse) Unmarshal

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

func (*QueryCommitmentsResponse) XXX_DiscardUnknown

func (m *QueryCommitmentsResponse) XXX_DiscardUnknown()

func (*QueryCommitmentsResponse) XXX_Marshal

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

func (*QueryCommitmentsResponse) XXX_Merge

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

func (*QueryCommitmentsResponse) XXX_Size

func (m *QueryCommitmentsResponse) XXX_Size() int

func (*QueryCommitmentsResponse) XXX_Unmarshal

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

type QueryGetAggregatedKeyShareRequest

type QueryGetAggregatedKeyShareRequest struct {
	Height uint64 `protobuf:"varint,1,opt,name=height,proto3" json:"height,omitempty"`
}

this line is used by starport scaffolding # 3

func (*QueryGetAggregatedKeyShareRequest) Descriptor

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

func (*QueryGetAggregatedKeyShareRequest) GetHeight

func (*QueryGetAggregatedKeyShareRequest) Marshal

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

func (*QueryGetAggregatedKeyShareRequest) MarshalTo

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

func (*QueryGetAggregatedKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryGetAggregatedKeyShareRequest) ProtoMessage

func (*QueryGetAggregatedKeyShareRequest) ProtoMessage()

func (*QueryGetAggregatedKeyShareRequest) Reset

func (*QueryGetAggregatedKeyShareRequest) Size

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

func (*QueryGetAggregatedKeyShareRequest) String

func (*QueryGetAggregatedKeyShareRequest) Unmarshal

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

func (*QueryGetAggregatedKeyShareRequest) XXX_DiscardUnknown

func (m *QueryGetAggregatedKeyShareRequest) XXX_DiscardUnknown()

func (*QueryGetAggregatedKeyShareRequest) XXX_Marshal

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

func (*QueryGetAggregatedKeyShareRequest) XXX_Merge

func (*QueryGetAggregatedKeyShareRequest) XXX_Size

func (m *QueryGetAggregatedKeyShareRequest) XXX_Size() int

func (*QueryGetAggregatedKeyShareRequest) XXX_Unmarshal

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

type QueryGetAggregatedKeyShareResponse

type QueryGetAggregatedKeyShareResponse struct {
	AggregatedKeyShare AggregatedKeyShare `protobuf:"bytes,1,opt,name=aggregatedKeyShare,proto3" json:"aggregatedKeyShare"`
}

func (*QueryGetAggregatedKeyShareResponse) Descriptor

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

func (*QueryGetAggregatedKeyShareResponse) GetAggregatedKeyShare

func (m *QueryGetAggregatedKeyShareResponse) GetAggregatedKeyShare() AggregatedKeyShare

func (*QueryGetAggregatedKeyShareResponse) Marshal

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

func (*QueryGetAggregatedKeyShareResponse) MarshalTo

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

func (*QueryGetAggregatedKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryGetAggregatedKeyShareResponse) ProtoMessage

func (*QueryGetAggregatedKeyShareResponse) ProtoMessage()

func (*QueryGetAggregatedKeyShareResponse) Reset

func (*QueryGetAggregatedKeyShareResponse) Size

func (*QueryGetAggregatedKeyShareResponse) String

func (*QueryGetAggregatedKeyShareResponse) Unmarshal

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

func (*QueryGetAggregatedKeyShareResponse) XXX_DiscardUnknown

func (m *QueryGetAggregatedKeyShareResponse) XXX_DiscardUnknown()

func (*QueryGetAggregatedKeyShareResponse) XXX_Marshal

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

func (*QueryGetAggregatedKeyShareResponse) XXX_Merge

func (*QueryGetAggregatedKeyShareResponse) XXX_Size

func (*QueryGetAggregatedKeyShareResponse) XXX_Unmarshal

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

type QueryGetAuthorizedAddressRequest

type QueryGetAuthorizedAddressRequest struct {
	Target string `protobuf:"bytes,1,opt,name=target,proto3" json:"target,omitempty"`
}

func (*QueryGetAuthorizedAddressRequest) Descriptor

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

func (*QueryGetAuthorizedAddressRequest) GetTarget

func (*QueryGetAuthorizedAddressRequest) Marshal

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

func (*QueryGetAuthorizedAddressRequest) MarshalTo

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

func (*QueryGetAuthorizedAddressRequest) MarshalToSizedBuffer

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

func (*QueryGetAuthorizedAddressRequest) ProtoMessage

func (*QueryGetAuthorizedAddressRequest) ProtoMessage()

func (*QueryGetAuthorizedAddressRequest) Reset

func (*QueryGetAuthorizedAddressRequest) Size

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

func (*QueryGetAuthorizedAddressRequest) String

func (*QueryGetAuthorizedAddressRequest) Unmarshal

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

func (*QueryGetAuthorizedAddressRequest) XXX_DiscardUnknown

func (m *QueryGetAuthorizedAddressRequest) XXX_DiscardUnknown()

func (*QueryGetAuthorizedAddressRequest) XXX_Marshal

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

func (*QueryGetAuthorizedAddressRequest) XXX_Merge

func (*QueryGetAuthorizedAddressRequest) XXX_Size

func (m *QueryGetAuthorizedAddressRequest) XXX_Size() int

func (*QueryGetAuthorizedAddressRequest) XXX_Unmarshal

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

type QueryGetAuthorizedAddressResponse

type QueryGetAuthorizedAddressResponse struct {
	AuthorizedAddress AuthorizedAddress `protobuf:"bytes,1,opt,name=authorizedAddress,proto3" json:"authorizedAddress"`
}

func (*QueryGetAuthorizedAddressResponse) Descriptor

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

func (*QueryGetAuthorizedAddressResponse) GetAuthorizedAddress

func (m *QueryGetAuthorizedAddressResponse) GetAuthorizedAddress() AuthorizedAddress

func (*QueryGetAuthorizedAddressResponse) Marshal

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

func (*QueryGetAuthorizedAddressResponse) MarshalTo

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

func (*QueryGetAuthorizedAddressResponse) MarshalToSizedBuffer

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

func (*QueryGetAuthorizedAddressResponse) ProtoMessage

func (*QueryGetAuthorizedAddressResponse) ProtoMessage()

func (*QueryGetAuthorizedAddressResponse) Reset

func (*QueryGetAuthorizedAddressResponse) Size

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

func (*QueryGetAuthorizedAddressResponse) String

func (*QueryGetAuthorizedAddressResponse) Unmarshal

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

func (*QueryGetAuthorizedAddressResponse) XXX_DiscardUnknown

func (m *QueryGetAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*QueryGetAuthorizedAddressResponse) XXX_Marshal

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

func (*QueryGetAuthorizedAddressResponse) XXX_Merge

func (*QueryGetAuthorizedAddressResponse) XXX_Size

func (m *QueryGetAuthorizedAddressResponse) XXX_Size() int

func (*QueryGetAuthorizedAddressResponse) XXX_Unmarshal

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

type QueryGetGeneralKeyShareRequest

type QueryGetGeneralKeyShareRequest struct {
	Validator string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	IdType    string `protobuf:"bytes,2,opt,name=idType,proto3" json:"idType,omitempty"`
	IdValue   string `protobuf:"bytes,3,opt,name=idValue,proto3" json:"idValue,omitempty"`
}

func (*QueryGetGeneralKeyShareRequest) Descriptor

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

func (*QueryGetGeneralKeyShareRequest) GetIdType

func (m *QueryGetGeneralKeyShareRequest) GetIdType() string

func (*QueryGetGeneralKeyShareRequest) GetIdValue

func (m *QueryGetGeneralKeyShareRequest) GetIdValue() string

func (*QueryGetGeneralKeyShareRequest) GetValidator

func (m *QueryGetGeneralKeyShareRequest) GetValidator() string

func (*QueryGetGeneralKeyShareRequest) Marshal

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

func (*QueryGetGeneralKeyShareRequest) MarshalTo

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

func (*QueryGetGeneralKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryGetGeneralKeyShareRequest) ProtoMessage

func (*QueryGetGeneralKeyShareRequest) ProtoMessage()

func (*QueryGetGeneralKeyShareRequest) Reset

func (m *QueryGetGeneralKeyShareRequest) Reset()

func (*QueryGetGeneralKeyShareRequest) Size

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

func (*QueryGetGeneralKeyShareRequest) String

func (*QueryGetGeneralKeyShareRequest) Unmarshal

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

func (*QueryGetGeneralKeyShareRequest) XXX_DiscardUnknown

func (m *QueryGetGeneralKeyShareRequest) XXX_DiscardUnknown()

func (*QueryGetGeneralKeyShareRequest) XXX_Marshal

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

func (*QueryGetGeneralKeyShareRequest) XXX_Merge

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

func (*QueryGetGeneralKeyShareRequest) XXX_Size

func (m *QueryGetGeneralKeyShareRequest) XXX_Size() int

func (*QueryGetGeneralKeyShareRequest) XXX_Unmarshal

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

type QueryGetGeneralKeyShareResponse

type QueryGetGeneralKeyShareResponse struct {
	GeneralKeyShare GeneralKeyShare `protobuf:"bytes,1,opt,name=generalKeyShare,proto3" json:"generalKeyShare"`
}

func (*QueryGetGeneralKeyShareResponse) Descriptor

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

func (*QueryGetGeneralKeyShareResponse) GetGeneralKeyShare

func (m *QueryGetGeneralKeyShareResponse) GetGeneralKeyShare() GeneralKeyShare

func (*QueryGetGeneralKeyShareResponse) Marshal

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

func (*QueryGetGeneralKeyShareResponse) MarshalTo

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

func (*QueryGetGeneralKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryGetGeneralKeyShareResponse) ProtoMessage

func (*QueryGetGeneralKeyShareResponse) ProtoMessage()

func (*QueryGetGeneralKeyShareResponse) Reset

func (*QueryGetGeneralKeyShareResponse) Size

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

func (*QueryGetGeneralKeyShareResponse) String

func (*QueryGetGeneralKeyShareResponse) Unmarshal

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

func (*QueryGetGeneralKeyShareResponse) XXX_DiscardUnknown

func (m *QueryGetGeneralKeyShareResponse) XXX_DiscardUnknown()

func (*QueryGetGeneralKeyShareResponse) XXX_Marshal

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

func (*QueryGetGeneralKeyShareResponse) XXX_Merge

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

func (*QueryGetGeneralKeyShareResponse) XXX_Size

func (m *QueryGetGeneralKeyShareResponse) XXX_Size() int

func (*QueryGetGeneralKeyShareResponse) XXX_Unmarshal

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

type QueryGetKeyShareRequest

type QueryGetKeyShareRequest struct {
	Validator   string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	BlockHeight uint64 `protobuf:"varint,2,opt,name=blockHeight,proto3" json:"blockHeight,omitempty"`
}

func (*QueryGetKeyShareRequest) Descriptor

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

func (*QueryGetKeyShareRequest) GetBlockHeight

func (m *QueryGetKeyShareRequest) GetBlockHeight() uint64

func (*QueryGetKeyShareRequest) GetValidator

func (m *QueryGetKeyShareRequest) GetValidator() string

func (*QueryGetKeyShareRequest) Marshal

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

func (*QueryGetKeyShareRequest) MarshalTo

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

func (*QueryGetKeyShareRequest) MarshalToSizedBuffer

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

func (*QueryGetKeyShareRequest) ProtoMessage

func (*QueryGetKeyShareRequest) ProtoMessage()

func (*QueryGetKeyShareRequest) Reset

func (m *QueryGetKeyShareRequest) Reset()

func (*QueryGetKeyShareRequest) Size

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

func (*QueryGetKeyShareRequest) String

func (m *QueryGetKeyShareRequest) String() string

func (*QueryGetKeyShareRequest) Unmarshal

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

func (*QueryGetKeyShareRequest) XXX_DiscardUnknown

func (m *QueryGetKeyShareRequest) XXX_DiscardUnknown()

func (*QueryGetKeyShareRequest) XXX_Marshal

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

func (*QueryGetKeyShareRequest) XXX_Merge

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

func (*QueryGetKeyShareRequest) XXX_Size

func (m *QueryGetKeyShareRequest) XXX_Size() int

func (*QueryGetKeyShareRequest) XXX_Unmarshal

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

type QueryGetKeyShareResponse

type QueryGetKeyShareResponse struct {
	KeyShare KeyShare `protobuf:"bytes,1,opt,name=keyShare,proto3" json:"keyShare"`
}

func (*QueryGetKeyShareResponse) Descriptor

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

func (*QueryGetKeyShareResponse) GetKeyShare

func (m *QueryGetKeyShareResponse) GetKeyShare() KeyShare

func (*QueryGetKeyShareResponse) Marshal

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

func (*QueryGetKeyShareResponse) MarshalTo

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

func (*QueryGetKeyShareResponse) MarshalToSizedBuffer

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

func (*QueryGetKeyShareResponse) ProtoMessage

func (*QueryGetKeyShareResponse) ProtoMessage()

func (*QueryGetKeyShareResponse) Reset

func (m *QueryGetKeyShareResponse) Reset()

func (*QueryGetKeyShareResponse) Size

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

func (*QueryGetKeyShareResponse) String

func (m *QueryGetKeyShareResponse) String() string

func (*QueryGetKeyShareResponse) Unmarshal

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

func (*QueryGetKeyShareResponse) XXX_DiscardUnknown

func (m *QueryGetKeyShareResponse) XXX_DiscardUnknown()

func (*QueryGetKeyShareResponse) XXX_Marshal

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

func (*QueryGetKeyShareResponse) XXX_Merge

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

func (*QueryGetKeyShareResponse) XXX_Size

func (m *QueryGetKeyShareResponse) XXX_Size() int

func (*QueryGetKeyShareResponse) XXX_Unmarshal

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

type QueryGetValidatorSetRequest

type QueryGetValidatorSetRequest struct {
	Index string `protobuf:"bytes,1,opt,name=index,proto3" json:"index,omitempty"`
}

func (*QueryGetValidatorSetRequest) Descriptor

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

func (*QueryGetValidatorSetRequest) GetIndex

func (m *QueryGetValidatorSetRequest) GetIndex() string

func (*QueryGetValidatorSetRequest) Marshal

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

func (*QueryGetValidatorSetRequest) MarshalTo

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

func (*QueryGetValidatorSetRequest) MarshalToSizedBuffer

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

func (*QueryGetValidatorSetRequest) ProtoMessage

func (*QueryGetValidatorSetRequest) ProtoMessage()

func (*QueryGetValidatorSetRequest) Reset

func (m *QueryGetValidatorSetRequest) Reset()

func (*QueryGetValidatorSetRequest) Size

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

func (*QueryGetValidatorSetRequest) String

func (m *QueryGetValidatorSetRequest) String() string

func (*QueryGetValidatorSetRequest) Unmarshal

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

func (*QueryGetValidatorSetRequest) XXX_DiscardUnknown

func (m *QueryGetValidatorSetRequest) XXX_DiscardUnknown()

func (*QueryGetValidatorSetRequest) XXX_Marshal

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

func (*QueryGetValidatorSetRequest) XXX_Merge

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

func (*QueryGetValidatorSetRequest) XXX_Size

func (m *QueryGetValidatorSetRequest) XXX_Size() int

func (*QueryGetValidatorSetRequest) XXX_Unmarshal

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

type QueryGetValidatorSetResponse

type QueryGetValidatorSetResponse struct {
	ValidatorSet ValidatorSet `protobuf:"bytes,1,opt,name=validatorSet,proto3" json:"validatorSet"`
}

func (*QueryGetValidatorSetResponse) Descriptor

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

func (*QueryGetValidatorSetResponse) GetValidatorSet

func (m *QueryGetValidatorSetResponse) GetValidatorSet() ValidatorSet

func (*QueryGetValidatorSetResponse) Marshal

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

func (*QueryGetValidatorSetResponse) MarshalTo

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

func (*QueryGetValidatorSetResponse) MarshalToSizedBuffer

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

func (*QueryGetValidatorSetResponse) ProtoMessage

func (*QueryGetValidatorSetResponse) ProtoMessage()

func (*QueryGetValidatorSetResponse) Reset

func (m *QueryGetValidatorSetResponse) Reset()

func (*QueryGetValidatorSetResponse) Size

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

func (*QueryGetValidatorSetResponse) String

func (*QueryGetValidatorSetResponse) Unmarshal

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

func (*QueryGetValidatorSetResponse) XXX_DiscardUnknown

func (m *QueryGetValidatorSetResponse) XXX_DiscardUnknown()

func (*QueryGetValidatorSetResponse) XXX_Marshal

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

func (*QueryGetValidatorSetResponse) XXX_Merge

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

func (*QueryGetValidatorSetResponse) XXX_Size

func (m *QueryGetValidatorSetResponse) XXX_Size() int

func (*QueryGetValidatorSetResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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

func (*QueryParamsRequest) Descriptor

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

func (*QueryParamsRequest) Marshal

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

func (*QueryParamsRequest) MarshalTo

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

func (*QueryParamsRequest) MarshalToSizedBuffer

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

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

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

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

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

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

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

func (*QueryParamsRequest) XXX_Merge

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

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

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

type QueryParamsResponse

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

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

func (*QueryParamsResponse) Descriptor

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

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

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

func (*QueryParamsResponse) MarshalTo

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

func (*QueryParamsResponse) MarshalToSizedBuffer

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

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

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

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

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

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

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

func (*QueryParamsResponse) XXX_Merge

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

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

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

type QueryPubKeyRequest

type QueryPubKeyRequest struct {
}

func (*QueryPubKeyRequest) Descriptor

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

func (*QueryPubKeyRequest) Marshal

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

func (*QueryPubKeyRequest) MarshalTo

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

func (*QueryPubKeyRequest) MarshalToSizedBuffer

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

func (*QueryPubKeyRequest) ProtoMessage

func (*QueryPubKeyRequest) ProtoMessage()

func (*QueryPubKeyRequest) Reset

func (m *QueryPubKeyRequest) Reset()

func (*QueryPubKeyRequest) Size

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

func (*QueryPubKeyRequest) String

func (m *QueryPubKeyRequest) String() string

func (*QueryPubKeyRequest) Unmarshal

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

func (*QueryPubKeyRequest) XXX_DiscardUnknown

func (m *QueryPubKeyRequest) XXX_DiscardUnknown()

func (*QueryPubKeyRequest) XXX_Marshal

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

func (*QueryPubKeyRequest) XXX_Merge

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

func (*QueryPubKeyRequest) XXX_Size

func (m *QueryPubKeyRequest) XXX_Size() int

func (*QueryPubKeyRequest) XXX_Unmarshal

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

type QueryPubKeyResponse

type QueryPubKeyResponse struct {
	ActivePubKey ActivePubKey `protobuf:"bytes,1,opt,name=activePubKey,proto3" json:"activePubKey"`
	QueuedPubKey QueuedPubKey `protobuf:"bytes,2,opt,name=queuedPubKey,proto3" json:"queuedPubKey"`
}

func (*QueryPubKeyResponse) Descriptor

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

func (*QueryPubKeyResponse) GetActivePubKey

func (m *QueryPubKeyResponse) GetActivePubKey() ActivePubKey

func (*QueryPubKeyResponse) GetQueuedPubKey

func (m *QueryPubKeyResponse) GetQueuedPubKey() QueuedPubKey

func (*QueryPubKeyResponse) Marshal

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

func (*QueryPubKeyResponse) MarshalTo

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

func (*QueryPubKeyResponse) MarshalToSizedBuffer

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

func (*QueryPubKeyResponse) ProtoMessage

func (*QueryPubKeyResponse) ProtoMessage()

func (*QueryPubKeyResponse) Reset

func (m *QueryPubKeyResponse) Reset()

func (*QueryPubKeyResponse) Size

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

func (*QueryPubKeyResponse) String

func (m *QueryPubKeyResponse) String() string

func (*QueryPubKeyResponse) Unmarshal

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

func (*QueryPubKeyResponse) XXX_DiscardUnknown

func (m *QueryPubKeyResponse) XXX_DiscardUnknown()

func (*QueryPubKeyResponse) XXX_Marshal

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

func (*QueryPubKeyResponse) XXX_Merge

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

func (*QueryPubKeyResponse) XXX_Size

func (m *QueryPubKeyResponse) XXX_Size() int

func (*QueryPubKeyResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	Commitments(context.Context, *QueryCommitmentsRequest) (*QueryCommitmentsResponse, error)
	// Parameters queries the parameters of the module.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// Queries a ValidatorSet by index.
	ValidatorSet(context.Context, *QueryGetValidatorSetRequest) (*QueryGetValidatorSetResponse, error)
	// Queries a list of ValidatorSet items.
	ValidatorSetAll(context.Context, *QueryAllValidatorSetRequest) (*QueryAllValidatorSetResponse, error)
	// Queries a KeyShare by index.
	KeyShare(context.Context, *QueryGetKeyShareRequest) (*QueryGetKeyShareResponse, error)
	// Queries a list of KeyShare items.
	KeyShareAll(context.Context, *QueryAllKeyShareRequest) (*QueryAllKeyShareResponse, error)
	// Queries a list of AggregatedKeyShare items.
	AggregatedKeyShare(context.Context, *QueryGetAggregatedKeyShareRequest) (*QueryGetAggregatedKeyShareResponse, error)
	AggregatedKeyShareAll(context.Context, *QueryAllAggregatedKeyShareRequest) (*QueryAllAggregatedKeyShareResponse, error)
	// Queries the public keys
	PubKey(context.Context, *QueryPubKeyRequest) (*QueryPubKeyResponse, error)
	// Queries a list of AuthorizedAddress items.
	AuthorizedAddress(context.Context, *QueryGetAuthorizedAddressRequest) (*QueryGetAuthorizedAddressResponse, error)
	AuthorizedAddressAll(context.Context, *QueryAllAuthorizedAddressRequest) (*QueryAllAuthorizedAddressResponse, error)
	// Queries a list of GeneralKeyShare items.
	GeneralKeyShare(context.Context, *QueryGetGeneralKeyShareRequest) (*QueryGetGeneralKeyShareResponse, error)
	GeneralKeyShareAll(context.Context, *QueryAllGeneralKeyShareRequest) (*QueryAllGeneralKeyShareResponse, error)
}

QueryServer is the server API for Query service.

type QueuedPubKey

type QueuedPubKey struct {
	PublicKey          string               `protobuf:"bytes,1,opt,name=publicKey,proto3" json:"publicKey,omitempty"`
	Creator            string               `protobuf:"bytes,2,opt,name=creator,proto3" json:"creator,omitempty"`
	Expiry             uint64               `protobuf:"varint,3,opt,name=expiry,proto3" json:"expiry,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=numberOfValidators,proto3" json:"numberOfValidators,omitempty"`
	EncryptedKeyShares []*EncryptedKeyShare `protobuf:"bytes,5,rep,name=encryptedKeyShares,proto3" json:"encryptedKeyShares,omitempty"`
}

func (*QueuedPubKey) Descriptor

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

func (*QueuedPubKey) GetCreator

func (m *QueuedPubKey) GetCreator() string

func (*QueuedPubKey) GetEncryptedKeyShares added in v0.5.0

func (m *QueuedPubKey) GetEncryptedKeyShares() []*EncryptedKeyShare

func (*QueuedPubKey) GetExpiry

func (m *QueuedPubKey) GetExpiry() uint64

func (*QueuedPubKey) GetNumberOfValidators added in v0.5.0

func (m *QueuedPubKey) GetNumberOfValidators() uint64

func (*QueuedPubKey) GetPublicKey

func (m *QueuedPubKey) GetPublicKey() string

func (*QueuedPubKey) Marshal

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

func (*QueuedPubKey) MarshalTo

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

func (*QueuedPubKey) MarshalToSizedBuffer

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

func (*QueuedPubKey) ProtoMessage

func (*QueuedPubKey) ProtoMessage()

func (*QueuedPubKey) Reset

func (m *QueuedPubKey) Reset()

func (*QueuedPubKey) Size

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

func (*QueuedPubKey) String

func (m *QueuedPubKey) String() string

func (*QueuedPubKey) Unmarshal

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

func (*QueuedPubKey) XXX_DiscardUnknown

func (m *QueuedPubKey) XXX_DiscardUnknown()

func (*QueuedPubKey) XXX_Marshal

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

func (*QueuedPubKey) XXX_Merge

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

func (*QueuedPubKey) XXX_Size

func (m *QueuedPubKey) XXX_Size() int

func (*QueuedPubKey) XXX_Unmarshal

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

type RequestAggrKeysharePacketAck

type RequestAggrKeysharePacketAck struct {
	Identity string `protobuf:"bytes,1,opt,name=identity,proto3" json:"identity,omitempty"`
	Pubkey   string `protobuf:"bytes,2,opt,name=pubkey,proto3" json:"pubkey,omitempty"`
}

RequestAggrKeysharePacketAck defines a struct for the packet acknowledgment

func (*RequestAggrKeysharePacketAck) Descriptor

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

func (*RequestAggrKeysharePacketAck) GetIdentity

func (m *RequestAggrKeysharePacketAck) GetIdentity() string

func (*RequestAggrKeysharePacketAck) GetPubkey

func (m *RequestAggrKeysharePacketAck) GetPubkey() string

func (*RequestAggrKeysharePacketAck) Marshal

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

func (*RequestAggrKeysharePacketAck) MarshalTo

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

func (*RequestAggrKeysharePacketAck) MarshalToSizedBuffer

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

func (*RequestAggrKeysharePacketAck) ProtoMessage

func (*RequestAggrKeysharePacketAck) ProtoMessage()

func (*RequestAggrKeysharePacketAck) Reset

func (m *RequestAggrKeysharePacketAck) Reset()

func (*RequestAggrKeysharePacketAck) Size

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

func (*RequestAggrKeysharePacketAck) String

func (*RequestAggrKeysharePacketAck) Unmarshal

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

func (*RequestAggrKeysharePacketAck) XXX_DiscardUnknown

func (m *RequestAggrKeysharePacketAck) XXX_DiscardUnknown()

func (*RequestAggrKeysharePacketAck) XXX_Marshal

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

func (*RequestAggrKeysharePacketAck) XXX_Merge

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

func (*RequestAggrKeysharePacketAck) XXX_Size

func (m *RequestAggrKeysharePacketAck) XXX_Size() int

func (*RequestAggrKeysharePacketAck) XXX_Unmarshal

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

type RequestAggrKeysharePacketData

type RequestAggrKeysharePacketData struct {
	// Types that are valid to be assigned to Id:
	//
	//	*RequestAggrKeysharePacketData_ProposalId
	//	*RequestAggrKeysharePacketData_RequestId
	Id isRequestAggrKeysharePacketData_Id `protobuf_oneof:"id"`
}

RequestAggrKeysharePacketData defines a struct for the packet payload

func (*RequestAggrKeysharePacketData) Descriptor

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

func (RequestAggrKeysharePacketData) GetBytes

func (p RequestAggrKeysharePacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*RequestAggrKeysharePacketData) GetId added in v0.4.0

func (m *RequestAggrKeysharePacketData) GetId() isRequestAggrKeysharePacketData_Id

func (*RequestAggrKeysharePacketData) GetProposalId

func (m *RequestAggrKeysharePacketData) GetProposalId() string

func (*RequestAggrKeysharePacketData) GetRequestId added in v0.4.0

func (m *RequestAggrKeysharePacketData) GetRequestId() string

func (*RequestAggrKeysharePacketData) Marshal

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

func (*RequestAggrKeysharePacketData) MarshalTo

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

func (*RequestAggrKeysharePacketData) MarshalToSizedBuffer

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

func (*RequestAggrKeysharePacketData) ProtoMessage

func (*RequestAggrKeysharePacketData) ProtoMessage()

func (*RequestAggrKeysharePacketData) Reset

func (m *RequestAggrKeysharePacketData) Reset()

func (*RequestAggrKeysharePacketData) Size

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

func (*RequestAggrKeysharePacketData) String

func (*RequestAggrKeysharePacketData) Unmarshal

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

func (RequestAggrKeysharePacketData) ValidateBasic

func (p RequestAggrKeysharePacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*RequestAggrKeysharePacketData) XXX_DiscardUnknown

func (m *RequestAggrKeysharePacketData) XXX_DiscardUnknown()

func (*RequestAggrKeysharePacketData) XXX_Marshal

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

func (*RequestAggrKeysharePacketData) XXX_Merge

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

func (*RequestAggrKeysharePacketData) XXX_OneofWrappers added in v0.4.0

func (*RequestAggrKeysharePacketData) XXX_OneofWrappers() []interface{}

XXX_OneofWrappers is for the internal use of the proto package.

func (*RequestAggrKeysharePacketData) XXX_Size

func (m *RequestAggrKeysharePacketData) XXX_Size() int

func (*RequestAggrKeysharePacketData) XXX_Unmarshal

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

type RequestAggrKeysharePacketData_ProposalId added in v0.4.0

type RequestAggrKeysharePacketData_ProposalId struct {
	ProposalId string `protobuf:"bytes,1,opt,name=proposal_id,json=proposalId,proto3,oneof" json:"proposal_id,omitempty"`
}

func (*RequestAggrKeysharePacketData_ProposalId) MarshalTo added in v0.4.0

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

func (*RequestAggrKeysharePacketData_ProposalId) MarshalToSizedBuffer added in v0.4.0

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

func (*RequestAggrKeysharePacketData_ProposalId) Size added in v0.4.0

type RequestAggrKeysharePacketData_RequestId added in v0.4.0

type RequestAggrKeysharePacketData_RequestId struct {
	RequestId string `protobuf:"bytes,2,opt,name=request_id,json=requestId,proto3,oneof" json:"request_id,omitempty"`
}

func (*RequestAggrKeysharePacketData_RequestId) MarshalTo added in v0.4.0

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

func (*RequestAggrKeysharePacketData_RequestId) MarshalToSizedBuffer added in v0.4.0

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

func (*RequestAggrKeysharePacketData_RequestId) Size added in v0.4.0

type ScopedKeeper

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

ScopedKeeper defines the expected IBC scoped keeper

type StakingKeeper

type StakingKeeper interface {
	GetAllValidators(ctx sdk.Context) []stakingtypes.Validator
	GetValidator(ctx sdk.Context, addr sdk.ValAddress) (stakingtypes.Validator, bool)
	Slash(sdk.Context, sdk.ConsAddress, int64, int64, sdk.Dec) math.Int
}

StakingKeeper defines the expected interface needed to retrieve the list of validators.

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) CreateAuthorizedAddress

func (*UnimplementedMsgServer) CreateGeneralKeyShare

func (*UnimplementedMsgServer) CreateLatestPubKey

func (*UnimplementedMsgServer) DeRegisterValidator added in v0.5.0

func (*UnimplementedMsgServer) DeleteAuthorizedAddress

func (*UnimplementedMsgServer) OverrideLatestPubKey added in v0.5.0

func (*UnimplementedMsgServer) RegisterValidator

func (*UnimplementedMsgServer) SendKeyshare

func (*UnimplementedMsgServer) UpdateAuthorizedAddress

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) Commitments

func (*UnimplementedQueryServer) GeneralKeyShare

func (*UnimplementedQueryServer) GeneralKeyShareAll

func (*UnimplementedQueryServer) KeyShare

func (*UnimplementedQueryServer) KeyShareAll

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) PubKey

func (*UnimplementedQueryServer) ValidatorSet

func (*UnimplementedQueryServer) ValidatorSetAll

type ValidatorSet

type ValidatorSet struct {
	Index     string `protobuf:"bytes,1,opt,name=index,proto3" json:"index,omitempty"`
	Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"`
	ConsAddr  string `protobuf:"bytes,3,opt,name=consAddr,proto3" json:"consAddr,omitempty"`
	IsActive  bool   `protobuf:"varint,4,opt,name=isActive,proto3" json:"isActive,omitempty"`
}

func (*ValidatorSet) Descriptor

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

func (*ValidatorSet) GetConsAddr

func (m *ValidatorSet) GetConsAddr() string

func (*ValidatorSet) GetIndex

func (m *ValidatorSet) GetIndex() string

func (*ValidatorSet) GetIsActive

func (m *ValidatorSet) GetIsActive() bool

func (*ValidatorSet) GetValidator

func (m *ValidatorSet) GetValidator() string

func (*ValidatorSet) Marshal

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

func (*ValidatorSet) MarshalTo

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

func (*ValidatorSet) MarshalToSizedBuffer

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

func (*ValidatorSet) ProtoMessage

func (*ValidatorSet) ProtoMessage()

func (*ValidatorSet) Reset

func (m *ValidatorSet) Reset()

func (*ValidatorSet) Size

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

func (*ValidatorSet) String

func (m *ValidatorSet) String() string

func (*ValidatorSet) Unmarshal

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

func (*ValidatorSet) XXX_DiscardUnknown

func (m *ValidatorSet) XXX_DiscardUnknown()

func (*ValidatorSet) XXX_Marshal

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

func (*ValidatorSet) XXX_Merge

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

func (*ValidatorSet) XXX_Size

func (m *ValidatorSet) XXX_Size() int

func (*ValidatorSet) XXX_Unmarshal

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

Jump to

Keyboard shortcuts

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