types

package
v7.0.1 Latest Latest
Warning

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

Go to latest
Published: Feb 9, 2024 License: Apache-2.0 Imports: 37 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	EventTypeAddPublisherIntent     = "add_publisher_intent"
	EventTypeAddSubscriberIntent    = "add_subscriber_intent"
	EventTypeAddSubscriber          = "add_subscriber"
	EventTypeRemovePublisherIntent  = "remove_publisher_intent"
	EventTypeRemoveSubscriberIntent = "remove_subscriber_intent"
	EventTypeRemoveSubscriber       = "remove_subscriber"
	EventTypeRemovePublisher        = "remove_publisher"

	AttributeKeyPublisherDomain   = "publisher_domain"
	AttributeKeyPublisherAddress  = "publisher_address"
	AttributeKeySubscriptionID    = "subscription_id"
	AttributeKeySubscriberAddress = "subscriber_address"

	AttributeValueCategory = ModuleName
)

pubsub module event types

View Source
const (
	// ModuleName defines the module name
	ModuleName = "pubsub"

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

	// RouterKey is the message route for slashing
	RouterKey = ModuleName

	// QuerierRoute defines the module's query routing key
	QuerierRoute = ModuleName
)
View Source
const (

	// PublisherPrefix - <prefix>|<publisher_domain_hash> -> Publisher
	PublisherKeyPrefix

	// SubscriberPrefix - <prefix>|<subscriber_address_bytes> -> Subscriber
	SubscriberKeyPrefix

	// PublisherIntentByPublisherDomainKeyPrefix - <prefix>|<publisher_domain_hash>|<subscription_id_hash> -> PublisherIntent
	PublisherIntentByPublisherDomainKeyPrefix

	// PublisherIntentBySubscriptionIDKeyPrefix - <prefix>|<subscription_id_hash>|<publisher_domain_hash> -> PublisherIntent
	PublisherIntentBySubscriptionIDKeyPrefix

	// SubscriberIntentBySubscriberAddressKeyPrefix - <prefix>|<subscriber_address_bytes>|<subscription_id_hash> -> SubscriberIntent
	SubscriberIntentBySubscriberAddressKeyPrefix

	// SubscriberIntentBySubscriptionIDKeyPrefix - <prefix>|<subscription_id_hash>|<subscriber_address_bytes> -> SubscriberIntent
	SubscriberIntentBySubscriptionIDKeyPrefix

	// SubscriberIntentByPublisherDomainKeyPrefix - <prefix>|<publisher_domain_hash>|<subscriber_address_bytes>|<subscription_id_hash> -> SubscriberIntent
	SubscriberIntentByPublisherDomainKeyPrefix

	// DefaultSubscriptionKeyPrefix - <prefix>|<subscription_id_hash> -> DefaultSubscription
	DefaultSubscriptionKeyPrefix
)

variable length string fields being stored under these keys are hashed to provide a fixed size key

View Source
const (
	TypeMsgAddPublisherIntentRequest     = "add_publisher_intent"
	TypeMsgAddSubscriberIntentRequest    = "add_subscriber_intent"
	TypeMsgAddSubscriberRequest          = "add_subscriber"
	TypeMsgRemovePublisherIntentRequest  = "remove_publisher_intent"
	TypeMsgRemoveSubscriberIntentRequest = "remove_subscriber_intent"
	TypeMsgRemoveSubscriberRequest       = "remove_subscriber"
	TypeMsgRemovePublisherRequest        = "remove_publisher"
)
View Source
const (
	ProposalTypeAddPublisher              = "AddPublisher"
	ProposalTypeRemovePublisher           = "RemovePublisher"
	ProposalTypeAddDefaultSubscription    = "AddDefaultSubscription"
	ProposalTypeRemoveDefaultSubscription = "RemoveDefaultSubscription"
)
View Source
const (
	MaxDomainLength         = 256
	MaxURLLength            = 512
	MaxCertLength           = 4096
	MaxSubscriptionIDLength = 128
	MaxAllowedSubscribers   = 256
)
View Source
const DefaultParamspace = ModuleName

Variables

View Source
var (
	ErrAlreadyExists = errorsmod.Register(ModuleName, 2, "entity already exists")
	ErrInvalid       = errorsmod.Register(ModuleName, 3, "entity is invalid")
)

x/pubsub module sentinel errors

View Source
var (
	ErrInvalidLengthGenesis        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowGenesis          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupGenesis = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthParams        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowParams          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupParams = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrInvalidLengthPubsub        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowPubsub          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupPubsub = 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 (
	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 AllowedSubscribers_name = map[int32]string{
	0: "ANY",
	1: "VALIDATORS",
	2: "LIST",
}
View Source
var AllowedSubscribers_value = map[string]int32{
	"ANY":        0,
	"VALIDATORS": 1,
	"LIST":       2,
}
View Source
var (

	// ModuleCdc references the global x/bank module codec. Note, the codec should
	// ONLY be used in certain instances of tests and for JSON encoding as Amino is
	// still used for that purpose.
	//
	// The actual codec used for serialization should be provided to x/staking and
	// defined at the application level.
	ModuleCdc = codec.NewAminoCodec(amino)
)
View Source
var PublishMethod_name = map[int32]string{
	0: "PULL",
	1: "PUSH",
}
View Source
var PublishMethod_value = map[string]int32{
	"PULL": 0,
	"PUSH": 1,
}

Functions

func GetDefaultSubscriptionKey

func GetDefaultSubscriptionKey(subsciptionID string) []byte

GetDefaultSubscriptionKey returns the key for a DefaultSubscription

func GetDefaultSubscriptionPrefix

func GetDefaultSubscriptionPrefix() []byte

GetDefaultSubscriptionPrefix returns a prefix for iterating all DefaultSubscripions

func GetPublisherIntentByPublisherDomainKey

func GetPublisherIntentByPublisherDomainKey(publisherDomain string, subscriptionID string) []byte

GetPublisherIntentByPublisherDomainKey returns the key for a PublisherIntent indexed by domain

func GetPublisherIntentBySubscriptionIDKey

func GetPublisherIntentBySubscriptionIDKey(subsciptionID string, publisherDomain string) []byte

GetPublisherIntentBySubscriptionIDKey returns the key for a PublisherIntent indexed by subscription ID

func GetPublisherIntentsByPublisherDomainPrefix

func GetPublisherIntentsByPublisherDomainPrefix(publisherDomain string) []byte

GetPublisherIntentsByPublisherDomainPrefix returns a prefix for all PublisherIntents indexed by publisher domain

func GetPublisherIntentsBySubscriptionIDPrefix

func GetPublisherIntentsBySubscriptionIDPrefix(subscriptionID string) []byte

GetPublisherIntentsBySubscriptionIDPrefix returns a prefix for all PublisherIntents indexed by subscription ID

func GetPublisherIntentsPrefix

func GetPublisherIntentsPrefix() []byte

GetPublisherIntentsPrefix returns a prefix for iterating all PublisherIntents by choosing the domain index as the default

func GetPublisherKey

func GetPublisherKey(publisherDomain string) []byte

GetPublisherKey returns the key for a Publisher

func GetPublishersPrefix

func GetPublishersPrefix() []byte

GetPublishersPrefix returns a prefix for iterating all Publishers

func GetSubscriberIntentByPublisherDomainKey

func GetSubscriberIntentByPublisherDomainKey(publisherDomain string, subscriberAddress sdk.AccAddress, subscriptionID string) []byte

GetSubscriberIntentByPublisherDomainKey returns the key for a SubscriberIntent indexed by publisher domain

func GetSubscriberIntentBySubscriberAddressKey

func GetSubscriberIntentBySubscriberAddressKey(subscriberAddress sdk.AccAddress, subscriptionID string) []byte

GetSubscriberIntentBySubscriberAddressKey returns the key for a SubscriberIntent indexed by address

func GetSubscriberIntentBySubscriptionIDKey

func GetSubscriberIntentBySubscriptionIDKey(subscriptionID string, subscriberAddress sdk.AccAddress) []byte

GetSubscriberIntentBySubscriptionIDKey returns the key for a SubscriberIntent indexed by subscription ID

func GetSubscriberIntentsByPublisherDomainPrefix

func GetSubscriberIntentsByPublisherDomainPrefix(publisherDomain string) []byte

GetSubscriberIntentsByPublisherDomainPrefix returns a prefix for all SubscriberIntents indexed by publisher domain

func GetSubscriberIntentsBySubscriberAddressPrefix

func GetSubscriberIntentsBySubscriberAddressPrefix(subscriberAddress sdk.AccAddress) []byte

GetSubscriberIntentsBySubscriberAddressPrefix returns a prefix for all SubscriberIntents indexed by address

func GetSubscriberIntentsBySubscriptionIDPrefix

func GetSubscriberIntentsBySubscriptionIDPrefix(subscriptionID string) []byte

GetSubscriberIntentsBySubscriptionIDPrefix returns a prefix for all SubscriberIntents indexed by subscription ID

func GetSubscriberIntentsPrefix

func GetSubscriberIntentsPrefix() []byte

GetSubscriberIntentsPrefix returns a prefix for iterating all SubscriberIntents by choosing the address index as the default

func GetSubscriberKey

func GetSubscriberKey(subscriberAddress sdk.AccAddress) []byte

GetSubscriberKey returns the key for a Subscriber

func GetSubscribersPrefix

func GetSubscribersPrefix() []byte

GetSubscribersPrefix returns a prefix for iterating all Subscribers

func ParamKeyTable

func ParamKeyTable() paramtypes.KeyTable

ParamKeyTable the param key table for the module

func RegisterInterfaces

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

RegisterLegacyAminoCodec registers the vesting interfaces and concrete types on the provided LegacyAmino codec. These types are used for Amino JSON serialization

func RegisterMsgServer

func RegisterMsgServer(s grpc1.Server, srv MsgServer)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func StringHash

func StringHash(inputString string) []byte

func ValidateAddress

func ValidateAddress(address string) error

func ValidateCaCertificate

func ValidateCaCertificate(certPem string) error

func ValidateDomain

func ValidateDomain(domain string) error

func ValidateGenericURL

func ValidateGenericURL(urlString string) error

func ValidateProofURL

func ValidateProofURL(proofURL string, domain string, address string) error

func ValidateSubscriptionID

func ValidateSubscriptionID(subscriptionID string) error

Types

type AddDefaultSubscriptionProposal

type AddDefaultSubscriptionProposal struct {
	Title           string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description     string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	SubscriptionId  string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	PublisherDomain string `protobuf:"bytes,4,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

set the default publisher for a given subscription ID these can be overridden by the client

func NewAddDefaultSubscriptionProposal

func NewAddDefaultSubscriptionProposal(title string, description string, subscriptionID string, publisherDomain string) *AddDefaultSubscriptionProposal

func (*AddDefaultSubscriptionProposal) Descriptor

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

func (*AddDefaultSubscriptionProposal) GetDescription

func (m *AddDefaultSubscriptionProposal) GetDescription() string

func (*AddDefaultSubscriptionProposal) GetPublisherDomain

func (m *AddDefaultSubscriptionProposal) GetPublisherDomain() string

func (*AddDefaultSubscriptionProposal) GetSubscriptionId

func (m *AddDefaultSubscriptionProposal) GetSubscriptionId() string

func (*AddDefaultSubscriptionProposal) GetTitle

func (m *AddDefaultSubscriptionProposal) GetTitle() string

func (*AddDefaultSubscriptionProposal) Marshal

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

func (*AddDefaultSubscriptionProposal) MarshalTo

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

func (*AddDefaultSubscriptionProposal) MarshalToSizedBuffer

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

func (*AddDefaultSubscriptionProposal) ProposalRoute

func (p *AddDefaultSubscriptionProposal) ProposalRoute() string

func (*AddDefaultSubscriptionProposal) ProposalType

func (p *AddDefaultSubscriptionProposal) ProposalType() string

func (*AddDefaultSubscriptionProposal) ProtoMessage

func (*AddDefaultSubscriptionProposal) ProtoMessage()

func (*AddDefaultSubscriptionProposal) Reset

func (m *AddDefaultSubscriptionProposal) Reset()

func (*AddDefaultSubscriptionProposal) Size

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

func (*AddDefaultSubscriptionProposal) String

func (*AddDefaultSubscriptionProposal) Unmarshal

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

func (*AddDefaultSubscriptionProposal) ValidateBasic

func (p *AddDefaultSubscriptionProposal) ValidateBasic() error

func (*AddDefaultSubscriptionProposal) XXX_DiscardUnknown

func (m *AddDefaultSubscriptionProposal) XXX_DiscardUnknown()

func (*AddDefaultSubscriptionProposal) XXX_Marshal

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

func (*AddDefaultSubscriptionProposal) XXX_Merge

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

func (*AddDefaultSubscriptionProposal) XXX_Size

func (m *AddDefaultSubscriptionProposal) XXX_Size() int

func (*AddDefaultSubscriptionProposal) XXX_Unmarshal

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

type AddDefaultSubscriptionProposalWithDeposit

type AddDefaultSubscriptionProposalWithDeposit struct {
	Title           string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description     string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	SubscriptionId  string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	PublisherDomain string `protobuf:"bytes,4,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
	Deposit         string `protobuf:"bytes,5,opt,name=deposit,proto3" json:"deposit,omitempty"`
}

func (*AddDefaultSubscriptionProposalWithDeposit) Descriptor

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

func (*AddDefaultSubscriptionProposalWithDeposit) GetDeposit

func (*AddDefaultSubscriptionProposalWithDeposit) GetDescription

func (*AddDefaultSubscriptionProposalWithDeposit) GetPublisherDomain

func (m *AddDefaultSubscriptionProposalWithDeposit) GetPublisherDomain() string

func (*AddDefaultSubscriptionProposalWithDeposit) GetSubscriptionId

func (m *AddDefaultSubscriptionProposalWithDeposit) GetSubscriptionId() string

func (*AddDefaultSubscriptionProposalWithDeposit) GetTitle

func (*AddDefaultSubscriptionProposalWithDeposit) Marshal

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

func (*AddDefaultSubscriptionProposalWithDeposit) MarshalTo

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

func (*AddDefaultSubscriptionProposalWithDeposit) MarshalToSizedBuffer

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

func (*AddDefaultSubscriptionProposalWithDeposit) ProtoMessage

func (*AddDefaultSubscriptionProposalWithDeposit) Reset

func (*AddDefaultSubscriptionProposalWithDeposit) Size

func (*AddDefaultSubscriptionProposalWithDeposit) String

func (*AddDefaultSubscriptionProposalWithDeposit) Unmarshal

func (*AddDefaultSubscriptionProposalWithDeposit) XXX_DiscardUnknown

func (m *AddDefaultSubscriptionProposalWithDeposit) XXX_DiscardUnknown()

func (*AddDefaultSubscriptionProposalWithDeposit) XXX_Marshal

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

func (*AddDefaultSubscriptionProposalWithDeposit) XXX_Merge

func (*AddDefaultSubscriptionProposalWithDeposit) XXX_Size

func (*AddDefaultSubscriptionProposalWithDeposit) XXX_Unmarshal

type AddPublisherProposal

type AddPublisherProposal struct {
	Title       string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Domain      string `protobuf:"bytes,3,opt,name=domain,proto3" json:"domain,omitempty"`
	Address     string `protobuf:"bytes,4,opt,name=address,proto3" json:"address,omitempty"`
	ProofUrl    string `protobuf:"bytes,5,opt,name=proof_url,json=proofUrl,proto3" json:"proof_url,omitempty"`
	CaCert      string `protobuf:"bytes,6,opt,name=ca_cert,json=caCert,proto3" json:"ca_cert,omitempty"`
}

governance proposal to add a publisher, with domain, adress, and ca_cert the same as the Publisher type proof URL expected in the format: https://<domain>/<address>/cacert.pem and serving cacert.pem matching ca_cert

func NewAddPublisherProposal

func NewAddPublisherProposal(title string, description string, domain string, address string, proofURL string, caCert string) *AddPublisherProposal

func (*AddPublisherProposal) Descriptor

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

func (*AddPublisherProposal) GetAddress

func (m *AddPublisherProposal) GetAddress() string

func (*AddPublisherProposal) GetCaCert

func (m *AddPublisherProposal) GetCaCert() string

func (*AddPublisherProposal) GetDescription

func (m *AddPublisherProposal) GetDescription() string

func (*AddPublisherProposal) GetDomain

func (m *AddPublisherProposal) GetDomain() string

func (*AddPublisherProposal) GetProofUrl

func (m *AddPublisherProposal) GetProofUrl() string

func (*AddPublisherProposal) GetTitle

func (m *AddPublisherProposal) GetTitle() string

func (*AddPublisherProposal) Marshal

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

func (*AddPublisherProposal) MarshalTo

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

func (*AddPublisherProposal) MarshalToSizedBuffer

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

func (*AddPublisherProposal) ProposalRoute

func (p *AddPublisherProposal) ProposalRoute() string

func (*AddPublisherProposal) ProposalType

func (p *AddPublisherProposal) ProposalType() string

func (*AddPublisherProposal) ProtoMessage

func (*AddPublisherProposal) ProtoMessage()

func (*AddPublisherProposal) Reset

func (m *AddPublisherProposal) Reset()

func (*AddPublisherProposal) Size

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

func (*AddPublisherProposal) String

func (m *AddPublisherProposal) String() string

func (*AddPublisherProposal) Unmarshal

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

func (*AddPublisherProposal) ValidateBasic

func (p *AddPublisherProposal) ValidateBasic() error

func (*AddPublisherProposal) XXX_DiscardUnknown

func (m *AddPublisherProposal) XXX_DiscardUnknown()

func (*AddPublisherProposal) XXX_Marshal

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

func (*AddPublisherProposal) XXX_Merge

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

func (*AddPublisherProposal) XXX_Size

func (m *AddPublisherProposal) XXX_Size() int

func (*AddPublisherProposal) XXX_Unmarshal

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

type AddPublisherProposalWithDeposit

type AddPublisherProposalWithDeposit struct {
	Title       string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Domain      string `protobuf:"bytes,3,opt,name=domain,proto3" json:"domain,omitempty"`
	Address     string `protobuf:"bytes,4,opt,name=address,proto3" json:"address,omitempty"`
	ProofUrl    string `protobuf:"bytes,5,opt,name=proof_url,json=proofUrl,proto3" json:"proof_url,omitempty"`
	CaCert      string `protobuf:"bytes,6,opt,name=ca_cert,json=caCert,proto3" json:"ca_cert,omitempty"`
	Deposit     string `protobuf:"bytes,7,opt,name=deposit,proto3" json:"deposit,omitempty"`
}

func (*AddPublisherProposalWithDeposit) Descriptor

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

func (*AddPublisherProposalWithDeposit) GetAddress

func (m *AddPublisherProposalWithDeposit) GetAddress() string

func (*AddPublisherProposalWithDeposit) GetCaCert

func (m *AddPublisherProposalWithDeposit) GetCaCert() string

func (*AddPublisherProposalWithDeposit) GetDeposit

func (m *AddPublisherProposalWithDeposit) GetDeposit() string

func (*AddPublisherProposalWithDeposit) GetDescription

func (m *AddPublisherProposalWithDeposit) GetDescription() string

func (*AddPublisherProposalWithDeposit) GetDomain

func (m *AddPublisherProposalWithDeposit) GetDomain() string

func (*AddPublisherProposalWithDeposit) GetProofUrl

func (m *AddPublisherProposalWithDeposit) GetProofUrl() string

func (*AddPublisherProposalWithDeposit) GetTitle

func (*AddPublisherProposalWithDeposit) Marshal

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

func (*AddPublisherProposalWithDeposit) MarshalTo

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

func (*AddPublisherProposalWithDeposit) MarshalToSizedBuffer

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

func (*AddPublisherProposalWithDeposit) ProtoMessage

func (*AddPublisherProposalWithDeposit) ProtoMessage()

func (*AddPublisherProposalWithDeposit) Reset

func (*AddPublisherProposalWithDeposit) Size

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

func (*AddPublisherProposalWithDeposit) String

func (*AddPublisherProposalWithDeposit) Unmarshal

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

func (*AddPublisherProposalWithDeposit) XXX_DiscardUnknown

func (m *AddPublisherProposalWithDeposit) XXX_DiscardUnknown()

func (*AddPublisherProposalWithDeposit) XXX_Marshal

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

func (*AddPublisherProposalWithDeposit) XXX_Merge

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

func (*AddPublisherProposalWithDeposit) XXX_Size

func (m *AddPublisherProposalWithDeposit) XXX_Size() int

func (*AddPublisherProposalWithDeposit) XXX_Unmarshal

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

type AllowedSubscribers

type AllowedSubscribers int32

for a given PublisherIntent, determines what types of subscribers may subscribe

const (
	// any valid account address
	AllowedSubscribers_ANY AllowedSubscribers = 0
	// account address must map to a validator in the active validator set
	AllowedSubscribers_VALIDATORS AllowedSubscribers = 1
	// a specific list of account addresses
	AllowedSubscribers_LIST AllowedSubscribers = 2
)

func (AllowedSubscribers) EnumDescriptor

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

func (AllowedSubscribers) String

func (x AllowedSubscribers) String() string

type DefaultSubscription

type DefaultSubscription struct {
	// arbitary string representing a subscription, max length of 128
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	// FQDN of the publisher, max length of 256
	PublisherDomain string `protobuf:"bytes,2,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

represents a default subscription voted in by governance that can be overridden by a subscriber

func (*DefaultSubscription) Descriptor

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

func (*DefaultSubscription) GetPublisherDomain

func (m *DefaultSubscription) GetPublisherDomain() string

func (*DefaultSubscription) GetSubscriptionId

func (m *DefaultSubscription) GetSubscriptionId() string

func (*DefaultSubscription) Marshal

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

func (*DefaultSubscription) MarshalTo

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

func (*DefaultSubscription) MarshalToSizedBuffer

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

func (*DefaultSubscription) ProtoMessage

func (*DefaultSubscription) ProtoMessage()

func (*DefaultSubscription) Reset

func (m *DefaultSubscription) Reset()

func (*DefaultSubscription) Size

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

func (*DefaultSubscription) String

func (m *DefaultSubscription) String() string

func (*DefaultSubscription) Unmarshal

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

func (*DefaultSubscription) ValidateBasic

func (ds *DefaultSubscription) ValidateBasic() error

func (*DefaultSubscription) XXX_DiscardUnknown

func (m *DefaultSubscription) XXX_DiscardUnknown()

func (*DefaultSubscription) XXX_Marshal

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

func (*DefaultSubscription) XXX_Merge

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

func (*DefaultSubscription) XXX_Size

func (m *DefaultSubscription) XXX_Size() int

func (*DefaultSubscription) XXX_Unmarshal

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

type GenesisState

type GenesisState struct {
	Params               Params                 `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	Publishers           []*Publisher           `protobuf:"bytes,2,rep,name=publishers,proto3" json:"publishers,omitempty"`
	Subscribers          []*Subscriber          `protobuf:"bytes,3,rep,name=subscribers,proto3" json:"subscribers,omitempty"`
	PublisherIntents     []*PublisherIntent     `protobuf:"bytes,4,rep,name=publisher_intents,json=publisherIntents,proto3" json:"publisher_intents,omitempty"`
	SubscriberIntents    []*SubscriberIntent    `protobuf:"bytes,5,rep,name=subscriber_intents,json=subscriberIntents,proto3" json:"subscriber_intents,omitempty"`
	DefaultSubscriptions []*DefaultSubscription `protobuf:"bytes,6,rep,name=default_subscriptions,json=defaultSubscriptions,proto3" json:"default_subscriptions,omitempty"`
}

GenesisState defines the pubsub module's genesis state.

func DefaultGenesisState

func DefaultGenesisState() GenesisState

DefaultGenesisState get raw genesis raw message for testing

func (*GenesisState) Descriptor

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

func (*GenesisState) GetDefaultSubscriptions

func (m *GenesisState) GetDefaultSubscriptions() []*DefaultSubscription

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetPublisherIntents

func (m *GenesisState) GetPublisherIntents() []*PublisherIntent

func (*GenesisState) GetPublishers

func (m *GenesisState) GetPublishers() []*Publisher

func (*GenesisState) GetSubscriberIntents

func (m *GenesisState) GetSubscriberIntents() []*SubscriberIntent

func (*GenesisState) GetSubscribers

func (m *GenesisState) GetSubscribers() []*Subscriber

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 a basic stateless validation of the genesis fields.

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 GravityKeeper

type GravityKeeper interface {
	GetOrchestratorValidatorAddress(sdk.Context, sdk.AccAddress) sdk.ValAddress
}

GravityKeeper defines the expected gravity keeper methods

type MsgAddPublisherIntentRequest

type MsgAddPublisherIntentRequest struct {
	PublisherIntent *PublisherIntent `protobuf:"bytes,1,opt,name=publisher_intent,json=publisherIntent,proto3" json:"publisher_intent,omitempty"`
	Signer          string           `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgAddPublisherIntentRequest

func NewMsgAddPublisherIntentRequest(publisherIntent PublisherIntent, signer sdk.AccAddress) (*MsgAddPublisherIntentRequest, error)

NewMsgAddPublisherIntentRequest returns a new MsgAddPublisherIntentRequest

func (*MsgAddPublisherIntentRequest) Descriptor

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

func (*MsgAddPublisherIntentRequest) GetPublisherIntent

func (m *MsgAddPublisherIntentRequest) GetPublisherIntent() *PublisherIntent

func (*MsgAddPublisherIntentRequest) GetSignBytes

func (m *MsgAddPublisherIntentRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgAddPublisherIntentRequest) GetSigner

func (m *MsgAddPublisherIntentRequest) GetSigner() string

func (*MsgAddPublisherIntentRequest) GetSigners

func (m *MsgAddPublisherIntentRequest) GetSigners() []sdk.AccAddress

GetSigners implements sdk.Msg

func (*MsgAddPublisherIntentRequest) Marshal

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

func (*MsgAddPublisherIntentRequest) MarshalTo

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

func (*MsgAddPublisherIntentRequest) MarshalToSizedBuffer

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

func (*MsgAddPublisherIntentRequest) MustGetSigner

func (m *MsgAddPublisherIntentRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgAddPublisherIntentRequest) ProtoMessage

func (*MsgAddPublisherIntentRequest) ProtoMessage()

func (*MsgAddPublisherIntentRequest) Reset

func (m *MsgAddPublisherIntentRequest) Reset()

func (*MsgAddPublisherIntentRequest) Route

Route implements sdk.Msg

func (*MsgAddPublisherIntentRequest) Size

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

func (*MsgAddPublisherIntentRequest) String

func (*MsgAddPublisherIntentRequest) Type

Type implements sdk.Msg

func (*MsgAddPublisherIntentRequest) Unmarshal

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

func (*MsgAddPublisherIntentRequest) ValidateBasic

func (m *MsgAddPublisherIntentRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgAddPublisherIntentRequest) XXX_DiscardUnknown

func (m *MsgAddPublisherIntentRequest) XXX_DiscardUnknown()

func (*MsgAddPublisherIntentRequest) XXX_Marshal

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

func (*MsgAddPublisherIntentRequest) XXX_Merge

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

func (*MsgAddPublisherIntentRequest) XXX_Size

func (m *MsgAddPublisherIntentRequest) XXX_Size() int

func (*MsgAddPublisherIntentRequest) XXX_Unmarshal

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

type MsgAddPublisherIntentResponse

type MsgAddPublisherIntentResponse struct {
}

func (*MsgAddPublisherIntentResponse) Descriptor

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

func (*MsgAddPublisherIntentResponse) Marshal

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

func (*MsgAddPublisherIntentResponse) MarshalTo

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

func (*MsgAddPublisherIntentResponse) MarshalToSizedBuffer

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

func (*MsgAddPublisherIntentResponse) ProtoMessage

func (*MsgAddPublisherIntentResponse) ProtoMessage()

func (*MsgAddPublisherIntentResponse) Reset

func (m *MsgAddPublisherIntentResponse) Reset()

func (*MsgAddPublisherIntentResponse) Size

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

func (*MsgAddPublisherIntentResponse) String

func (*MsgAddPublisherIntentResponse) Unmarshal

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

func (*MsgAddPublisherIntentResponse) XXX_DiscardUnknown

func (m *MsgAddPublisherIntentResponse) XXX_DiscardUnknown()

func (*MsgAddPublisherIntentResponse) XXX_Marshal

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

func (*MsgAddPublisherIntentResponse) XXX_Merge

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

func (*MsgAddPublisherIntentResponse) XXX_Size

func (m *MsgAddPublisherIntentResponse) XXX_Size() int

func (*MsgAddPublisherIntentResponse) XXX_Unmarshal

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

type MsgAddSubscriberIntentRequest

type MsgAddSubscriberIntentRequest struct {
	SubscriberIntent *SubscriberIntent `protobuf:"bytes,1,opt,name=subscriber_intent,json=subscriberIntent,proto3" json:"subscriber_intent,omitempty"`
	Signer           string            `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgAddSubscriberIntentRequest

func NewMsgAddSubscriberIntentRequest(subscriberIntent SubscriberIntent, signer sdk.AccAddress) (*MsgAddSubscriberIntentRequest, error)

NewMsgAddSubscriberIntentRequest returns a new MsgAddSubscriberIntentRequest

func (*MsgAddSubscriberIntentRequest) Descriptor

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

func (*MsgAddSubscriberIntentRequest) GetSignBytes

func (m *MsgAddSubscriberIntentRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgAddSubscriberIntentRequest) GetSigner

func (m *MsgAddSubscriberIntentRequest) GetSigner() string

func (*MsgAddSubscriberIntentRequest) GetSigners

func (m *MsgAddSubscriberIntentRequest) GetSigners() []sdk.AccAddress

GetSigners implements sdk.Msg

func (*MsgAddSubscriberIntentRequest) GetSubscriberIntent

func (m *MsgAddSubscriberIntentRequest) GetSubscriberIntent() *SubscriberIntent

func (*MsgAddSubscriberIntentRequest) Marshal

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

func (*MsgAddSubscriberIntentRequest) MarshalTo

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

func (*MsgAddSubscriberIntentRequest) MarshalToSizedBuffer

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

func (*MsgAddSubscriberIntentRequest) MustGetSigner

func (m *MsgAddSubscriberIntentRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgAddSubscriberIntentRequest) ProtoMessage

func (*MsgAddSubscriberIntentRequest) ProtoMessage()

func (*MsgAddSubscriberIntentRequest) Reset

func (m *MsgAddSubscriberIntentRequest) Reset()

func (*MsgAddSubscriberIntentRequest) Route

Route implements sdk.Msg

func (*MsgAddSubscriberIntentRequest) Size

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

func (*MsgAddSubscriberIntentRequest) String

func (*MsgAddSubscriberIntentRequest) Type

Type implements sdk.Msg

func (*MsgAddSubscriberIntentRequest) Unmarshal

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

func (*MsgAddSubscriberIntentRequest) ValidateBasic

func (m *MsgAddSubscriberIntentRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgAddSubscriberIntentRequest) XXX_DiscardUnknown

func (m *MsgAddSubscriberIntentRequest) XXX_DiscardUnknown()

func (*MsgAddSubscriberIntentRequest) XXX_Marshal

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

func (*MsgAddSubscriberIntentRequest) XXX_Merge

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

func (*MsgAddSubscriberIntentRequest) XXX_Size

func (m *MsgAddSubscriberIntentRequest) XXX_Size() int

func (*MsgAddSubscriberIntentRequest) XXX_Unmarshal

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

type MsgAddSubscriberIntentResponse

type MsgAddSubscriberIntentResponse struct {
}

func (*MsgAddSubscriberIntentResponse) Descriptor

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

func (*MsgAddSubscriberIntentResponse) Marshal

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

func (*MsgAddSubscriberIntentResponse) MarshalTo

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

func (*MsgAddSubscriberIntentResponse) MarshalToSizedBuffer

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

func (*MsgAddSubscriberIntentResponse) ProtoMessage

func (*MsgAddSubscriberIntentResponse) ProtoMessage()

func (*MsgAddSubscriberIntentResponse) Reset

func (m *MsgAddSubscriberIntentResponse) Reset()

func (*MsgAddSubscriberIntentResponse) Size

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

func (*MsgAddSubscriberIntentResponse) String

func (*MsgAddSubscriberIntentResponse) Unmarshal

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

func (*MsgAddSubscriberIntentResponse) XXX_DiscardUnknown

func (m *MsgAddSubscriberIntentResponse) XXX_DiscardUnknown()

func (*MsgAddSubscriberIntentResponse) XXX_Marshal

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

func (*MsgAddSubscriberIntentResponse) XXX_Merge

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

func (*MsgAddSubscriberIntentResponse) XXX_Size

func (m *MsgAddSubscriberIntentResponse) XXX_Size() int

func (*MsgAddSubscriberIntentResponse) XXX_Unmarshal

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

type MsgAddSubscriberRequest

type MsgAddSubscriberRequest struct {
	Subscriber *Subscriber `protobuf:"bytes,1,opt,name=subscriber,proto3" json:"subscriber,omitempty"`
	Signer     string      `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgAddSubscriberRequest

func NewMsgAddSubscriberRequest(subscriber Subscriber, signer sdk.AccAddress) (*MsgAddSubscriberRequest, error)

NewMsgAddSubscriberRequest returns a new MsgAddSubscriberRequest

func (*MsgAddSubscriberRequest) Descriptor

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

func (*MsgAddSubscriberRequest) GetSignBytes

func (m *MsgAddSubscriberRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgAddSubscriberRequest) GetSigner

func (m *MsgAddSubscriberRequest) GetSigner() string

func (*MsgAddSubscriberRequest) GetSigners

func (m *MsgAddSubscriberRequest) GetSigners() []sdk.AccAddress

GetSigners implements sdk.Msg

func (*MsgAddSubscriberRequest) GetSubscriber

func (m *MsgAddSubscriberRequest) GetSubscriber() *Subscriber

func (*MsgAddSubscriberRequest) Marshal

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

func (*MsgAddSubscriberRequest) MarshalTo

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

func (*MsgAddSubscriberRequest) MarshalToSizedBuffer

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

func (*MsgAddSubscriberRequest) MustGetSigner

func (m *MsgAddSubscriberRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgAddSubscriberRequest) ProtoMessage

func (*MsgAddSubscriberRequest) ProtoMessage()

func (*MsgAddSubscriberRequest) Reset

func (m *MsgAddSubscriberRequest) Reset()

func (*MsgAddSubscriberRequest) Route

func (m *MsgAddSubscriberRequest) Route() string

Route implements sdk.Msg

func (*MsgAddSubscriberRequest) Size

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

func (*MsgAddSubscriberRequest) String

func (m *MsgAddSubscriberRequest) String() string

func (*MsgAddSubscriberRequest) Type

func (m *MsgAddSubscriberRequest) Type() string

Type implements sdk.Msg

func (*MsgAddSubscriberRequest) Unmarshal

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

func (*MsgAddSubscriberRequest) ValidateBasic

func (m *MsgAddSubscriberRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgAddSubscriberRequest) XXX_DiscardUnknown

func (m *MsgAddSubscriberRequest) XXX_DiscardUnknown()

func (*MsgAddSubscriberRequest) XXX_Marshal

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

func (*MsgAddSubscriberRequest) XXX_Merge

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

func (*MsgAddSubscriberRequest) XXX_Size

func (m *MsgAddSubscriberRequest) XXX_Size() int

func (*MsgAddSubscriberRequest) XXX_Unmarshal

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

type MsgAddSubscriberResponse

type MsgAddSubscriberResponse struct {
}

func (*MsgAddSubscriberResponse) Descriptor

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

func (*MsgAddSubscriberResponse) Marshal

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

func (*MsgAddSubscriberResponse) MarshalTo

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

func (*MsgAddSubscriberResponse) MarshalToSizedBuffer

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

func (*MsgAddSubscriberResponse) ProtoMessage

func (*MsgAddSubscriberResponse) ProtoMessage()

func (*MsgAddSubscriberResponse) Reset

func (m *MsgAddSubscriberResponse) Reset()

func (*MsgAddSubscriberResponse) Size

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

func (*MsgAddSubscriberResponse) String

func (m *MsgAddSubscriberResponse) String() string

func (*MsgAddSubscriberResponse) Unmarshal

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

func (*MsgAddSubscriberResponse) XXX_DiscardUnknown

func (m *MsgAddSubscriberResponse) XXX_DiscardUnknown()

func (*MsgAddSubscriberResponse) XXX_Marshal

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

func (*MsgAddSubscriberResponse) XXX_Merge

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

func (*MsgAddSubscriberResponse) XXX_Size

func (m *MsgAddSubscriberResponse) XXX_Size() int

func (*MsgAddSubscriberResponse) XXX_Unmarshal

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

type MsgClient

MsgClient is the client API for Msg service.

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

func NewMsgClient

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgRemovePublisherIntentRequest

type MsgRemovePublisherIntentRequest struct {
	SubscriptionId  string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	PublisherDomain string `protobuf:"bytes,2,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
	Signer          string `protobuf:"bytes,3,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgRemovePublisherIntentRequest

func NewMsgRemovePublisherIntentRequest(subscriptionID string, publisherDomain string, signer sdk.AccAddress) (*MsgRemovePublisherIntentRequest, error)

NewMsgRemovePublisherIntentRequest returns a new MsgRemovePublisherIntentRequest

func (*MsgRemovePublisherIntentRequest) Descriptor

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

func (*MsgRemovePublisherIntentRequest) GetPublisherDomain

func (m *MsgRemovePublisherIntentRequest) GetPublisherDomain() string

func (*MsgRemovePublisherIntentRequest) GetSignBytes

func (m *MsgRemovePublisherIntentRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgRemovePublisherIntentRequest) GetSigner

func (m *MsgRemovePublisherIntentRequest) GetSigner() string

func (*MsgRemovePublisherIntentRequest) GetSigners

GetSigners implements sdk.Msg

func (*MsgRemovePublisherIntentRequest) GetSubscriptionId

func (m *MsgRemovePublisherIntentRequest) GetSubscriptionId() string

func (*MsgRemovePublisherIntentRequest) Marshal

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

func (*MsgRemovePublisherIntentRequest) MarshalTo

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

func (*MsgRemovePublisherIntentRequest) MarshalToSizedBuffer

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

func (*MsgRemovePublisherIntentRequest) MustGetSigner

func (m *MsgRemovePublisherIntentRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgRemovePublisherIntentRequest) ProtoMessage

func (*MsgRemovePublisherIntentRequest) ProtoMessage()

func (*MsgRemovePublisherIntentRequest) Reset

func (*MsgRemovePublisherIntentRequest) Route

Route implements sdk.Msg

func (*MsgRemovePublisherIntentRequest) Size

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

func (*MsgRemovePublisherIntentRequest) String

func (*MsgRemovePublisherIntentRequest) Type

Type implements sdk.Msg

func (*MsgRemovePublisherIntentRequest) Unmarshal

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

func (*MsgRemovePublisherIntentRequest) ValidateBasic

func (m *MsgRemovePublisherIntentRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgRemovePublisherIntentRequest) XXX_DiscardUnknown

func (m *MsgRemovePublisherIntentRequest) XXX_DiscardUnknown()

func (*MsgRemovePublisherIntentRequest) XXX_Marshal

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

func (*MsgRemovePublisherIntentRequest) XXX_Merge

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

func (*MsgRemovePublisherIntentRequest) XXX_Size

func (m *MsgRemovePublisherIntentRequest) XXX_Size() int

func (*MsgRemovePublisherIntentRequest) XXX_Unmarshal

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

type MsgRemovePublisherIntentResponse

type MsgRemovePublisherIntentResponse struct {
}

func (*MsgRemovePublisherIntentResponse) Descriptor

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

func (*MsgRemovePublisherIntentResponse) Marshal

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

func (*MsgRemovePublisherIntentResponse) MarshalTo

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

func (*MsgRemovePublisherIntentResponse) MarshalToSizedBuffer

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

func (*MsgRemovePublisherIntentResponse) ProtoMessage

func (*MsgRemovePublisherIntentResponse) ProtoMessage()

func (*MsgRemovePublisherIntentResponse) Reset

func (*MsgRemovePublisherIntentResponse) Size

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

func (*MsgRemovePublisherIntentResponse) String

func (*MsgRemovePublisherIntentResponse) Unmarshal

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

func (*MsgRemovePublisherIntentResponse) XXX_DiscardUnknown

func (m *MsgRemovePublisherIntentResponse) XXX_DiscardUnknown()

func (*MsgRemovePublisherIntentResponse) XXX_Marshal

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

func (*MsgRemovePublisherIntentResponse) XXX_Merge

func (*MsgRemovePublisherIntentResponse) XXX_Size

func (m *MsgRemovePublisherIntentResponse) XXX_Size() int

func (*MsgRemovePublisherIntentResponse) XXX_Unmarshal

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

type MsgRemovePublisherRequest

type MsgRemovePublisherRequest struct {
	PublisherDomain string `protobuf:"bytes,1,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
	Signer          string `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgRemovePublisherRequest

func NewMsgRemovePublisherRequest(publisherDomain string, signer sdk.AccAddress) (*MsgRemovePublisherRequest, error)

NewMsgRemovePublisherRequest returns a new MsgRemovePublisherRequest

func (*MsgRemovePublisherRequest) Descriptor

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

func (*MsgRemovePublisherRequest) GetPublisherDomain

func (m *MsgRemovePublisherRequest) GetPublisherDomain() string

func (*MsgRemovePublisherRequest) GetSignBytes

func (m *MsgRemovePublisherRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgRemovePublisherRequest) GetSigner

func (m *MsgRemovePublisherRequest) GetSigner() string

func (*MsgRemovePublisherRequest) GetSigners

func (m *MsgRemovePublisherRequest) GetSigners() []sdk.AccAddress

GetSigners implements sdk.Msg

func (*MsgRemovePublisherRequest) Marshal

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

func (*MsgRemovePublisherRequest) MarshalTo

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

func (*MsgRemovePublisherRequest) MarshalToSizedBuffer

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

func (*MsgRemovePublisherRequest) MustGetSigner

func (m *MsgRemovePublisherRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgRemovePublisherRequest) ProtoMessage

func (*MsgRemovePublisherRequest) ProtoMessage()

func (*MsgRemovePublisherRequest) Reset

func (m *MsgRemovePublisherRequest) Reset()

func (*MsgRemovePublisherRequest) Route

func (m *MsgRemovePublisherRequest) Route() string

Route implements sdk.Msg

func (*MsgRemovePublisherRequest) Size

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

func (*MsgRemovePublisherRequest) String

func (m *MsgRemovePublisherRequest) String() string

func (*MsgRemovePublisherRequest) Type

Type implements sdk.Msg

func (*MsgRemovePublisherRequest) Unmarshal

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

func (*MsgRemovePublisherRequest) ValidateBasic

func (m *MsgRemovePublisherRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgRemovePublisherRequest) XXX_DiscardUnknown

func (m *MsgRemovePublisherRequest) XXX_DiscardUnknown()

func (*MsgRemovePublisherRequest) XXX_Marshal

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

func (*MsgRemovePublisherRequest) XXX_Merge

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

func (*MsgRemovePublisherRequest) XXX_Size

func (m *MsgRemovePublisherRequest) XXX_Size() int

func (*MsgRemovePublisherRequest) XXX_Unmarshal

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

type MsgRemovePublisherResponse

type MsgRemovePublisherResponse struct {
}

func (*MsgRemovePublisherResponse) Descriptor

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

func (*MsgRemovePublisherResponse) Marshal

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

func (*MsgRemovePublisherResponse) MarshalTo

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

func (*MsgRemovePublisherResponse) MarshalToSizedBuffer

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

func (*MsgRemovePublisherResponse) ProtoMessage

func (*MsgRemovePublisherResponse) ProtoMessage()

func (*MsgRemovePublisherResponse) Reset

func (m *MsgRemovePublisherResponse) Reset()

func (*MsgRemovePublisherResponse) Size

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

func (*MsgRemovePublisherResponse) String

func (m *MsgRemovePublisherResponse) String() string

func (*MsgRemovePublisherResponse) Unmarshal

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

func (*MsgRemovePublisherResponse) XXX_DiscardUnknown

func (m *MsgRemovePublisherResponse) XXX_DiscardUnknown()

func (*MsgRemovePublisherResponse) XXX_Marshal

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

func (*MsgRemovePublisherResponse) XXX_Merge

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

func (*MsgRemovePublisherResponse) XXX_Size

func (m *MsgRemovePublisherResponse) XXX_Size() int

func (*MsgRemovePublisherResponse) XXX_Unmarshal

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

type MsgRemoveSubscriberIntentRequest

type MsgRemoveSubscriberIntentRequest struct {
	SubscriptionId    string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	SubscriberAddress string `protobuf:"bytes,2,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
	Signer            string `protobuf:"bytes,3,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgRemoveSubscriberIntentRequest

func NewMsgRemoveSubscriberIntentRequest(subscriptionID string, subscriberAddress string, signer sdk.AccAddress) (*MsgRemoveSubscriberIntentRequest, error)

NewMsgRemoveSubscriberIntentRequest returns a new MsgRemoveSubscriberIntentRequest

func (*MsgRemoveSubscriberIntentRequest) Descriptor

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

func (*MsgRemoveSubscriberIntentRequest) GetSignBytes

func (m *MsgRemoveSubscriberIntentRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgRemoveSubscriberIntentRequest) GetSigner

func (*MsgRemoveSubscriberIntentRequest) GetSigners

GetSigners implements sdk.Msg

func (*MsgRemoveSubscriberIntentRequest) GetSubscriberAddress

func (m *MsgRemoveSubscriberIntentRequest) GetSubscriberAddress() string

func (*MsgRemoveSubscriberIntentRequest) GetSubscriptionId

func (m *MsgRemoveSubscriberIntentRequest) GetSubscriptionId() string

func (*MsgRemoveSubscriberIntentRequest) Marshal

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

func (*MsgRemoveSubscriberIntentRequest) MarshalTo

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

func (*MsgRemoveSubscriberIntentRequest) MarshalToSizedBuffer

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

func (*MsgRemoveSubscriberIntentRequest) MustGetSigner

func (m *MsgRemoveSubscriberIntentRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgRemoveSubscriberIntentRequest) ProtoMessage

func (*MsgRemoveSubscriberIntentRequest) ProtoMessage()

func (*MsgRemoveSubscriberIntentRequest) Reset

func (*MsgRemoveSubscriberIntentRequest) Route

Route implements sdk.Msg

func (*MsgRemoveSubscriberIntentRequest) Size

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

func (*MsgRemoveSubscriberIntentRequest) String

func (*MsgRemoveSubscriberIntentRequest) Type

Type implements sdk.Msg

func (*MsgRemoveSubscriberIntentRequest) Unmarshal

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

func (*MsgRemoveSubscriberIntentRequest) ValidateBasic

func (m *MsgRemoveSubscriberIntentRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgRemoveSubscriberIntentRequest) XXX_DiscardUnknown

func (m *MsgRemoveSubscriberIntentRequest) XXX_DiscardUnknown()

func (*MsgRemoveSubscriberIntentRequest) XXX_Marshal

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

func (*MsgRemoveSubscriberIntentRequest) XXX_Merge

func (*MsgRemoveSubscriberIntentRequest) XXX_Size

func (m *MsgRemoveSubscriberIntentRequest) XXX_Size() int

func (*MsgRemoveSubscriberIntentRequest) XXX_Unmarshal

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

type MsgRemoveSubscriberIntentResponse

type MsgRemoveSubscriberIntentResponse struct {
}

func (*MsgRemoveSubscriberIntentResponse) Descriptor

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

func (*MsgRemoveSubscriberIntentResponse) Marshal

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

func (*MsgRemoveSubscriberIntentResponse) MarshalTo

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

func (*MsgRemoveSubscriberIntentResponse) MarshalToSizedBuffer

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

func (*MsgRemoveSubscriberIntentResponse) ProtoMessage

func (*MsgRemoveSubscriberIntentResponse) ProtoMessage()

func (*MsgRemoveSubscriberIntentResponse) Reset

func (*MsgRemoveSubscriberIntentResponse) Size

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

func (*MsgRemoveSubscriberIntentResponse) String

func (*MsgRemoveSubscriberIntentResponse) Unmarshal

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

func (*MsgRemoveSubscriberIntentResponse) XXX_DiscardUnknown

func (m *MsgRemoveSubscriberIntentResponse) XXX_DiscardUnknown()

func (*MsgRemoveSubscriberIntentResponse) XXX_Marshal

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

func (*MsgRemoveSubscriberIntentResponse) XXX_Merge

func (*MsgRemoveSubscriberIntentResponse) XXX_Size

func (m *MsgRemoveSubscriberIntentResponse) XXX_Size() int

func (*MsgRemoveSubscriberIntentResponse) XXX_Unmarshal

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

type MsgRemoveSubscriberRequest

type MsgRemoveSubscriberRequest struct {
	SubscriberAddress string `protobuf:"bytes,1,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
	Signer            string `protobuf:"bytes,2,opt,name=signer,proto3" json:"signer,omitempty"`
}

func NewMsgRemoveSubscriberRequest

func NewMsgRemoveSubscriberRequest(subscriberAddress string, signer sdk.AccAddress) (*MsgRemoveSubscriberRequest, error)

NewMsgRemoveSubscriberRequest returns a new MsgRemoveSubscriberRequest

func (*MsgRemoveSubscriberRequest) Descriptor

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

func (*MsgRemoveSubscriberRequest) GetSignBytes

func (m *MsgRemoveSubscriberRequest) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (*MsgRemoveSubscriberRequest) GetSigner

func (m *MsgRemoveSubscriberRequest) GetSigner() string

func (*MsgRemoveSubscriberRequest) GetSigners

func (m *MsgRemoveSubscriberRequest) GetSigners() []sdk.AccAddress

GetSigners implements sdk.Msg

func (*MsgRemoveSubscriberRequest) GetSubscriberAddress

func (m *MsgRemoveSubscriberRequest) GetSubscriberAddress() string

func (*MsgRemoveSubscriberRequest) Marshal

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

func (*MsgRemoveSubscriberRequest) MarshalTo

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

func (*MsgRemoveSubscriberRequest) MarshalToSizedBuffer

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

func (*MsgRemoveSubscriberRequest) MustGetSigner

func (m *MsgRemoveSubscriberRequest) MustGetSigner() sdk.AccAddress

MustGetSigner returns the signer address

func (*MsgRemoveSubscriberRequest) ProtoMessage

func (*MsgRemoveSubscriberRequest) ProtoMessage()

func (*MsgRemoveSubscriberRequest) Reset

func (m *MsgRemoveSubscriberRequest) Reset()

func (*MsgRemoveSubscriberRequest) Route

Route implements sdk.Msg

func (*MsgRemoveSubscriberRequest) Size

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

func (*MsgRemoveSubscriberRequest) String

func (m *MsgRemoveSubscriberRequest) String() string

func (*MsgRemoveSubscriberRequest) Type

Type implements sdk.Msg

func (*MsgRemoveSubscriberRequest) Unmarshal

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

func (*MsgRemoveSubscriberRequest) ValidateBasic

func (m *MsgRemoveSubscriberRequest) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgRemoveSubscriberRequest) XXX_DiscardUnknown

func (m *MsgRemoveSubscriberRequest) XXX_DiscardUnknown()

func (*MsgRemoveSubscriberRequest) XXX_Marshal

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

func (*MsgRemoveSubscriberRequest) XXX_Merge

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

func (*MsgRemoveSubscriberRequest) XXX_Size

func (m *MsgRemoveSubscriberRequest) XXX_Size() int

func (*MsgRemoveSubscriberRequest) XXX_Unmarshal

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

type MsgRemoveSubscriberResponse

type MsgRemoveSubscriberResponse struct {
}

func (*MsgRemoveSubscriberResponse) Descriptor

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

func (*MsgRemoveSubscriberResponse) Marshal

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

func (*MsgRemoveSubscriberResponse) MarshalTo

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

func (*MsgRemoveSubscriberResponse) MarshalToSizedBuffer

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

func (*MsgRemoveSubscriberResponse) ProtoMessage

func (*MsgRemoveSubscriberResponse) ProtoMessage()

func (*MsgRemoveSubscriberResponse) Reset

func (m *MsgRemoveSubscriberResponse) Reset()

func (*MsgRemoveSubscriberResponse) Size

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

func (*MsgRemoveSubscriberResponse) String

func (m *MsgRemoveSubscriberResponse) String() string

func (*MsgRemoveSubscriberResponse) Unmarshal

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

func (*MsgRemoveSubscriberResponse) XXX_DiscardUnknown

func (m *MsgRemoveSubscriberResponse) XXX_DiscardUnknown()

func (*MsgRemoveSubscriberResponse) XXX_Marshal

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

func (*MsgRemoveSubscriberResponse) XXX_Merge

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

func (*MsgRemoveSubscriberResponse) XXX_Size

func (m *MsgRemoveSubscriberResponse) XXX_Size() int

func (*MsgRemoveSubscriberResponse) XXX_Unmarshal

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

type Params

type Params struct {
}

Params defines the parameters for the module.

func DefaultParams

func DefaultParams() Params

DefaultParams returns a default set of parameters

func (*Params) Descriptor

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

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

ParamSetPairs get the params.ParamSet

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

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

func (Params) String

func (p Params) String() string

String implements the Stringer interface.

func (*Params) Unmarshal

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

func (Params) ValidateBasic

func (p Params) ValidateBasic() 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 PublishMethod

type PublishMethod int32

for a given PublisherIntent, whether or not it is pulled or pushed

const (
	// subscribers should pull from the provided URL
	PublishMethod_PULL PublishMethod = 0
	// subscribers must provide a URL to receive push messages
	PublishMethod_PUSH PublishMethod = 1
)

func (PublishMethod) EnumDescriptor

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

func (PublishMethod) String

func (x PublishMethod) String() string

type Publisher

type Publisher struct {
	// account address of the publisher
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	// unique key, FQDN of the publisher, max length of 256
	Domain string `protobuf:"bytes,2,opt,name=domain,proto3" json:"domain,omitempty"`
	// the publisher's self-signed CA cert PEM file, expecting TLS 1.3 compatible ECDSA certificates, max length 4096
	CaCert string `protobuf:"bytes,3,opt,name=ca_cert,json=caCert,proto3" json:"ca_cert,omitempty"`
}

represents a publisher, which are added via governance

func (*Publisher) Descriptor

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

func (*Publisher) GetAddress

func (m *Publisher) GetAddress() string

func (*Publisher) GetCaCert

func (m *Publisher) GetCaCert() string

func (*Publisher) GetDomain

func (m *Publisher) GetDomain() string

func (*Publisher) Marshal

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

func (*Publisher) MarshalTo

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

func (*Publisher) MarshalToSizedBuffer

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

func (*Publisher) ProtoMessage

func (*Publisher) ProtoMessage()

func (*Publisher) Reset

func (m *Publisher) Reset()

func (*Publisher) Size

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

func (*Publisher) String

func (m *Publisher) String() string

func (*Publisher) Unmarshal

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

func (*Publisher) ValidateBasic

func (p *Publisher) ValidateBasic() error

func (*Publisher) XXX_DiscardUnknown

func (m *Publisher) XXX_DiscardUnknown()

func (*Publisher) XXX_Marshal

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

func (*Publisher) XXX_Merge

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

func (*Publisher) XXX_Size

func (m *Publisher) XXX_Size() int

func (*Publisher) XXX_Unmarshal

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

type PublisherIntent

type PublisherIntent struct {
	// arbitary string representing a subscription, max length of 128
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	// FQDN of the publisher, max length of 256
	PublisherDomain string `protobuf:"bytes,2,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
	// either PULL or PUSH (see enum above for details)
	Method PublishMethod `protobuf:"varint,3,opt,name=method,proto3,enum=pubsub.v1.PublishMethod" json:"method,omitempty"`
	// optional, only needs to be set if using the PULL method, max length of 512
	PullUrl string `protobuf:"bytes,4,opt,name=pull_url,json=pullUrl,proto3" json:"pull_url,omitempty"`
	// either ANY, VALIDATORS, or LIST (see enum above for details)
	AllowedSubscribers AllowedSubscribers `` /* 150-byte string literal not displayed */
	// optional, must be provided if allowed_subscribers is LIST, list of account addresses, max length 256
	AllowedAddresses []string `protobuf:"bytes,6,rep,name=allowed_addresses,json=allowedAddresses,proto3" json:"allowed_addresses,omitempty"`
}

represents a publisher committing to sending messages for a specific subscription ID

func (*PublisherIntent) Descriptor

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

func (*PublisherIntent) GetAllowedAddresses

func (m *PublisherIntent) GetAllowedAddresses() []string

func (*PublisherIntent) GetAllowedSubscribers

func (m *PublisherIntent) GetAllowedSubscribers() AllowedSubscribers

func (*PublisherIntent) GetMethod

func (m *PublisherIntent) GetMethod() PublishMethod

func (*PublisherIntent) GetPublisherDomain

func (m *PublisherIntent) GetPublisherDomain() string

func (*PublisherIntent) GetPullUrl

func (m *PublisherIntent) GetPullUrl() string

func (*PublisherIntent) GetSubscriptionId

func (m *PublisherIntent) GetSubscriptionId() string

func (*PublisherIntent) Marshal

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

func (*PublisherIntent) MarshalTo

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

func (*PublisherIntent) MarshalToSizedBuffer

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

func (*PublisherIntent) ProtoMessage

func (*PublisherIntent) ProtoMessage()

func (*PublisherIntent) Reset

func (m *PublisherIntent) Reset()

func (*PublisherIntent) Size

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

func (*PublisherIntent) String

func (m *PublisherIntent) String() string

func (*PublisherIntent) Unmarshal

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

func (*PublisherIntent) ValidateBasic

func (pi *PublisherIntent) ValidateBasic() error

func (*PublisherIntent) XXX_DiscardUnknown

func (m *PublisherIntent) XXX_DiscardUnknown()

func (*PublisherIntent) XXX_Marshal

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

func (*PublisherIntent) XXX_Merge

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

func (*PublisherIntent) XXX_Size

func (m *PublisherIntent) XXX_Size() int

func (*PublisherIntent) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
	QueryPublisher(ctx context.Context, in *QueryPublisherRequest, opts ...grpc.CallOption) (*QueryPublisherResponse, error)
	QueryPublishers(ctx context.Context, in *QueryPublishersRequest, opts ...grpc.CallOption) (*QueryPublishersResponse, error)
	QuerySubscriber(ctx context.Context, in *QuerySubscriberRequest, opts ...grpc.CallOption) (*QuerySubscriberResponse, error)
	QuerySubscribers(ctx context.Context, in *QuerySubscribersRequest, opts ...grpc.CallOption) (*QuerySubscribersResponse, error)
	QueryValidatorSubscribers(ctx context.Context, in *QueryValidatorSubscribersRequest, opts ...grpc.CallOption) (*QueryValidatorSubscribersResponse, error)
	QueryPublisherIntent(ctx context.Context, in *QueryPublisherIntentRequest, opts ...grpc.CallOption) (*QueryPublisherIntentResponse, error)
	QueryPublisherIntents(ctx context.Context, in *QueryPublisherIntentsRequest, opts ...grpc.CallOption) (*QueryPublisherIntentsResponse, error)
	QueryPublisherIntentsByPublisherDomain(ctx context.Context, in *QueryPublisherIntentsByPublisherDomainRequest, opts ...grpc.CallOption) (*QueryPublisherIntentsByPublisherDomainResponse, error)
	QueryPublisherIntentsBySubscriptionID(ctx context.Context, in *QueryPublisherIntentsBySubscriptionIDRequest, opts ...grpc.CallOption) (*QueryPublisherIntentsBySubscriptionIDResponse, error)
	QuerySubscriberIntent(ctx context.Context, in *QuerySubscriberIntentRequest, opts ...grpc.CallOption) (*QuerySubscriberIntentResponse, error)
	QuerySubscriberIntents(ctx context.Context, in *QuerySubscriberIntentsRequest, opts ...grpc.CallOption) (*QuerySubscriberIntentsResponse, error)
	QuerySubscriberIntentsBySubscriberAddress(ctx context.Context, in *QuerySubscriberIntentsBySubscriberAddressRequest, opts ...grpc.CallOption) (*QuerySubscriberIntentsBySubscriberAddressResponse, error)
	QuerySubscriberIntentsBySubscriptionID(ctx context.Context, in *QuerySubscriberIntentsBySubscriptionIDRequest, opts ...grpc.CallOption) (*QuerySubscriberIntentsBySubscriptionIDResponse, error)
	QuerySubscriberIntentsByPublisherDomain(ctx context.Context, in *QuerySubscriberIntentsByPublisherDomainRequest, opts ...grpc.CallOption) (*QuerySubscriberIntentsByPublisherDomainResponse, error)
	QueryDefaultSubscription(ctx context.Context, in *QueryDefaultSubscriptionRequest, opts ...grpc.CallOption) (*QueryDefaultSubscriptionResponse, error)
	QueryDefaultSubscriptions(ctx context.Context, in *QueryDefaultSubscriptionsRequest, opts ...grpc.CallOption) (*QueryDefaultSubscriptionsResponse, 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 QueryDefaultSubscriptionRequest

type QueryDefaultSubscriptionRequest struct {
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

func (*QueryDefaultSubscriptionRequest) Descriptor

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

func (*QueryDefaultSubscriptionRequest) GetSubscriptionId

func (m *QueryDefaultSubscriptionRequest) GetSubscriptionId() string

func (*QueryDefaultSubscriptionRequest) Marshal

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

func (*QueryDefaultSubscriptionRequest) MarshalTo

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

func (*QueryDefaultSubscriptionRequest) MarshalToSizedBuffer

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

func (*QueryDefaultSubscriptionRequest) ProtoMessage

func (*QueryDefaultSubscriptionRequest) ProtoMessage()

func (*QueryDefaultSubscriptionRequest) Reset

func (*QueryDefaultSubscriptionRequest) Size

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

func (*QueryDefaultSubscriptionRequest) String

func (*QueryDefaultSubscriptionRequest) Unmarshal

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

func (*QueryDefaultSubscriptionRequest) XXX_DiscardUnknown

func (m *QueryDefaultSubscriptionRequest) XXX_DiscardUnknown()

func (*QueryDefaultSubscriptionRequest) XXX_Marshal

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

func (*QueryDefaultSubscriptionRequest) XXX_Merge

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

func (*QueryDefaultSubscriptionRequest) XXX_Size

func (m *QueryDefaultSubscriptionRequest) XXX_Size() int

func (*QueryDefaultSubscriptionRequest) XXX_Unmarshal

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

type QueryDefaultSubscriptionResponse

type QueryDefaultSubscriptionResponse struct {
	DefaultSubscription *DefaultSubscription `protobuf:"bytes,1,opt,name=default_subscription,json=defaultSubscription,proto3" json:"default_subscription,omitempty"`
}

func (*QueryDefaultSubscriptionResponse) Descriptor

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

func (*QueryDefaultSubscriptionResponse) GetDefaultSubscription

func (m *QueryDefaultSubscriptionResponse) GetDefaultSubscription() *DefaultSubscription

func (*QueryDefaultSubscriptionResponse) Marshal

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

func (*QueryDefaultSubscriptionResponse) MarshalTo

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

func (*QueryDefaultSubscriptionResponse) MarshalToSizedBuffer

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

func (*QueryDefaultSubscriptionResponse) ProtoMessage

func (*QueryDefaultSubscriptionResponse) ProtoMessage()

func (*QueryDefaultSubscriptionResponse) Reset

func (*QueryDefaultSubscriptionResponse) Size

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

func (*QueryDefaultSubscriptionResponse) String

func (*QueryDefaultSubscriptionResponse) Unmarshal

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

func (*QueryDefaultSubscriptionResponse) XXX_DiscardUnknown

func (m *QueryDefaultSubscriptionResponse) XXX_DiscardUnknown()

func (*QueryDefaultSubscriptionResponse) XXX_Marshal

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

func (*QueryDefaultSubscriptionResponse) XXX_Merge

func (*QueryDefaultSubscriptionResponse) XXX_Size

func (m *QueryDefaultSubscriptionResponse) XXX_Size() int

func (*QueryDefaultSubscriptionResponse) XXX_Unmarshal

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

type QueryDefaultSubscriptionsRequest

type QueryDefaultSubscriptionsRequest struct {
}

func (*QueryDefaultSubscriptionsRequest) Descriptor

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

func (*QueryDefaultSubscriptionsRequest) Marshal

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

func (*QueryDefaultSubscriptionsRequest) MarshalTo

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

func (*QueryDefaultSubscriptionsRequest) MarshalToSizedBuffer

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

func (*QueryDefaultSubscriptionsRequest) ProtoMessage

func (*QueryDefaultSubscriptionsRequest) ProtoMessage()

func (*QueryDefaultSubscriptionsRequest) Reset

func (*QueryDefaultSubscriptionsRequest) Size

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

func (*QueryDefaultSubscriptionsRequest) String

func (*QueryDefaultSubscriptionsRequest) Unmarshal

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

func (*QueryDefaultSubscriptionsRequest) XXX_DiscardUnknown

func (m *QueryDefaultSubscriptionsRequest) XXX_DiscardUnknown()

func (*QueryDefaultSubscriptionsRequest) XXX_Marshal

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

func (*QueryDefaultSubscriptionsRequest) XXX_Merge

func (*QueryDefaultSubscriptionsRequest) XXX_Size

func (m *QueryDefaultSubscriptionsRequest) XXX_Size() int

func (*QueryDefaultSubscriptionsRequest) XXX_Unmarshal

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

type QueryDefaultSubscriptionsResponse

type QueryDefaultSubscriptionsResponse struct {
	DefaultSubscriptions []*DefaultSubscription `protobuf:"bytes,1,rep,name=default_subscriptions,json=defaultSubscriptions,proto3" json:"default_subscriptions,omitempty"`
}

func (*QueryDefaultSubscriptionsResponse) Descriptor

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

func (*QueryDefaultSubscriptionsResponse) GetDefaultSubscriptions

func (m *QueryDefaultSubscriptionsResponse) GetDefaultSubscriptions() []*DefaultSubscription

func (*QueryDefaultSubscriptionsResponse) Marshal

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

func (*QueryDefaultSubscriptionsResponse) MarshalTo

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

func (*QueryDefaultSubscriptionsResponse) MarshalToSizedBuffer

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

func (*QueryDefaultSubscriptionsResponse) ProtoMessage

func (*QueryDefaultSubscriptionsResponse) ProtoMessage()

func (*QueryDefaultSubscriptionsResponse) Reset

func (*QueryDefaultSubscriptionsResponse) Size

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

func (*QueryDefaultSubscriptionsResponse) String

func (*QueryDefaultSubscriptionsResponse) Unmarshal

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

func (*QueryDefaultSubscriptionsResponse) XXX_DiscardUnknown

func (m *QueryDefaultSubscriptionsResponse) XXX_DiscardUnknown()

func (*QueryDefaultSubscriptionsResponse) XXX_Marshal

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

func (*QueryDefaultSubscriptionsResponse) XXX_Merge

func (*QueryDefaultSubscriptionsResponse) XXX_Size

func (m *QueryDefaultSubscriptionsResponse) XXX_Size() int

func (*QueryDefaultSubscriptionsResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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 Params `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
}

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 QueryPublisherIntentRequest

type QueryPublisherIntentRequest struct {
	PublisherDomain string `protobuf:"bytes,1,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
	SubscriptionId  string `protobuf:"bytes,2,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

func (*QueryPublisherIntentRequest) Descriptor

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

func (*QueryPublisherIntentRequest) GetPublisherDomain

func (m *QueryPublisherIntentRequest) GetPublisherDomain() string

func (*QueryPublisherIntentRequest) GetSubscriptionId

func (m *QueryPublisherIntentRequest) GetSubscriptionId() string

func (*QueryPublisherIntentRequest) Marshal

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

func (*QueryPublisherIntentRequest) MarshalTo

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

func (*QueryPublisherIntentRequest) MarshalToSizedBuffer

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

func (*QueryPublisherIntentRequest) ProtoMessage

func (*QueryPublisherIntentRequest) ProtoMessage()

func (*QueryPublisherIntentRequest) Reset

func (m *QueryPublisherIntentRequest) Reset()

func (*QueryPublisherIntentRequest) Size

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

func (*QueryPublisherIntentRequest) String

func (m *QueryPublisherIntentRequest) String() string

func (*QueryPublisherIntentRequest) Unmarshal

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

func (*QueryPublisherIntentRequest) XXX_DiscardUnknown

func (m *QueryPublisherIntentRequest) XXX_DiscardUnknown()

func (*QueryPublisherIntentRequest) XXX_Marshal

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

func (*QueryPublisherIntentRequest) XXX_Merge

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

func (*QueryPublisherIntentRequest) XXX_Size

func (m *QueryPublisherIntentRequest) XXX_Size() int

func (*QueryPublisherIntentRequest) XXX_Unmarshal

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

type QueryPublisherIntentResponse

type QueryPublisherIntentResponse struct {
	PublisherIntent *PublisherIntent `protobuf:"bytes,1,opt,name=publisher_intent,json=publisherIntent,proto3" json:"publisher_intent,omitempty"`
}

func (*QueryPublisherIntentResponse) Descriptor

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

func (*QueryPublisherIntentResponse) GetPublisherIntent

func (m *QueryPublisherIntentResponse) GetPublisherIntent() *PublisherIntent

func (*QueryPublisherIntentResponse) Marshal

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

func (*QueryPublisherIntentResponse) MarshalTo

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

func (*QueryPublisherIntentResponse) MarshalToSizedBuffer

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

func (*QueryPublisherIntentResponse) ProtoMessage

func (*QueryPublisherIntentResponse) ProtoMessage()

func (*QueryPublisherIntentResponse) Reset

func (m *QueryPublisherIntentResponse) Reset()

func (*QueryPublisherIntentResponse) Size

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

func (*QueryPublisherIntentResponse) String

func (*QueryPublisherIntentResponse) Unmarshal

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

func (*QueryPublisherIntentResponse) XXX_DiscardUnknown

func (m *QueryPublisherIntentResponse) XXX_DiscardUnknown()

func (*QueryPublisherIntentResponse) XXX_Marshal

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

func (*QueryPublisherIntentResponse) XXX_Merge

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

func (*QueryPublisherIntentResponse) XXX_Size

func (m *QueryPublisherIntentResponse) XXX_Size() int

func (*QueryPublisherIntentResponse) XXX_Unmarshal

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

type QueryPublisherIntentsByPublisherDomainRequest

type QueryPublisherIntentsByPublisherDomainRequest struct {
	PublisherDomain string `protobuf:"bytes,1,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

func (*QueryPublisherIntentsByPublisherDomainRequest) Descriptor

func (*QueryPublisherIntentsByPublisherDomainRequest) GetPublisherDomain

func (m *QueryPublisherIntentsByPublisherDomainRequest) GetPublisherDomain() string

func (*QueryPublisherIntentsByPublisherDomainRequest) Marshal

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

func (*QueryPublisherIntentsByPublisherDomainRequest) MarshalTo

func (*QueryPublisherIntentsByPublisherDomainRequest) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsByPublisherDomainRequest) ProtoMessage

func (*QueryPublisherIntentsByPublisherDomainRequest) Reset

func (*QueryPublisherIntentsByPublisherDomainRequest) Size

func (*QueryPublisherIntentsByPublisherDomainRequest) String

func (*QueryPublisherIntentsByPublisherDomainRequest) Unmarshal

func (*QueryPublisherIntentsByPublisherDomainRequest) XXX_DiscardUnknown

func (m *QueryPublisherIntentsByPublisherDomainRequest) XXX_DiscardUnknown()

func (*QueryPublisherIntentsByPublisherDomainRequest) XXX_Marshal

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

func (*QueryPublisherIntentsByPublisherDomainRequest) XXX_Merge

func (*QueryPublisherIntentsByPublisherDomainRequest) XXX_Size

func (*QueryPublisherIntentsByPublisherDomainRequest) XXX_Unmarshal

type QueryPublisherIntentsByPublisherDomainResponse

type QueryPublisherIntentsByPublisherDomainResponse struct {
	PublisherIntents []*PublisherIntent `protobuf:"bytes,1,rep,name=publisher_intents,json=publisherIntents,proto3" json:"publisher_intents,omitempty"`
}

func (*QueryPublisherIntentsByPublisherDomainResponse) Descriptor

func (*QueryPublisherIntentsByPublisherDomainResponse) GetPublisherIntents

func (*QueryPublisherIntentsByPublisherDomainResponse) Marshal

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

func (*QueryPublisherIntentsByPublisherDomainResponse) MarshalTo

func (*QueryPublisherIntentsByPublisherDomainResponse) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsByPublisherDomainResponse) ProtoMessage

func (*QueryPublisherIntentsByPublisherDomainResponse) Reset

func (*QueryPublisherIntentsByPublisherDomainResponse) Size

func (*QueryPublisherIntentsByPublisherDomainResponse) String

func (*QueryPublisherIntentsByPublisherDomainResponse) Unmarshal

func (*QueryPublisherIntentsByPublisherDomainResponse) XXX_DiscardUnknown

func (m *QueryPublisherIntentsByPublisherDomainResponse) XXX_DiscardUnknown()

func (*QueryPublisherIntentsByPublisherDomainResponse) XXX_Marshal

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

func (*QueryPublisherIntentsByPublisherDomainResponse) XXX_Merge

func (*QueryPublisherIntentsByPublisherDomainResponse) XXX_Size

func (*QueryPublisherIntentsByPublisherDomainResponse) XXX_Unmarshal

type QueryPublisherIntentsBySubscriptionIDRequest

type QueryPublisherIntentsBySubscriptionIDRequest struct {
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

func (*QueryPublisherIntentsBySubscriptionIDRequest) Descriptor

func (*QueryPublisherIntentsBySubscriptionIDRequest) GetSubscriptionId

func (*QueryPublisherIntentsBySubscriptionIDRequest) Marshal

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

func (*QueryPublisherIntentsBySubscriptionIDRequest) MarshalTo

func (*QueryPublisherIntentsBySubscriptionIDRequest) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsBySubscriptionIDRequest) ProtoMessage

func (*QueryPublisherIntentsBySubscriptionIDRequest) Reset

func (*QueryPublisherIntentsBySubscriptionIDRequest) Size

func (*QueryPublisherIntentsBySubscriptionIDRequest) String

func (*QueryPublisherIntentsBySubscriptionIDRequest) Unmarshal

func (*QueryPublisherIntentsBySubscriptionIDRequest) XXX_DiscardUnknown

func (m *QueryPublisherIntentsBySubscriptionIDRequest) XXX_DiscardUnknown()

func (*QueryPublisherIntentsBySubscriptionIDRequest) XXX_Marshal

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

func (*QueryPublisherIntentsBySubscriptionIDRequest) XXX_Merge

func (*QueryPublisherIntentsBySubscriptionIDRequest) XXX_Size

func (*QueryPublisherIntentsBySubscriptionIDRequest) XXX_Unmarshal

type QueryPublisherIntentsBySubscriptionIDResponse

type QueryPublisherIntentsBySubscriptionIDResponse struct {
	PublisherIntents []*PublisherIntent `protobuf:"bytes,1,rep,name=publisher_intents,json=publisherIntents,proto3" json:"publisher_intents,omitempty"`
}

func (*QueryPublisherIntentsBySubscriptionIDResponse) Descriptor

func (*QueryPublisherIntentsBySubscriptionIDResponse) GetPublisherIntents

func (*QueryPublisherIntentsBySubscriptionIDResponse) Marshal

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

func (*QueryPublisherIntentsBySubscriptionIDResponse) MarshalTo

func (*QueryPublisherIntentsBySubscriptionIDResponse) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsBySubscriptionIDResponse) ProtoMessage

func (*QueryPublisherIntentsBySubscriptionIDResponse) Reset

func (*QueryPublisherIntentsBySubscriptionIDResponse) Size

func (*QueryPublisherIntentsBySubscriptionIDResponse) String

func (*QueryPublisherIntentsBySubscriptionIDResponse) Unmarshal

func (*QueryPublisherIntentsBySubscriptionIDResponse) XXX_DiscardUnknown

func (m *QueryPublisherIntentsBySubscriptionIDResponse) XXX_DiscardUnknown()

func (*QueryPublisherIntentsBySubscriptionIDResponse) XXX_Marshal

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

func (*QueryPublisherIntentsBySubscriptionIDResponse) XXX_Merge

func (*QueryPublisherIntentsBySubscriptionIDResponse) XXX_Size

func (*QueryPublisherIntentsBySubscriptionIDResponse) XXX_Unmarshal

type QueryPublisherIntentsRequest

type QueryPublisherIntentsRequest struct {
}

func (*QueryPublisherIntentsRequest) Descriptor

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

func (*QueryPublisherIntentsRequest) Marshal

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

func (*QueryPublisherIntentsRequest) MarshalTo

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

func (*QueryPublisherIntentsRequest) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsRequest) ProtoMessage

func (*QueryPublisherIntentsRequest) ProtoMessage()

func (*QueryPublisherIntentsRequest) Reset

func (m *QueryPublisherIntentsRequest) Reset()

func (*QueryPublisherIntentsRequest) Size

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

func (*QueryPublisherIntentsRequest) String

func (*QueryPublisherIntentsRequest) Unmarshal

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

func (*QueryPublisherIntentsRequest) XXX_DiscardUnknown

func (m *QueryPublisherIntentsRequest) XXX_DiscardUnknown()

func (*QueryPublisherIntentsRequest) XXX_Marshal

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

func (*QueryPublisherIntentsRequest) XXX_Merge

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

func (*QueryPublisherIntentsRequest) XXX_Size

func (m *QueryPublisherIntentsRequest) XXX_Size() int

func (*QueryPublisherIntentsRequest) XXX_Unmarshal

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

type QueryPublisherIntentsResponse

type QueryPublisherIntentsResponse struct {
	PublisherIntents []*PublisherIntent `protobuf:"bytes,1,rep,name=publisher_intents,json=publisherIntents,proto3" json:"publisher_intents,omitempty"`
}

func (*QueryPublisherIntentsResponse) Descriptor

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

func (*QueryPublisherIntentsResponse) GetPublisherIntents

func (m *QueryPublisherIntentsResponse) GetPublisherIntents() []*PublisherIntent

func (*QueryPublisherIntentsResponse) Marshal

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

func (*QueryPublisherIntentsResponse) MarshalTo

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

func (*QueryPublisherIntentsResponse) MarshalToSizedBuffer

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

func (*QueryPublisherIntentsResponse) ProtoMessage

func (*QueryPublisherIntentsResponse) ProtoMessage()

func (*QueryPublisherIntentsResponse) Reset

func (m *QueryPublisherIntentsResponse) Reset()

func (*QueryPublisherIntentsResponse) Size

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

func (*QueryPublisherIntentsResponse) String

func (*QueryPublisherIntentsResponse) Unmarshal

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

func (*QueryPublisherIntentsResponse) XXX_DiscardUnknown

func (m *QueryPublisherIntentsResponse) XXX_DiscardUnknown()

func (*QueryPublisherIntentsResponse) XXX_Marshal

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

func (*QueryPublisherIntentsResponse) XXX_Merge

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

func (*QueryPublisherIntentsResponse) XXX_Size

func (m *QueryPublisherIntentsResponse) XXX_Size() int

func (*QueryPublisherIntentsResponse) XXX_Unmarshal

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

type QueryPublisherRequest

type QueryPublisherRequest struct {
	PublisherDomain string `protobuf:"bytes,1,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

func (*QueryPublisherRequest) Descriptor

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

func (*QueryPublisherRequest) GetPublisherDomain

func (m *QueryPublisherRequest) GetPublisherDomain() string

func (*QueryPublisherRequest) Marshal

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

func (*QueryPublisherRequest) MarshalTo

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

func (*QueryPublisherRequest) MarshalToSizedBuffer

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

func (*QueryPublisherRequest) ProtoMessage

func (*QueryPublisherRequest) ProtoMessage()

func (*QueryPublisherRequest) Reset

func (m *QueryPublisherRequest) Reset()

func (*QueryPublisherRequest) Size

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

func (*QueryPublisherRequest) String

func (m *QueryPublisherRequest) String() string

func (*QueryPublisherRequest) Unmarshal

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

func (*QueryPublisherRequest) XXX_DiscardUnknown

func (m *QueryPublisherRequest) XXX_DiscardUnknown()

func (*QueryPublisherRequest) XXX_Marshal

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

func (*QueryPublisherRequest) XXX_Merge

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

func (*QueryPublisherRequest) XXX_Size

func (m *QueryPublisherRequest) XXX_Size() int

func (*QueryPublisherRequest) XXX_Unmarshal

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

type QueryPublisherResponse

type QueryPublisherResponse struct {
	Publisher *Publisher `protobuf:"bytes,1,opt,name=publisher,proto3" json:"publisher,omitempty"`
}

func (*QueryPublisherResponse) Descriptor

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

func (*QueryPublisherResponse) GetPublisher

func (m *QueryPublisherResponse) GetPublisher() *Publisher

func (*QueryPublisherResponse) Marshal

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

func (*QueryPublisherResponse) MarshalTo

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

func (*QueryPublisherResponse) MarshalToSizedBuffer

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

func (*QueryPublisherResponse) ProtoMessage

func (*QueryPublisherResponse) ProtoMessage()

func (*QueryPublisherResponse) Reset

func (m *QueryPublisherResponse) Reset()

func (*QueryPublisherResponse) Size

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

func (*QueryPublisherResponse) String

func (m *QueryPublisherResponse) String() string

func (*QueryPublisherResponse) Unmarshal

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

func (*QueryPublisherResponse) XXX_DiscardUnknown

func (m *QueryPublisherResponse) XXX_DiscardUnknown()

func (*QueryPublisherResponse) XXX_Marshal

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

func (*QueryPublisherResponse) XXX_Merge

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

func (*QueryPublisherResponse) XXX_Size

func (m *QueryPublisherResponse) XXX_Size() int

func (*QueryPublisherResponse) XXX_Unmarshal

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

type QueryPublishersRequest

type QueryPublishersRequest struct {
}

func (*QueryPublishersRequest) Descriptor

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

func (*QueryPublishersRequest) Marshal

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

func (*QueryPublishersRequest) MarshalTo

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

func (*QueryPublishersRequest) MarshalToSizedBuffer

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

func (*QueryPublishersRequest) ProtoMessage

func (*QueryPublishersRequest) ProtoMessage()

func (*QueryPublishersRequest) Reset

func (m *QueryPublishersRequest) Reset()

func (*QueryPublishersRequest) Size

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

func (*QueryPublishersRequest) String

func (m *QueryPublishersRequest) String() string

func (*QueryPublishersRequest) Unmarshal

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

func (*QueryPublishersRequest) XXX_DiscardUnknown

func (m *QueryPublishersRequest) XXX_DiscardUnknown()

func (*QueryPublishersRequest) XXX_Marshal

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

func (*QueryPublishersRequest) XXX_Merge

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

func (*QueryPublishersRequest) XXX_Size

func (m *QueryPublishersRequest) XXX_Size() int

func (*QueryPublishersRequest) XXX_Unmarshal

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

type QueryPublishersResponse

type QueryPublishersResponse struct {
	Publishers []*Publisher `protobuf:"bytes,1,rep,name=publishers,proto3" json:"publishers,omitempty"`
}

func (*QueryPublishersResponse) Descriptor

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

func (*QueryPublishersResponse) GetPublishers

func (m *QueryPublishersResponse) GetPublishers() []*Publisher

func (*QueryPublishersResponse) Marshal

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

func (*QueryPublishersResponse) MarshalTo

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

func (*QueryPublishersResponse) MarshalToSizedBuffer

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

func (*QueryPublishersResponse) ProtoMessage

func (*QueryPublishersResponse) ProtoMessage()

func (*QueryPublishersResponse) Reset

func (m *QueryPublishersResponse) Reset()

func (*QueryPublishersResponse) Size

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

func (*QueryPublishersResponse) String

func (m *QueryPublishersResponse) String() string

func (*QueryPublishersResponse) Unmarshal

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

func (*QueryPublishersResponse) XXX_DiscardUnknown

func (m *QueryPublishersResponse) XXX_DiscardUnknown()

func (*QueryPublishersResponse) XXX_Marshal

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

func (*QueryPublishersResponse) XXX_Merge

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

func (*QueryPublishersResponse) XXX_Size

func (m *QueryPublishersResponse) XXX_Size() int

func (*QueryPublishersResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
	QueryPublisher(context.Context, *QueryPublisherRequest) (*QueryPublisherResponse, error)
	QueryPublishers(context.Context, *QueryPublishersRequest) (*QueryPublishersResponse, error)
	QuerySubscriber(context.Context, *QuerySubscriberRequest) (*QuerySubscriberResponse, error)
	QuerySubscribers(context.Context, *QuerySubscribersRequest) (*QuerySubscribersResponse, error)
	QueryValidatorSubscribers(context.Context, *QueryValidatorSubscribersRequest) (*QueryValidatorSubscribersResponse, error)
	QueryPublisherIntent(context.Context, *QueryPublisherIntentRequest) (*QueryPublisherIntentResponse, error)
	QueryPublisherIntents(context.Context, *QueryPublisherIntentsRequest) (*QueryPublisherIntentsResponse, error)
	QueryPublisherIntentsByPublisherDomain(context.Context, *QueryPublisherIntentsByPublisherDomainRequest) (*QueryPublisherIntentsByPublisherDomainResponse, error)
	QueryPublisherIntentsBySubscriptionID(context.Context, *QueryPublisherIntentsBySubscriptionIDRequest) (*QueryPublisherIntentsBySubscriptionIDResponse, error)
	QuerySubscriberIntent(context.Context, *QuerySubscriberIntentRequest) (*QuerySubscriberIntentResponse, error)
	QuerySubscriberIntents(context.Context, *QuerySubscriberIntentsRequest) (*QuerySubscriberIntentsResponse, error)
	QuerySubscriberIntentsBySubscriberAddress(context.Context, *QuerySubscriberIntentsBySubscriberAddressRequest) (*QuerySubscriberIntentsBySubscriberAddressResponse, error)
	QuerySubscriberIntentsBySubscriptionID(context.Context, *QuerySubscriberIntentsBySubscriptionIDRequest) (*QuerySubscriberIntentsBySubscriptionIDResponse, error)
	QuerySubscriberIntentsByPublisherDomain(context.Context, *QuerySubscriberIntentsByPublisherDomainRequest) (*QuerySubscriberIntentsByPublisherDomainResponse, error)
	QueryDefaultSubscription(context.Context, *QueryDefaultSubscriptionRequest) (*QueryDefaultSubscriptionResponse, error)
	QueryDefaultSubscriptions(context.Context, *QueryDefaultSubscriptionsRequest) (*QueryDefaultSubscriptionsResponse, error)
}

QueryServer is the server API for Query service.

type QuerySubscriberIntentRequest

type QuerySubscriberIntentRequest struct {
	SubscriberAddress string `protobuf:"bytes,1,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
	SubscriptionId    string `protobuf:"bytes,2,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

func (*QuerySubscriberIntentRequest) Descriptor

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

func (*QuerySubscriberIntentRequest) GetSubscriberAddress

func (m *QuerySubscriberIntentRequest) GetSubscriberAddress() string

func (*QuerySubscriberIntentRequest) GetSubscriptionId

func (m *QuerySubscriberIntentRequest) GetSubscriptionId() string

func (*QuerySubscriberIntentRequest) Marshal

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

func (*QuerySubscriberIntentRequest) MarshalTo

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

func (*QuerySubscriberIntentRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentRequest) ProtoMessage

func (*QuerySubscriberIntentRequest) ProtoMessage()

func (*QuerySubscriberIntentRequest) Reset

func (m *QuerySubscriberIntentRequest) Reset()

func (*QuerySubscriberIntentRequest) Size

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

func (*QuerySubscriberIntentRequest) String

func (*QuerySubscriberIntentRequest) Unmarshal

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

func (*QuerySubscriberIntentRequest) XXX_DiscardUnknown

func (m *QuerySubscriberIntentRequest) XXX_DiscardUnknown()

func (*QuerySubscriberIntentRequest) XXX_Marshal

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

func (*QuerySubscriberIntentRequest) XXX_Merge

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

func (*QuerySubscriberIntentRequest) XXX_Size

func (m *QuerySubscriberIntentRequest) XXX_Size() int

func (*QuerySubscriberIntentRequest) XXX_Unmarshal

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

type QuerySubscriberIntentResponse

type QuerySubscriberIntentResponse struct {
	SubscriberIntent *SubscriberIntent `protobuf:"bytes,1,opt,name=subscriber_intent,json=subscriberIntent,proto3" json:"subscriber_intent,omitempty"`
}

func (*QuerySubscriberIntentResponse) Descriptor

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

func (*QuerySubscriberIntentResponse) GetSubscriberIntent

func (m *QuerySubscriberIntentResponse) GetSubscriberIntent() *SubscriberIntent

func (*QuerySubscriberIntentResponse) Marshal

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

func (*QuerySubscriberIntentResponse) MarshalTo

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

func (*QuerySubscriberIntentResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentResponse) ProtoMessage

func (*QuerySubscriberIntentResponse) ProtoMessage()

func (*QuerySubscriberIntentResponse) Reset

func (m *QuerySubscriberIntentResponse) Reset()

func (*QuerySubscriberIntentResponse) Size

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

func (*QuerySubscriberIntentResponse) String

func (*QuerySubscriberIntentResponse) Unmarshal

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

func (*QuerySubscriberIntentResponse) XXX_DiscardUnknown

func (m *QuerySubscriberIntentResponse) XXX_DiscardUnknown()

func (*QuerySubscriberIntentResponse) XXX_Marshal

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

func (*QuerySubscriberIntentResponse) XXX_Merge

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

func (*QuerySubscriberIntentResponse) XXX_Size

func (m *QuerySubscriberIntentResponse) XXX_Size() int

func (*QuerySubscriberIntentResponse) XXX_Unmarshal

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

type QuerySubscriberIntentsByPublisherDomainRequest

type QuerySubscriberIntentsByPublisherDomainRequest struct {
	PublisherDomain string `protobuf:"bytes,1,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

func (*QuerySubscriberIntentsByPublisherDomainRequest) Descriptor

func (*QuerySubscriberIntentsByPublisherDomainRequest) GetPublisherDomain

func (*QuerySubscriberIntentsByPublisherDomainRequest) Marshal

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

func (*QuerySubscriberIntentsByPublisherDomainRequest) MarshalTo

func (*QuerySubscriberIntentsByPublisherDomainRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsByPublisherDomainRequest) ProtoMessage

func (*QuerySubscriberIntentsByPublisherDomainRequest) Reset

func (*QuerySubscriberIntentsByPublisherDomainRequest) Size

func (*QuerySubscriberIntentsByPublisherDomainRequest) String

func (*QuerySubscriberIntentsByPublisherDomainRequest) Unmarshal

func (*QuerySubscriberIntentsByPublisherDomainRequest) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsByPublisherDomainRequest) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsByPublisherDomainRequest) XXX_Marshal

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

func (*QuerySubscriberIntentsByPublisherDomainRequest) XXX_Merge

func (*QuerySubscriberIntentsByPublisherDomainRequest) XXX_Size

func (*QuerySubscriberIntentsByPublisherDomainRequest) XXX_Unmarshal

type QuerySubscriberIntentsByPublisherDomainResponse

type QuerySubscriberIntentsByPublisherDomainResponse struct {
	SubscriberIntents []*SubscriberIntent `protobuf:"bytes,1,rep,name=subscriber_intents,json=subscriberIntents,proto3" json:"subscriber_intents,omitempty"`
}

func (*QuerySubscriberIntentsByPublisherDomainResponse) Descriptor

func (*QuerySubscriberIntentsByPublisherDomainResponse) GetSubscriberIntents

func (*QuerySubscriberIntentsByPublisherDomainResponse) Marshal

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

func (*QuerySubscriberIntentsByPublisherDomainResponse) MarshalTo

func (*QuerySubscriberIntentsByPublisherDomainResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsByPublisherDomainResponse) ProtoMessage

func (*QuerySubscriberIntentsByPublisherDomainResponse) Reset

func (*QuerySubscriberIntentsByPublisherDomainResponse) Size

func (*QuerySubscriberIntentsByPublisherDomainResponse) String

func (*QuerySubscriberIntentsByPublisherDomainResponse) Unmarshal

func (*QuerySubscriberIntentsByPublisherDomainResponse) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsByPublisherDomainResponse) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsByPublisherDomainResponse) XXX_Marshal

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

func (*QuerySubscriberIntentsByPublisherDomainResponse) XXX_Merge

func (*QuerySubscriberIntentsByPublisherDomainResponse) XXX_Size

func (*QuerySubscriberIntentsByPublisherDomainResponse) XXX_Unmarshal

type QuerySubscriberIntentsBySubscriberAddressRequest

type QuerySubscriberIntentsBySubscriberAddressRequest struct {
	SubscriberAddress string `protobuf:"bytes,1,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
}

func (*QuerySubscriberIntentsBySubscriberAddressRequest) Descriptor

func (*QuerySubscriberIntentsBySubscriberAddressRequest) GetSubscriberAddress

func (m *QuerySubscriberIntentsBySubscriberAddressRequest) GetSubscriberAddress() string

func (*QuerySubscriberIntentsBySubscriberAddressRequest) Marshal

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

func (*QuerySubscriberIntentsBySubscriberAddressRequest) MarshalTo

func (*QuerySubscriberIntentsBySubscriberAddressRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsBySubscriberAddressRequest) ProtoMessage

func (*QuerySubscriberIntentsBySubscriberAddressRequest) Reset

func (*QuerySubscriberIntentsBySubscriberAddressRequest) Size

func (*QuerySubscriberIntentsBySubscriberAddressRequest) String

func (*QuerySubscriberIntentsBySubscriberAddressRequest) Unmarshal

func (*QuerySubscriberIntentsBySubscriberAddressRequest) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsBySubscriberAddressRequest) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsBySubscriberAddressRequest) XXX_Marshal

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

func (*QuerySubscriberIntentsBySubscriberAddressRequest) XXX_Merge

func (*QuerySubscriberIntentsBySubscriberAddressRequest) XXX_Size

func (*QuerySubscriberIntentsBySubscriberAddressRequest) XXX_Unmarshal

type QuerySubscriberIntentsBySubscriberAddressResponse

type QuerySubscriberIntentsBySubscriberAddressResponse struct {
	SubscriberIntents []*SubscriberIntent `protobuf:"bytes,1,rep,name=subscriber_intents,json=subscriberIntents,proto3" json:"subscriber_intents,omitempty"`
}

func (*QuerySubscriberIntentsBySubscriberAddressResponse) Descriptor

func (*QuerySubscriberIntentsBySubscriberAddressResponse) GetSubscriberIntents

func (*QuerySubscriberIntentsBySubscriberAddressResponse) Marshal

func (*QuerySubscriberIntentsBySubscriberAddressResponse) MarshalTo

func (*QuerySubscriberIntentsBySubscriberAddressResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsBySubscriberAddressResponse) ProtoMessage

func (*QuerySubscriberIntentsBySubscriberAddressResponse) Reset

func (*QuerySubscriberIntentsBySubscriberAddressResponse) Size

func (*QuerySubscriberIntentsBySubscriberAddressResponse) String

func (*QuerySubscriberIntentsBySubscriberAddressResponse) Unmarshal

func (*QuerySubscriberIntentsBySubscriberAddressResponse) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsBySubscriberAddressResponse) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsBySubscriberAddressResponse) XXX_Marshal

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

func (*QuerySubscriberIntentsBySubscriberAddressResponse) XXX_Merge

func (*QuerySubscriberIntentsBySubscriberAddressResponse) XXX_Size

func (*QuerySubscriberIntentsBySubscriberAddressResponse) XXX_Unmarshal

type QuerySubscriberIntentsBySubscriptionIDRequest

type QuerySubscriberIntentsBySubscriptionIDRequest struct {
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

func (*QuerySubscriberIntentsBySubscriptionIDRequest) Descriptor

func (*QuerySubscriberIntentsBySubscriptionIDRequest) GetSubscriptionId

func (*QuerySubscriberIntentsBySubscriptionIDRequest) Marshal

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

func (*QuerySubscriberIntentsBySubscriptionIDRequest) MarshalTo

func (*QuerySubscriberIntentsBySubscriptionIDRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsBySubscriptionIDRequest) ProtoMessage

func (*QuerySubscriberIntentsBySubscriptionIDRequest) Reset

func (*QuerySubscriberIntentsBySubscriptionIDRequest) Size

func (*QuerySubscriberIntentsBySubscriptionIDRequest) String

func (*QuerySubscriberIntentsBySubscriptionIDRequest) Unmarshal

func (*QuerySubscriberIntentsBySubscriptionIDRequest) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsBySubscriptionIDRequest) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsBySubscriptionIDRequest) XXX_Marshal

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

func (*QuerySubscriberIntentsBySubscriptionIDRequest) XXX_Merge

func (*QuerySubscriberIntentsBySubscriptionIDRequest) XXX_Size

func (*QuerySubscriberIntentsBySubscriptionIDRequest) XXX_Unmarshal

type QuerySubscriberIntentsBySubscriptionIDResponse

type QuerySubscriberIntentsBySubscriptionIDResponse struct {
	SubscriberIntents []*SubscriberIntent `protobuf:"bytes,1,rep,name=subscriber_intents,json=subscriberIntents,proto3" json:"subscriber_intents,omitempty"`
}

func (*QuerySubscriberIntentsBySubscriptionIDResponse) Descriptor

func (*QuerySubscriberIntentsBySubscriptionIDResponse) GetSubscriberIntents

func (*QuerySubscriberIntentsBySubscriptionIDResponse) Marshal

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

func (*QuerySubscriberIntentsBySubscriptionIDResponse) MarshalTo

func (*QuerySubscriberIntentsBySubscriptionIDResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsBySubscriptionIDResponse) ProtoMessage

func (*QuerySubscriberIntentsBySubscriptionIDResponse) Reset

func (*QuerySubscriberIntentsBySubscriptionIDResponse) Size

func (*QuerySubscriberIntentsBySubscriptionIDResponse) String

func (*QuerySubscriberIntentsBySubscriptionIDResponse) Unmarshal

func (*QuerySubscriberIntentsBySubscriptionIDResponse) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsBySubscriptionIDResponse) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsBySubscriptionIDResponse) XXX_Marshal

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

func (*QuerySubscriberIntentsBySubscriptionIDResponse) XXX_Merge

func (*QuerySubscriberIntentsBySubscriptionIDResponse) XXX_Size

func (*QuerySubscriberIntentsBySubscriptionIDResponse) XXX_Unmarshal

type QuerySubscriberIntentsRequest

type QuerySubscriberIntentsRequest struct {
}

func (*QuerySubscriberIntentsRequest) Descriptor

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

func (*QuerySubscriberIntentsRequest) Marshal

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

func (*QuerySubscriberIntentsRequest) MarshalTo

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

func (*QuerySubscriberIntentsRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsRequest) ProtoMessage

func (*QuerySubscriberIntentsRequest) ProtoMessage()

func (*QuerySubscriberIntentsRequest) Reset

func (m *QuerySubscriberIntentsRequest) Reset()

func (*QuerySubscriberIntentsRequest) Size

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

func (*QuerySubscriberIntentsRequest) String

func (*QuerySubscriberIntentsRequest) Unmarshal

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

func (*QuerySubscriberIntentsRequest) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsRequest) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsRequest) XXX_Marshal

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

func (*QuerySubscriberIntentsRequest) XXX_Merge

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

func (*QuerySubscriberIntentsRequest) XXX_Size

func (m *QuerySubscriberIntentsRequest) XXX_Size() int

func (*QuerySubscriberIntentsRequest) XXX_Unmarshal

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

type QuerySubscriberIntentsResponse

type QuerySubscriberIntentsResponse struct {
	SubscriberIntents []*SubscriberIntent `protobuf:"bytes,1,rep,name=subscriber_intents,json=subscriberIntents,proto3" json:"subscriber_intents,omitempty"`
}

func (*QuerySubscriberIntentsResponse) Descriptor

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

func (*QuerySubscriberIntentsResponse) GetSubscriberIntents

func (m *QuerySubscriberIntentsResponse) GetSubscriberIntents() []*SubscriberIntent

func (*QuerySubscriberIntentsResponse) Marshal

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

func (*QuerySubscriberIntentsResponse) MarshalTo

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

func (*QuerySubscriberIntentsResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberIntentsResponse) ProtoMessage

func (*QuerySubscriberIntentsResponse) ProtoMessage()

func (*QuerySubscriberIntentsResponse) Reset

func (m *QuerySubscriberIntentsResponse) Reset()

func (*QuerySubscriberIntentsResponse) Size

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

func (*QuerySubscriberIntentsResponse) String

func (*QuerySubscriberIntentsResponse) Unmarshal

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

func (*QuerySubscriberIntentsResponse) XXX_DiscardUnknown

func (m *QuerySubscriberIntentsResponse) XXX_DiscardUnknown()

func (*QuerySubscriberIntentsResponse) XXX_Marshal

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

func (*QuerySubscriberIntentsResponse) XXX_Merge

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

func (*QuerySubscriberIntentsResponse) XXX_Size

func (m *QuerySubscriberIntentsResponse) XXX_Size() int

func (*QuerySubscriberIntentsResponse) XXX_Unmarshal

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

type QuerySubscriberRequest

type QuerySubscriberRequest struct {
	SubscriberAddress string `protobuf:"bytes,1,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
}

func (*QuerySubscriberRequest) Descriptor

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

func (*QuerySubscriberRequest) GetSubscriberAddress

func (m *QuerySubscriberRequest) GetSubscriberAddress() string

func (*QuerySubscriberRequest) Marshal

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

func (*QuerySubscriberRequest) MarshalTo

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

func (*QuerySubscriberRequest) MarshalToSizedBuffer

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

func (*QuerySubscriberRequest) ProtoMessage

func (*QuerySubscriberRequest) ProtoMessage()

func (*QuerySubscriberRequest) Reset

func (m *QuerySubscriberRequest) Reset()

func (*QuerySubscriberRequest) Size

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

func (*QuerySubscriberRequest) String

func (m *QuerySubscriberRequest) String() string

func (*QuerySubscriberRequest) Unmarshal

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

func (*QuerySubscriberRequest) XXX_DiscardUnknown

func (m *QuerySubscriberRequest) XXX_DiscardUnknown()

func (*QuerySubscriberRequest) XXX_Marshal

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

func (*QuerySubscriberRequest) XXX_Merge

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

func (*QuerySubscriberRequest) XXX_Size

func (m *QuerySubscriberRequest) XXX_Size() int

func (*QuerySubscriberRequest) XXX_Unmarshal

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

type QuerySubscriberResponse

type QuerySubscriberResponse struct {
	Subscriber *Subscriber `protobuf:"bytes,1,opt,name=subscriber,proto3" json:"subscriber,omitempty"`
}

func (*QuerySubscriberResponse) Descriptor

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

func (*QuerySubscriberResponse) GetSubscriber

func (m *QuerySubscriberResponse) GetSubscriber() *Subscriber

func (*QuerySubscriberResponse) Marshal

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

func (*QuerySubscriberResponse) MarshalTo

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

func (*QuerySubscriberResponse) MarshalToSizedBuffer

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

func (*QuerySubscriberResponse) ProtoMessage

func (*QuerySubscriberResponse) ProtoMessage()

func (*QuerySubscriberResponse) Reset

func (m *QuerySubscriberResponse) Reset()

func (*QuerySubscriberResponse) Size

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

func (*QuerySubscriberResponse) String

func (m *QuerySubscriberResponse) String() string

func (*QuerySubscriberResponse) Unmarshal

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

func (*QuerySubscriberResponse) XXX_DiscardUnknown

func (m *QuerySubscriberResponse) XXX_DiscardUnknown()

func (*QuerySubscriberResponse) XXX_Marshal

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

func (*QuerySubscriberResponse) XXX_Merge

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

func (*QuerySubscriberResponse) XXX_Size

func (m *QuerySubscriberResponse) XXX_Size() int

func (*QuerySubscriberResponse) XXX_Unmarshal

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

type QuerySubscribersRequest

type QuerySubscribersRequest struct {
}

func (*QuerySubscribersRequest) Descriptor

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

func (*QuerySubscribersRequest) Marshal

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

func (*QuerySubscribersRequest) MarshalTo

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

func (*QuerySubscribersRequest) MarshalToSizedBuffer

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

func (*QuerySubscribersRequest) ProtoMessage

func (*QuerySubscribersRequest) ProtoMessage()

func (*QuerySubscribersRequest) Reset

func (m *QuerySubscribersRequest) Reset()

func (*QuerySubscribersRequest) Size

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

func (*QuerySubscribersRequest) String

func (m *QuerySubscribersRequest) String() string

func (*QuerySubscribersRequest) Unmarshal

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

func (*QuerySubscribersRequest) XXX_DiscardUnknown

func (m *QuerySubscribersRequest) XXX_DiscardUnknown()

func (*QuerySubscribersRequest) XXX_Marshal

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

func (*QuerySubscribersRequest) XXX_Merge

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

func (*QuerySubscribersRequest) XXX_Size

func (m *QuerySubscribersRequest) XXX_Size() int

func (*QuerySubscribersRequest) XXX_Unmarshal

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

type QuerySubscribersResponse

type QuerySubscribersResponse struct {
	Subscribers []*Subscriber `protobuf:"bytes,1,rep,name=subscribers,proto3" json:"subscribers,omitempty"`
}

func (*QuerySubscribersResponse) Descriptor

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

func (*QuerySubscribersResponse) GetSubscribers

func (m *QuerySubscribersResponse) GetSubscribers() []*Subscriber

func (*QuerySubscribersResponse) Marshal

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

func (*QuerySubscribersResponse) MarshalTo

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

func (*QuerySubscribersResponse) MarshalToSizedBuffer

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

func (*QuerySubscribersResponse) ProtoMessage

func (*QuerySubscribersResponse) ProtoMessage()

func (*QuerySubscribersResponse) Reset

func (m *QuerySubscribersResponse) Reset()

func (*QuerySubscribersResponse) Size

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

func (*QuerySubscribersResponse) String

func (m *QuerySubscribersResponse) String() string

func (*QuerySubscribersResponse) Unmarshal

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

func (*QuerySubscribersResponse) XXX_DiscardUnknown

func (m *QuerySubscribersResponse) XXX_DiscardUnknown()

func (*QuerySubscribersResponse) XXX_Marshal

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

func (*QuerySubscribersResponse) XXX_Merge

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

func (*QuerySubscribersResponse) XXX_Size

func (m *QuerySubscribersResponse) XXX_Size() int

func (*QuerySubscribersResponse) XXX_Unmarshal

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

type QueryValidatorSubscribersRequest

type QueryValidatorSubscribersRequest struct {
}

func (*QueryValidatorSubscribersRequest) Descriptor

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

func (*QueryValidatorSubscribersRequest) Marshal

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

func (*QueryValidatorSubscribersRequest) MarshalTo

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

func (*QueryValidatorSubscribersRequest) MarshalToSizedBuffer

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

func (*QueryValidatorSubscribersRequest) ProtoMessage

func (*QueryValidatorSubscribersRequest) ProtoMessage()

func (*QueryValidatorSubscribersRequest) Reset

func (*QueryValidatorSubscribersRequest) Size

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

func (*QueryValidatorSubscribersRequest) String

func (*QueryValidatorSubscribersRequest) Unmarshal

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

func (*QueryValidatorSubscribersRequest) XXX_DiscardUnknown

func (m *QueryValidatorSubscribersRequest) XXX_DiscardUnknown()

func (*QueryValidatorSubscribersRequest) XXX_Marshal

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

func (*QueryValidatorSubscribersRequest) XXX_Merge

func (*QueryValidatorSubscribersRequest) XXX_Size

func (m *QueryValidatorSubscribersRequest) XXX_Size() int

func (*QueryValidatorSubscribersRequest) XXX_Unmarshal

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

type QueryValidatorSubscribersResponse

type QueryValidatorSubscribersResponse struct {
	Subscribers []*Subscriber `protobuf:"bytes,1,rep,name=subscribers,proto3" json:"subscribers,omitempty"`
}

func (*QueryValidatorSubscribersResponse) Descriptor

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

func (*QueryValidatorSubscribersResponse) GetSubscribers

func (m *QueryValidatorSubscribersResponse) GetSubscribers() []*Subscriber

func (*QueryValidatorSubscribersResponse) Marshal

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

func (*QueryValidatorSubscribersResponse) MarshalTo

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

func (*QueryValidatorSubscribersResponse) MarshalToSizedBuffer

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

func (*QueryValidatorSubscribersResponse) ProtoMessage

func (*QueryValidatorSubscribersResponse) ProtoMessage()

func (*QueryValidatorSubscribersResponse) Reset

func (*QueryValidatorSubscribersResponse) Size

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

func (*QueryValidatorSubscribersResponse) String

func (*QueryValidatorSubscribersResponse) Unmarshal

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

func (*QueryValidatorSubscribersResponse) XXX_DiscardUnknown

func (m *QueryValidatorSubscribersResponse) XXX_DiscardUnknown()

func (*QueryValidatorSubscribersResponse) XXX_Marshal

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

func (*QueryValidatorSubscribersResponse) XXX_Merge

func (*QueryValidatorSubscribersResponse) XXX_Size

func (m *QueryValidatorSubscribersResponse) XXX_Size() int

func (*QueryValidatorSubscribersResponse) XXX_Unmarshal

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

type RemoveDefaultSubscriptionProposal

type RemoveDefaultSubscriptionProposal struct {
	Title          string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description    string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	SubscriptionId string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
}

remove a default subscription

func NewRemoveDefaultSubscriptionProposal

func NewRemoveDefaultSubscriptionProposal(title string, description string, subscriptionID string) *RemoveDefaultSubscriptionProposal

func (*RemoveDefaultSubscriptionProposal) Descriptor

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

func (*RemoveDefaultSubscriptionProposal) GetDescription

func (m *RemoveDefaultSubscriptionProposal) GetDescription() string

func (*RemoveDefaultSubscriptionProposal) GetSubscriptionId

func (m *RemoveDefaultSubscriptionProposal) GetSubscriptionId() string

func (*RemoveDefaultSubscriptionProposal) GetTitle

func (*RemoveDefaultSubscriptionProposal) Marshal

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

func (*RemoveDefaultSubscriptionProposal) MarshalTo

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

func (*RemoveDefaultSubscriptionProposal) MarshalToSizedBuffer

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

func (*RemoveDefaultSubscriptionProposal) ProposalRoute

func (p *RemoveDefaultSubscriptionProposal) ProposalRoute() string

func (*RemoveDefaultSubscriptionProposal) ProposalType

func (p *RemoveDefaultSubscriptionProposal) ProposalType() string

func (*RemoveDefaultSubscriptionProposal) ProtoMessage

func (*RemoveDefaultSubscriptionProposal) ProtoMessage()

func (*RemoveDefaultSubscriptionProposal) Reset

func (*RemoveDefaultSubscriptionProposal) Size

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

func (*RemoveDefaultSubscriptionProposal) String

func (*RemoveDefaultSubscriptionProposal) Unmarshal

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

func (*RemoveDefaultSubscriptionProposal) ValidateBasic

func (p *RemoveDefaultSubscriptionProposal) ValidateBasic() error

func (*RemoveDefaultSubscriptionProposal) XXX_DiscardUnknown

func (m *RemoveDefaultSubscriptionProposal) XXX_DiscardUnknown()

func (*RemoveDefaultSubscriptionProposal) XXX_Marshal

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

func (*RemoveDefaultSubscriptionProposal) XXX_Merge

func (*RemoveDefaultSubscriptionProposal) XXX_Size

func (m *RemoveDefaultSubscriptionProposal) XXX_Size() int

func (*RemoveDefaultSubscriptionProposal) XXX_Unmarshal

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

type RemoveDefaultSubscriptionProposalWithDeposit

type RemoveDefaultSubscriptionProposalWithDeposit struct {
	Title          string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description    string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	SubscriptionId string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	Deposit        string `protobuf:"bytes,4,opt,name=deposit,proto3" json:"deposit,omitempty"`
}

func (*RemoveDefaultSubscriptionProposalWithDeposit) Descriptor

func (*RemoveDefaultSubscriptionProposalWithDeposit) GetDeposit

func (*RemoveDefaultSubscriptionProposalWithDeposit) GetDescription

func (*RemoveDefaultSubscriptionProposalWithDeposit) GetSubscriptionId

func (*RemoveDefaultSubscriptionProposalWithDeposit) GetTitle

func (*RemoveDefaultSubscriptionProposalWithDeposit) Marshal

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

func (*RemoveDefaultSubscriptionProposalWithDeposit) MarshalTo

func (*RemoveDefaultSubscriptionProposalWithDeposit) MarshalToSizedBuffer

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

func (*RemoveDefaultSubscriptionProposalWithDeposit) ProtoMessage

func (*RemoveDefaultSubscriptionProposalWithDeposit) Reset

func (*RemoveDefaultSubscriptionProposalWithDeposit) Size

func (*RemoveDefaultSubscriptionProposalWithDeposit) String

func (*RemoveDefaultSubscriptionProposalWithDeposit) Unmarshal

func (*RemoveDefaultSubscriptionProposalWithDeposit) XXX_DiscardUnknown

func (m *RemoveDefaultSubscriptionProposalWithDeposit) XXX_DiscardUnknown()

func (*RemoveDefaultSubscriptionProposalWithDeposit) XXX_Marshal

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

func (*RemoveDefaultSubscriptionProposalWithDeposit) XXX_Merge

func (*RemoveDefaultSubscriptionProposalWithDeposit) XXX_Size

func (*RemoveDefaultSubscriptionProposalWithDeposit) XXX_Unmarshal

type RemovePublisherProposal

type RemovePublisherProposal struct {
	Title       string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Domain      string `protobuf:"bytes,3,opt,name=domain,proto3" json:"domain,omitempty"`
}

governance proposal to remove a publisher (publishers can remove themselves, but this might be necessary in the event of a malicious publisher or a key compromise), since Publishers are unique by domain, it's the only necessary information to remove one

func NewRemovePublisherProposal

func NewRemovePublisherProposal(title string, description string, domain string) *RemovePublisherProposal

func (*RemovePublisherProposal) Descriptor

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

func (*RemovePublisherProposal) GetDescription

func (m *RemovePublisherProposal) GetDescription() string

func (*RemovePublisherProposal) GetDomain

func (m *RemovePublisherProposal) GetDomain() string

func (*RemovePublisherProposal) GetTitle

func (m *RemovePublisherProposal) GetTitle() string

func (*RemovePublisherProposal) Marshal

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

func (*RemovePublisherProposal) MarshalTo

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

func (*RemovePublisherProposal) MarshalToSizedBuffer

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

func (*RemovePublisherProposal) ProposalRoute

func (p *RemovePublisherProposal) ProposalRoute() string

func (*RemovePublisherProposal) ProposalType

func (p *RemovePublisherProposal) ProposalType() string

func (*RemovePublisherProposal) ProtoMessage

func (*RemovePublisherProposal) ProtoMessage()

func (*RemovePublisherProposal) Reset

func (m *RemovePublisherProposal) Reset()

func (*RemovePublisherProposal) Size

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

func (*RemovePublisherProposal) String

func (m *RemovePublisherProposal) String() string

func (*RemovePublisherProposal) Unmarshal

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

func (*RemovePublisherProposal) ValidateBasic

func (p *RemovePublisherProposal) ValidateBasic() error

func (*RemovePublisherProposal) XXX_DiscardUnknown

func (m *RemovePublisherProposal) XXX_DiscardUnknown()

func (*RemovePublisherProposal) XXX_Marshal

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

func (*RemovePublisherProposal) XXX_Merge

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

func (*RemovePublisherProposal) XXX_Size

func (m *RemovePublisherProposal) XXX_Size() int

func (*RemovePublisherProposal) XXX_Unmarshal

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

type RemovePublisherProposalWithDeposit

type RemovePublisherProposalWithDeposit struct {
	Title       string `protobuf:"bytes,1,opt,name=title,proto3" json:"title,omitempty"`
	Description string `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Domain      string `protobuf:"bytes,3,opt,name=domain,proto3" json:"domain,omitempty"`
	Deposit     string `protobuf:"bytes,4,opt,name=deposit,proto3" json:"deposit,omitempty"`
}

func (*RemovePublisherProposalWithDeposit) Descriptor

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

func (*RemovePublisherProposalWithDeposit) GetDeposit

func (*RemovePublisherProposalWithDeposit) GetDescription

func (m *RemovePublisherProposalWithDeposit) GetDescription() string

func (*RemovePublisherProposalWithDeposit) GetDomain

func (*RemovePublisherProposalWithDeposit) GetTitle

func (*RemovePublisherProposalWithDeposit) Marshal

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

func (*RemovePublisherProposalWithDeposit) MarshalTo

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

func (*RemovePublisherProposalWithDeposit) MarshalToSizedBuffer

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

func (*RemovePublisherProposalWithDeposit) ProtoMessage

func (*RemovePublisherProposalWithDeposit) ProtoMessage()

func (*RemovePublisherProposalWithDeposit) Reset

func (*RemovePublisherProposalWithDeposit) Size

func (*RemovePublisherProposalWithDeposit) String

func (*RemovePublisherProposalWithDeposit) Unmarshal

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

func (*RemovePublisherProposalWithDeposit) XXX_DiscardUnknown

func (m *RemovePublisherProposalWithDeposit) XXX_DiscardUnknown()

func (*RemovePublisherProposalWithDeposit) XXX_Marshal

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

func (*RemovePublisherProposalWithDeposit) XXX_Merge

func (*RemovePublisherProposalWithDeposit) XXX_Size

func (*RemovePublisherProposalWithDeposit) XXX_Unmarshal

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

type StakingKeeper

type StakingKeeper interface {
	GetBondedValidatorsByPower(ctx sdk.Context) []stakingtypes.Validator
	GetLastValidatorPower(ctx sdk.Context, operator sdk.ValAddress) int64
	GetLastTotalPower(ctx sdk.Context) (power math.Int)
	GetValidator(ctx sdk.Context, addr sdk.ValAddress) (validator stakingtypes.Validator, found bool)
	IterateValidators(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	IterateBondedValidatorsByPower(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	IterateLastValidators(sdk.Context, func(index int64, validator stakingtypes.ValidatorI) (stop bool))
	Validator(sdk.Context, sdk.ValAddress) stakingtypes.ValidatorI
	ValidatorByConsAddr(sdk.Context, sdk.ConsAddress) stakingtypes.ValidatorI
	Slash(sdk.Context, sdk.ConsAddress, int64, int64, sdk.Dec) math.Int
	Jail(sdk.Context, sdk.ConsAddress)
	PowerReduction(ctx sdk.Context) math.Int
}

StakingKeeper defines the expected staking keeper methods

type Subscriber

type Subscriber struct {
	// unique key, account address representation of either an account or a validator
	Address string `protobuf:"bytes,1,opt,name=address,proto3" json:"address,omitempty"`
	// the subscriber's self-signed CA cert PEM file, expecting TLS 1.3 compatible ECDSA certificates, max length 4096
	CaCert string `protobuf:"bytes,2,opt,name=ca_cert,json=caCert,proto3" json:"ca_cert,omitempty"`
	// max length of 512
	PushUrl string `protobuf:"bytes,3,opt,name=push_url,json=pushUrl,proto3" json:"push_url,omitempty"`
}

represents a subscriber, can be set or modified by the owner of the subscriber address

func (*Subscriber) Descriptor

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

func (*Subscriber) GetAddress

func (m *Subscriber) GetAddress() string

func (*Subscriber) GetCaCert

func (m *Subscriber) GetCaCert() string

func (*Subscriber) GetPushUrl

func (m *Subscriber) GetPushUrl() string

func (*Subscriber) Marshal

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

func (*Subscriber) MarshalTo

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

func (*Subscriber) MarshalToSizedBuffer

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

func (*Subscriber) ProtoMessage

func (*Subscriber) ProtoMessage()

func (*Subscriber) Reset

func (m *Subscriber) Reset()

func (*Subscriber) Size

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

func (*Subscriber) String

func (m *Subscriber) String() string

func (*Subscriber) Unmarshal

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

func (*Subscriber) ValidateBasic

func (s *Subscriber) ValidateBasic() error

func (*Subscriber) XXX_DiscardUnknown

func (m *Subscriber) XXX_DiscardUnknown()

func (*Subscriber) XXX_Marshal

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

func (*Subscriber) XXX_Merge

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

func (*Subscriber) XXX_Size

func (m *Subscriber) XXX_Size() int

func (*Subscriber) XXX_Unmarshal

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

type SubscriberIntent

type SubscriberIntent struct {
	// arbitary string representing a subscription, max length of 128
	SubscriptionId string `protobuf:"bytes,1,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"`
	// account address of the subscriber
	SubscriberAddress string `protobuf:"bytes,2,opt,name=subscriber_address,json=subscriberAddress,proto3" json:"subscriber_address,omitempty"`
	// FQDN of the publisher, max length of 256
	PublisherDomain string `protobuf:"bytes,3,opt,name=publisher_domain,json=publisherDomain,proto3" json:"publisher_domain,omitempty"`
}

represents a subscriber requesting messages for a specific subscription ID and publisher

func (*SubscriberIntent) Descriptor

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

func (*SubscriberIntent) GetPublisherDomain

func (m *SubscriberIntent) GetPublisherDomain() string

func (*SubscriberIntent) GetSubscriberAddress

func (m *SubscriberIntent) GetSubscriberAddress() string

func (*SubscriberIntent) GetSubscriptionId

func (m *SubscriberIntent) GetSubscriptionId() string

func (*SubscriberIntent) Marshal

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

func (*SubscriberIntent) MarshalTo

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

func (*SubscriberIntent) MarshalToSizedBuffer

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

func (*SubscriberIntent) ProtoMessage

func (*SubscriberIntent) ProtoMessage()

func (*SubscriberIntent) Reset

func (m *SubscriberIntent) Reset()

func (*SubscriberIntent) Size

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

func (*SubscriberIntent) String

func (m *SubscriberIntent) String() string

func (*SubscriberIntent) Unmarshal

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

func (*SubscriberIntent) ValidateBasic

func (si *SubscriberIntent) ValidateBasic() error

func (*SubscriberIntent) XXX_DiscardUnknown

func (m *SubscriberIntent) XXX_DiscardUnknown()

func (*SubscriberIntent) XXX_Marshal

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

func (*SubscriberIntent) XXX_Merge

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

func (*SubscriberIntent) XXX_Size

func (m *SubscriberIntent) XXX_Size() int

func (*SubscriberIntent) XXX_Unmarshal

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

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) AddPublisherIntent

func (*UnimplementedMsgServer) AddSubscriber

func (*UnimplementedMsgServer) AddSubscriberIntent

func (*UnimplementedMsgServer) RemovePublisher

func (*UnimplementedMsgServer) RemovePublisherIntent

func (*UnimplementedMsgServer) RemoveSubscriber

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) QueryDefaultSubscription

func (*UnimplementedQueryServer) QueryDefaultSubscriptions

func (*UnimplementedQueryServer) QueryPublisher

func (*UnimplementedQueryServer) QueryPublisherIntent

func (*UnimplementedQueryServer) QueryPublisherIntents

func (*UnimplementedQueryServer) QueryPublishers

func (*UnimplementedQueryServer) QuerySubscriber

func (*UnimplementedQueryServer) QuerySubscriberIntent

func (*UnimplementedQueryServer) QuerySubscriberIntents

func (*UnimplementedQueryServer) QuerySubscribers

func (*UnimplementedQueryServer) QueryValidatorSubscribers

Jump to

Keyboard shortcuts

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