types

package
v0.10.2 Latest Latest
Warning

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

Go to latest
Published: Oct 27, 2024 License: Apache-2.0 Imports: 48 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"

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

	EventTypeRequestDecryptionKeyPacket        = "requestDecryptionKey_packet"
	EventTypeRequestPrivateDecryptionKeyPacket = "requestPrivateDecryptionKey_packet"
	EventTypeGetDecryptionKeyPacket            = "getDecryptionKey_packet"
	EventTypeGetPrivateDecryptionKeyPacket     = "getPrivateDecryptionKey_packet"
	EventTypeDecryptionKeyDataPacket           = "DecryptionKeyData_packet"
	EventTypePrivateDecryptionKeyPacket        = "privateDecryptionKey_packet"
	EventTypeCurrentKeysPacket                 = "currentKeys_packet"

	AttributeKeyAckIdentity = "identity"
	AttributeKeyAckPubkey   = "pubkey"
)

IBC events

View Source
const (
	// DecryptionKeyKeyPrefix is the prefix to retrieve all decryption keys
	DecryptionKeyKeyPrefix    = "DecryptionKey/value/"
	DecryptionKeyLengthPrefix = "DecryptionKey/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 (
	// DecryptionKeyRequestKeyPrefix is the prefix to retrieve all decryption key requests
	DecryptionKeyRequestKeyPrefix        = "DecryptionKeyRequest/value/"
	PrivateDecryptionKeyRequestKeyPrefix = "PrivateDecryptionKeyRequest/value/"
)
View Source
const (
	// GeneralKeyshareKeyPrefix is the prefix to retrieve all GeneralKeyshare
	GeneralKeyshareKeyPrefix = "GeneralKeyshare/value/"
	PrivateKeyshareKeyPrefix = "PrivateKeyshare/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

	// 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"
)
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"
	StartSendEncryptedKeyshareEventType      = "start-send-encrypted-keyshare"
	StartSendGeneralKeyshareEventIdentity    = "identity"
	StartSendEncryptedKeyshareEventRequester = "requester"
	StartSendEncryptedKeyshareEventPubkey    = "secp256k1-pubkey"
)
View Source
const (
	SendGeneralKeyshareEventType                = "keyshare-sent"
	SendEncryptedKeyshareEventType              = "encrypted-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_keyshare"
	KeyTotalInvalidKeyshareSubmitted = "total_invalid_keyshare"
)
View Source
const (
	PubkeyHexLength     = 96
	CommitmentHexLength = 96
)
View Source
const AvgBlockTime = 5.6
View Source
const DefaultIndex uint64 = 1

DefaultIndex is the default global index

View Source
const (
	// KeyLastSubmittedHeightPrefix is the prefix to retrieve all LastSubmittedHeight
	KeyLastSubmittedHeightPrefix = "LastSubmittedHeight/value/"
)
View Source
const (
	KeyshareHexLen = 192
)
View Source
const (
	// KeyshareKeyPrefix is the prefix to retrieve all Keyshare
	KeyshareKeyPrefix = "Keyshare/value/"
)
View Source
const (
	SlashPower int64 = 100
)
View Source
const (
	// ValidatorSetKeyPrefix is the prefix to retrieve all ValidatorSet
	ValidatorSetKeyPrefix = "ValidatorSet/value/"
)

Variables

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 (
	ErrInvalidLengthDecryptionKey        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowDecryptionKey          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupDecryptionKey = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidSigner                   = sdkerrors.Register(ModuleName, 1100, "expected gov account as only signer for proposal message")
	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")
	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 keyshares")
	ErrInvalidEncryptedShareData       = sdkerrors.Register(ModuleName, 1130, "invalid encrypted share data")
	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, "keyshare request for the given identity not found")
	ErrDecryptionKeyAlreadyExists      = sdkerrors.Register(ModuleName, 1912, "decryption key already exists for the given identity")
)

x/keyshare module sentinel errors

View Source
var (
	ErrInvalidLengthGenesis        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGenesis          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGenesis = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	// 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 (
	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 (
	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 = math.LegacyNewDecWithPrec(5, 1) // 0.5
)
View Source
var (
	KeySlashFractionWrongKeyshare     = []byte("KeyWrongShareSlashFraction")
	DefaultSlashFractionWrongKeyshare = math.LegacyNewDecWithPrec(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 (
	ErrInvalidLengthRequestedDecryptionKey        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowRequestedDecryptionKey          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupRequestedDecryptionKey = 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")
)
View Source
var (
	// ModuleCdc references the global x/ibc-transfer module codec. Note, the codec
	// should ONLY be used in certain instances of tests and for JSON encoding.
	//
	// The actual codec used for serialization should be provided to x/ibc transfer and
	// defined at the application level.
	ModuleCdc = codec.NewProtoCodec(cdctypes.NewInterfaceRegistry())
)
View Source
var Msg_serviceDesc = _Msg_serviceDesc
View Source
var ParamsKey = []byte("p_keyshare")
View Source
var Query_serviceDesc = _Query_serviceDesc

Functions

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 DecryptionKeyKey added in v0.10.0

func DecryptionKeyKey(
	height uint64,
) []byte

DecryptionKeyKey returns the store key to retrieve a decryption key from the index fields

func GeneralKeyshareKey added in v0.10.0

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 added in v0.10.0

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 PrivateKeyshareKey added in v0.10.0

func PrivateKeyshareKey(
	validator string,
	identity string,
	requester string,
) []byte

PrivateKeyshareKey returns the store key to retrieve a GeneralKeyshare from the index fields

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 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(context.Context, sdk.AccAddress) sdk.AccountI // only used for simulation

}

AccountKeeper defines the expected interface for the Account module.

type ActivePubkey added in v0.10.0

type ActivePubkey struct {
	PublicKey          string               `protobuf:"bytes,1,opt,name=public_key,json=publicKey,proto3" json:"public_key,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=number_of_validators,json=numberOfValidators,proto3" json:"number_of_validators,omitempty"`
	EncryptedKeyshares []*EncryptedKeyshare `protobuf:"bytes,5,rep,name=encrypted_keyshares,json=encryptedKeyshares,proto3" json:"encrypted_keyshares,omitempty"`
}

ActivePubkey defines the structure of the active public key

func (*ActivePubkey) Descriptor added in v0.10.0

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

func (*ActivePubkey) GetCreator added in v0.10.0

func (m *ActivePubkey) GetCreator() string

func (*ActivePubkey) GetEncryptedKeyshares added in v0.10.0

func (m *ActivePubkey) GetEncryptedKeyshares() []*EncryptedKeyshare

func (*ActivePubkey) GetExpiry added in v0.10.0

func (m *ActivePubkey) GetExpiry() uint64

func (*ActivePubkey) GetNumberOfValidators added in v0.10.0

func (m *ActivePubkey) GetNumberOfValidators() uint64

func (*ActivePubkey) GetPublicKey added in v0.10.0

func (m *ActivePubkey) GetPublicKey() string

func (*ActivePubkey) Marshal added in v0.10.0

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

func (*ActivePubkey) MarshalTo added in v0.10.0

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

func (*ActivePubkey) MarshalToSizedBuffer added in v0.10.0

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

func (*ActivePubkey) ProtoMessage added in v0.10.0

func (*ActivePubkey) ProtoMessage()

func (*ActivePubkey) Reset added in v0.10.0

func (m *ActivePubkey) Reset()

func (*ActivePubkey) Size added in v0.10.0

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

func (*ActivePubkey) String added in v0.10.0

func (m *ActivePubkey) String() string

func (*ActivePubkey) Unmarshal added in v0.10.0

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

func (*ActivePubkey) XXX_DiscardUnknown added in v0.10.0

func (m *ActivePubkey) XXX_DiscardUnknown()

func (*ActivePubkey) XXX_Marshal added in v0.10.0

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

func (*ActivePubkey) XXX_Merge added in v0.10.0

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

func (*ActivePubkey) XXX_Size added in v0.10.0

func (m *ActivePubkey) XXX_Size() int

func (*ActivePubkey) XXX_Unmarshal added in v0.10.0

func (m *ActivePubkey) 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=is_authorized,json=isAuthorized,proto3" json:"is_authorized,omitempty"`
	AuthorizedBy string `protobuf:"bytes,3,opt,name=authorized_by,json=authorizedBy,proto3" json:"authorized_by,omitempty"`
}

AuthorizedAddress defines if an address is authorized to submit keyshares

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(context.Context, sdk.AccAddress) sdk.Coins
}

BankKeeper defines the expected interface for the Bank module.

type ChannelKeeper

type ChannelKeeper interface {
	GetChannel(ctx context.Context, portID, channelID string) (channeltypes.Channel, bool)
	GetNextSequenceSend(ctx context.Context, portID, channelID string) (uint64, bool)
	SendPacket(
		ctx context.Context,
		channelCap *capabilitytypes.Capability,
		sourcePort string,
		sourceChannel string,
		timeoutHeight clienttypes.Height,
		timeoutTimestamp uint64,
		data []byte,
	) (uint64, error)
	ChanCloseInit(ctx context.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"`
}

Commitments defines the list of commitments to verify the keyshares submitted by validators

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 CounterPartyIBCInfo

type CounterPartyIBCInfo struct {
	ClientId     string `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	ConnectionId string `protobuf:"bytes,2,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
	ChannelId    string `protobuf:"bytes,3,opt,name=channel_id,json=channelId,proto3" json:"channel_id,omitempty"`
	PortId       string `protobuf:"bytes,4,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
}

CounterPartyIBCInfo defines the structure to send general and private keyshares if the request was made over IBC

func (*CounterPartyIBCInfo) Descriptor

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

func (*CounterPartyIBCInfo) GetChannelId added in v0.10.0

func (m *CounterPartyIBCInfo) GetChannelId() string

func (*CounterPartyIBCInfo) GetClientId added in v0.10.0

func (m *CounterPartyIBCInfo) GetClientId() string

func (*CounterPartyIBCInfo) GetConnectionId added in v0.10.0

func (m *CounterPartyIBCInfo) GetConnectionId() string

func (*CounterPartyIBCInfo) GetPortId added in v0.10.0

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 CurrentKeysPacketAck added in v0.6.0

type CurrentKeysPacketAck struct {
	ActiveKey *types.ActivePublicKey `protobuf:"bytes,1,opt,name=active_key,json=activeKey,proto3" json:"active_key,omitempty"`
	QueuedKey *types.QueuedPublicKey `protobuf:"bytes,2,opt,name=queued_key,json=queuedKey,proto3" json:"queued_key,omitempty"`
}

CurrentKeysPacketAck defines a struct for the packet acknowledgment

func (*CurrentKeysPacketAck) Descriptor added in v0.6.0

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

func (*CurrentKeysPacketAck) GetActiveKey added in v0.6.0

func (m *CurrentKeysPacketAck) GetActiveKey() *types.ActivePublicKey

func (*CurrentKeysPacketAck) GetQueuedKey added in v0.6.0

func (m *CurrentKeysPacketAck) GetQueuedKey() *types.QueuedPublicKey

func (*CurrentKeysPacketAck) Marshal added in v0.6.0

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

func (*CurrentKeysPacketAck) MarshalTo added in v0.6.0

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

func (*CurrentKeysPacketAck) MarshalToSizedBuffer added in v0.6.0

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

func (*CurrentKeysPacketAck) ProtoMessage added in v0.6.0

func (*CurrentKeysPacketAck) ProtoMessage()

func (*CurrentKeysPacketAck) Reset added in v0.6.0

func (m *CurrentKeysPacketAck) Reset()

func (*CurrentKeysPacketAck) Size added in v0.6.0

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

func (*CurrentKeysPacketAck) String added in v0.6.0

func (m *CurrentKeysPacketAck) String() string

func (*CurrentKeysPacketAck) Unmarshal added in v0.6.0

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

func (*CurrentKeysPacketAck) XXX_DiscardUnknown added in v0.6.0

func (m *CurrentKeysPacketAck) XXX_DiscardUnknown()

func (*CurrentKeysPacketAck) XXX_Marshal added in v0.6.0

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

func (*CurrentKeysPacketAck) XXX_Merge added in v0.6.0

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

func (*CurrentKeysPacketAck) XXX_Size added in v0.6.0

func (m *CurrentKeysPacketAck) XXX_Size() int

func (*CurrentKeysPacketAck) XXX_Unmarshal added in v0.6.0

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

type CurrentKeysPacketData added in v0.6.0

type CurrentKeysPacketData struct {
}

CurrentKeysPacketData defines a struct for the packet payload

func (*CurrentKeysPacketData) Descriptor added in v0.6.0

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

func (CurrentKeysPacketData) GetBytes added in v0.6.0

func (p CurrentKeysPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*CurrentKeysPacketData) Marshal added in v0.6.0

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

func (*CurrentKeysPacketData) MarshalTo added in v0.6.0

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

func (*CurrentKeysPacketData) MarshalToSizedBuffer added in v0.6.0

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

func (*CurrentKeysPacketData) ProtoMessage added in v0.6.0

func (*CurrentKeysPacketData) ProtoMessage()

func (*CurrentKeysPacketData) Reset added in v0.6.0

func (m *CurrentKeysPacketData) Reset()

func (*CurrentKeysPacketData) Size added in v0.6.0

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

func (*CurrentKeysPacketData) String added in v0.6.0

func (m *CurrentKeysPacketData) String() string

func (*CurrentKeysPacketData) Unmarshal added in v0.6.0

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

func (CurrentKeysPacketData) ValidateBasic added in v0.6.0

func (p CurrentKeysPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*CurrentKeysPacketData) XXX_DiscardUnknown added in v0.6.0

func (m *CurrentKeysPacketData) XXX_DiscardUnknown()

func (*CurrentKeysPacketData) XXX_Marshal added in v0.6.0

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

func (*CurrentKeysPacketData) XXX_Merge added in v0.6.0

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

func (*CurrentKeysPacketData) XXX_Size added in v0.6.0

func (m *CurrentKeysPacketData) XXX_Size() int

func (*CurrentKeysPacketData) XXX_Unmarshal added in v0.6.0

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

type DecryptionKey added in v0.10.0

type DecryptionKey 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"`
}

Decryption key defines the structure and height for a decryption key

func (*DecryptionKey) Descriptor added in v0.10.0

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

func (*DecryptionKey) GetData added in v0.10.0

func (m *DecryptionKey) GetData() string

func (*DecryptionKey) GetHeight added in v0.10.0

func (m *DecryptionKey) GetHeight() uint64

func (*DecryptionKey) Marshal added in v0.10.0

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

func (*DecryptionKey) MarshalTo added in v0.10.0

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

func (*DecryptionKey) MarshalToSizedBuffer added in v0.10.0

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

func (*DecryptionKey) ProtoMessage added in v0.10.0

func (*DecryptionKey) ProtoMessage()

func (*DecryptionKey) Reset added in v0.10.0

func (m *DecryptionKey) Reset()

func (*DecryptionKey) Size added in v0.10.0

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

func (*DecryptionKey) String added in v0.10.0

func (m *DecryptionKey) String() string

func (*DecryptionKey) Unmarshal added in v0.10.0

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

func (*DecryptionKey) XXX_DiscardUnknown added in v0.10.0

func (m *DecryptionKey) XXX_DiscardUnknown()

func (*DecryptionKey) XXX_Marshal added in v0.10.0

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

func (*DecryptionKey) XXX_Merge added in v0.10.0

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

func (*DecryptionKey) XXX_Size added in v0.10.0

func (m *DecryptionKey) XXX_Size() int

func (*DecryptionKey) XXX_Unmarshal added in v0.10.0

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

type DecryptionKeyDataPacketData added in v0.10.0

type DecryptionKeyDataPacketData 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"`
	DecryptionKey string `protobuf:"bytes,3,opt,name=decryption_key,json=decryptionKey,proto3" json:"decryption_key,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"`
	Retries       uint64 `protobuf:"varint,6,opt,name=retries,proto3" json:"retries,omitempty"`
}

DecryptionKeyDataPacketData defines a struct for the packet payload

func (*DecryptionKeyDataPacketData) Descriptor added in v0.10.0

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

func (*DecryptionKeyDataPacketData) GetAggrHeight added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetAggrHeight() string

func (DecryptionKeyDataPacketData) GetBytes added in v0.10.0

func (p DecryptionKeyDataPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*DecryptionKeyDataPacketData) GetDecryptionKey added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetDecryptionKey() string

func (*DecryptionKeyDataPacketData) GetIdentity added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetIdentity() string

func (*DecryptionKeyDataPacketData) GetProposalId added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetProposalId() string

func (*DecryptionKeyDataPacketData) GetPubkey added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetPubkey() string

func (*DecryptionKeyDataPacketData) GetRetries added in v0.10.0

func (m *DecryptionKeyDataPacketData) GetRetries() uint64

func (*DecryptionKeyDataPacketData) Marshal added in v0.10.0

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

func (*DecryptionKeyDataPacketData) MarshalTo added in v0.10.0

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

func (*DecryptionKeyDataPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*DecryptionKeyDataPacketData) ProtoMessage added in v0.10.0

func (*DecryptionKeyDataPacketData) ProtoMessage()

func (*DecryptionKeyDataPacketData) Reset added in v0.10.0

func (m *DecryptionKeyDataPacketData) Reset()

func (*DecryptionKeyDataPacketData) Size added in v0.10.0

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

func (*DecryptionKeyDataPacketData) String added in v0.10.0

func (m *DecryptionKeyDataPacketData) String() string

func (*DecryptionKeyDataPacketData) Unmarshal added in v0.10.0

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

func (DecryptionKeyDataPacketData) ValidateBasic added in v0.10.0

func (p DecryptionKeyDataPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*DecryptionKeyDataPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *DecryptionKeyDataPacketData) XXX_DiscardUnknown()

func (*DecryptionKeyDataPacketData) XXX_Marshal added in v0.10.0

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

func (*DecryptionKeyDataPacketData) XXX_Merge added in v0.10.0

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

func (*DecryptionKeyDataPacketData) XXX_Size added in v0.10.0

func (m *DecryptionKeyDataPacketData) XXX_Size() int

func (*DecryptionKeyDataPacketData) XXX_Unmarshal added in v0.10.0

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

type DecryptionKeyPacketAck added in v0.10.0

type DecryptionKeyPacketAck struct {
}

DecryptionKeyPacketAck defines a struct for the packet acknowledgment

func (*DecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*DecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*DecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*DecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*DecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*DecryptionKeyPacketAck) ProtoMessage()

func (*DecryptionKeyPacketAck) Reset added in v0.10.0

func (m *DecryptionKeyPacketAck) Reset()

func (*DecryptionKeyPacketAck) Size added in v0.10.0

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

func (*DecryptionKeyPacketAck) String added in v0.10.0

func (m *DecryptionKeyPacketAck) String() string

func (*DecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*DecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *DecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*DecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*DecryptionKeyPacketAck) XXX_Merge added in v0.10.0

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

func (*DecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (m *DecryptionKeyPacketAck) XXX_Size() int

func (*DecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type DecryptionKeyRequest added in v0.10.0

type DecryptionKeyRequest 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"`
	DecryptionKey string               `protobuf:"bytes,5,opt,name=decryption_key,json=decryptionKey,proto3" json:"decryption_key,omitempty"`
	ProposalId    string               `protobuf:"bytes,6,opt,name=proposal_id,json=proposalId,proto3" json:"proposal_id,omitempty"`
	Sent          bool                 `protobuf:"varint,7,opt,name=sent,proto3" json:"sent,omitempty"`
}

DecryptionKeyRequest defines the storage structure for general keyshare requests

func (*DecryptionKeyRequest) Descriptor added in v0.10.0

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

func (*DecryptionKeyRequest) GetCounterparty added in v0.10.0

func (m *DecryptionKeyRequest) GetCounterparty() *CounterPartyIBCInfo

func (*DecryptionKeyRequest) GetDecryptionKey added in v0.10.0

func (m *DecryptionKeyRequest) GetDecryptionKey() string

func (*DecryptionKeyRequest) GetIbcInfo added in v0.10.0

func (m *DecryptionKeyRequest) GetIbcInfo() *IBCInfo

func (*DecryptionKeyRequest) GetIdentity added in v0.10.0

func (m *DecryptionKeyRequest) GetIdentity() string

func (*DecryptionKeyRequest) GetProposalId added in v0.10.0

func (m *DecryptionKeyRequest) GetProposalId() string

func (*DecryptionKeyRequest) GetPubkey added in v0.10.0

func (m *DecryptionKeyRequest) GetPubkey() string

func (*DecryptionKeyRequest) GetSent added in v0.10.0

func (m *DecryptionKeyRequest) GetSent() bool

func (*DecryptionKeyRequest) Marshal added in v0.10.0

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

func (*DecryptionKeyRequest) MarshalTo added in v0.10.0

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

func (*DecryptionKeyRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*DecryptionKeyRequest) ProtoMessage added in v0.10.0

func (*DecryptionKeyRequest) ProtoMessage()

func (*DecryptionKeyRequest) Reset added in v0.10.0

func (m *DecryptionKeyRequest) Reset()

func (*DecryptionKeyRequest) Size added in v0.10.0

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

func (*DecryptionKeyRequest) String added in v0.10.0

func (m *DecryptionKeyRequest) String() string

func (*DecryptionKeyRequest) Unmarshal added in v0.10.0

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

func (*DecryptionKeyRequest) XXX_DiscardUnknown added in v0.10.0

func (m *DecryptionKeyRequest) XXX_DiscardUnknown()

func (*DecryptionKeyRequest) XXX_Marshal added in v0.10.0

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

func (*DecryptionKeyRequest) XXX_Merge added in v0.10.0

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

func (*DecryptionKeyRequest) XXX_Size added in v0.10.0

func (m *DecryptionKeyRequest) XXX_Size() int

func (*DecryptionKeyRequest) XXX_Unmarshal added in v0.10.0

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

type EncryptedKeyshare added in v0.10.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"`
}

EncryptedKeyshare defines the structure for storing the keyshare of the master secret key distributed to the validators

func (*EncryptedKeyshare) Descriptor added in v0.10.0

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

func (*EncryptedKeyshare) GetData added in v0.10.0

func (m *EncryptedKeyshare) GetData() string

func (*EncryptedKeyshare) GetValidator added in v0.10.0

func (m *EncryptedKeyshare) GetValidator() string

func (*EncryptedKeyshare) Marshal added in v0.10.0

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

func (*EncryptedKeyshare) MarshalTo added in v0.10.0

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

func (*EncryptedKeyshare) MarshalToSizedBuffer added in v0.10.0

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

func (*EncryptedKeyshare) ProtoMessage added in v0.10.0

func (*EncryptedKeyshare) ProtoMessage()

func (*EncryptedKeyshare) Reset added in v0.10.0

func (m *EncryptedKeyshare) Reset()

func (*EncryptedKeyshare) Size added in v0.10.0

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

func (*EncryptedKeyshare) String added in v0.10.0

func (m *EncryptedKeyshare) String() string

func (*EncryptedKeyshare) Unmarshal added in v0.10.0

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

func (*EncryptedKeyshare) XXX_DiscardUnknown added in v0.10.0

func (m *EncryptedKeyshare) XXX_DiscardUnknown()

func (*EncryptedKeyshare) XXX_Marshal added in v0.10.0

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

func (*EncryptedKeyshare) XXX_Merge added in v0.10.0

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

func (*EncryptedKeyshare) XXX_Size added in v0.10.0

func (m *EncryptedKeyshare) XXX_Size() int

func (*EncryptedKeyshare) XXX_Unmarshal added in v0.10.0

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

type GeneralKeyshare added in v0.10.0

type GeneralKeyshare struct {
	Validator           string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=id_type,json=idType,proto3" json:"id_type,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=id_value,json=idValue,proto3" json:"id_value,omitempty"`
	Keyshare            string `protobuf:"bytes,4,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,5,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,6,opt,name=received_timestamp,json=receivedTimestamp,proto3" json:"received_timestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,7,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
}

GeneralKeyshare defines the structure for submitting general keyshares by validators

func (*GeneralKeyshare) Descriptor added in v0.10.0

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

func (*GeneralKeyshare) GetIdType added in v0.10.0

func (m *GeneralKeyshare) GetIdType() string

func (*GeneralKeyshare) GetIdValue added in v0.10.0

func (m *GeneralKeyshare) GetIdValue() string

func (*GeneralKeyshare) GetKeyshare added in v0.10.0

func (m *GeneralKeyshare) GetKeyshare() string

func (*GeneralKeyshare) GetKeyshareIndex added in v0.10.0

func (m *GeneralKeyshare) GetKeyshareIndex() uint64

func (*GeneralKeyshare) GetReceivedBlockHeight added in v0.10.0

func (m *GeneralKeyshare) GetReceivedBlockHeight() uint64

func (*GeneralKeyshare) GetReceivedTimestamp added in v0.10.0

func (m *GeneralKeyshare) GetReceivedTimestamp() uint64

func (*GeneralKeyshare) GetValidator added in v0.10.0

func (m *GeneralKeyshare) GetValidator() string

func (*GeneralKeyshare) Marshal added in v0.10.0

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

func (*GeneralKeyshare) MarshalTo added in v0.10.0

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

func (*GeneralKeyshare) MarshalToSizedBuffer added in v0.10.0

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

func (*GeneralKeyshare) ProtoMessage added in v0.10.0

func (*GeneralKeyshare) ProtoMessage()

func (*GeneralKeyshare) Reset added in v0.10.0

func (m *GeneralKeyshare) Reset()

func (*GeneralKeyshare) Size added in v0.10.0

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

func (*GeneralKeyshare) String added in v0.10.0

func (m *GeneralKeyshare) String() string

func (*GeneralKeyshare) Unmarshal added in v0.10.0

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

func (*GeneralKeyshare) XXX_DiscardUnknown added in v0.10.0

func (m *GeneralKeyshare) XXX_DiscardUnknown()

func (*GeneralKeyshare) XXX_Marshal added in v0.10.0

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

func (*GeneralKeyshare) XXX_Merge added in v0.10.0

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

func (*GeneralKeyshare) XXX_Size added in v0.10.0

func (m *GeneralKeyshare) XXX_Size() int

func (*GeneralKeyshare) XXX_Unmarshal added in v0.10.0

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

type GenesisState

type GenesisState struct {
	// params defines all the parameters of the module.
	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=validator_set_list,json=validatorSetList,proto3" json:"validator_set_list"`
	KeyshareList          []Keyshare          `protobuf:"bytes,4,rep,name=keyshare_list,json=keyshareList,proto3" json:"keyshare_list"`
	DecryptionKeyList     []DecryptionKey     `protobuf:"bytes,5,rep,name=decryption_key_list,json=decryptionKeyList,proto3" json:"decryption_key_list"`
	ActivePubkey          ActivePubkey        `protobuf:"bytes,6,opt,name=active_pubkey,json=activePubkey,proto3" json:"active_pubkey"`
	QueuedPubkey          QueuedPubkey        `protobuf:"bytes,7,opt,name=queued_pubkey,json=queuedPubkey,proto3" json:"queued_pubkey"`
	AuthorizedAddressList []AuthorizedAddress `protobuf:"bytes,8,rep,name=authorized_address_list,json=authorizedAddressList,proto3" json:"authorized_address_list"`
	RequestCount          uint64              `protobuf:"varint,9,opt,name=request_count,json=requestCount,proto3" json:"request_count,omitempty"`
	GeneralKeyshareList   []GeneralKeyshare   `protobuf:"bytes,10,rep,name=general_keyshare_list,json=generalKeyshareList,proto3" json:"general_keyshare_list"`
}

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 added in v0.10.0

func (m *GenesisState) GetActivePubkey() ActivePubkey

func (*GenesisState) GetAuthorizedAddressList

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

func (*GenesisState) GetDecryptionKeyList added in v0.10.0

func (m *GenesisState) GetDecryptionKeyList() []DecryptionKey

func (*GenesisState) GetGeneralKeyshareList added in v0.10.0

func (m *GenesisState) GetGeneralKeyshareList() []GeneralKeyshare

func (*GenesisState) GetKeyshareList added in v0.10.0

func (m *GenesisState) GetKeyshareList() []Keyshare

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPortId

func (m *GenesisState) GetPortId() string

func (*GenesisState) GetQueuedPubkey added in v0.10.0

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 GetDecryptionKeyPacketAck added in v0.10.0

type GetDecryptionKeyPacketAck struct {
}

GetDecryptionKeyPacketAck defines a struct for the packet acknowledgment

func (*GetDecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*GetDecryptionKeyPacketAck) ProtoMessage()

func (*GetDecryptionKeyPacketAck) Reset added in v0.10.0

func (m *GetDecryptionKeyPacketAck) Reset()

func (*GetDecryptionKeyPacketAck) Size added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) String added in v0.10.0

func (m *GetDecryptionKeyPacketAck) String() string

func (*GetDecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *GetDecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*GetDecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) XXX_Merge added in v0.10.0

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

func (*GetDecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (m *GetDecryptionKeyPacketAck) XXX_Size() int

func (*GetDecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type GetDecryptionKeyPacketData added in v0.10.0

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

GetDecryptionKeyPacketData defines a struct for the packet payload

func (*GetDecryptionKeyPacketData) Descriptor added in v0.10.0

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

func (GetDecryptionKeyPacketData) GetBytes added in v0.10.0

func (p GetDecryptionKeyPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*GetDecryptionKeyPacketData) GetIdentity added in v0.10.0

func (m *GetDecryptionKeyPacketData) GetIdentity() string

func (*GetDecryptionKeyPacketData) Marshal added in v0.10.0

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

func (*GetDecryptionKeyPacketData) MarshalTo added in v0.10.0

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

func (*GetDecryptionKeyPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*GetDecryptionKeyPacketData) ProtoMessage added in v0.10.0

func (*GetDecryptionKeyPacketData) ProtoMessage()

func (*GetDecryptionKeyPacketData) Reset added in v0.10.0

func (m *GetDecryptionKeyPacketData) Reset()

func (*GetDecryptionKeyPacketData) Size added in v0.10.0

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

func (*GetDecryptionKeyPacketData) String added in v0.10.0

func (m *GetDecryptionKeyPacketData) String() string

func (*GetDecryptionKeyPacketData) Unmarshal added in v0.10.0

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

func (GetDecryptionKeyPacketData) ValidateBasic added in v0.10.0

func (p GetDecryptionKeyPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*GetDecryptionKeyPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *GetDecryptionKeyPacketData) XXX_DiscardUnknown()

func (*GetDecryptionKeyPacketData) XXX_Marshal added in v0.10.0

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

func (*GetDecryptionKeyPacketData) XXX_Merge added in v0.10.0

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

func (*GetDecryptionKeyPacketData) XXX_Size added in v0.10.0

func (m *GetDecryptionKeyPacketData) XXX_Size() int

func (*GetDecryptionKeyPacketData) XXX_Unmarshal added in v0.10.0

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

type GetPrivateDecryptionKeyPacketAck added in v0.10.0

type GetPrivateDecryptionKeyPacketAck struct {
}

GetPrivateKeysharePacketAck defines a struct for the packet acknowledgment

func (*GetPrivateDecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*GetPrivateDecryptionKeyPacketAck) ProtoMessage()

func (*GetPrivateDecryptionKeyPacketAck) Reset added in v0.10.0

func (*GetPrivateDecryptionKeyPacketAck) Size added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) String added in v0.10.0

func (*GetPrivateDecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*GetPrivateDecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketAck) XXX_Merge added in v0.10.0

func (*GetPrivateDecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketAck) XXX_Size() int

func (*GetPrivateDecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type GetPrivateDecryptionKeyPacketData added in v0.10.0

type GetPrivateDecryptionKeyPacketData struct {
	Identity   string `protobuf:"bytes,1,opt,name=identity,proto3" json:"identity,omitempty"`
	Requester  string `protobuf:"bytes,2,opt,name=requester,proto3" json:"requester,omitempty"`
	SecpPubkey string `protobuf:"bytes,3,opt,name=secp_pubkey,json=secpPubkey,proto3" json:"secp_pubkey,omitempty"`
}

GetPrivateDecryptionKeyPacketData defines a struct for the packet payload

func (*GetPrivateDecryptionKeyPacketData) Descriptor added in v0.10.0

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

func (GetPrivateDecryptionKeyPacketData) GetBytes added in v0.10.0

func (p GetPrivateDecryptionKeyPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*GetPrivateDecryptionKeyPacketData) GetIdentity added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketData) GetIdentity() string

func (*GetPrivateDecryptionKeyPacketData) GetRequester added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketData) GetRequester() string

func (*GetPrivateDecryptionKeyPacketData) GetSecpPubkey added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketData) GetSecpPubkey() string

func (*GetPrivateDecryptionKeyPacketData) Marshal added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketData) MarshalTo added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketData) ProtoMessage added in v0.10.0

func (*GetPrivateDecryptionKeyPacketData) ProtoMessage()

func (*GetPrivateDecryptionKeyPacketData) Reset added in v0.10.0

func (*GetPrivateDecryptionKeyPacketData) Size added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketData) String added in v0.10.0

func (*GetPrivateDecryptionKeyPacketData) Unmarshal added in v0.10.0

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

func (GetPrivateDecryptionKeyPacketData) ValidateBasic added in v0.10.0

func (p GetPrivateDecryptionKeyPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*GetPrivateDecryptionKeyPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketData) XXX_DiscardUnknown()

func (*GetPrivateDecryptionKeyPacketData) XXX_Marshal added in v0.10.0

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

func (*GetPrivateDecryptionKeyPacketData) XXX_Merge added in v0.10.0

func (*GetPrivateDecryptionKeyPacketData) XXX_Size added in v0.10.0

func (m *GetPrivateDecryptionKeyPacketData) XXX_Size() int

func (*GetPrivateDecryptionKeyPacketData) XXX_Unmarshal added in v0.10.0

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

type GovKeeper added in v0.4.0

type GovKeeper interface {
	GetRequestQueueEntry(ctx sdk.Context, reqID string) (val commontypes.RequestDecryptionKey, found bool)
	SetReqQueueEntry(ctx sdk.Context, val commontypes.RequestDecryptionKey)
	RemoveReqQueueEntry(ctx sdk.Context, reqID string)
	GetAllReqQueueEntry(ctx sdk.Context) (list []commontypes.RequestDecryptionKey)
	GetSignalQueueEntry(ctx sdk.Context, reqID string) (val commontypes.GetDecryptionKey, found bool)
	SetSignalQueueEntry(ctx sdk.Context, val commontypes.GetDecryptionKey)
	RemoveSignalQueueEntry(ctx sdk.Context, reqID string)
	GetAllSignalQueueEntry(ctx sdk.Context) (list []commontypes.GetDecryptionKey)
	GetProposal(ctx context.Context, proposalID uint64) (v1.Proposal, bool)
	SetProposal(ctx context.Context, proposal v1.Proposal) error
}

type IBCInfo

type IBCInfo struct {
	ClientId     string `protobuf:"bytes,1,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	ConnectionId string `protobuf:"bytes,2,opt,name=connection_id,json=connectionId,proto3" json:"connection_id,omitempty"`
	ChannelId    string `protobuf:"bytes,3,opt,name=channel_id,json=channelId,proto3" json:"channel_id,omitempty"`
	PortId       string `protobuf:"bytes,4,opt,name=port_id,json=portId,proto3" json:"port_id,omitempty"`
}

IBCInfo defines the structure to verify request for general and private keyshares in case the request was made over IBC

func (*IBCInfo) Descriptor

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

func (*IBCInfo) GetChannelId added in v0.10.0

func (m *IBCInfo) GetChannelId() string

func (*IBCInfo) GetClientId added in v0.10.0

func (m *IBCInfo) GetClientId() string

func (*IBCInfo) GetConnectionId added in v0.10.0

func (m *IBCInfo) GetConnectionId() string

func (*IBCInfo) GetPortId added in v0.10.0

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 Keyshare added in v0.10.0

type Keyshare struct {
	Validator           string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	BlockHeight         uint64 `protobuf:"varint,2,opt,name=block_height,json=blockHeight,proto3" json:"block_height,omitempty"`
	Keyshare            string `protobuf:"bytes,3,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,4,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,5,opt,name=received_timestamp,json=receivedTimestamp,proto3" json:"received_timestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
}

Keyshare defines the structure for submitting blockwise keyshares by validators

func (*Keyshare) Descriptor added in v0.10.0

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

func (*Keyshare) GetBlockHeight added in v0.10.0

func (m *Keyshare) GetBlockHeight() uint64

func (*Keyshare) GetKeyshare added in v0.10.0

func (m *Keyshare) GetKeyshare() string

func (*Keyshare) GetKeyshareIndex added in v0.10.0

func (m *Keyshare) GetKeyshareIndex() uint64

func (*Keyshare) GetReceivedBlockHeight added in v0.10.0

func (m *Keyshare) GetReceivedBlockHeight() uint64

func (*Keyshare) GetReceivedTimestamp added in v0.10.0

func (m *Keyshare) GetReceivedTimestamp() uint64

func (*Keyshare) GetValidator added in v0.10.0

func (m *Keyshare) GetValidator() string

func (*Keyshare) Marshal added in v0.10.0

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

func (*Keyshare) MarshalTo added in v0.10.0

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

func (*Keyshare) MarshalToSizedBuffer added in v0.10.0

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

func (*Keyshare) ProtoMessage added in v0.10.0

func (*Keyshare) ProtoMessage()

func (*Keyshare) Reset added in v0.10.0

func (m *Keyshare) Reset()

func (*Keyshare) Size added in v0.10.0

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

func (*Keyshare) String added in v0.10.0

func (m *Keyshare) String() string

func (*Keyshare) Unmarshal added in v0.10.0

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

func (*Keyshare) XXX_DiscardUnknown added in v0.10.0

func (m *Keyshare) XXX_DiscardUnknown()

func (*Keyshare) XXX_Marshal added in v0.10.0

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

func (*Keyshare) XXX_Merge added in v0.10.0

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

func (*Keyshare) XXX_Size added in v0.10.0

func (m *Keyshare) XXX_Size() int

func (*Keyshare) XXX_Unmarshal added in v0.10.0

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

type KeysharePacketData

type KeysharePacketData struct {
	// packet can be one of the following types
	//
	// Types that are valid to be assigned to Packet:
	//	*KeysharePacketData_NoData
	//	*KeysharePacketData_RequestDecryptionKeyPacket
	//	*KeysharePacketData_GetDecryptionKeyPacket
	//	*KeysharePacketData_DecryptionKeyDataPacket
	//	*KeysharePacketData_PrivateDecryptionKeyDataPacket
	//	*KeysharePacketData_CurrentKeysPacket
	//	*KeysharePacketData_RequestPrivateDecryptionKeyPacket
	//	*KeysharePacketData_GetPrivateDecryptionKeyPacket
	Packet isKeysharePacketData_Packet `protobuf_oneof:"packet"`
}

KeysharePacketData defines all the packet types of the keyshare module

func (*KeysharePacketData) Descriptor

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

func (*KeysharePacketData) GetCurrentKeysPacket added in v0.6.0

func (m *KeysharePacketData) GetCurrentKeysPacket() *CurrentKeysPacketData

func (*KeysharePacketData) GetDecryptionKeyDataPacket added in v0.10.0

func (m *KeysharePacketData) GetDecryptionKeyDataPacket() *DecryptionKeyDataPacketData

func (*KeysharePacketData) GetGetDecryptionKeyPacket added in v0.10.0

func (m *KeysharePacketData) GetGetDecryptionKeyPacket() *GetDecryptionKeyPacketData

func (*KeysharePacketData) GetGetPrivateDecryptionKeyPacket added in v0.10.0

func (m *KeysharePacketData) GetGetPrivateDecryptionKeyPacket() *GetPrivateDecryptionKeyPacketData

func (*KeysharePacketData) GetNoData

func (m *KeysharePacketData) GetNoData() *NoData

func (*KeysharePacketData) GetPacket

func (m *KeysharePacketData) GetPacket() isKeysharePacketData_Packet

func (*KeysharePacketData) GetPrivateDecryptionKeyDataPacket added in v0.10.0

func (m *KeysharePacketData) GetPrivateDecryptionKeyDataPacket() *PrivateDecryptionKeyDataPacketData

func (*KeysharePacketData) GetRequestDecryptionKeyPacket added in v0.10.0

func (m *KeysharePacketData) GetRequestDecryptionKeyPacket() *RequestDecryptionKeyPacketData

func (*KeysharePacketData) GetRequestPrivateDecryptionKeyPacket added in v0.10.0

func (m *KeysharePacketData) GetRequestPrivateDecryptionKeyPacket() *RequestPrivateDecryptionKeyPacketData

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_CurrentKeysPacket added in v0.6.0

type KeysharePacketData_CurrentKeysPacket struct {
	CurrentKeysPacket *CurrentKeysPacketData `protobuf:"bytes,6,opt,name=current_keys_packet,json=currentKeysPacket,proto3,oneof" json:"current_keys_packet,omitempty"`
}

func (*KeysharePacketData_CurrentKeysPacket) MarshalTo added in v0.6.0

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

func (*KeysharePacketData_CurrentKeysPacket) MarshalToSizedBuffer added in v0.6.0

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

func (*KeysharePacketData_CurrentKeysPacket) Size added in v0.6.0

type KeysharePacketData_DecryptionKeyDataPacket added in v0.10.0

type KeysharePacketData_DecryptionKeyDataPacket struct {
	DecryptionKeyDataPacket *DecryptionKeyDataPacketData `` /* 140-byte string literal not displayed */
}

func (*KeysharePacketData_DecryptionKeyDataPacket) MarshalTo added in v0.10.0

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

func (*KeysharePacketData_DecryptionKeyDataPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_DecryptionKeyDataPacket) Size added in v0.10.0

type KeysharePacketData_GetDecryptionKeyPacket added in v0.10.0

type KeysharePacketData_GetDecryptionKeyPacket struct {
	GetDecryptionKeyPacket *GetDecryptionKeyPacketData `` /* 137-byte string literal not displayed */
}

func (*KeysharePacketData_GetDecryptionKeyPacket) MarshalTo added in v0.10.0

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

func (*KeysharePacketData_GetDecryptionKeyPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_GetDecryptionKeyPacket) Size added in v0.10.0

type KeysharePacketData_GetPrivateDecryptionKeyPacket added in v0.10.0

type KeysharePacketData_GetPrivateDecryptionKeyPacket struct {
	GetPrivateDecryptionKeyPacket *GetPrivateDecryptionKeyPacketData `` /* 160-byte string literal not displayed */
}

func (*KeysharePacketData_GetPrivateDecryptionKeyPacket) MarshalTo added in v0.10.0

func (*KeysharePacketData_GetPrivateDecryptionKeyPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_GetPrivateDecryptionKeyPacket) Size added in v0.10.0

type KeysharePacketData_NoData

type KeysharePacketData_NoData struct {
	NoData *NoData `protobuf:"bytes,1,opt,name=no_data,json=noData,proto3,oneof" json:"no_data,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_PrivateDecryptionKeyDataPacket added in v0.10.0

type KeysharePacketData_PrivateDecryptionKeyDataPacket struct {
	PrivateDecryptionKeyDataPacket *PrivateDecryptionKeyDataPacketData `` /* 163-byte string literal not displayed */
}

func (*KeysharePacketData_PrivateDecryptionKeyDataPacket) MarshalTo added in v0.10.0

func (*KeysharePacketData_PrivateDecryptionKeyDataPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_PrivateDecryptionKeyDataPacket) Size added in v0.10.0

type KeysharePacketData_RequestDecryptionKeyPacket added in v0.10.0

type KeysharePacketData_RequestDecryptionKeyPacket struct {
	RequestDecryptionKeyPacket *RequestDecryptionKeyPacketData `` /* 149-byte string literal not displayed */
}

func (*KeysharePacketData_RequestDecryptionKeyPacket) MarshalTo added in v0.10.0

func (*KeysharePacketData_RequestDecryptionKeyPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_RequestDecryptionKeyPacket) Size added in v0.10.0

type KeysharePacketData_RequestPrivateDecryptionKeyPacket added in v0.10.0

type KeysharePacketData_RequestPrivateDecryptionKeyPacket struct {
	RequestPrivateDecryptionKeyPacket *RequestPrivateDecryptionKeyPacketData `` /* 172-byte string literal not displayed */
}

func (*KeysharePacketData_RequestPrivateDecryptionKeyPacket) MarshalTo added in v0.10.0

func (*KeysharePacketData_RequestPrivateDecryptionKeyPacket) MarshalToSizedBuffer added in v0.10.0

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

func (*KeysharePacketData_RequestPrivateDecryptionKeyPacket) Size added in v0.10.0

type MsgClient

type MsgClient interface {
	// UpdateParams defines a (governance) operation for updating the module
	// parameters. The authority defaults to the x/gov module account.
	UpdateParams(ctx context.Context, in *MsgUpdateParams, opts ...grpc.CallOption) (*MsgUpdateParamsResponse, error)
	// RegisterValidator defines a operation to register validator which
	// is then eligible to participate in sending keyshares
	RegisterValidator(ctx context.Context, in *MsgRegisterValidator, opts ...grpc.CallOption) (*MsgRegisterValidatorResponse, error)
	// DeRegisterValidator defines an operation to de-register
	// a registered validator
	DeRegisterValidator(ctx context.Context, in *MsgDeRegisterValidator, opts ...grpc.CallOption) (*MsgDeRegisterValidatorResponse, error)
	// SendKeyshare defines an operation to submit keyshares
	// every block from registered validators
	SendKeyshare(ctx context.Context, in *MsgSendKeyshare, opts ...grpc.CallOption) (*MsgSendKeyshareResponse, error)
	// CreateLatestPubkey defines an operation to add a
	// public key to the chain (can only be done by an authorized address)
	CreateLatestPubkey(ctx context.Context, in *MsgCreateLatestPubkey, opts ...grpc.CallOption) (*MsgCreateLatestPubkeyResponse, error)
	// OverrideLatestPubkey defines an operation to override the current active pubkey
	OverrideLatestPubkey(ctx context.Context, in *MsgOverrideLatestPubkey, opts ...grpc.CallOption) (*MsgOverrideLatestPubkeyResponse, error)
	// CreateAuthorizedAddress defines an operation to mark an address
	// as authorized to create and/or update pubkeys on the chain
	CreateAuthorizedAddress(ctx context.Context, in *MsgCreateAuthorizedAddress, opts ...grpc.CallOption) (*MsgCreateAuthorizedAddressResponse, error)
	// UpdateAuthorizedAddress defines an operation to update the
	// list of authorized addresses
	UpdateAuthorizedAddress(ctx context.Context, in *MsgUpdateAuthorizedAddress, opts ...grpc.CallOption) (*MsgUpdateAuthorizedAddressResponse, error)
	// DeleteAuthorizedAddress defines an operation to revoke the
	// authorization of a previously authorized address
	DeleteAuthorizedAddress(ctx context.Context, in *MsgDeleteAuthorizedAddress, opts ...grpc.CallOption) (*MsgDeleteAuthorizedAddressResponse, error)
	// SubmitGeneralKeyshare defines an operation to submit a
	// general keyshare from a registered validator
	SubmitGeneralKeyshare(ctx context.Context, in *MsgSubmitGeneralKeyshare, opts ...grpc.CallOption) (*MsgSubmitGeneralKeyshareResponse, error)
	// SubmitEncryptedKeyshare defines an operation to submit
	// an encrypted keyshare from a registered validator
	SubmitEncryptedKeyshare(ctx context.Context, in *MsgSubmitEncryptedKeyshare, opts ...grpc.CallOption) (*MsgSubmitEncryptedKeyshareResponse, 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"`
}

MsgCreateAuthorizedAddress is the Msg/CreateAuthorizedAddress request type.

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

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

func (*MsgCreateAuthorizedAddress) String

func (m *MsgCreateAuthorizedAddress) String() 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 {
}

MsgCreateAuthorizedAddressResponse defines the response structure for executing a MsgCreateAuthorizedAddress message.

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 MsgCreateLatestPubkey added in v0.10.0

type MsgCreateLatestPubkey struct {
	Creator            string               `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	PublicKey          string               `protobuf:"bytes,2,opt,name=public_key,json=publicKey,proto3" json:"public_key,omitempty"`
	Commitments        []string             `protobuf:"bytes,3,rep,name=commitments,proto3" json:"commitments,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=number_of_validators,json=numberOfValidators,proto3" json:"number_of_validators,omitempty"`
	EncryptedKeyshares []*EncryptedKeyshare `protobuf:"bytes,5,rep,name=encrypted_keyshares,json=encryptedKeyshares,proto3" json:"encrypted_keyshares,omitempty"`
}

MsgCreateLatestPubkey is the Msg/CreateLatestPubkey request type.

func NewMsgCreateLatestPubkey added in v0.10.0

func NewMsgCreateLatestPubkey(
	creator string,
	publicKey string,
	commitments []string,
	numberOfValidators uint64,
	encryptedKeyshares []*EncryptedKeyshare,
) *MsgCreateLatestPubkey

func (*MsgCreateLatestPubkey) Descriptor added in v0.10.0

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

func (*MsgCreateLatestPubkey) GetCommitments added in v0.10.0

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

func (*MsgCreateLatestPubkey) GetCreator added in v0.10.0

func (m *MsgCreateLatestPubkey) GetCreator() string

func (*MsgCreateLatestPubkey) GetEncryptedKeyshares added in v0.10.0

func (m *MsgCreateLatestPubkey) GetEncryptedKeyshares() []*EncryptedKeyshare

func (*MsgCreateLatestPubkey) GetNumberOfValidators added in v0.10.0

func (m *MsgCreateLatestPubkey) GetNumberOfValidators() uint64

func (*MsgCreateLatestPubkey) GetPublicKey added in v0.10.0

func (m *MsgCreateLatestPubkey) GetPublicKey() string

func (*MsgCreateLatestPubkey) Marshal added in v0.10.0

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

func (*MsgCreateLatestPubkey) MarshalTo added in v0.10.0

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

func (*MsgCreateLatestPubkey) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgCreateLatestPubkey) ProtoMessage added in v0.10.0

func (*MsgCreateLatestPubkey) ProtoMessage()

func (*MsgCreateLatestPubkey) Reset added in v0.10.0

func (m *MsgCreateLatestPubkey) Reset()

func (*MsgCreateLatestPubkey) Size added in v0.10.0

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

func (*MsgCreateLatestPubkey) String added in v0.10.0

func (m *MsgCreateLatestPubkey) String() string

func (*MsgCreateLatestPubkey) Unmarshal added in v0.10.0

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

func (*MsgCreateLatestPubkey) ValidateBasic added in v0.10.0

func (msg *MsgCreateLatestPubkey) ValidateBasic() error

func (*MsgCreateLatestPubkey) XXX_DiscardUnknown added in v0.10.0

func (m *MsgCreateLatestPubkey) XXX_DiscardUnknown()

func (*MsgCreateLatestPubkey) XXX_Marshal added in v0.10.0

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

func (*MsgCreateLatestPubkey) XXX_Merge added in v0.10.0

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

func (*MsgCreateLatestPubkey) XXX_Size added in v0.10.0

func (m *MsgCreateLatestPubkey) XXX_Size() int

func (*MsgCreateLatestPubkey) XXX_Unmarshal added in v0.10.0

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

type MsgCreateLatestPubkeyResponse added in v0.10.0

type MsgCreateLatestPubkeyResponse struct {
}

MsgCreateLatestPubkeyResponse defines the response structure for executing a MsgCreateLatestPubkey message.

func (*MsgCreateLatestPubkeyResponse) Descriptor added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) Marshal added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) MarshalTo added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) ProtoMessage added in v0.10.0

func (*MsgCreateLatestPubkeyResponse) ProtoMessage()

func (*MsgCreateLatestPubkeyResponse) Reset added in v0.10.0

func (m *MsgCreateLatestPubkeyResponse) Reset()

func (*MsgCreateLatestPubkeyResponse) Size added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) String added in v0.10.0

func (*MsgCreateLatestPubkeyResponse) Unmarshal added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) XXX_DiscardUnknown added in v0.10.0

func (m *MsgCreateLatestPubkeyResponse) XXX_DiscardUnknown()

func (*MsgCreateLatestPubkeyResponse) XXX_Marshal added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) XXX_Merge added in v0.10.0

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

func (*MsgCreateLatestPubkeyResponse) XXX_Size added in v0.10.0

func (m *MsgCreateLatestPubkeyResponse) XXX_Size() int

func (*MsgCreateLatestPubkeyResponse) XXX_Unmarshal added in v0.10.0

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"`
}

MsgDeRegisterValidator is the Msg/DeRegisterValidator request type.

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) 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) 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) 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"`
}

MsgDeRegisterValidatorResponse defines the response structure for executing a MsgDeRegisterValidator message.

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"`
}

MsgDeleteAuthorizedAddress is the Msg/DeleteAuthorizedAddress request type.

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

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

func (*MsgDeleteAuthorizedAddress) String

func (m *MsgDeleteAuthorizedAddress) String() 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 {
}

MsgDeleteAuthorizedAddressResponse defines the response structure for executing a MsgDeleteAuthorizedAddress message.

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.10.0

type MsgOverrideLatestPubkey struct {
	Creator            string               `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	PublicKey          string               `protobuf:"bytes,2,opt,name=public_key,json=publicKey,proto3" json:"public_key,omitempty"`
	Commitments        []string             `protobuf:"bytes,3,rep,name=commitments,proto3" json:"commitments,omitempty"`
	NumberOfValidators uint64               `protobuf:"varint,4,opt,name=number_of_validators,json=numberOfValidators,proto3" json:"number_of_validators,omitempty"`
	EncryptedKeyshares []*EncryptedKeyshare `protobuf:"bytes,5,rep,name=encrypted_keyshares,json=encryptedKeyshares,proto3" json:"encrypted_keyshares,omitempty"`
}

MsgOverrideLatestPubkey is the Msg/OverrideLatestPubkey request type.

func NewMsgOverrideLatestPubkey added in v0.10.0

func NewMsgOverrideLatestPubkey(
	creator string,
	publicKey string,
	commitments []string,
	numberOfValidators uint64,
	encryptedKeyshares []*EncryptedKeyshare,
) *MsgOverrideLatestPubkey

func (*MsgOverrideLatestPubkey) Descriptor added in v0.10.0

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

func (*MsgOverrideLatestPubkey) GetCommitments added in v0.10.0

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

func (*MsgOverrideLatestPubkey) GetCreator added in v0.10.0

func (m *MsgOverrideLatestPubkey) GetCreator() string

func (*MsgOverrideLatestPubkey) GetEncryptedKeyshares added in v0.10.0

func (m *MsgOverrideLatestPubkey) GetEncryptedKeyshares() []*EncryptedKeyshare

func (*MsgOverrideLatestPubkey) GetNumberOfValidators added in v0.10.0

func (m *MsgOverrideLatestPubkey) GetNumberOfValidators() uint64

func (*MsgOverrideLatestPubkey) GetPublicKey added in v0.10.0

func (m *MsgOverrideLatestPubkey) GetPublicKey() string

func (*MsgOverrideLatestPubkey) Marshal added in v0.10.0

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

func (*MsgOverrideLatestPubkey) MarshalTo added in v0.10.0

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

func (*MsgOverrideLatestPubkey) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgOverrideLatestPubkey) ProtoMessage added in v0.10.0

func (*MsgOverrideLatestPubkey) ProtoMessage()

func (*MsgOverrideLatestPubkey) Reset added in v0.10.0

func (m *MsgOverrideLatestPubkey) Reset()

func (*MsgOverrideLatestPubkey) Size added in v0.10.0

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

func (*MsgOverrideLatestPubkey) String added in v0.10.0

func (m *MsgOverrideLatestPubkey) String() string

func (*MsgOverrideLatestPubkey) Unmarshal added in v0.10.0

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

func (*MsgOverrideLatestPubkey) ValidateBasic added in v0.10.0

func (msg *MsgOverrideLatestPubkey) ValidateBasic() error

func (*MsgOverrideLatestPubkey) XXX_DiscardUnknown added in v0.10.0

func (m *MsgOverrideLatestPubkey) XXX_DiscardUnknown()

func (*MsgOverrideLatestPubkey) XXX_Marshal added in v0.10.0

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

func (*MsgOverrideLatestPubkey) XXX_Merge added in v0.10.0

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

func (*MsgOverrideLatestPubkey) XXX_Size added in v0.10.0

func (m *MsgOverrideLatestPubkey) XXX_Size() int

func (*MsgOverrideLatestPubkey) XXX_Unmarshal added in v0.10.0

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

type MsgOverrideLatestPubkeyResponse added in v0.10.0

type MsgOverrideLatestPubkeyResponse struct {
}

MsgOverrideLatestPubkeyResponse defines the response structure for executing a MsgOverrideLatestPubkey message.

func (*MsgOverrideLatestPubkeyResponse) Descriptor added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) Marshal added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) MarshalTo added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) ProtoMessage added in v0.10.0

func (*MsgOverrideLatestPubkeyResponse) ProtoMessage()

func (*MsgOverrideLatestPubkeyResponse) Reset added in v0.10.0

func (*MsgOverrideLatestPubkeyResponse) Size added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) String added in v0.10.0

func (*MsgOverrideLatestPubkeyResponse) Unmarshal added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) XXX_DiscardUnknown added in v0.10.0

func (m *MsgOverrideLatestPubkeyResponse) XXX_DiscardUnknown()

func (*MsgOverrideLatestPubkeyResponse) XXX_Marshal added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) XXX_Merge added in v0.10.0

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

func (*MsgOverrideLatestPubkeyResponse) XXX_Size added in v0.10.0

func (m *MsgOverrideLatestPubkeyResponse) XXX_Size() int

func (*MsgOverrideLatestPubkeyResponse) XXX_Unmarshal added in v0.10.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"`
}

MsgRegisterValidator is the Msg/RegisterValidator request type.

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

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

func (*MsgRegisterValidator) String

func (m *MsgRegisterValidator) String() 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"`
}

MsgRegisterValidatorResponse defines the response structure for executing a MsgRegisterValidator message.

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=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	BlockHeight   uint64 `protobuf:"varint,4,opt,name=block_height,json=blockHeight,proto3" json:"block_height,omitempty"`
}

MsgSendKeyshare is the Msg/SendKeyshare request type.

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 added in v0.10.0

func (m *MsgSendKeyshare) GetKeyshareIndex() uint64

func (*MsgSendKeyshare) GetMessage

func (m *MsgSendKeyshare) GetMessage() string

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

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

func (*MsgSendKeyshare) String

func (m *MsgSendKeyshare) String() 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=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	BlockHeight         uint64 `protobuf:"varint,4,opt,name=block_height,json=blockHeight,proto3" json:"block_height,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,5,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
	Success             bool   `protobuf:"varint,6,opt,name=success,proto3" json:"success,omitempty"`
	ErrorMessage        string `protobuf:"bytes,7,opt,name=error_message,json=errorMessage,proto3" json:"error_message,omitempty"`
}

MsgSendKeyshareResponse defines the response structure for executing a MsgSendKeyshare message.

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 MsgServer

type MsgServer interface {
	// UpdateParams defines a (governance) operation for updating the module
	// parameters. The authority defaults to the x/gov module account.
	UpdateParams(context.Context, *MsgUpdateParams) (*MsgUpdateParamsResponse, error)
	// RegisterValidator defines a operation to register validator which
	// is then eligible to participate in sending keyshares
	RegisterValidator(context.Context, *MsgRegisterValidator) (*MsgRegisterValidatorResponse, error)
	// DeRegisterValidator defines an operation to de-register
	// a registered validator
	DeRegisterValidator(context.Context, *MsgDeRegisterValidator) (*MsgDeRegisterValidatorResponse, error)
	// SendKeyshare defines an operation to submit keyshares
	// every block from registered validators
	SendKeyshare(context.Context, *MsgSendKeyshare) (*MsgSendKeyshareResponse, error)
	// CreateLatestPubkey defines an operation to add a
	// public key to the chain (can only be done by an authorized address)
	CreateLatestPubkey(context.Context, *MsgCreateLatestPubkey) (*MsgCreateLatestPubkeyResponse, error)
	// OverrideLatestPubkey defines an operation to override the current active pubkey
	OverrideLatestPubkey(context.Context, *MsgOverrideLatestPubkey) (*MsgOverrideLatestPubkeyResponse, error)
	// CreateAuthorizedAddress defines an operation to mark an address
	// as authorized to create and/or update pubkeys on the chain
	CreateAuthorizedAddress(context.Context, *MsgCreateAuthorizedAddress) (*MsgCreateAuthorizedAddressResponse, error)
	// UpdateAuthorizedAddress defines an operation to update the
	// list of authorized addresses
	UpdateAuthorizedAddress(context.Context, *MsgUpdateAuthorizedAddress) (*MsgUpdateAuthorizedAddressResponse, error)
	// DeleteAuthorizedAddress defines an operation to revoke the
	// authorization of a previously authorized address
	DeleteAuthorizedAddress(context.Context, *MsgDeleteAuthorizedAddress) (*MsgDeleteAuthorizedAddressResponse, error)
	// SubmitGeneralKeyshare defines an operation to submit a
	// general keyshare from a registered validator
	SubmitGeneralKeyshare(context.Context, *MsgSubmitGeneralKeyshare) (*MsgSubmitGeneralKeyshareResponse, error)
	// SubmitEncryptedKeyshare defines an operation to submit
	// an encrypted keyshare from a registered validator
	SubmitEncryptedKeyshare(context.Context, *MsgSubmitEncryptedKeyshare) (*MsgSubmitEncryptedKeyshareResponse, error)
}

MsgServer is the server API for Msg service.

type MsgSubmitEncryptedKeyshare added in v0.9.0

type MsgSubmitEncryptedKeyshare struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	Identity            string `protobuf:"bytes,2,opt,name=identity,proto3" json:"identity,omitempty"`
	EncryptedKeyshare   string `protobuf:"bytes,3,opt,name=encrypted_keyshare,json=encryptedKeyshare,proto3" json:"encrypted_keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,4,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,5,opt,name=received_timestamp,json=receivedTimestamp,proto3" json:"received_timestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
	Requester           string `protobuf:"bytes,7,opt,name=requester,proto3" json:"requester,omitempty"`
}

MsgSubmitEncryptedKeyshare is the Msg/SubmitEncryptedKeyshare request type.

func NewMsgSubmitEncryptedKeyshare added in v0.9.0

func NewMsgSubmitEncryptedKeyshare(
	creator string,
	identity string,
	requester string,
	encryptedKeyshare string,
	keyshareIndex uint64,
) *MsgSubmitEncryptedKeyshare

func (*MsgSubmitEncryptedKeyshare) Descriptor added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) GetCreator added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetCreator() string

func (*MsgSubmitEncryptedKeyshare) GetEncryptedKeyshare added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetEncryptedKeyshare() string

func (*MsgSubmitEncryptedKeyshare) GetIdentity added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetIdentity() string

func (*MsgSubmitEncryptedKeyshare) GetKeyshareIndex added in v0.10.0

func (m *MsgSubmitEncryptedKeyshare) GetKeyshareIndex() uint64

func (*MsgSubmitEncryptedKeyshare) GetReceivedBlockHeight added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetReceivedBlockHeight() uint64

func (*MsgSubmitEncryptedKeyshare) GetReceivedTimestamp added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetReceivedTimestamp() uint64

func (*MsgSubmitEncryptedKeyshare) GetRequester added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) GetRequester() string

func (*MsgSubmitEncryptedKeyshare) Marshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) MarshalTo added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) MarshalToSizedBuffer added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) ProtoMessage added in v0.9.0

func (*MsgSubmitEncryptedKeyshare) ProtoMessage()

func (*MsgSubmitEncryptedKeyshare) Reset added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) Reset()

func (*MsgSubmitEncryptedKeyshare) Size added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) String added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) String() string

func (*MsgSubmitEncryptedKeyshare) Unmarshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) ValidateBasic added in v0.9.0

func (msg *MsgSubmitEncryptedKeyshare) ValidateBasic() error

func (*MsgSubmitEncryptedKeyshare) XXX_DiscardUnknown added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) XXX_DiscardUnknown()

func (*MsgSubmitEncryptedKeyshare) XXX_Marshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) XXX_Merge added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshare) XXX_Size added in v0.9.0

func (m *MsgSubmitEncryptedKeyshare) XXX_Size() int

func (*MsgSubmitEncryptedKeyshare) XXX_Unmarshal added in v0.9.0

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

type MsgSubmitEncryptedKeyshareResponse added in v0.9.0

type MsgSubmitEncryptedKeyshareResponse struct {
}

MsgSubmitEncryptedKeyshareResponse defines the response structure for executing a MsgSubmitEncryptedKeyshare message.

func (*MsgSubmitEncryptedKeyshareResponse) Descriptor added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) Marshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) MarshalTo added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) MarshalToSizedBuffer added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) ProtoMessage added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) ProtoMessage()

func (*MsgSubmitEncryptedKeyshareResponse) Reset added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) Size added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) String added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) Unmarshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) XXX_DiscardUnknown added in v0.9.0

func (m *MsgSubmitEncryptedKeyshareResponse) XXX_DiscardUnknown()

func (*MsgSubmitEncryptedKeyshareResponse) XXX_Marshal added in v0.9.0

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

func (*MsgSubmitEncryptedKeyshareResponse) XXX_Merge added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) XXX_Size added in v0.9.0

func (*MsgSubmitEncryptedKeyshareResponse) XXX_Unmarshal added in v0.9.0

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

type MsgSubmitGeneralKeyshare added in v0.10.0

type MsgSubmitGeneralKeyshare struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=id_type,json=idType,proto3" json:"id_type,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=id_value,json=idValue,proto3" json:"id_value,omitempty"`
	Keyshare            string `protobuf:"bytes,4,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,5,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,6,opt,name=received_timestamp,json=receivedTimestamp,proto3" json:"received_timestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,7,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
}

MsgSubmitGeneralKeyshare is the Msg/CreateGeneralKeyshare request type.

func NewMsgSubmitGeneralKeyshare added in v0.10.0

func NewMsgSubmitGeneralKeyshare(
	creator string,
	idType string,
	idValue string,
	keyshare string,
	keyshareIndex uint64,
) *MsgSubmitGeneralKeyshare

func (*MsgSubmitGeneralKeyshare) Descriptor added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) GetCreator added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetCreator() string

func (*MsgSubmitGeneralKeyshare) GetIdType added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetIdType() string

func (*MsgSubmitGeneralKeyshare) GetIdValue added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetIdValue() string

func (*MsgSubmitGeneralKeyshare) GetKeyshare added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetKeyshare() string

func (*MsgSubmitGeneralKeyshare) GetKeyshareIndex added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetKeyshareIndex() uint64

func (*MsgSubmitGeneralKeyshare) GetReceivedBlockHeight added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetReceivedBlockHeight() uint64

func (*MsgSubmitGeneralKeyshare) GetReceivedTimestamp added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) GetReceivedTimestamp() uint64

func (*MsgSubmitGeneralKeyshare) Marshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) MarshalTo added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) ProtoMessage added in v0.10.0

func (*MsgSubmitGeneralKeyshare) ProtoMessage()

func (*MsgSubmitGeneralKeyshare) Reset added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) Reset()

func (*MsgSubmitGeneralKeyshare) Size added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) String added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) String() string

func (*MsgSubmitGeneralKeyshare) Unmarshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) ValidateBasic added in v0.10.0

func (msg *MsgSubmitGeneralKeyshare) ValidateBasic() error

func (*MsgSubmitGeneralKeyshare) XXX_DiscardUnknown added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) XXX_DiscardUnknown()

func (*MsgSubmitGeneralKeyshare) XXX_Marshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) XXX_Merge added in v0.10.0

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

func (*MsgSubmitGeneralKeyshare) XXX_Size added in v0.10.0

func (m *MsgSubmitGeneralKeyshare) XXX_Size() int

func (*MsgSubmitGeneralKeyshare) XXX_Unmarshal added in v0.10.0

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

type MsgSubmitGeneralKeyshareResponse added in v0.10.0

type MsgSubmitGeneralKeyshareResponse struct {
	Creator             string `protobuf:"bytes,1,opt,name=creator,proto3" json:"creator,omitempty"`
	IdType              string `protobuf:"bytes,2,opt,name=id_type,json=idType,proto3" json:"id_type,omitempty"`
	IdValue             string `protobuf:"bytes,3,opt,name=id_value,json=idValue,proto3" json:"id_value,omitempty"`
	Keyshare            string `protobuf:"bytes,4,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,5,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
	Success             bool   `protobuf:"varint,7,opt,name=success,proto3" json:"success,omitempty"`
	ErrorMessage        string `protobuf:"bytes,8,opt,name=error_message,json=errorMessage,proto3" json:"error_message,omitempty"`
}

MsgSubmitGeneralKeyshareResponse defines the response structure for executing a MsgSubmitGeneralKeyshare message.

func (*MsgSubmitGeneralKeyshareResponse) Descriptor added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) GetCreator added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetCreator() string

func (*MsgSubmitGeneralKeyshareResponse) GetErrorMessage added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetErrorMessage() string

func (*MsgSubmitGeneralKeyshareResponse) GetIdType added in v0.10.0

func (*MsgSubmitGeneralKeyshareResponse) GetIdValue added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetIdValue() string

func (*MsgSubmitGeneralKeyshareResponse) GetKeyshare added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetKeyshare() string

func (*MsgSubmitGeneralKeyshareResponse) GetKeyshareIndex added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetKeyshareIndex() uint64

func (*MsgSubmitGeneralKeyshareResponse) GetReceivedBlockHeight added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetReceivedBlockHeight() uint64

func (*MsgSubmitGeneralKeyshareResponse) GetSuccess added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) GetSuccess() bool

func (*MsgSubmitGeneralKeyshareResponse) Marshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) MarshalTo added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) ProtoMessage added in v0.10.0

func (*MsgSubmitGeneralKeyshareResponse) ProtoMessage()

func (*MsgSubmitGeneralKeyshareResponse) Reset added in v0.10.0

func (*MsgSubmitGeneralKeyshareResponse) Size added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) String added in v0.10.0

func (*MsgSubmitGeneralKeyshareResponse) Unmarshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) XXX_DiscardUnknown added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) XXX_DiscardUnknown()

func (*MsgSubmitGeneralKeyshareResponse) XXX_Marshal added in v0.10.0

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

func (*MsgSubmitGeneralKeyshareResponse) XXX_Merge added in v0.10.0

func (*MsgSubmitGeneralKeyshareResponse) XXX_Size added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) XXX_Size() int

func (*MsgSubmitGeneralKeyshareResponse) XXX_Unmarshal added in v0.10.0

func (m *MsgSubmitGeneralKeyshareResponse) 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=is_authorized,json=isAuthorized,proto3" json:"is_authorized,omitempty"`
	Creator      string `protobuf:"bytes,3,opt,name=creator,proto3" json:"creator,omitempty"`
}

MsgUpdateAuthorizedAddress is the Msg/UpdateAuthorizedAddress request type.

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

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

func (*MsgUpdateAuthorizedAddress) String

func (m *MsgUpdateAuthorizedAddress) String() 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 {
}

MsgUpdateAuthorizedAddressResponse defines the response structure for executing a MsgUpdateAuthorizedAddress message.

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 MsgUpdateParams added in v0.7.0

type MsgUpdateParams struct {
	// authority is the address that controls the module (defaults to x/gov unless overwritten).
	Authority string `protobuf:"bytes,1,opt,name=authority,proto3" json:"authority,omitempty"`
	// NOTE: All parameters must be supplied.
	Params Params `protobuf:"bytes,2,opt,name=params,proto3" json:"params"`
}

MsgUpdateParams is the Msg/UpdateParams request type.

func (*MsgUpdateParams) Descriptor added in v0.7.0

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

func (*MsgUpdateParams) GetAuthority added in v0.7.0

func (m *MsgUpdateParams) GetAuthority() string

func (*MsgUpdateParams) GetParams added in v0.7.0

func (m *MsgUpdateParams) GetParams() Params

func (*MsgUpdateParams) Marshal added in v0.7.0

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

func (*MsgUpdateParams) MarshalTo added in v0.7.0

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

func (*MsgUpdateParams) MarshalToSizedBuffer added in v0.7.0

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

func (*MsgUpdateParams) ProtoMessage added in v0.7.0

func (*MsgUpdateParams) ProtoMessage()

func (*MsgUpdateParams) Reset added in v0.7.0

func (m *MsgUpdateParams) Reset()

func (*MsgUpdateParams) Size added in v0.7.0

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

func (*MsgUpdateParams) String added in v0.7.0

func (m *MsgUpdateParams) String() string

func (*MsgUpdateParams) Unmarshal added in v0.7.0

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

func (*MsgUpdateParams) ValidateBasic added in v0.7.0

func (m *MsgUpdateParams) ValidateBasic() error

ValidateBasic does a sanity check on the provided data.

func (*MsgUpdateParams) XXX_DiscardUnknown added in v0.7.0

func (m *MsgUpdateParams) XXX_DiscardUnknown()

func (*MsgUpdateParams) XXX_Marshal added in v0.7.0

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

func (*MsgUpdateParams) XXX_Merge added in v0.7.0

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

func (*MsgUpdateParams) XXX_Size added in v0.7.0

func (m *MsgUpdateParams) XXX_Size() int

func (*MsgUpdateParams) XXX_Unmarshal added in v0.7.0

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

type MsgUpdateParamsResponse added in v0.7.0

type MsgUpdateParamsResponse struct {
}

MsgUpdateParamsResponse defines the response structure for executing a MsgUpdateParams message.

func (*MsgUpdateParamsResponse) Descriptor added in v0.7.0

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

func (*MsgUpdateParamsResponse) Marshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) MarshalTo added in v0.7.0

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

func (*MsgUpdateParamsResponse) MarshalToSizedBuffer added in v0.7.0

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

func (*MsgUpdateParamsResponse) ProtoMessage added in v0.7.0

func (*MsgUpdateParamsResponse) ProtoMessage()

func (*MsgUpdateParamsResponse) Reset added in v0.7.0

func (m *MsgUpdateParamsResponse) Reset()

func (*MsgUpdateParamsResponse) Size added in v0.7.0

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

func (*MsgUpdateParamsResponse) String added in v0.7.0

func (m *MsgUpdateParamsResponse) String() string

func (*MsgUpdateParamsResponse) Unmarshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_DiscardUnknown added in v0.7.0

func (m *MsgUpdateParamsResponse) XXX_DiscardUnknown()

func (*MsgUpdateParamsResponse) XXX_Marshal added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_Merge added in v0.7.0

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

func (*MsgUpdateParamsResponse) XXX_Size added in v0.7.0

func (m *MsgUpdateParamsResponse) XXX_Size() int

func (*MsgUpdateParamsResponse) XXX_Unmarshal added in v0.7.0

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

type NoData

type NoData struct {
}

NoData defines a blank packet

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 ParamSubspace added in v0.7.0

type ParamSubspace interface {
	Get(context.Context, []byte, interface{})
	Set(context.Context, []byte, interface{})
}

ParamSubspace defines the expected Subspace interface for parameters.

type Params

type Params struct {
	KeyExpiry                  uint64                      `protobuf:"varint,1,opt,name=key_expiry,json=keyExpiry,proto3" json:"key_expiry,omitempty" yaml:"key_expiry"`
	MinimumBonded              uint64                      `protobuf:"varint,2,opt,name=minimum_bonded,json=minimumBonded,proto3" json:"minimum_bonded,omitempty" yaml:"minimum_bonded"`
	MaxIdledBlock              uint64                      `` /* 126-byte string literal not displayed */
	TrustedAddresses           []string                    `` /* 134-byte string literal not displayed */
	SlashFractionNoKeyshare    cosmossdk_io_math.LegacyDec `` /* 197-byte string literal not displayed */
	SlashFractionWrongKeyshare cosmossdk_io_math.LegacyDec `` /* 209-byte string literal not displayed */
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func NewParams

func NewParams(
	keyExp uint64,
	trAddrs []string,
	minimumBonded uint64,
	noKeyshareFraction math.LegacyDec,
	wrongKeyshareFraction math.LegacyDec,
	maxIdledBlock uint64,
) Params

NewParams creates a new Params instance

func (*Params) Descriptor

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

func (*Params) Equal added in v0.7.0

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

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

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 context.Context, activePubkey commontypes.ActivePublicKey)
	SetQueuedPubkey(ctx context.Context, queuedPubkey commontypes.QueuedPublicKey)
	GetActivePubkey(ctx context.Context) (val commontypes.ActivePublicKey, found bool)
	GetQueuedPubkey(ctx context.Context) (val commontypes.QueuedPublicKey, found bool)
	DeleteActivePubkey(ctx context.Context)
	DeleteQueuedPubkey(ctx context.Context)
	SetEntry(ctx context.Context, val peptypes.IdentityExecutionEntry)
	GetEntry(ctx context.Context, reqID string) (val peptypes.IdentityExecutionEntry, found bool)
	RemoveEntry(ctx context.Context, reqID string)
	GetAllGenEncTxEntry(ctx context.Context) (list []peptypes.IdentityExecutionEntry)
	GetSignalQueueEntry(ctx context.Context, reqID string) (val commontypes.GetDecryptionKey, found bool)
	SetSignalQueueEntry(ctx context.Context, val commontypes.GetDecryptionKey)
	RemoveSignalQueueEntry(ctx context.Context, reqID string)
	GetAllGenEncTxSignalQueueEntry(ctx context.Context) (list []commontypes.GetDecryptionKey)
	GetExecutionQueueEntry(ctx context.Context, reqID string) (val peptypes.IdentityExecutionEntry, found bool)
	SetExecutionQueueEntry(ctx context.Context, val peptypes.IdentityExecutionEntry)
	RemoveExecutionQueueEntry(ctx context.Context, reqID string)
	GetAllGenEncTxExecutionQueueEntry(ctx context.Context) (list []peptypes.IdentityExecutionEntry)
	GetRequestQueueEntry(ctx context.Context, reqID string) (val commontypes.RequestDecryptionKey, found bool)
	SetReqQueueEntry(ctx context.Context, val commontypes.RequestDecryptionKey)
	RemoveReqQueueEntry(ctx context.Context, reqID string)
	GetAllGenEncTxReqQueueEntry(ctx context.Context) (list []commontypes.RequestDecryptionKey)
	GetPrivateRequestQueueEntry(ctx context.Context, reqID string) (val commontypes.RequestPrivateDecryptionKey, found bool)
	SetPrivateReqQueueEntry(ctx context.Context, val commontypes.RequestPrivateDecryptionKey)
	RemovePrivateReqQueueEntry(ctx context.Context, reqID string)
	GetAllPrivateReqQueueEntry(ctx context.Context) (list []commontypes.RequestPrivateDecryptionKey)
	GetPrivateSignalQueueEntry(ctx context.Context, reqID string) (val commontypes.GetPrivateDecryptionKey, found bool)
	SetPrivateSignalQueueEntry(ctx context.Context, val commontypes.GetPrivateDecryptionKey)
	RemovePrivateSignalQueueEntry(ctx context.Context, reqID string)
	GetAllPrivateSignalQueueEntry(ctx context.Context) (list []commontypes.GetPrivateDecryptionKey)
	SetPrivateRequest(ctx context.Context, request peptypes.PrivateRequest)
	GetPrivateRequest(ctx context.Context, reqID string) (val peptypes.PrivateRequest, found bool)
	GetAllPrivateRequest(ctx context.Context) (list []peptypes.PrivateRequest)
	GetDecryptionKey(ctx context.Context, height uint64) (val peptypes.DecryptionKey, found bool)
	SetDecryptionKey(ctx context.Context, decryptionKey peptypes.DecryptionKey)
	GetLatestHeight(ctx context.Context) string
	SetLatestHeight(ctx context.Context, height string)
}

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

type PortKeeper

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

PortKeeper defines the expected IBC port keeper.

type PrivateDecryptionKeyDataPacketData added in v0.10.0

type PrivateDecryptionKeyDataPacketData 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"`
	PrivateDecryptionKey []*types.PrivateDecryptionKey `protobuf:"bytes,4,rep,name=private_decryption_key,json=privateDecryptionKey,proto3" json:"private_decryption_key,omitempty"`
}

PrivateDecryptionKeyDataPacketData defines a struct for the packet payload

func (*PrivateDecryptionKeyDataPacketData) Descriptor added in v0.10.0

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

func (PrivateDecryptionKeyDataPacketData) GetBytes added in v0.10.0

GetBytes is a helper for serialising

func (*PrivateDecryptionKeyDataPacketData) GetIdentity added in v0.10.0

func (m *PrivateDecryptionKeyDataPacketData) GetIdentity() string

func (*PrivateDecryptionKeyDataPacketData) GetPrivateDecryptionKey added in v0.10.0

func (m *PrivateDecryptionKeyDataPacketData) GetPrivateDecryptionKey() []*types.PrivateDecryptionKey

func (*PrivateDecryptionKeyDataPacketData) GetPubkey added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyDataPacketData) MarshalTo added in v0.10.0

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

func (*PrivateDecryptionKeyDataPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*PrivateDecryptionKeyDataPacketData) ProtoMessage added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) ProtoMessage()

func (*PrivateDecryptionKeyDataPacketData) Reset added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) Size added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) String added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) Unmarshal added in v0.10.0

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

func (PrivateDecryptionKeyDataPacketData) ValidateBasic added in v0.10.0

func (p PrivateDecryptionKeyDataPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*PrivateDecryptionKeyDataPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *PrivateDecryptionKeyDataPacketData) XXX_DiscardUnknown()

func (*PrivateDecryptionKeyDataPacketData) XXX_Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyDataPacketData) XXX_Merge added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) XXX_Size added in v0.10.0

func (*PrivateDecryptionKeyDataPacketData) XXX_Unmarshal added in v0.10.0

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

type PrivateDecryptionKeyPacketAck added in v0.10.0

type PrivateDecryptionKeyPacketAck struct {
}

PrivateDecryptionKeyPacketAck defines a struct for the packet payload

func (*PrivateDecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*PrivateDecryptionKeyPacketAck) ProtoMessage()

func (*PrivateDecryptionKeyPacketAck) Reset added in v0.10.0

func (m *PrivateDecryptionKeyPacketAck) Reset()

func (*PrivateDecryptionKeyPacketAck) Size added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) String added in v0.10.0

func (*PrivateDecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *PrivateDecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*PrivateDecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) XXX_Merge added in v0.10.0

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

func (*PrivateDecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (m *PrivateDecryptionKeyPacketAck) XXX_Size() int

func (*PrivateDecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type PrivateDecryptionKeyRequest added in v0.10.0

type PrivateDecryptionKeyRequest 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"`
	PrivateDecryptionKeys []*types.PrivateDecryptionKey `` /* 126-byte string literal not displayed */
	Sent                  bool                          `protobuf:"varint,7,opt,name=sent,proto3" json:"sent,omitempty"`
}

PrivateDecryptionKeyRequest defines the stroage structure for private encrypted and unaggregated decryption key requests

func (*PrivateDecryptionKeyRequest) Descriptor added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) GetCounterparty added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetCounterparty() *CounterPartyIBCInfo

func (*PrivateDecryptionKeyRequest) GetIbcInfo added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetIbcInfo() *IBCInfo

func (*PrivateDecryptionKeyRequest) GetIdentity added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetIdentity() string

func (*PrivateDecryptionKeyRequest) GetPrivateDecryptionKeys added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetPrivateDecryptionKeys() []*types.PrivateDecryptionKey

func (*PrivateDecryptionKeyRequest) GetPubkey added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetPubkey() string

func (*PrivateDecryptionKeyRequest) GetSent added in v0.10.0

func (m *PrivateDecryptionKeyRequest) GetSent() bool

func (*PrivateDecryptionKeyRequest) Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) MarshalTo added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) ProtoMessage added in v0.10.0

func (*PrivateDecryptionKeyRequest) ProtoMessage()

func (*PrivateDecryptionKeyRequest) Reset added in v0.10.0

func (m *PrivateDecryptionKeyRequest) Reset()

func (*PrivateDecryptionKeyRequest) Size added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) String added in v0.10.0

func (m *PrivateDecryptionKeyRequest) String() string

func (*PrivateDecryptionKeyRequest) Unmarshal added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) XXX_DiscardUnknown added in v0.10.0

func (m *PrivateDecryptionKeyRequest) XXX_DiscardUnknown()

func (*PrivateDecryptionKeyRequest) XXX_Marshal added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) XXX_Merge added in v0.10.0

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

func (*PrivateDecryptionKeyRequest) XXX_Size added in v0.10.0

func (m *PrivateDecryptionKeyRequest) XXX_Size() int

func (*PrivateDecryptionKeyRequest) XXX_Unmarshal added in v0.10.0

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

type QueryAuthorizedAddressAllRequest added in v0.10.0

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

QueryAuthorizedAddressAllRequest is request type for the Query/AuthorizedAddressAll RPC method.

func (*QueryAuthorizedAddressAllRequest) Descriptor added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) GetPagination added in v0.10.0

func (*QueryAuthorizedAddressAllRequest) Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) MarshalTo added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) ProtoMessage added in v0.10.0

func (*QueryAuthorizedAddressAllRequest) ProtoMessage()

func (*QueryAuthorizedAddressAllRequest) Reset added in v0.10.0

func (*QueryAuthorizedAddressAllRequest) Size added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) String added in v0.10.0

func (*QueryAuthorizedAddressAllRequest) Unmarshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryAuthorizedAddressAllRequest) XXX_DiscardUnknown()

func (*QueryAuthorizedAddressAllRequest) XXX_Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllRequest) XXX_Merge added in v0.10.0

func (*QueryAuthorizedAddressAllRequest) XXX_Size added in v0.10.0

func (m *QueryAuthorizedAddressAllRequest) XXX_Size() int

func (*QueryAuthorizedAddressAllRequest) XXX_Unmarshal added in v0.10.0

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

type QueryAuthorizedAddressAllResponse added in v0.10.0

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

QueryAuthorizedAddressAllResponse is response type for the Query/AuthorizedAddressAll RPC method.

func (*QueryAuthorizedAddressAllResponse) Descriptor added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) GetAuthorizedAddress added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) GetPagination added in v0.10.0

func (*QueryAuthorizedAddressAllResponse) Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) MarshalTo added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) ProtoMessage added in v0.10.0

func (*QueryAuthorizedAddressAllResponse) ProtoMessage()

func (*QueryAuthorizedAddressAllResponse) Reset added in v0.10.0

func (*QueryAuthorizedAddressAllResponse) Size added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) String added in v0.10.0

func (*QueryAuthorizedAddressAllResponse) Unmarshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryAuthorizedAddressAllResponse) XXX_DiscardUnknown()

func (*QueryAuthorizedAddressAllResponse) XXX_Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressAllResponse) XXX_Merge added in v0.10.0

func (*QueryAuthorizedAddressAllResponse) XXX_Size added in v0.10.0

func (m *QueryAuthorizedAddressAllResponse) XXX_Size() int

func (*QueryAuthorizedAddressAllResponse) XXX_Unmarshal added in v0.10.0

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

type QueryAuthorizedAddressRequest added in v0.10.0

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

QueryAuthorizedAddressRequest is request type for the Query/AuthorizedAddress RPC method.

func (*QueryAuthorizedAddressRequest) Descriptor added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) GetTarget added in v0.10.0

func (m *QueryAuthorizedAddressRequest) GetTarget() string

func (*QueryAuthorizedAddressRequest) Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) MarshalTo added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) ProtoMessage added in v0.10.0

func (*QueryAuthorizedAddressRequest) ProtoMessage()

func (*QueryAuthorizedAddressRequest) Reset added in v0.10.0

func (m *QueryAuthorizedAddressRequest) Reset()

func (*QueryAuthorizedAddressRequest) Size added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) String added in v0.10.0

func (*QueryAuthorizedAddressRequest) Unmarshal added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryAuthorizedAddressRequest) XXX_DiscardUnknown()

func (*QueryAuthorizedAddressRequest) XXX_Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) XXX_Merge added in v0.10.0

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

func (*QueryAuthorizedAddressRequest) XXX_Size added in v0.10.0

func (m *QueryAuthorizedAddressRequest) XXX_Size() int

func (*QueryAuthorizedAddressRequest) XXX_Unmarshal added in v0.10.0

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

type QueryAuthorizedAddressResponse added in v0.10.0

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

QueryAuthorizedAddressResponse is response type for the Query/AuthorizedAddress RPC method.

func (*QueryAuthorizedAddressResponse) Descriptor added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) GetAuthorizedAddress added in v0.10.0

func (m *QueryAuthorizedAddressResponse) GetAuthorizedAddress() AuthorizedAddress

func (*QueryAuthorizedAddressResponse) Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) MarshalTo added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) ProtoMessage added in v0.10.0

func (*QueryAuthorizedAddressResponse) ProtoMessage()

func (*QueryAuthorizedAddressResponse) Reset added in v0.10.0

func (m *QueryAuthorizedAddressResponse) Reset()

func (*QueryAuthorizedAddressResponse) Size added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) String added in v0.10.0

func (*QueryAuthorizedAddressResponse) Unmarshal added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryAuthorizedAddressResponse) XXX_DiscardUnknown()

func (*QueryAuthorizedAddressResponse) XXX_Marshal added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) XXX_Merge added in v0.10.0

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

func (*QueryAuthorizedAddressResponse) XXX_Size added in v0.10.0

func (m *QueryAuthorizedAddressResponse) XXX_Size() int

func (*QueryAuthorizedAddressResponse) XXX_Unmarshal added in v0.10.0

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

type QueryClient

type QueryClient interface {
	// Parameters queries the parameters of the module.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	// Commitments queries the lists of active and queued commitments
	Commitments(ctx context.Context, in *QueryCommitmentsRequest, opts ...grpc.CallOption) (*QueryCommitmentsResponse, error)
	// Queries a ValidatorSet by index.
	ValidatorSet(ctx context.Context, in *QueryValidatorSetRequest, opts ...grpc.CallOption) (*QueryValidatorSetResponse, error)
	// Queries a list of ValidatorSet items.
	ValidatorSetAll(ctx context.Context, in *QueryValidatorSetAllRequest, opts ...grpc.CallOption) (*QueryValidatorSetAllResponse, error)
	// Queries a Keyshare by index.
	Keyshare(ctx context.Context, in *QueryKeyshareRequest, opts ...grpc.CallOption) (*QueryKeyshareResponse, error)
	// Queries a list of Keyshare items.
	KeyshareAll(ctx context.Context, in *QueryKeyshareAllRequest, opts ...grpc.CallOption) (*QueryKeyshareAllResponse, error)
	// DecryptionKey queries a DecryptionKey item by height.
	DecryptionKey(ctx context.Context, in *QueryDecryptionKeyRequest, opts ...grpc.CallOption) (*QueryDecryptionKeyResponse, error)
	// DecryptionKeyAll Queries a list of DecryptionKey items.
	DecryptionKeyAll(ctx context.Context, in *QueryDecryptionKeyAllRequest, opts ...grpc.CallOption) (*QueryDecryptionKeyAllResponse, error)
	// Queries the public keys
	Pubkey(ctx context.Context, in *QueryPubkeyRequest, opts ...grpc.CallOption) (*QueryPubkeyResponse, error)
	// Queries a AuthorizedAddress item by target.
	AuthorizedAddress(ctx context.Context, in *QueryAuthorizedAddressRequest, opts ...grpc.CallOption) (*QueryAuthorizedAddressResponse, error)
	// Queries a list of AuthorizedAddress items
	AuthorizedAddressAll(ctx context.Context, in *QueryAuthorizedAddressAllRequest, opts ...grpc.CallOption) (*QueryAuthorizedAddressAllResponse, error)
	// Queries a GeneralKeyshare item by validator address and identity.
	GeneralKeyshare(ctx context.Context, in *QueryGeneralKeyshareRequest, opts ...grpc.CallOption) (*QueryGeneralKeyshareResponse, error)
	// Queries a list of GeneralKeyshare items
	GeneralKeyshareAll(ctx context.Context, in *QueryGeneralKeyshareAllRequest, opts ...grpc.CallOption) (*QueryGeneralKeyshareAllResponse, error)
	// Queries verifiable randomness
	VerifiableRandomness(ctx context.Context, in *QueryVerifiableRandomnessRequest, opts ...grpc.CallOption) (*QueryVerifiableRandomnessResponse, 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 {
}

QueryCommitmentsRequest is request type for the Query/Commitments RPC method.

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=active_commitments,json=activeCommitments,proto3" json:"active_commitments,omitempty"`
	QueuedCommitments *Commitments `protobuf:"bytes,2,opt,name=queued_commitments,json=queuedCommitments,proto3" json:"queued_commitments,omitempty"`
}

QueryCommitmentsResponse is response type for the Query/Commitments RPC method

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 QueryDecryptionKeyAllRequest added in v0.10.0

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

QueryDecryptionKeyAllRequest is request type for the Query/DecryptionKeyAll RPC method.

func (*QueryDecryptionKeyAllRequest) Descriptor added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) GetPagination added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) Marshal added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) MarshalTo added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) ProtoMessage added in v0.10.0

func (*QueryDecryptionKeyAllRequest) ProtoMessage()

func (*QueryDecryptionKeyAllRequest) Reset added in v0.10.0

func (m *QueryDecryptionKeyAllRequest) Reset()

func (*QueryDecryptionKeyAllRequest) Size added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) String added in v0.10.0

func (*QueryDecryptionKeyAllRequest) Unmarshal added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryDecryptionKeyAllRequest) XXX_DiscardUnknown()

func (*QueryDecryptionKeyAllRequest) XXX_Marshal added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) XXX_Merge added in v0.10.0

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

func (*QueryDecryptionKeyAllRequest) XXX_Size added in v0.10.0

func (m *QueryDecryptionKeyAllRequest) XXX_Size() int

func (*QueryDecryptionKeyAllRequest) XXX_Unmarshal added in v0.10.0

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

type QueryDecryptionKeyAllResponse added in v0.10.0

type QueryDecryptionKeyAllResponse struct {
	DecryptionKeys []DecryptionKey     `protobuf:"bytes,1,rep,name=decryption_keys,json=decryptionKeys,proto3" json:"decryption_keys"`
	Pagination     *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryDecryptionKeyAllResponse is response type for the Query/DecryptionKeyAll RPC method.

func (*QueryDecryptionKeyAllResponse) Descriptor added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) GetDecryptionKeys added in v0.10.0

func (m *QueryDecryptionKeyAllResponse) GetDecryptionKeys() []DecryptionKey

func (*QueryDecryptionKeyAllResponse) GetPagination added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) Marshal added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) MarshalTo added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) ProtoMessage added in v0.10.0

func (*QueryDecryptionKeyAllResponse) ProtoMessage()

func (*QueryDecryptionKeyAllResponse) Reset added in v0.10.0

func (m *QueryDecryptionKeyAllResponse) Reset()

func (*QueryDecryptionKeyAllResponse) Size added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) String added in v0.10.0

func (*QueryDecryptionKeyAllResponse) Unmarshal added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryDecryptionKeyAllResponse) XXX_DiscardUnknown()

func (*QueryDecryptionKeyAllResponse) XXX_Marshal added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) XXX_Merge added in v0.10.0

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

func (*QueryDecryptionKeyAllResponse) XXX_Size added in v0.10.0

func (m *QueryDecryptionKeyAllResponse) XXX_Size() int

func (*QueryDecryptionKeyAllResponse) XXX_Unmarshal added in v0.10.0

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

type QueryDecryptionKeyRequest added in v0.10.0

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

QueryDecryptionKeyRequest is request type for the Query/DecryptionKey RPC method.

func (*QueryDecryptionKeyRequest) Descriptor added in v0.10.0

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

func (*QueryDecryptionKeyRequest) GetHeight added in v0.10.0

func (m *QueryDecryptionKeyRequest) GetHeight() uint64

func (*QueryDecryptionKeyRequest) Marshal added in v0.10.0

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

func (*QueryDecryptionKeyRequest) MarshalTo added in v0.10.0

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

func (*QueryDecryptionKeyRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryDecryptionKeyRequest) ProtoMessage added in v0.10.0

func (*QueryDecryptionKeyRequest) ProtoMessage()

func (*QueryDecryptionKeyRequest) Reset added in v0.10.0

func (m *QueryDecryptionKeyRequest) Reset()

func (*QueryDecryptionKeyRequest) Size added in v0.10.0

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

func (*QueryDecryptionKeyRequest) String added in v0.10.0

func (m *QueryDecryptionKeyRequest) String() string

func (*QueryDecryptionKeyRequest) Unmarshal added in v0.10.0

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

func (*QueryDecryptionKeyRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryDecryptionKeyRequest) XXX_DiscardUnknown()

func (*QueryDecryptionKeyRequest) XXX_Marshal added in v0.10.0

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

func (*QueryDecryptionKeyRequest) XXX_Merge added in v0.10.0

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

func (*QueryDecryptionKeyRequest) XXX_Size added in v0.10.0

func (m *QueryDecryptionKeyRequest) XXX_Size() int

func (*QueryDecryptionKeyRequest) XXX_Unmarshal added in v0.10.0

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

type QueryDecryptionKeyResponse added in v0.10.0

type QueryDecryptionKeyResponse struct {
	DecryptionKey DecryptionKey `protobuf:"bytes,1,opt,name=decryption_key,json=decryptionKey,proto3" json:"decryption_key"`
}

QueryDecryptionKeyResponse is response type for the Query/DecryptionKey RPC method.

func (*QueryDecryptionKeyResponse) Descriptor added in v0.10.0

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

func (*QueryDecryptionKeyResponse) GetDecryptionKey added in v0.10.0

func (m *QueryDecryptionKeyResponse) GetDecryptionKey() DecryptionKey

func (*QueryDecryptionKeyResponse) Marshal added in v0.10.0

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

func (*QueryDecryptionKeyResponse) MarshalTo added in v0.10.0

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

func (*QueryDecryptionKeyResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryDecryptionKeyResponse) ProtoMessage added in v0.10.0

func (*QueryDecryptionKeyResponse) ProtoMessage()

func (*QueryDecryptionKeyResponse) Reset added in v0.10.0

func (m *QueryDecryptionKeyResponse) Reset()

func (*QueryDecryptionKeyResponse) Size added in v0.10.0

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

func (*QueryDecryptionKeyResponse) String added in v0.10.0

func (m *QueryDecryptionKeyResponse) String() string

func (*QueryDecryptionKeyResponse) Unmarshal added in v0.10.0

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

func (*QueryDecryptionKeyResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryDecryptionKeyResponse) XXX_DiscardUnknown()

func (*QueryDecryptionKeyResponse) XXX_Marshal added in v0.10.0

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

func (*QueryDecryptionKeyResponse) XXX_Merge added in v0.10.0

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

func (*QueryDecryptionKeyResponse) XXX_Size added in v0.10.0

func (m *QueryDecryptionKeyResponse) XXX_Size() int

func (*QueryDecryptionKeyResponse) XXX_Unmarshal added in v0.10.0

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

type QueryGeneralKeyshareAllRequest added in v0.10.0

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

QueryGeneralKeyshareAllRequest is request type for the Query/GeneralKeyshareAll RPC method.

func (*QueryGeneralKeyshareAllRequest) Descriptor added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) GetPagination added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) MarshalTo added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) ProtoMessage added in v0.10.0

func (*QueryGeneralKeyshareAllRequest) ProtoMessage()

func (*QueryGeneralKeyshareAllRequest) Reset added in v0.10.0

func (m *QueryGeneralKeyshareAllRequest) Reset()

func (*QueryGeneralKeyshareAllRequest) Size added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) String added in v0.10.0

func (*QueryGeneralKeyshareAllRequest) Unmarshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryGeneralKeyshareAllRequest) XXX_DiscardUnknown()

func (*QueryGeneralKeyshareAllRequest) XXX_Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) XXX_Merge added in v0.10.0

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

func (*QueryGeneralKeyshareAllRequest) XXX_Size added in v0.10.0

func (m *QueryGeneralKeyshareAllRequest) XXX_Size() int

func (*QueryGeneralKeyshareAllRequest) XXX_Unmarshal added in v0.10.0

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

type QueryGeneralKeyshareAllResponse added in v0.10.0

type QueryGeneralKeyshareAllResponse struct {
	GeneralKeyshare []GeneralKeyshare   `protobuf:"bytes,1,rep,name=general_keyshare,json=generalKeyshare,proto3" json:"general_keyshare"`
	Pagination      *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

QueryGeneralKeyshareAllResponse is response type for the Query/GeneralKeyshareAll RPC method.

func (*QueryGeneralKeyshareAllResponse) Descriptor added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) GetGeneralKeyshare added in v0.10.0

func (m *QueryGeneralKeyshareAllResponse) GetGeneralKeyshare() []GeneralKeyshare

func (*QueryGeneralKeyshareAllResponse) GetPagination added in v0.10.0

func (*QueryGeneralKeyshareAllResponse) Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) MarshalTo added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) ProtoMessage added in v0.10.0

func (*QueryGeneralKeyshareAllResponse) ProtoMessage()

func (*QueryGeneralKeyshareAllResponse) Reset added in v0.10.0

func (*QueryGeneralKeyshareAllResponse) Size added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) String added in v0.10.0

func (*QueryGeneralKeyshareAllResponse) Unmarshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryGeneralKeyshareAllResponse) XXX_DiscardUnknown()

func (*QueryGeneralKeyshareAllResponse) XXX_Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) XXX_Merge added in v0.10.0

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

func (*QueryGeneralKeyshareAllResponse) XXX_Size added in v0.10.0

func (m *QueryGeneralKeyshareAllResponse) XXX_Size() int

func (*QueryGeneralKeyshareAllResponse) XXX_Unmarshal added in v0.10.0

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

type QueryGeneralKeyshareRequest added in v0.10.0

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

QueryGeneralKeyshareRequest is request type for the Query/GeneralKeyshare RPC method.

func (*QueryGeneralKeyshareRequest) Descriptor added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) GetIdType added in v0.10.0

func (m *QueryGeneralKeyshareRequest) GetIdType() string

func (*QueryGeneralKeyshareRequest) GetIdValue added in v0.10.0

func (m *QueryGeneralKeyshareRequest) GetIdValue() string

func (*QueryGeneralKeyshareRequest) GetValidator added in v0.10.0

func (m *QueryGeneralKeyshareRequest) GetValidator() string

func (*QueryGeneralKeyshareRequest) Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) MarshalTo added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) ProtoMessage added in v0.10.0

func (*QueryGeneralKeyshareRequest) ProtoMessage()

func (*QueryGeneralKeyshareRequest) Reset added in v0.10.0

func (m *QueryGeneralKeyshareRequest) Reset()

func (*QueryGeneralKeyshareRequest) Size added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) String added in v0.10.0

func (m *QueryGeneralKeyshareRequest) String() string

func (*QueryGeneralKeyshareRequest) Unmarshal added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryGeneralKeyshareRequest) XXX_DiscardUnknown()

func (*QueryGeneralKeyshareRequest) XXX_Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) XXX_Merge added in v0.10.0

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

func (*QueryGeneralKeyshareRequest) XXX_Size added in v0.10.0

func (m *QueryGeneralKeyshareRequest) XXX_Size() int

func (*QueryGeneralKeyshareRequest) XXX_Unmarshal added in v0.10.0

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

type QueryGeneralKeyshareResponse added in v0.10.0

type QueryGeneralKeyshareResponse struct {
	GeneralKeyshare GeneralKeyshare `protobuf:"bytes,1,opt,name=general_keyshare,json=generalKeyshare,proto3" json:"general_keyshare"`
}

QueryGeneralKeyshareResponse is response type for the Query/GeneralKeyshare RPC method.

func (*QueryGeneralKeyshareResponse) Descriptor added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) GetGeneralKeyshare added in v0.10.0

func (m *QueryGeneralKeyshareResponse) GetGeneralKeyshare() GeneralKeyshare

func (*QueryGeneralKeyshareResponse) Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) MarshalTo added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) ProtoMessage added in v0.10.0

func (*QueryGeneralKeyshareResponse) ProtoMessage()

func (*QueryGeneralKeyshareResponse) Reset added in v0.10.0

func (m *QueryGeneralKeyshareResponse) Reset()

func (*QueryGeneralKeyshareResponse) Size added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) String added in v0.10.0

func (*QueryGeneralKeyshareResponse) Unmarshal added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryGeneralKeyshareResponse) XXX_DiscardUnknown()

func (*QueryGeneralKeyshareResponse) XXX_Marshal added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) XXX_Merge added in v0.10.0

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

func (*QueryGeneralKeyshareResponse) XXX_Size added in v0.10.0

func (m *QueryGeneralKeyshareResponse) XXX_Size() int

func (*QueryGeneralKeyshareResponse) XXX_Unmarshal added in v0.10.0

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

type QueryKeyshareAllRequest added in v0.10.0

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

QueryKeyshareAllRequest is request type for the Query/KeyshareAll RPC method.

func (*QueryKeyshareAllRequest) Descriptor added in v0.10.0

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

func (*QueryKeyshareAllRequest) GetPagination added in v0.10.0

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

func (*QueryKeyshareAllRequest) Marshal added in v0.10.0

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

func (*QueryKeyshareAllRequest) MarshalTo added in v0.10.0

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

func (*QueryKeyshareAllRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryKeyshareAllRequest) ProtoMessage added in v0.10.0

func (*QueryKeyshareAllRequest) ProtoMessage()

func (*QueryKeyshareAllRequest) Reset added in v0.10.0

func (m *QueryKeyshareAllRequest) Reset()

func (*QueryKeyshareAllRequest) Size added in v0.10.0

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

func (*QueryKeyshareAllRequest) String added in v0.10.0

func (m *QueryKeyshareAllRequest) String() string

func (*QueryKeyshareAllRequest) Unmarshal added in v0.10.0

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

func (*QueryKeyshareAllRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryKeyshareAllRequest) XXX_DiscardUnknown()

func (*QueryKeyshareAllRequest) XXX_Marshal added in v0.10.0

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

func (*QueryKeyshareAllRequest) XXX_Merge added in v0.10.0

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

func (*QueryKeyshareAllRequest) XXX_Size added in v0.10.0

func (m *QueryKeyshareAllRequest) XXX_Size() int

func (*QueryKeyshareAllRequest) XXX_Unmarshal added in v0.10.0

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

type QueryKeyshareAllResponse added in v0.10.0

type QueryKeyshareAllResponse 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"`
}

QueryKeyshareAllResponse is response type for the Query/KeyshareAll RPC method.

func (*QueryKeyshareAllResponse) Descriptor added in v0.10.0

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

func (*QueryKeyshareAllResponse) GetKeyshare added in v0.10.0

func (m *QueryKeyshareAllResponse) GetKeyshare() []Keyshare

func (*QueryKeyshareAllResponse) GetPagination added in v0.10.0

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

func (*QueryKeyshareAllResponse) Marshal added in v0.10.0

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

func (*QueryKeyshareAllResponse) MarshalTo added in v0.10.0

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

func (*QueryKeyshareAllResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryKeyshareAllResponse) ProtoMessage added in v0.10.0

func (*QueryKeyshareAllResponse) ProtoMessage()

func (*QueryKeyshareAllResponse) Reset added in v0.10.0

func (m *QueryKeyshareAllResponse) Reset()

func (*QueryKeyshareAllResponse) Size added in v0.10.0

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

func (*QueryKeyshareAllResponse) String added in v0.10.0

func (m *QueryKeyshareAllResponse) String() string

func (*QueryKeyshareAllResponse) Unmarshal added in v0.10.0

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

func (*QueryKeyshareAllResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryKeyshareAllResponse) XXX_DiscardUnknown()

func (*QueryKeyshareAllResponse) XXX_Marshal added in v0.10.0

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

func (*QueryKeyshareAllResponse) XXX_Merge added in v0.10.0

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

func (*QueryKeyshareAllResponse) XXX_Size added in v0.10.0

func (m *QueryKeyshareAllResponse) XXX_Size() int

func (*QueryKeyshareAllResponse) XXX_Unmarshal added in v0.10.0

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

type QueryKeyshareRequest added in v0.10.0

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

QueryKeyshareRequest is request type for the Query/Keyshare RPC method.

func (*QueryKeyshareRequest) Descriptor added in v0.10.0

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

func (*QueryKeyshareRequest) GetBlockHeight added in v0.10.0

func (m *QueryKeyshareRequest) GetBlockHeight() uint64

func (*QueryKeyshareRequest) GetValidator added in v0.10.0

func (m *QueryKeyshareRequest) GetValidator() string

func (*QueryKeyshareRequest) Marshal added in v0.10.0

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

func (*QueryKeyshareRequest) MarshalTo added in v0.10.0

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

func (*QueryKeyshareRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryKeyshareRequest) ProtoMessage added in v0.10.0

func (*QueryKeyshareRequest) ProtoMessage()

func (*QueryKeyshareRequest) Reset added in v0.10.0

func (m *QueryKeyshareRequest) Reset()

func (*QueryKeyshareRequest) Size added in v0.10.0

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

func (*QueryKeyshareRequest) String added in v0.10.0

func (m *QueryKeyshareRequest) String() string

func (*QueryKeyshareRequest) Unmarshal added in v0.10.0

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

func (*QueryKeyshareRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryKeyshareRequest) XXX_DiscardUnknown()

func (*QueryKeyshareRequest) XXX_Marshal added in v0.10.0

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

func (*QueryKeyshareRequest) XXX_Merge added in v0.10.0

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

func (*QueryKeyshareRequest) XXX_Size added in v0.10.0

func (m *QueryKeyshareRequest) XXX_Size() int

func (*QueryKeyshareRequest) XXX_Unmarshal added in v0.10.0

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

type QueryKeyshareResponse added in v0.10.0

type QueryKeyshareResponse struct {
	Keyshare Keyshare `protobuf:"bytes,1,opt,name=keyshare,proto3" json:"keyshare"`
}

QueryKeyshareResponse is response type for the Query/Keyshare RPC method.

func (*QueryKeyshareResponse) Descriptor added in v0.10.0

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

func (*QueryKeyshareResponse) GetKeyshare added in v0.10.0

func (m *QueryKeyshareResponse) GetKeyshare() Keyshare

func (*QueryKeyshareResponse) Marshal added in v0.10.0

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

func (*QueryKeyshareResponse) MarshalTo added in v0.10.0

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

func (*QueryKeyshareResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryKeyshareResponse) ProtoMessage added in v0.10.0

func (*QueryKeyshareResponse) ProtoMessage()

func (*QueryKeyshareResponse) Reset added in v0.10.0

func (m *QueryKeyshareResponse) Reset()

func (*QueryKeyshareResponse) Size added in v0.10.0

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

func (*QueryKeyshareResponse) String added in v0.10.0

func (m *QueryKeyshareResponse) String() string

func (*QueryKeyshareResponse) Unmarshal added in v0.10.0

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

func (*QueryKeyshareResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryKeyshareResponse) XXX_DiscardUnknown()

func (*QueryKeyshareResponse) XXX_Marshal added in v0.10.0

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

func (*QueryKeyshareResponse) XXX_Merge added in v0.10.0

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

func (*QueryKeyshareResponse) XXX_Size added in v0.10.0

func (m *QueryKeyshareResponse) XXX_Size() int

func (*QueryKeyshareResponse) XXX_Unmarshal added in v0.10.0

func (m *QueryKeyshareResponse) 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 added in v0.10.0

type QueryPubkeyRequest struct {
}

QueryPubkeyRequest is request type for the Query/Pubkey RPC method.

func (*QueryPubkeyRequest) Descriptor added in v0.10.0

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

func (*QueryPubkeyRequest) Marshal added in v0.10.0

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

func (*QueryPubkeyRequest) MarshalTo added in v0.10.0

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

func (*QueryPubkeyRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryPubkeyRequest) ProtoMessage added in v0.10.0

func (*QueryPubkeyRequest) ProtoMessage()

func (*QueryPubkeyRequest) Reset added in v0.10.0

func (m *QueryPubkeyRequest) Reset()

func (*QueryPubkeyRequest) Size added in v0.10.0

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

func (*QueryPubkeyRequest) String added in v0.10.0

func (m *QueryPubkeyRequest) String() string

func (*QueryPubkeyRequest) Unmarshal added in v0.10.0

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

func (*QueryPubkeyRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryPubkeyRequest) XXX_DiscardUnknown()

func (*QueryPubkeyRequest) XXX_Marshal added in v0.10.0

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

func (*QueryPubkeyRequest) XXX_Merge added in v0.10.0

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

func (*QueryPubkeyRequest) XXX_Size added in v0.10.0

func (m *QueryPubkeyRequest) XXX_Size() int

func (*QueryPubkeyRequest) XXX_Unmarshal added in v0.10.0

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

type QueryPubkeyResponse added in v0.10.0

type QueryPubkeyResponse struct {
	ActivePubkey ActivePubkey `protobuf:"bytes,1,opt,name=active_pubkey,json=activePubkey,proto3" json:"active_pubkey"`
	QueuedPubkey QueuedPubkey `protobuf:"bytes,2,opt,name=queued_pubkey,json=queuedPubkey,proto3" json:"queued_pubkey"`
}

QueryPubkeyResponse is response type for the Query/Pubkey RPC method.

func (*QueryPubkeyResponse) Descriptor added in v0.10.0

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

func (*QueryPubkeyResponse) GetActivePubkey added in v0.10.0

func (m *QueryPubkeyResponse) GetActivePubkey() ActivePubkey

func (*QueryPubkeyResponse) GetQueuedPubkey added in v0.10.0

func (m *QueryPubkeyResponse) GetQueuedPubkey() QueuedPubkey

func (*QueryPubkeyResponse) Marshal added in v0.10.0

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

func (*QueryPubkeyResponse) MarshalTo added in v0.10.0

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

func (*QueryPubkeyResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryPubkeyResponse) ProtoMessage added in v0.10.0

func (*QueryPubkeyResponse) ProtoMessage()

func (*QueryPubkeyResponse) Reset added in v0.10.0

func (m *QueryPubkeyResponse) Reset()

func (*QueryPubkeyResponse) Size added in v0.10.0

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

func (*QueryPubkeyResponse) String added in v0.10.0

func (m *QueryPubkeyResponse) String() string

func (*QueryPubkeyResponse) Unmarshal added in v0.10.0

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

func (*QueryPubkeyResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryPubkeyResponse) XXX_DiscardUnknown()

func (*QueryPubkeyResponse) XXX_Marshal added in v0.10.0

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

func (*QueryPubkeyResponse) XXX_Merge added in v0.10.0

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

func (*QueryPubkeyResponse) XXX_Size added in v0.10.0

func (m *QueryPubkeyResponse) XXX_Size() int

func (*QueryPubkeyResponse) XXX_Unmarshal added in v0.10.0

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

type QueryServer

type QueryServer interface {
	// Parameters queries the parameters of the module.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	// Commitments queries the lists of active and queued commitments
	Commitments(context.Context, *QueryCommitmentsRequest) (*QueryCommitmentsResponse, error)
	// Queries a ValidatorSet by index.
	ValidatorSet(context.Context, *QueryValidatorSetRequest) (*QueryValidatorSetResponse, error)
	// Queries a list of ValidatorSet items.
	ValidatorSetAll(context.Context, *QueryValidatorSetAllRequest) (*QueryValidatorSetAllResponse, error)
	// Queries a Keyshare by index.
	Keyshare(context.Context, *QueryKeyshareRequest) (*QueryKeyshareResponse, error)
	// Queries a list of Keyshare items.
	KeyshareAll(context.Context, *QueryKeyshareAllRequest) (*QueryKeyshareAllResponse, error)
	// DecryptionKey queries a DecryptionKey item by height.
	DecryptionKey(context.Context, *QueryDecryptionKeyRequest) (*QueryDecryptionKeyResponse, error)
	// DecryptionKeyAll Queries a list of DecryptionKey items.
	DecryptionKeyAll(context.Context, *QueryDecryptionKeyAllRequest) (*QueryDecryptionKeyAllResponse, error)
	// Queries the public keys
	Pubkey(context.Context, *QueryPubkeyRequest) (*QueryPubkeyResponse, error)
	// Queries a AuthorizedAddress item by target.
	AuthorizedAddress(context.Context, *QueryAuthorizedAddressRequest) (*QueryAuthorizedAddressResponse, error)
	// Queries a list of AuthorizedAddress items
	AuthorizedAddressAll(context.Context, *QueryAuthorizedAddressAllRequest) (*QueryAuthorizedAddressAllResponse, error)
	// Queries a GeneralKeyshare item by validator address and identity.
	GeneralKeyshare(context.Context, *QueryGeneralKeyshareRequest) (*QueryGeneralKeyshareResponse, error)
	// Queries a list of GeneralKeyshare items
	GeneralKeyshareAll(context.Context, *QueryGeneralKeyshareAllRequest) (*QueryGeneralKeyshareAllResponse, error)
	// Queries verifiable randomness
	VerifiableRandomness(context.Context, *QueryVerifiableRandomnessRequest) (*QueryVerifiableRandomnessResponse, error)
}

QueryServer is the server API for Query service.

type QueryValidatorSetAllRequest added in v0.10.0

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

QueryValidatorSetAllRequest is request type for the Query/ValidatorSetAll RPC method.

func (*QueryValidatorSetAllRequest) Descriptor added in v0.10.0

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

func (*QueryValidatorSetAllRequest) GetPagination added in v0.10.0

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

func (*QueryValidatorSetAllRequest) Marshal added in v0.10.0

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

func (*QueryValidatorSetAllRequest) MarshalTo added in v0.10.0

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

func (*QueryValidatorSetAllRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryValidatorSetAllRequest) ProtoMessage added in v0.10.0

func (*QueryValidatorSetAllRequest) ProtoMessage()

func (*QueryValidatorSetAllRequest) Reset added in v0.10.0

func (m *QueryValidatorSetAllRequest) Reset()

func (*QueryValidatorSetAllRequest) Size added in v0.10.0

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

func (*QueryValidatorSetAllRequest) String added in v0.10.0

func (m *QueryValidatorSetAllRequest) String() string

func (*QueryValidatorSetAllRequest) Unmarshal added in v0.10.0

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

func (*QueryValidatorSetAllRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryValidatorSetAllRequest) XXX_DiscardUnknown()

func (*QueryValidatorSetAllRequest) XXX_Marshal added in v0.10.0

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

func (*QueryValidatorSetAllRequest) XXX_Merge added in v0.10.0

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

func (*QueryValidatorSetAllRequest) XXX_Size added in v0.10.0

func (m *QueryValidatorSetAllRequest) XXX_Size() int

func (*QueryValidatorSetAllRequest) XXX_Unmarshal added in v0.10.0

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

type QueryValidatorSetAllResponse added in v0.10.0

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

QueryValidatorSetAllResponse is response type for the Query/ValidatorSetAll RPC method.

func (*QueryValidatorSetAllResponse) Descriptor added in v0.10.0

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

func (*QueryValidatorSetAllResponse) GetPagination added in v0.10.0

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

func (*QueryValidatorSetAllResponse) GetValidatorSet added in v0.10.0

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

func (*QueryValidatorSetAllResponse) Marshal added in v0.10.0

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

func (*QueryValidatorSetAllResponse) MarshalTo added in v0.10.0

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

func (*QueryValidatorSetAllResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryValidatorSetAllResponse) ProtoMessage added in v0.10.0

func (*QueryValidatorSetAllResponse) ProtoMessage()

func (*QueryValidatorSetAllResponse) Reset added in v0.10.0

func (m *QueryValidatorSetAllResponse) Reset()

func (*QueryValidatorSetAllResponse) Size added in v0.10.0

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

func (*QueryValidatorSetAllResponse) String added in v0.10.0

func (*QueryValidatorSetAllResponse) Unmarshal added in v0.10.0

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

func (*QueryValidatorSetAllResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryValidatorSetAllResponse) XXX_DiscardUnknown()

func (*QueryValidatorSetAllResponse) XXX_Marshal added in v0.10.0

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

func (*QueryValidatorSetAllResponse) XXX_Merge added in v0.10.0

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

func (*QueryValidatorSetAllResponse) XXX_Size added in v0.10.0

func (m *QueryValidatorSetAllResponse) XXX_Size() int

func (*QueryValidatorSetAllResponse) XXX_Unmarshal added in v0.10.0

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

type QueryValidatorSetRequest added in v0.10.0

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

QueryValidatorSetRequest is request type for the Query/ValidatorSet RPC method.

func (*QueryValidatorSetRequest) Descriptor added in v0.10.0

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

func (*QueryValidatorSetRequest) GetIndex added in v0.10.0

func (m *QueryValidatorSetRequest) GetIndex() string

func (*QueryValidatorSetRequest) Marshal added in v0.10.0

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

func (*QueryValidatorSetRequest) MarshalTo added in v0.10.0

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

func (*QueryValidatorSetRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryValidatorSetRequest) ProtoMessage added in v0.10.0

func (*QueryValidatorSetRequest) ProtoMessage()

func (*QueryValidatorSetRequest) Reset added in v0.10.0

func (m *QueryValidatorSetRequest) Reset()

func (*QueryValidatorSetRequest) Size added in v0.10.0

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

func (*QueryValidatorSetRequest) String added in v0.10.0

func (m *QueryValidatorSetRequest) String() string

func (*QueryValidatorSetRequest) Unmarshal added in v0.10.0

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

func (*QueryValidatorSetRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryValidatorSetRequest) XXX_DiscardUnknown()

func (*QueryValidatorSetRequest) XXX_Marshal added in v0.10.0

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

func (*QueryValidatorSetRequest) XXX_Merge added in v0.10.0

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

func (*QueryValidatorSetRequest) XXX_Size added in v0.10.0

func (m *QueryValidatorSetRequest) XXX_Size() int

func (*QueryValidatorSetRequest) XXX_Unmarshal added in v0.10.0

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

type QueryValidatorSetResponse added in v0.10.0

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

QueryValidatorSetResponse is response type for the Query/ValidatorSet RPC method.

func (*QueryValidatorSetResponse) Descriptor added in v0.10.0

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

func (*QueryValidatorSetResponse) GetValidatorSet added in v0.10.0

func (m *QueryValidatorSetResponse) GetValidatorSet() ValidatorSet

func (*QueryValidatorSetResponse) Marshal added in v0.10.0

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

func (*QueryValidatorSetResponse) MarshalTo added in v0.10.0

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

func (*QueryValidatorSetResponse) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryValidatorSetResponse) ProtoMessage added in v0.10.0

func (*QueryValidatorSetResponse) ProtoMessage()

func (*QueryValidatorSetResponse) Reset added in v0.10.0

func (m *QueryValidatorSetResponse) Reset()

func (*QueryValidatorSetResponse) Size added in v0.10.0

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

func (*QueryValidatorSetResponse) String added in v0.10.0

func (m *QueryValidatorSetResponse) String() string

func (*QueryValidatorSetResponse) Unmarshal added in v0.10.0

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

func (*QueryValidatorSetResponse) XXX_DiscardUnknown added in v0.10.0

func (m *QueryValidatorSetResponse) XXX_DiscardUnknown()

func (*QueryValidatorSetResponse) XXX_Marshal added in v0.10.0

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

func (*QueryValidatorSetResponse) XXX_Merge added in v0.10.0

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

func (*QueryValidatorSetResponse) XXX_Size added in v0.10.0

func (m *QueryValidatorSetResponse) XXX_Size() int

func (*QueryValidatorSetResponse) XXX_Unmarshal added in v0.10.0

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

type QueryVerifiableRandomnessRequest added in v0.10.0

type QueryVerifiableRandomnessRequest struct {
}

QueryVerifiableRandomnessRequest is the request type for the Query/VerifiableRandomness method

func (*QueryVerifiableRandomnessRequest) Descriptor added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) Marshal added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) MarshalTo added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) MarshalToSizedBuffer added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) ProtoMessage added in v0.10.0

func (*QueryVerifiableRandomnessRequest) ProtoMessage()

func (*QueryVerifiableRandomnessRequest) Reset added in v0.10.0

func (*QueryVerifiableRandomnessRequest) Size added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) String added in v0.10.0

func (*QueryVerifiableRandomnessRequest) Unmarshal added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) XXX_DiscardUnknown added in v0.10.0

func (m *QueryVerifiableRandomnessRequest) XXX_DiscardUnknown()

func (*QueryVerifiableRandomnessRequest) XXX_Marshal added in v0.10.0

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

func (*QueryVerifiableRandomnessRequest) XXX_Merge added in v0.10.0

func (*QueryVerifiableRandomnessRequest) XXX_Size added in v0.10.0

func (m *QueryVerifiableRandomnessRequest) XXX_Size() int

func (*QueryVerifiableRandomnessRequest) XXX_Unmarshal added in v0.10.0

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

type QueryVerifiableRandomnessResponse added in v0.7.0

type QueryVerifiableRandomnessResponse struct {
	Randomness string `protobuf:"bytes,1,opt,name=randomness,proto3" json:"randomness,omitempty"`
	Round      uint64 `protobuf:"varint,2,opt,name=round,proto3" json:"round,omitempty"`
}

QueryVerifiableRandomnessResponse is the response type for the Query/VerifiableRandomness method

func (*QueryVerifiableRandomnessResponse) Descriptor added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) GetRandomness added in v0.7.0

func (m *QueryVerifiableRandomnessResponse) GetRandomness() string

func (*QueryVerifiableRandomnessResponse) GetRound added in v0.7.0

func (*QueryVerifiableRandomnessResponse) Marshal added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) MarshalTo added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) MarshalToSizedBuffer added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) ProtoMessage added in v0.7.0

func (*QueryVerifiableRandomnessResponse) ProtoMessage()

func (*QueryVerifiableRandomnessResponse) Reset added in v0.7.0

func (*QueryVerifiableRandomnessResponse) Size added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) String added in v0.7.0

func (*QueryVerifiableRandomnessResponse) Unmarshal added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) XXX_DiscardUnknown added in v0.7.0

func (m *QueryVerifiableRandomnessResponse) XXX_DiscardUnknown()

func (*QueryVerifiableRandomnessResponse) XXX_Marshal added in v0.7.0

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

func (*QueryVerifiableRandomnessResponse) XXX_Merge added in v0.7.0

func (*QueryVerifiableRandomnessResponse) XXX_Size added in v0.7.0

func (m *QueryVerifiableRandomnessResponse) XXX_Size() int

func (*QueryVerifiableRandomnessResponse) XXX_Unmarshal added in v0.7.0

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

type QueuedPubkey added in v0.10.0

type QueuedPubkey struct {
	PublicKey          string               `protobuf:"bytes,1,opt,name=public_key,json=publicKey,proto3" json:"public_key,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=number_of_validators,json=numberOfValidators,proto3" json:"number_of_validators,omitempty"`
	EncryptedKeyshares []*EncryptedKeyshare `protobuf:"bytes,5,rep,name=encrypted_keyshares,json=encryptedKeyshares,proto3" json:"encrypted_keyshares,omitempty"`
}

QueuedPubkey defines the structure of the queued public key

func (*QueuedPubkey) Descriptor added in v0.10.0

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

func (*QueuedPubkey) GetCreator added in v0.10.0

func (m *QueuedPubkey) GetCreator() string

func (*QueuedPubkey) GetEncryptedKeyshares added in v0.10.0

func (m *QueuedPubkey) GetEncryptedKeyshares() []*EncryptedKeyshare

func (*QueuedPubkey) GetExpiry added in v0.10.0

func (m *QueuedPubkey) GetExpiry() uint64

func (*QueuedPubkey) GetNumberOfValidators added in v0.10.0

func (m *QueuedPubkey) GetNumberOfValidators() uint64

func (*QueuedPubkey) GetPublicKey added in v0.10.0

func (m *QueuedPubkey) GetPublicKey() string

func (*QueuedPubkey) Marshal added in v0.10.0

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

func (*QueuedPubkey) MarshalTo added in v0.10.0

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

func (*QueuedPubkey) MarshalToSizedBuffer added in v0.10.0

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

func (*QueuedPubkey) ProtoMessage added in v0.10.0

func (*QueuedPubkey) ProtoMessage()

func (*QueuedPubkey) Reset added in v0.10.0

func (m *QueuedPubkey) Reset()

func (*QueuedPubkey) Size added in v0.10.0

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

func (*QueuedPubkey) String added in v0.10.0

func (m *QueuedPubkey) String() string

func (*QueuedPubkey) Unmarshal added in v0.10.0

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

func (*QueuedPubkey) XXX_DiscardUnknown added in v0.10.0

func (m *QueuedPubkey) XXX_DiscardUnknown()

func (*QueuedPubkey) XXX_Marshal added in v0.10.0

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

func (*QueuedPubkey) XXX_Merge added in v0.10.0

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

func (*QueuedPubkey) XXX_Size added in v0.10.0

func (m *QueuedPubkey) XXX_Size() int

func (*QueuedPubkey) XXX_Unmarshal added in v0.10.0

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

type RequestDecryptionKeyPacketAck added in v0.10.0

type RequestDecryptionKeyPacketAck 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"`
}

RequestDecryptionKeyPacketAck defines a struct for the packet acknowledgment

func (*RequestDecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) GetIdentity added in v0.10.0

func (m *RequestDecryptionKeyPacketAck) GetIdentity() string

func (*RequestDecryptionKeyPacketAck) GetPubkey added in v0.10.0

func (m *RequestDecryptionKeyPacketAck) GetPubkey() string

func (*RequestDecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*RequestDecryptionKeyPacketAck) ProtoMessage()

func (*RequestDecryptionKeyPacketAck) Reset added in v0.10.0

func (m *RequestDecryptionKeyPacketAck) Reset()

func (*RequestDecryptionKeyPacketAck) Size added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) String added in v0.10.0

func (*RequestDecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *RequestDecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*RequestDecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) XXX_Merge added in v0.10.0

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

func (*RequestDecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (m *RequestDecryptionKeyPacketAck) XXX_Size() int

func (*RequestDecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type RequestDecryptionKeyPacketData added in v0.10.0

type RequestDecryptionKeyPacketData struct {
	Requester string `protobuf:"bytes,1,opt,name=requester,proto3" json:"requester,omitempty"`
	// id can either be a request id or a proposal id
	//
	// Types that are valid to be assigned to Id:
	//	*RequestDecryptionKeyPacketData_ProposalId
	//	*RequestDecryptionKeyPacketData_Identity
	Id             isRequestDecryptionKeyPacketData_Id `protobuf_oneof:"id"`
	EstimatedDelay *time.Duration                      `protobuf:"bytes,4,opt,name=estimated_delay,json=estimatedDelay,proto3,stdduration" json:"estimated_delay,omitempty"`
}

RequestDecryptionKeyPacketData defines a struct for the packet payload

func (*RequestDecryptionKeyPacketData) Descriptor added in v0.10.0

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

func (RequestDecryptionKeyPacketData) GetBytes added in v0.10.0

func (p RequestDecryptionKeyPacketData) GetBytes() []byte

GetBytes is a helper for serialising

func (*RequestDecryptionKeyPacketData) GetEstimatedDelay added in v0.10.0

func (m *RequestDecryptionKeyPacketData) GetEstimatedDelay() *time.Duration

func (*RequestDecryptionKeyPacketData) GetId added in v0.10.0

func (m *RequestDecryptionKeyPacketData) GetId() isRequestDecryptionKeyPacketData_Id

func (*RequestDecryptionKeyPacketData) GetIdentity added in v0.10.2

func (m *RequestDecryptionKeyPacketData) GetIdentity() string

func (*RequestDecryptionKeyPacketData) GetProposalId added in v0.10.0

func (m *RequestDecryptionKeyPacketData) GetProposalId() string

func (*RequestDecryptionKeyPacketData) GetRequester added in v0.10.0

func (m *RequestDecryptionKeyPacketData) GetRequester() string

func (*RequestDecryptionKeyPacketData) Marshal added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) MarshalTo added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) ProtoMessage added in v0.10.0

func (*RequestDecryptionKeyPacketData) ProtoMessage()

func (*RequestDecryptionKeyPacketData) Reset added in v0.10.0

func (m *RequestDecryptionKeyPacketData) Reset()

func (*RequestDecryptionKeyPacketData) Size added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) String added in v0.10.0

func (*RequestDecryptionKeyPacketData) Unmarshal added in v0.10.0

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

func (RequestDecryptionKeyPacketData) ValidateBasic added in v0.10.0

func (p RequestDecryptionKeyPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*RequestDecryptionKeyPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *RequestDecryptionKeyPacketData) XXX_DiscardUnknown()

func (*RequestDecryptionKeyPacketData) XXX_Marshal added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) XXX_Merge added in v0.10.0

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

func (*RequestDecryptionKeyPacketData) XXX_OneofWrappers added in v0.10.0

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

XXX_OneofWrappers is for the internal use of the proto package.

func (*RequestDecryptionKeyPacketData) XXX_Size added in v0.10.0

func (m *RequestDecryptionKeyPacketData) XXX_Size() int

func (*RequestDecryptionKeyPacketData) XXX_Unmarshal added in v0.10.0

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

type RequestDecryptionKeyPacketData_Identity added in v0.10.2

type RequestDecryptionKeyPacketData_Identity struct {
	Identity string `protobuf:"bytes,3,opt,name=identity,proto3,oneof" json:"identity,omitempty"`
}

func (*RequestDecryptionKeyPacketData_Identity) MarshalTo added in v0.10.2

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

func (*RequestDecryptionKeyPacketData_Identity) MarshalToSizedBuffer added in v0.10.2

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

func (*RequestDecryptionKeyPacketData_Identity) Size added in v0.10.2

type RequestDecryptionKeyPacketData_ProposalId added in v0.10.0

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

func (*RequestDecryptionKeyPacketData_ProposalId) MarshalTo added in v0.10.0

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

func (*RequestDecryptionKeyPacketData_ProposalId) MarshalToSizedBuffer added in v0.10.0

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

func (*RequestDecryptionKeyPacketData_ProposalId) Size added in v0.10.0

type RequestPrivateDecryptionKeyPacketAck added in v0.10.0

type RequestPrivateDecryptionKeyPacketAck 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"`
}

RequestPrivateDecryptionKeyPacketAck defines a struct for the packet acknowledgment

func (*RequestPrivateDecryptionKeyPacketAck) Descriptor added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) GetIdentity added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) GetPubkey added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) Marshal added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) MarshalTo added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) MarshalToSizedBuffer added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) ProtoMessage added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) ProtoMessage()

func (*RequestPrivateDecryptionKeyPacketAck) Reset added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) Size added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) String added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) Unmarshal added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) XXX_DiscardUnknown added in v0.10.0

func (m *RequestPrivateDecryptionKeyPacketAck) XXX_DiscardUnknown()

func (*RequestPrivateDecryptionKeyPacketAck) XXX_Marshal added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketAck) XXX_Merge added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) XXX_Size added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketAck) XXX_Unmarshal added in v0.10.0

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

type RequestPrivateDecryptionKeyPacketData added in v0.10.0

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

RequestPrivateDecryptionKeyPacketData defines a struct for the packet payload

func (*RequestPrivateDecryptionKeyPacketData) Descriptor added in v0.10.0

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

func (RequestPrivateDecryptionKeyPacketData) GetBytes added in v0.10.0

GetBytes is a helper for serialising

func (*RequestPrivateDecryptionKeyPacketData) GetIdentity added in v0.10.2

func (*RequestPrivateDecryptionKeyPacketData) GetRequester added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) Marshal added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketData) MarshalTo added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketData) MarshalToSizedBuffer added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketData) ProtoMessage added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) ProtoMessage()

func (*RequestPrivateDecryptionKeyPacketData) Reset added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) Size added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) String added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) Unmarshal added in v0.10.0

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

func (RequestPrivateDecryptionKeyPacketData) ValidateBasic added in v0.10.0

func (p RequestPrivateDecryptionKeyPacketData) ValidateBasic() error

ValidateBasic is used for validating the packet

func (*RequestPrivateDecryptionKeyPacketData) XXX_DiscardUnknown added in v0.10.0

func (m *RequestPrivateDecryptionKeyPacketData) XXX_DiscardUnknown()

func (*RequestPrivateDecryptionKeyPacketData) XXX_Marshal added in v0.10.0

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

func (*RequestPrivateDecryptionKeyPacketData) XXX_Merge added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) XXX_Size added in v0.10.0

func (*RequestPrivateDecryptionKeyPacketData) XXX_Unmarshal added in v0.10.0

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

type ScopedKeeper

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

ScopedKeeper defines the expected IBC scoped keeper.

type SlashingKeeper added in v0.7.0

type SlashingKeeper interface {
	Slash(ctx context.Context, consAddr sdk.ConsAddress, fraction sdkmath.LegacyDec, power int64, distributionHeight int64) error
	IsTombstoned(context.Context, sdk.ConsAddress) bool
	Jail(context.Context, sdk.ConsAddress) error
}

SlashingKeeper defines the expected interface for the Slashing module.

type StakingKeeper

type StakingKeeper interface {
	GetAllValidators(ctx context.Context) (validators []stakingtypes.Validator, err error)
	GetValidator(ctx context.Context, addr sdk.ValAddress) (stakingtypes.Validator, error)
}

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) CreateLatestPubkey added in v0.10.0

func (*UnimplementedMsgServer) DeRegisterValidator added in v0.5.0

func (*UnimplementedMsgServer) DeleteAuthorizedAddress

func (*UnimplementedMsgServer) OverrideLatestPubkey added in v0.10.0

func (*UnimplementedMsgServer) RegisterValidator

func (*UnimplementedMsgServer) SendKeyshare

func (*UnimplementedMsgServer) SubmitEncryptedKeyshare added in v0.9.0

func (*UnimplementedMsgServer) SubmitGeneralKeyshare added in v0.10.0

func (*UnimplementedMsgServer) UpdateAuthorizedAddress

func (*UnimplementedMsgServer) UpdateParams added in v0.7.0

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) AuthorizedAddress

func (*UnimplementedQueryServer) Commitments

func (*UnimplementedQueryServer) DecryptionKey added in v0.10.0

func (*UnimplementedQueryServer) DecryptionKeyAll added in v0.10.0

func (*UnimplementedQueryServer) GeneralKeyshare added in v0.10.0

func (*UnimplementedQueryServer) GeneralKeyshareAll added in v0.10.0

func (*UnimplementedQueryServer) Keyshare added in v0.10.0

func (*UnimplementedQueryServer) KeyshareAll added in v0.10.0

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) Pubkey added in v0.10.0

func (*UnimplementedQueryServer) ValidatorSet

func (*UnimplementedQueryServer) ValidatorSetAll

func (*UnimplementedQueryServer) VerifiableRandomness added in v0.7.0

type ValidatorEncryptedKeyshare added in v0.10.0

type ValidatorEncryptedKeyshare struct {
	Validator           string `protobuf:"bytes,1,opt,name=validator,proto3" json:"validator,omitempty"`
	Requester           string `protobuf:"bytes,2,opt,name=requester,proto3" json:"requester,omitempty"`
	Keyshare            string `protobuf:"bytes,3,opt,name=keyshare,proto3" json:"keyshare,omitempty"`
	KeyshareIndex       uint64 `protobuf:"varint,4,opt,name=keyshare_index,json=keyshareIndex,proto3" json:"keyshare_index,omitempty"`
	ReceivedTimestamp   uint64 `protobuf:"varint,5,opt,name=received_timestamp,json=receivedTimestamp,proto3" json:"received_timestamp,omitempty"`
	ReceivedBlockHeight uint64 `protobuf:"varint,6,opt,name=received_block_height,json=receivedBlockHeight,proto3" json:"received_block_height,omitempty"`
	Identity            string `protobuf:"bytes,7,opt,name=identity,proto3" json:"identity,omitempty"`
}

ValidatorEncryptedKeyshare defines the structure for submitting encrypted keyshares by validators

func (*ValidatorEncryptedKeyshare) Descriptor added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) GetIdentity added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetIdentity() string

func (*ValidatorEncryptedKeyshare) GetKeyshare added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetKeyshare() string

func (*ValidatorEncryptedKeyshare) GetKeyshareIndex added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetKeyshareIndex() uint64

func (*ValidatorEncryptedKeyshare) GetReceivedBlockHeight added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetReceivedBlockHeight() uint64

func (*ValidatorEncryptedKeyshare) GetReceivedTimestamp added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetReceivedTimestamp() uint64

func (*ValidatorEncryptedKeyshare) GetRequester added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetRequester() string

func (*ValidatorEncryptedKeyshare) GetValidator added in v0.10.0

func (m *ValidatorEncryptedKeyshare) GetValidator() string

func (*ValidatorEncryptedKeyshare) Marshal added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) MarshalTo added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) MarshalToSizedBuffer added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) ProtoMessage added in v0.10.0

func (*ValidatorEncryptedKeyshare) ProtoMessage()

func (*ValidatorEncryptedKeyshare) Reset added in v0.10.0

func (m *ValidatorEncryptedKeyshare) Reset()

func (*ValidatorEncryptedKeyshare) Size added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) String added in v0.10.0

func (m *ValidatorEncryptedKeyshare) String() string

func (*ValidatorEncryptedKeyshare) Unmarshal added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) XXX_DiscardUnknown added in v0.10.0

func (m *ValidatorEncryptedKeyshare) XXX_DiscardUnknown()

func (*ValidatorEncryptedKeyshare) XXX_Marshal added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) XXX_Merge added in v0.10.0

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

func (*ValidatorEncryptedKeyshare) XXX_Size added in v0.10.0

func (m *ValidatorEncryptedKeyshare) XXX_Size() int

func (*ValidatorEncryptedKeyshare) XXX_Unmarshal added in v0.10.0

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

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=cons_addr,json=consAddr,proto3" json:"cons_addr,omitempty"`
	IsActive  bool   `protobuf:"varint,4,opt,name=is_active,json=isActive,proto3" json:"is_active,omitempty"`
}

ValidatorSet defines the structure for storing the list of validators who will be eligible to send keyshares

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