types

package
v0.0.0-...-def7031 Latest Latest
Warning

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

Go to latest
Published: Jan 12, 2020 License: Apache-2.0 Imports: 41 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

nolint

Index

Constants

View Source
const (
	MicroAtomDenom  = "uatom"
	MicroHiloDenom  = "uhilo"
	USDDenom        = "USD"
	BlocksPerMinute = uint64(10)
	BlocksPerHour   = BlocksPerMinute * 60
	BlocksPerDay    = BlocksPerHour * 24
	BlocksPerWeek   = BlocksPerDay * 7
	BlocksPerMonth  = BlocksPerDay * 30
	BlocksPerYear   = BlocksPerDay * 365
	MicroUnit       = int64(1e6)
)

Denomination constants

View Source
const (
	EventTypeExchangeRateUpdate = "exchange_rate_update"
	EventTypePrevote            = "prevote"
	EventTypeVote               = "vote"
	EventTypeFeedDelegate       = "feed_delegate"
	EventTypeAggregatePrevote   = "aggregate_prevote"
	EventTypeAggregateVote      = "aggregate_vote"

	EventAttrKeyDenom         = "denom"
	EventAttrKeyVoter         = "voter"
	EventAttrKeyExchangeRate  = "exchange_rate"
	EventAttrKeyExchangeRates = "exchange_rates"
	EventAttrKeyOperator      = "operator"
	EventAttrKeyFeeder        = "feeder"
	EventAttrValueCategory    = ModuleName
)

Oracle module event types

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

	// StoreKey is the string store representation
	StoreKey = ModuleName

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

	// QuerierRoute is the query router key for the oracle module
	QuerierRoute = ModuleName
)
View Source
const (
	TypeMsgDelegateFeedConsent          = "delegate_feeder"
	TypeMsgAggregateExchangeRatePrevote = "aggregate_exchange_rate_prevote"
	TypeMsgAggregateExchangeRateVote    = "aggregate_exchange_rate_vote"
)

Messages types constants

View Source
const (
	DefaultVotePeriod               = BlocksPerMinute / 2 // 30 seconds
	DefaultSlashWindow              = BlocksPerWeek       // window for a week
	DefaultRewardDistributionWindow = BlocksPerYear       // window for a year
)

Default parameter values

View Source
const (
	QueryParameters        = "parameters"
	QueryExchangeRate      = "exchangeRate"
	QueryExchangeRates     = "exchangeRates"
	QueryActives           = "actives"
	QueryFeederDelegation  = "feederDelegation"
	QueryMissCounter       = "missCounter"
	QueryAggregatePrevote  = "aggregatePrevote"
	QueryAggregatePrevotes = "aggregatePrevotes"
	QueryAggregateVote     = "aggregateVote"
	QueryAggregateVotes    = "aggregateVotes"
	QueryVoteTargets       = "voteTargets"
	QueryTobinTax          = "tobinTax"
	QueryTobinTaxes        = "tobinTaxes"
)

Defines the prefix of each query path

View Source
const OracleDecPrecision = 8

OracleDecPrecision nolint

Variables

View Source
var (
	ErrInvalidExchangeRate   = sdkerrors.Register(ModuleName, 2, "invalid exchange rate")
	ErrNoPrevote             = sdkerrors.Register(ModuleName, 3, "no prevote")
	ErrNoVote                = sdkerrors.Register(ModuleName, 4, "no vote")
	ErrNoVotingPermission    = sdkerrors.Register(ModuleName, 5, "unauthorized voter")
	ErrInvalidHash           = sdkerrors.Register(ModuleName, 6, "invalid hash")
	ErrInvalidHashLength     = sdkerrors.Register(ModuleName, 7, fmt.Sprintf("invalid hash length; should equal %d", tmhash.TruncatedSize))
	ErrVerificationFailed    = sdkerrors.Register(ModuleName, 8, "hash verification failed")
	ErrRevealPeriodMissMatch = sdkerrors.Register(ModuleName, 9, "reveal period of submitted vote do not match with registered prevote")
	ErrInvalidSaltLength     = sdkerrors.Register(ModuleName, 10, "invalid salt length; should be 1~4")
	ErrNoAggregatePrevote    = sdkerrors.Register(ModuleName, 11, "no aggregate prevote")
	ErrNoAggregateVote       = sdkerrors.Register(ModuleName, 12, "no aggregate vote")
	ErrNoTobinTax            = sdkerrors.Register(ModuleName, 13, "no tobin tax")
	ErrUnknownDenom          = sdkerrors.Register(ModuleName, 14, "unknown denom")
)

Oracle sentinel errors nolint: lll

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 (
	KeyPrefixExchangeRate                 = []byte{0x01} // prefix for each key to a rate
	KeyPrefixFeederDelegation             = []byte{0x02} // prefix for each key to a feeder delegation
	KeyPrefixMissCounter                  = []byte{0x03} // prefix for each key to a miss counter
	KeyPrefixAggregateExchangeRatePrevote = []byte{0x04} // prefix for each key to a aggregate prevote
	KeyPrefixAggregateExchangeRateVote    = []byte{0x05} // prefix for each key to a aggregate vote
	KeyPrefixTobinTax                     = []byte{0x06} // prefix for each key to a tobin tax
	ExchangeRateKey                       = []byte{0x01} // prefix for each key to a rate
	FeederDelegationKey                   = []byte{0x02} // prefix for each key to a feeder delegation
	MissCounterKey                        = []byte{0x03} // prefix for each key to a miss counter
	AggregateExchangeRatePrevoteKey       = []byte{0x04} // prefix for each key to a aggregate prevote
	AggregateExchangeRateVoteKey          = []byte{0x05} // prefix for each key to a aggregate vote
	TobinTaxKey                           = []byte{0x06} // prefix for each key to a tobin tax
)

KVStore key prefixes

View Source
var (
	ErrInvalidLengthOracle        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowOracle          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupOracle = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	KeyVotePeriod               = []byte("VotePeriod")
	KeyVoteThreshold            = []byte("VoteThreshold")
	KeyRewardBand               = []byte("RewardBand")
	KeyRewardDistributionWindow = []byte("RewardDistributionWindow")
	KeyWhitelist                = []byte("Whitelist")
	KeySlashFraction            = []byte("SlashFraction")
	KeySlashWindow              = []byte("SlashWindow")
	KeyMinValidPerWindow        = []byte("MinValidPerWindow")
)

Parameter keys

View Source
var (
	DefaultVoteThreshold = sdk.NewDecWithPrec(50, 2) // 50%
	DefaultRewardBand    = sdk.NewDecWithPrec(2, 2)  // 2% (-1, 1)
	DefaultTobinTax      = sdk.NewDecWithPrec(25, 4) // 0.25%
	DefaultWhitelist     = DenomList{
		{Name: MicroAtomDenom, TobinTax: DefaultTobinTax},
		{Name: MicroHiloDenom, TobinTax: DefaultTobinTax},
	}
	DefaultSlashFraction     = sdk.NewDecWithPrec(1, 4) // 0.01%
	DefaultMinValidPerWindow = sdk.NewDecWithPrec(5, 2) // 5%
)

Default parameter values

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 (

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

Functions

func ExtractDenomFromTobinTaxKey

func ExtractDenomFromTobinTaxKey(key []byte) (denom string)

ExtractDenomFromTobinTaxKey - split denom from the tobin tax key

func GetAggregateExchangeRatePrevoteKey

func GetAggregateExchangeRatePrevoteKey(v sdk.ValAddress) (key []byte)

GetAggregateExchangeRatePrevoteKey - stored by *Validator* address

func GetAggregateExchangeRateVoteKey

func GetAggregateExchangeRateVoteKey(v sdk.ValAddress) (key []byte)

GetAggregateExchangeRateVoteKey - stored by *Validator* address

func GetExchangeRateKey

func GetExchangeRateKey(denom string) (key []byte)

GetExchangeRateKey - stored by *denom*

func GetFeederDelegationKey

func GetFeederDelegationKey(v sdk.ValAddress) (key []byte)

GetFeederDelegationKey - stored by *Validator* address

func GetMissCounterKey

func GetMissCounterKey(v sdk.ValAddress) (key []byte)

GetMissCounterKey - stored by *Validator* address

func GetTobinTaxKey

func GetTobinTaxKey(d string) (key []byte)

GetTobinTaxKey - stored by *denom* bytes

func ParamKeyTable

func ParamKeyTable() paramstypes.KeyTable

ParamKeyTable returns the parameter key table.

func RegisterInterfaces

func RegisterInterfaces(registry codectypes.InterfaceRegistry)

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

func RegisterLegacyAminoCodec

func RegisterLegacyAminoCodec(cdc *codec.LegacyAmino)

RegisterLegacyAminoCodec registers the necessary x/oracle 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 (such as grpc.SendHeader, etc) to stop working. Consider using RegisterQueryHandlerFromEndpoint instead.

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ValidateGenesis

func ValidateGenesis(data *GenesisState) error

ValidateGenesis validates the oracle genesis state.

Types

type AccountKeeper

type AccountKeeper interface {
	GetModuleAddress(name string) sdk.AccAddress
	GetModuleAccount(ctx sdk.Context, moduleName string) authtypes.ModuleAccountI

	// only used for simulation
	GetAccount(ctx sdk.Context, addr sdk.AccAddress) authtypes.AccountI
}

AccountKeeper defines the expected interface contract defined by the x/auth module.

type AggregateExchangeRatePrevote

type AggregateExchangeRatePrevote struct {
	Hash        string `protobuf:"bytes,1,opt,name=hash,proto3" json:"hash,omitempty" yaml:"hash"`
	Voter       string `protobuf:"bytes,2,opt,name=voter,proto3" json:"voter,omitempty" yaml:"voter"`
	SubmitBlock uint64 `protobuf:"varint,3,opt,name=submit_block,json=submitBlock,proto3" json:"submit_block,omitempty" yaml:"submit_block"`
}

struct for aggregate prevoting on the ExchangeRateVote. The purpose of aggregate prevote is to hide vote exchange rates with hash which is formatted as hex string in SHA256("{salt}:{exchange rate}{denom},...,{exchange rate}{denom}:{voter}")

func NewAggregateExchangeRatePrevote

func NewAggregateExchangeRatePrevote(
	hash AggregateVoteHash,
	voter sdk.ValAddress,
	submitBlock uint64,
) AggregateExchangeRatePrevote

func (*AggregateExchangeRatePrevote) Descriptor

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

func (*AggregateExchangeRatePrevote) Marshal

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

func (*AggregateExchangeRatePrevote) MarshalTo

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

func (*AggregateExchangeRatePrevote) MarshalToSizedBuffer

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

func (*AggregateExchangeRatePrevote) ProtoMessage

func (*AggregateExchangeRatePrevote) ProtoMessage()

func (*AggregateExchangeRatePrevote) Reset

func (m *AggregateExchangeRatePrevote) Reset()

func (*AggregateExchangeRatePrevote) Size

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

func (AggregateExchangeRatePrevote) String

String implement stringify

func (*AggregateExchangeRatePrevote) Unmarshal

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

func (*AggregateExchangeRatePrevote) XXX_DiscardUnknown

func (m *AggregateExchangeRatePrevote) XXX_DiscardUnknown()

func (*AggregateExchangeRatePrevote) XXX_Marshal

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

func (*AggregateExchangeRatePrevote) XXX_Merge

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

func (*AggregateExchangeRatePrevote) XXX_Size

func (m *AggregateExchangeRatePrevote) XXX_Size() int

func (*AggregateExchangeRatePrevote) XXX_Unmarshal

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

type AggregateExchangeRateVote

type AggregateExchangeRateVote struct {
	ExchangeRateTuples ExchangeRateTuples `` /* 167-byte string literal not displayed */
	Voter              string             `protobuf:"bytes,2,opt,name=voter,proto3" json:"voter,omitempty" yaml:"voter"`
}

MsgAggregateExchangeRateVote - struct for voting on the exchange rates of USD denominated in various assets.

func NewAggregateExchangeRateVote

func NewAggregateExchangeRateVote(
	exchangeRateTuples ExchangeRateTuples,
	voter sdk.ValAddress,
) AggregateExchangeRateVote

func (*AggregateExchangeRateVote) Descriptor

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

func (*AggregateExchangeRateVote) Marshal

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

func (*AggregateExchangeRateVote) MarshalTo

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

func (*AggregateExchangeRateVote) MarshalToSizedBuffer

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

func (*AggregateExchangeRateVote) ProtoMessage

func (*AggregateExchangeRateVote) ProtoMessage()

func (*AggregateExchangeRateVote) Reset

func (m *AggregateExchangeRateVote) Reset()

func (*AggregateExchangeRateVote) Size

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

func (AggregateExchangeRateVote) String

func (v AggregateExchangeRateVote) String() string

String implement stringify

func (*AggregateExchangeRateVote) Unmarshal

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

func (*AggregateExchangeRateVote) XXX_DiscardUnknown

func (m *AggregateExchangeRateVote) XXX_DiscardUnknown()

func (*AggregateExchangeRateVote) XXX_Marshal

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

func (*AggregateExchangeRateVote) XXX_Merge

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

func (*AggregateExchangeRateVote) XXX_Size

func (m *AggregateExchangeRateVote) XXX_Size() int

func (*AggregateExchangeRateVote) XXX_Unmarshal

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

type AggregateVoteHash

type AggregateVoteHash []byte

AggregateVoteHash is hash value to hide vote exchange rates which is formatted as hex string in SHA256("{salt}:{exchange rate}{denom},...,{exchange rate}{denom}:{voter}")

func AggregateVoteHashFromHexString

func AggregateVoteHashFromHexString(s string) (AggregateVoteHash, error)

AggregateVoteHashFromHexString convert hex string to AggregateVoteHash

func GetAggregateVoteHash

func GetAggregateVoteHash(salt string, exchangeRatesStr string, voter sdk.ValAddress) AggregateVoteHash

GetAggregateVoteHash computes hash value of ExchangeRateVote to avoid redundant DecCoins stringify operation, use string argument

func (AggregateVoteHash) Bytes

func (h AggregateVoteHash) Bytes() []byte

Bytes returns the raw address bytes.

func (AggregateVoteHash) Empty

func (h AggregateVoteHash) Empty() bool

Empty check the name hash has zero length

func (AggregateVoteHash) Equal

Equal does bytes equal check

func (AggregateVoteHash) Format

func (h AggregateVoteHash) Format(s fmt.State, verb rune)

Format implements the fmt.Formatter interface.

func (AggregateVoteHash) Marshal

func (h AggregateVoteHash) Marshal() ([]byte, error)

Marshal returns the raw address bytes. It is needed for protobuf compatibility.

func (AggregateVoteHash) MarshalJSON

func (h AggregateVoteHash) MarshalJSON() ([]byte, error)

MarshalJSON marshals to JSON using Bech32.

func (AggregateVoteHash) MarshalYAML

func (h AggregateVoteHash) MarshalYAML() (interface{}, error)

MarshalYAML marshals to YAML using Bech32.

func (AggregateVoteHash) Size

func (h AggregateVoteHash) Size() int

Size returns the raw address bytes.

func (AggregateVoteHash) String

func (h AggregateVoteHash) String() string

String implements fmt.Stringer interface

func (*AggregateVoteHash) Unmarshal

func (h *AggregateVoteHash) Unmarshal(data []byte) error

Unmarshal sets the address to the given data. It is needed for protobuf compatibility.

func (*AggregateVoteHash) UnmarshalJSON

func (h *AggregateVoteHash) UnmarshalJSON(data []byte) error

UnmarshalJSON unmarshals from JSON assuming Bech32 encoding.

type BankKeeper

type BankKeeper interface {
	GetBalance(ctx sdk.Context, addr sdk.AccAddress, denom string) sdk.Coin
	GetAllBalances(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
	SendCoinsFromModuleToModule(ctx sdk.Context, senderModule string, recipientModule string, amt sdk.Coins) error
	GetDenomMetaData(ctx sdk.Context, denom string) (banktypes.Metadata, bool)
	SetDenomMetaData(ctx sdk.Context, denomMetaData banktypes.Metadata)

	// only used for simulation
	SpendableCoins(ctx sdk.Context, addr sdk.AccAddress) sdk.Coins
}

BankKeeper defines the expected interface contract defined by the x/bank module.

type Claim

type Claim struct {
	Power     int64
	Weight    int64
	WinCount  int64
	Recipient sdk.ValAddress
}

Claim is an interface that directs its rewards to an attached bank account.

func NewClaim

func NewClaim(power, weight, winCount int64, recipient sdk.ValAddress) Claim

NewClaim generates a Claim instance.

type Denom

type Denom struct {
	Name     string                                 `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty" yaml:"name"`
	TobinTax github_com_cosmos_cosmos_sdk_types.Dec `` /* 142-byte string literal not displayed */
}

Denom - the object to hold configurations of each denom

func (*Denom) Descriptor

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

func (Denom) Equal

func (d Denom) Equal(d1 *Denom) bool

Equal implements equal interface

func (*Denom) Marshal

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

func (*Denom) MarshalTo

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

func (*Denom) MarshalToSizedBuffer

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

func (*Denom) ProtoMessage

func (*Denom) ProtoMessage()

func (*Denom) Reset

func (m *Denom) Reset()

func (*Denom) Size

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

func (Denom) String

func (d Denom) String() string

String implements fmt.Stringer interface

func (*Denom) Unmarshal

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

func (*Denom) XXX_DiscardUnknown

func (m *Denom) XXX_DiscardUnknown()

func (*Denom) XXX_Marshal

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

func (*Denom) XXX_Merge

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

func (*Denom) XXX_Size

func (m *Denom) XXX_Size() int

func (*Denom) XXX_Unmarshal

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

type DenomList

type DenomList []Denom

DenomList is array of Denom

func (DenomList) String

func (dl DenomList) String() (out string)

String implements fmt.Stringer interface

type DistributionKeeper

type DistributionKeeper interface {
	AllocateTokensToValidator(ctx sdk.Context, val stakingtypes.ValidatorI, tokens sdk.DecCoins)
	GetValidatorOutstandingRewardsCoins(ctx sdk.Context, val sdk.ValAddress) sdk.DecCoins
}

DistributionKeeper defines the expected interface contract defined by the x/distribution module.

type DummyStakingKeeper

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

DummyStakingKeeper dummy staking keeper to test ballot

func GenerateRandomTestCase

func GenerateRandomTestCase() (rates []float64, valValAddrs []sdk.ValAddress, stakingKeeper DummyStakingKeeper)

GenerateRandomTestCase nolint

func NewDummyStakingKeeper

func NewDummyStakingKeeper(validators []MockValidator) DummyStakingKeeper

NewDummyStakingKeeper returns new DummyStakingKeeper instance

func (DummyStakingKeeper) GetLastValidatorPower

func (sk DummyStakingKeeper) GetLastValidatorPower(ctx sdk.Context, operator sdk.ValAddress) (power int64)

GetLastValidatorPower nolint

func (DummyStakingKeeper) Jail

Jail nolint

func (DummyStakingKeeper) MaxValidators

func (DummyStakingKeeper) MaxValidators(sdk.Context) uint32

MaxValidators returns the maximum amount of bonded validators

func (DummyStakingKeeper) PowerReduction

func (DummyStakingKeeper) PowerReduction(ctx sdk.Context) (res sdk.Int)

PowerReduction - is the amount of staking tokens required for 1 unit of consensus-engine power

func (DummyStakingKeeper) Slash

Slash nolint

func (DummyStakingKeeper) TotalBondedTokens

func (DummyStakingKeeper) TotalBondedTokens(_ sdk.Context) sdk.Int

TotalBondedTokens nolint

func (DummyStakingKeeper) Validator

func (sk DummyStakingKeeper) Validator(ctx sdk.Context, address sdk.ValAddress) stakingtypes.ValidatorI

Validator nolint

func (DummyStakingKeeper) Validators

func (sk DummyStakingKeeper) Validators() []MockValidator

Validators nolint

func (DummyStakingKeeper) ValidatorsPowerStoreIterator

func (DummyStakingKeeper) ValidatorsPowerStoreIterator(ctx sdk.Context) sdk.Iterator

ValidatorsPowerStoreIterator nolint

type ExchangeRateBallot

type ExchangeRateBallot []VoteForTally

ExchangeRateBallot is a convenience wrapper around a ExchangeRateVote slice.

func (ExchangeRateBallot) Len

func (pb ExchangeRateBallot) Len() int

Len implements sort.Interface

func (ExchangeRateBallot) Less

func (pb ExchangeRateBallot) Less(i, j int) bool

Less reports whether the element with index i should sort before the element with index j.

func (ExchangeRateBallot) Power

func (pb ExchangeRateBallot) Power() int64

Power returns the total amount of voting power in the ballot.

func (ExchangeRateBallot) StandardDeviation

func (pb ExchangeRateBallot) StandardDeviation() (standardDeviation sdk.Dec, err error)

StandardDeviation returns the standard deviation by the power of the ExchangeRateVote.

func (ExchangeRateBallot) Swap

func (pb ExchangeRateBallot) Swap(i, j int)

Swap implements sort.Interface.

func (ExchangeRateBallot) ToCrossRate

func (pb ExchangeRateBallot) ToCrossRate(bases map[string]sdk.Dec) (cb ExchangeRateBallot)

ToCrossRate return cross_rate(base/exchange_rate) ballot.

func (ExchangeRateBallot) ToMap

func (pb ExchangeRateBallot) ToMap() map[string]sdk.Dec

ToMap return organized exchange rate map by validator.

func (ExchangeRateBallot) WeightedMedian

func (pb ExchangeRateBallot) WeightedMedian() sdk.Dec

WeightedMedian returns the median weighted by the power of the ExchangeRateVote. CONTRACT: The ballot must be sorted.

type ExchangeRatePrevote

type ExchangeRatePrevote struct {
	Hash        VoteHash       `json:"hash"`  // Vote hex hash to protect centralize data source problem
	Denom       string         `json:"denom"` // Ticker name of target fiat currency
	Voter       sdk.ValAddress `json:"voter"` // Voter val address
	SubmitBlock int64          `json:"submit_block"`
}

ExchangeRatePrevote defines a structure to store a validator's prevote on the rate of USD in the denom asset.

type ExchangeRateTuple

type ExchangeRateTuple struct {
	Denom        string                                 `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty" yaml:"denom"`
	ExchangeRate github_com_cosmos_cosmos_sdk_types.Dec `` /* 158-byte string literal not displayed */
}

ExchangeRateTuple - struct to store interpreted exchange rates data to store

func NewExchangeRateTuple

func NewExchangeRateTuple(denom string, exchangeRate sdk.Dec) ExchangeRateTuple

NewExchangeRateTuple creates a ExchangeRateTuple instance

func (*ExchangeRateTuple) Descriptor

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

func (*ExchangeRateTuple) Marshal

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

func (*ExchangeRateTuple) MarshalTo

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

func (*ExchangeRateTuple) MarshalToSizedBuffer

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

func (*ExchangeRateTuple) ProtoMessage

func (*ExchangeRateTuple) ProtoMessage()

func (*ExchangeRateTuple) Reset

func (m *ExchangeRateTuple) Reset()

func (*ExchangeRateTuple) Size

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

func (ExchangeRateTuple) String

func (v ExchangeRateTuple) String() string

String implement stringify

func (*ExchangeRateTuple) Unmarshal

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

func (*ExchangeRateTuple) XXX_DiscardUnknown

func (m *ExchangeRateTuple) XXX_DiscardUnknown()

func (*ExchangeRateTuple) XXX_Marshal

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

func (*ExchangeRateTuple) XXX_Merge

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

func (*ExchangeRateTuple) XXX_Size

func (m *ExchangeRateTuple) XXX_Size() int

func (*ExchangeRateTuple) XXX_Unmarshal

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

type ExchangeRateTuples

type ExchangeRateTuples []ExchangeRateTuple

ExchangeRateTuples - array of ExchangeRateTuple

func ParseExchangeRateTuples

func ParseExchangeRateTuples(tuplesStr string) (ExchangeRateTuples, error)

ParseExchangeRateTuples ExchangeRateTuple parser

func (ExchangeRateTuples) String

func (tuples ExchangeRateTuples) String() string

String implements fmt.Stringer interface

type ExchangeRateVote

type ExchangeRateVote struct {
	ExchangeRate sdk.Dec        `json:"exchange_rate"` // ExchangeRate of Luna in target fiat currency
	Denom        string         `json:"denom"`         // Ticker name of target fiat currency
	Voter        sdk.ValAddress `json:"voter"`         // voter val address of validator
}

ExchangeRateVote defines a structure to store a validator's vote on the rate of USD in the denom asset.

type FeederDelegation

type FeederDelegation struct {
	FeederAddress    string `protobuf:"bytes,1,opt,name=feeder_address,json=feederAddress,proto3" json:"feeder_address,omitempty"`
	ValidatorAddress string `protobuf:"bytes,2,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
}

FeederDelegation is the address for where oracle feeder authority are delegated to. By default this struct is only used at genesis to feed in default feeder addresses.

func (*FeederDelegation) Descriptor

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

func (*FeederDelegation) GetFeederAddress

func (m *FeederDelegation) GetFeederAddress() string

func (*FeederDelegation) GetValidatorAddress

func (m *FeederDelegation) GetValidatorAddress() string

func (*FeederDelegation) Marshal

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

func (*FeederDelegation) MarshalTo

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

func (*FeederDelegation) MarshalToSizedBuffer

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

func (*FeederDelegation) ProtoMessage

func (*FeederDelegation) ProtoMessage()

func (*FeederDelegation) Reset

func (m *FeederDelegation) Reset()

func (*FeederDelegation) Size

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

func (*FeederDelegation) String

func (m *FeederDelegation) String() string

func (*FeederDelegation) Unmarshal

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

func (*FeederDelegation) XXX_DiscardUnknown

func (m *FeederDelegation) XXX_DiscardUnknown()

func (*FeederDelegation) XXX_Marshal

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

func (*FeederDelegation) XXX_Merge

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

func (*FeederDelegation) XXX_Size

func (m *FeederDelegation) XXX_Size() int

func (*FeederDelegation) XXX_Unmarshal

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

type GenesisState

type GenesisState struct {
	Params                        Params                         `protobuf:"bytes,1,opt,name=params,proto3" json:"params"`
	FeederDelegations             []FeederDelegation             `protobuf:"bytes,2,rep,name=feeder_delegations,json=feederDelegations,proto3" json:"feeder_delegations"`
	ExchangeRates                 ExchangeRateTuples             `protobuf:"bytes,3,rep,name=exchange_rates,json=exchangeRates,proto3,castrepeated=ExchangeRateTuples" json:"exchange_rates"`
	MissCounters                  []MissCounter                  `protobuf:"bytes,4,rep,name=miss_counters,json=missCounters,proto3" json:"miss_counters"`
	AggregateExchangeRatePrevotes []AggregateExchangeRatePrevote `` /* 142-byte string literal not displayed */
	AggregateExchangeRateVotes    []AggregateExchangeRateVote    `` /* 133-byte string literal not displayed */
	TobinTaxes                    []TobinTax                     `protobuf:"bytes,7,rep,name=tobin_taxes,json=tobinTaxes,proto3" json:"tobin_taxes"`
}

GenesisState defines the oracle module's genesis state.

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

DefaultGenesisState returns the default genesesis state for the x/oracle module.

func GetGenesisStateFromAppState

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

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

func NewGenesisState

func NewGenesisState(
	params Params,
	rates []ExchangeRateTuple,
	feederDelegations []FeederDelegation,
	missCounters []MissCounter,
	aggregateExchangeRatePrevotes []AggregateExchangeRatePrevote,
	aggregateExchangeRateVotes []AggregateExchangeRateVote,
	tobinTaxes []TobinTax,
) *GenesisState

NewGenesisState creates a new GenesisState object

func (*GenesisState) Descriptor

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

func (*GenesisState) GetAggregateExchangeRatePrevotes

func (m *GenesisState) GetAggregateExchangeRatePrevotes() []AggregateExchangeRatePrevote

func (*GenesisState) GetAggregateExchangeRateVotes

func (m *GenesisState) GetAggregateExchangeRateVotes() []AggregateExchangeRateVote

func (*GenesisState) GetExchangeRates

func (m *GenesisState) GetExchangeRates() ExchangeRateTuples

func (*GenesisState) GetFeederDelegations

func (m *GenesisState) GetFeederDelegations() []FeederDelegation

func (*GenesisState) GetMissCounters

func (m *GenesisState) GetMissCounters() []MissCounter

func (*GenesisState) GetParams

func (m *GenesisState) GetParams() Params

func (*GenesisState) GetTobinTaxes

func (m *GenesisState) GetTobinTaxes() []TobinTax

func (*GenesisState) Marshal

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

func (*GenesisState) MarshalTo

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

func (*GenesisState) MarshalToSizedBuffer

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

func (*GenesisState) ProtoMessage

func (*GenesisState) ProtoMessage()

func (*GenesisState) Reset

func (m *GenesisState) Reset()

func (*GenesisState) Size

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

func (*GenesisState) String

func (m *GenesisState) String() string

func (*GenesisState) Unmarshal

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

func (*GenesisState) XXX_DiscardUnknown

func (m *GenesisState) XXX_DiscardUnknown()

func (*GenesisState) XXX_Marshal

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

func (*GenesisState) XXX_Merge

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

func (*GenesisState) XXX_Size

func (m *GenesisState) XXX_Size() int

func (*GenesisState) XXX_Unmarshal

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

type MissCounter

type MissCounter struct {
	ValidatorAddress string `protobuf:"bytes,1,opt,name=validator_address,json=validatorAddress,proto3" json:"validator_address,omitempty"`
	MissCounter      uint64 `protobuf:"varint,2,opt,name=miss_counter,json=missCounter,proto3" json:"miss_counter,omitempty"`
}

MissCounter defines an miss counter and validator address pair used in oracle module's genesis state

func (*MissCounter) Descriptor

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

func (*MissCounter) GetMissCounter

func (m *MissCounter) GetMissCounter() uint64

func (*MissCounter) GetValidatorAddress

func (m *MissCounter) GetValidatorAddress() string

func (*MissCounter) Marshal

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

func (*MissCounter) MarshalTo

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

func (*MissCounter) MarshalToSizedBuffer

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

func (*MissCounter) ProtoMessage

func (*MissCounter) ProtoMessage()

func (*MissCounter) Reset

func (m *MissCounter) Reset()

func (*MissCounter) Size

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

func (*MissCounter) String

func (m *MissCounter) String() string

func (*MissCounter) Unmarshal

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

func (*MissCounter) XXX_DiscardUnknown

func (m *MissCounter) XXX_DiscardUnknown()

func (*MissCounter) XXX_Marshal

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

func (*MissCounter) XXX_Merge

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

func (*MissCounter) XXX_Size

func (m *MissCounter) XXX_Size() int

func (*MissCounter) XXX_Unmarshal

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

type MockValidator

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

MockValidator nolint

func NewMockValidator

func NewMockValidator(valAddr sdk.ValAddress, power int64) MockValidator

func (MockValidator) ConsPubKey

func (MockValidator) ConsPubKey() (cryptotypes.PubKey, error)

func (MockValidator) GetBondedTokens

func (v MockValidator) GetBondedTokens() sdk.Int

func (MockValidator) GetCommission

func (v MockValidator) GetCommission() sdk.Dec

func (MockValidator) GetConsAddr

func (MockValidator) GetConsAddr() (sdk.ConsAddress, error)

func (MockValidator) GetConsensusPower

func (v MockValidator) GetConsensusPower(powerReduction sdk.Int) int64

func (MockValidator) GetDelegatorShares

func (v MockValidator) GetDelegatorShares() sdk.Dec

func (MockValidator) GetMinSelfDelegation

func (v MockValidator) GetMinSelfDelegation() sdk.Int

func (MockValidator) GetMoniker

func (MockValidator) GetMoniker() string

func (MockValidator) GetOperator

func (v MockValidator) GetOperator() sdk.ValAddress

func (MockValidator) GetStatus

func (MockValidator) GetTokens

func (v MockValidator) GetTokens() sdk.Int

func (MockValidator) IsBonded

func (MockValidator) IsBonded() bool

func (MockValidator) IsJailed

func (MockValidator) IsJailed() bool

func (MockValidator) IsUnbonded

func (MockValidator) IsUnbonded() bool

func (MockValidator) IsUnbonding

func (MockValidator) IsUnbonding() bool

func (*MockValidator) SetConsensusPower

func (v *MockValidator) SetConsensusPower(power int64)

func (MockValidator) SharesFromTokens

func (v MockValidator) SharesFromTokens(amt sdk.Int) (sdk.Dec, error)

func (MockValidator) SharesFromTokensTruncated

func (v MockValidator) SharesFromTokensTruncated(amt sdk.Int) (sdk.Dec, error)

func (MockValidator) TmConsPublicKey

func (MockValidator) TmConsPublicKey() (tmprotocrypto.PublicKey, error)

func (MockValidator) TokensFromShares

func (v MockValidator) TokensFromShares(sdk.Dec) sdk.Dec

func (MockValidator) TokensFromSharesRoundUp

func (v MockValidator) TokensFromSharesRoundUp(sdk.Dec) sdk.Dec

func (MockValidator) TokensFromSharesTruncated

func (v MockValidator) TokensFromSharesTruncated(sdk.Dec) sdk.Dec

type MsgAggregateExchangeRatePrevote

type MsgAggregateExchangeRatePrevote struct {
	Hash      string `protobuf:"bytes,1,opt,name=hash,proto3" json:"hash,omitempty" yaml:"hash"`
	Feeder    string `protobuf:"bytes,2,opt,name=feeder,proto3" json:"feeder,omitempty" yaml:"feeder"`
	Validator string `protobuf:"bytes,3,opt,name=validator,proto3" json:"validator,omitempty" yaml:"validator"`
}

MsgAggregateExchangeRatePrevote represents a message to submit an aggregate exchange rate prevote.

func NewMsgAggregateExchangeRatePrevote

func NewMsgAggregateExchangeRatePrevote(
	hash AggregateVoteHash,
	feeder sdk.AccAddress,
	validator sdk.ValAddress,
) *MsgAggregateExchangeRatePrevote

func (*MsgAggregateExchangeRatePrevote) Descriptor

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

func (MsgAggregateExchangeRatePrevote) GetSignBytes

func (msg MsgAggregateExchangeRatePrevote) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgAggregateExchangeRatePrevote) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgAggregateExchangeRatePrevote) Marshal

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

func (*MsgAggregateExchangeRatePrevote) MarshalTo

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

func (*MsgAggregateExchangeRatePrevote) MarshalToSizedBuffer

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

func (*MsgAggregateExchangeRatePrevote) ProtoMessage

func (*MsgAggregateExchangeRatePrevote) ProtoMessage()

func (*MsgAggregateExchangeRatePrevote) Reset

func (MsgAggregateExchangeRatePrevote) Route

Route implements sdk.Msg

func (*MsgAggregateExchangeRatePrevote) Size

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

func (*MsgAggregateExchangeRatePrevote) String

func (MsgAggregateExchangeRatePrevote) Type

Type implements sdk.Msg

func (*MsgAggregateExchangeRatePrevote) Unmarshal

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

func (MsgAggregateExchangeRatePrevote) ValidateBasic

func (msg MsgAggregateExchangeRatePrevote) ValidateBasic() error

ValidateBasic Implements sdk.Msg

func (*MsgAggregateExchangeRatePrevote) XXX_DiscardUnknown

func (m *MsgAggregateExchangeRatePrevote) XXX_DiscardUnknown()

func (*MsgAggregateExchangeRatePrevote) XXX_Marshal

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

func (*MsgAggregateExchangeRatePrevote) XXX_Merge

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

func (*MsgAggregateExchangeRatePrevote) XXX_Size

func (m *MsgAggregateExchangeRatePrevote) XXX_Size() int

func (*MsgAggregateExchangeRatePrevote) XXX_Unmarshal

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

type MsgAggregateExchangeRatePrevoteResponse

type MsgAggregateExchangeRatePrevoteResponse struct {
}

MsgAggregateExchangeRatePrevoteResponse defines the Msg/AggregateExchangeRatePrevote response type.

func (*MsgAggregateExchangeRatePrevoteResponse) Descriptor

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

func (*MsgAggregateExchangeRatePrevoteResponse) Marshal

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

func (*MsgAggregateExchangeRatePrevoteResponse) MarshalTo

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

func (*MsgAggregateExchangeRatePrevoteResponse) MarshalToSizedBuffer

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

func (*MsgAggregateExchangeRatePrevoteResponse) ProtoMessage

func (*MsgAggregateExchangeRatePrevoteResponse) Reset

func (*MsgAggregateExchangeRatePrevoteResponse) Size

func (*MsgAggregateExchangeRatePrevoteResponse) String

func (*MsgAggregateExchangeRatePrevoteResponse) Unmarshal

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

func (*MsgAggregateExchangeRatePrevoteResponse) XXX_DiscardUnknown

func (m *MsgAggregateExchangeRatePrevoteResponse) XXX_DiscardUnknown()

func (*MsgAggregateExchangeRatePrevoteResponse) XXX_Marshal

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

func (*MsgAggregateExchangeRatePrevoteResponse) XXX_Merge

func (*MsgAggregateExchangeRatePrevoteResponse) XXX_Size

func (*MsgAggregateExchangeRatePrevoteResponse) XXX_Unmarshal

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

type MsgAggregateExchangeRateVote

type MsgAggregateExchangeRateVote struct {
	Salt          string `protobuf:"bytes,1,opt,name=salt,proto3" json:"salt,omitempty" yaml:"salt"`
	ExchangeRates string `protobuf:"bytes,2,opt,name=exchange_rates,json=exchangeRates,proto3" json:"exchange_rates,omitempty" yaml:"exchange_rates"`
	Feeder        string `protobuf:"bytes,3,opt,name=feeder,proto3" json:"feeder,omitempty" yaml:"feeder"`
	Validator     string `protobuf:"bytes,4,opt,name=validator,proto3" json:"validator,omitempty" yaml:"validator"`
}

MsgAggregateExchangeRateVote represents a message to submit anaggregate exchange rate vote.

func NewMsgAggregateExchangeRateVote

func NewMsgAggregateExchangeRateVote(
	salt string,
	exchangeRates string,
	feeder sdk.AccAddress,
	validator sdk.ValAddress,
) *MsgAggregateExchangeRateVote

func (*MsgAggregateExchangeRateVote) Descriptor

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

func (MsgAggregateExchangeRateVote) GetSignBytes

func (msg MsgAggregateExchangeRateVote) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgAggregateExchangeRateVote) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgAggregateExchangeRateVote) Marshal

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

func (*MsgAggregateExchangeRateVote) MarshalTo

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

func (*MsgAggregateExchangeRateVote) MarshalToSizedBuffer

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

func (*MsgAggregateExchangeRateVote) ProtoMessage

func (*MsgAggregateExchangeRateVote) ProtoMessage()

func (*MsgAggregateExchangeRateVote) Reset

func (m *MsgAggregateExchangeRateVote) Reset()

func (MsgAggregateExchangeRateVote) Route

Route implements sdk.Msg

func (*MsgAggregateExchangeRateVote) Size

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

func (*MsgAggregateExchangeRateVote) String

func (MsgAggregateExchangeRateVote) Type

Type implements sdk.Msg

func (*MsgAggregateExchangeRateVote) Unmarshal

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

func (MsgAggregateExchangeRateVote) ValidateBasic

func (msg MsgAggregateExchangeRateVote) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgAggregateExchangeRateVote) XXX_DiscardUnknown

func (m *MsgAggregateExchangeRateVote) XXX_DiscardUnknown()

func (*MsgAggregateExchangeRateVote) XXX_Marshal

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

func (*MsgAggregateExchangeRateVote) XXX_Merge

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

func (*MsgAggregateExchangeRateVote) XXX_Size

func (m *MsgAggregateExchangeRateVote) XXX_Size() int

func (*MsgAggregateExchangeRateVote) XXX_Unmarshal

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

type MsgAggregateExchangeRateVoteResponse

type MsgAggregateExchangeRateVoteResponse struct {
}

MsgAggregateExchangeRateVoteResponse defines the Msg/AggregateExchangeRateVote response type.

func (*MsgAggregateExchangeRateVoteResponse) Descriptor

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

func (*MsgAggregateExchangeRateVoteResponse) Marshal

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

func (*MsgAggregateExchangeRateVoteResponse) MarshalTo

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

func (*MsgAggregateExchangeRateVoteResponse) MarshalToSizedBuffer

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

func (*MsgAggregateExchangeRateVoteResponse) ProtoMessage

func (*MsgAggregateExchangeRateVoteResponse) ProtoMessage()

func (*MsgAggregateExchangeRateVoteResponse) Reset

func (*MsgAggregateExchangeRateVoteResponse) Size

func (*MsgAggregateExchangeRateVoteResponse) String

func (*MsgAggregateExchangeRateVoteResponse) Unmarshal

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

func (*MsgAggregateExchangeRateVoteResponse) XXX_DiscardUnknown

func (m *MsgAggregateExchangeRateVoteResponse) XXX_DiscardUnknown()

func (*MsgAggregateExchangeRateVoteResponse) XXX_Marshal

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

func (*MsgAggregateExchangeRateVoteResponse) XXX_Merge

func (*MsgAggregateExchangeRateVoteResponse) XXX_Size

func (*MsgAggregateExchangeRateVoteResponse) XXX_Unmarshal

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

type MsgClient

type MsgClient interface {
	// AggregateExchangeRatePrevote defines a method for submitting an aggregate
	// exchange rate prevote.
	AggregateExchangeRatePrevote(ctx context.Context, in *MsgAggregateExchangeRatePrevote, opts ...grpc.CallOption) (*MsgAggregateExchangeRatePrevoteResponse, error)
	// AggregateExchangeRateVote defines a method for submitting an aggregate
	// exchange rate vote.
	AggregateExchangeRateVote(ctx context.Context, in *MsgAggregateExchangeRateVote, opts ...grpc.CallOption) (*MsgAggregateExchangeRateVoteResponse, error)
	// DelegateFeedConsent defines a method for setting the feeder delegation.
	DelegateFeedConsent(ctx context.Context, in *MsgDelegateFeedConsent, opts ...grpc.CallOption) (*MsgDelegateFeedConsentResponse, error)
}

MsgClient is the client API for Msg service.

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

func NewMsgClient

func NewMsgClient(cc grpc1.ClientConn) MsgClient

type MsgDelegateFeedConsent

type MsgDelegateFeedConsent struct {
	Operator string `protobuf:"bytes,1,opt,name=operator,proto3" json:"operator,omitempty" yaml:"operator"`
	Delegate string `protobuf:"bytes,2,opt,name=delegate,proto3" json:"delegate,omitempty" yaml:"delegate"`
}

MsgDelegateFeedConsent represents a message to delegate oracle voting rights to another address.

func NewMsgDelegateFeedConsent

func NewMsgDelegateFeedConsent(operatorAddress sdk.ValAddress, feederAddress sdk.AccAddress) *MsgDelegateFeedConsent

NewMsgDelegateFeedConsent creates a MsgDelegateFeedConsent instance

func (*MsgDelegateFeedConsent) Descriptor

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

func (MsgDelegateFeedConsent) GetSignBytes

func (msg MsgDelegateFeedConsent) GetSignBytes() []byte

GetSignBytes implements sdk.Msg

func (MsgDelegateFeedConsent) GetSigners

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

GetSigners implements sdk.Msg

func (*MsgDelegateFeedConsent) Marshal

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

func (*MsgDelegateFeedConsent) MarshalTo

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

func (*MsgDelegateFeedConsent) MarshalToSizedBuffer

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

func (*MsgDelegateFeedConsent) ProtoMessage

func (*MsgDelegateFeedConsent) ProtoMessage()

func (*MsgDelegateFeedConsent) Reset

func (m *MsgDelegateFeedConsent) Reset()

func (MsgDelegateFeedConsent) Route

func (msg MsgDelegateFeedConsent) Route() string

Route implements sdk.Msg

func (*MsgDelegateFeedConsent) Size

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

func (*MsgDelegateFeedConsent) String

func (m *MsgDelegateFeedConsent) String() string

func (MsgDelegateFeedConsent) Type

func (msg MsgDelegateFeedConsent) Type() string

Type implements sdk.Msg

func (*MsgDelegateFeedConsent) Unmarshal

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

func (MsgDelegateFeedConsent) ValidateBasic

func (msg MsgDelegateFeedConsent) ValidateBasic() error

ValidateBasic implements sdk.Msg

func (*MsgDelegateFeedConsent) XXX_DiscardUnknown

func (m *MsgDelegateFeedConsent) XXX_DiscardUnknown()

func (*MsgDelegateFeedConsent) XXX_Marshal

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

func (*MsgDelegateFeedConsent) XXX_Merge

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

func (*MsgDelegateFeedConsent) XXX_Size

func (m *MsgDelegateFeedConsent) XXX_Size() int

func (*MsgDelegateFeedConsent) XXX_Unmarshal

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

type MsgDelegateFeedConsentResponse

type MsgDelegateFeedConsentResponse struct {
}

MsgDelegateFeedConsentResponse defines the Msg/DelegateFeedConsent response type.

func (*MsgDelegateFeedConsentResponse) Descriptor

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

func (*MsgDelegateFeedConsentResponse) Marshal

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

func (*MsgDelegateFeedConsentResponse) MarshalTo

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

func (*MsgDelegateFeedConsentResponse) MarshalToSizedBuffer

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

func (*MsgDelegateFeedConsentResponse) ProtoMessage

func (*MsgDelegateFeedConsentResponse) ProtoMessage()

func (*MsgDelegateFeedConsentResponse) Reset

func (m *MsgDelegateFeedConsentResponse) Reset()

func (*MsgDelegateFeedConsentResponse) Size

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

func (*MsgDelegateFeedConsentResponse) String

func (*MsgDelegateFeedConsentResponse) Unmarshal

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

func (*MsgDelegateFeedConsentResponse) XXX_DiscardUnknown

func (m *MsgDelegateFeedConsentResponse) XXX_DiscardUnknown()

func (*MsgDelegateFeedConsentResponse) XXX_Marshal

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

func (*MsgDelegateFeedConsentResponse) XXX_Merge

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

func (*MsgDelegateFeedConsentResponse) XXX_Size

func (m *MsgDelegateFeedConsentResponse) XXX_Size() int

func (*MsgDelegateFeedConsentResponse) XXX_Unmarshal

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

type MsgServer

type MsgServer interface {
	// AggregateExchangeRatePrevote defines a method for submitting an aggregate
	// exchange rate prevote.
	AggregateExchangeRatePrevote(context.Context, *MsgAggregateExchangeRatePrevote) (*MsgAggregateExchangeRatePrevoteResponse, error)
	// AggregateExchangeRateVote defines a method for submitting an aggregate
	// exchange rate vote.
	AggregateExchangeRateVote(context.Context, *MsgAggregateExchangeRateVote) (*MsgAggregateExchangeRateVoteResponse, error)
	// DelegateFeedConsent defines a method for setting the feeder delegation.
	DelegateFeedConsent(context.Context, *MsgDelegateFeedConsent) (*MsgDelegateFeedConsentResponse, error)
}

MsgServer is the server API for Msg service.

type Params

type Params struct {
	VotePeriod               uint64                                 `protobuf:"varint,1,opt,name=vote_period,json=votePeriod,proto3" json:"vote_period,omitempty" yaml:"vote_period"`
	VoteThreshold            github_com_cosmos_cosmos_sdk_types.Dec `` /* 162-byte string literal not displayed */
	RewardBand               github_com_cosmos_cosmos_sdk_types.Dec `` /* 150-byte string literal not displayed */
	RewardDistributionWindow uint64                                 `` /* 170-byte string literal not displayed */
	Whitelist                DenomList                              `protobuf:"bytes,5,rep,name=whitelist,proto3,castrepeated=DenomList" json:"whitelist" yaml:"whitelist"`
	SlashFraction            github_com_cosmos_cosmos_sdk_types.Dec `` /* 162-byte string literal not displayed */
	SlashWindow              uint64                                 `protobuf:"varint,7,opt,name=slash_window,json=slashWindow,proto3" json:"slash_window,omitempty" yaml:"slash_window"`
	MinValidPerWindow        github_com_cosmos_cosmos_sdk_types.Dec `` /* 184-byte string literal not displayed */
}

Params defines the parameters for the oracle module.

func DefaultParams

func DefaultParams() Params

DefaultParams creates default oracle module parameters

func (*Params) Descriptor

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

func (*Params) Equal

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

func (*Params) GetRewardDistributionWindow

func (m *Params) GetRewardDistributionWindow() uint64

func (*Params) GetSlashWindow

func (m *Params) GetSlashWindow() uint64

func (*Params) GetVotePeriod

func (m *Params) GetVotePeriod() uint64

func (*Params) GetWhitelist

func (m *Params) GetWhitelist() DenomList

func (*Params) Marshal

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

func (*Params) MarshalTo

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

func (*Params) MarshalToSizedBuffer

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

func (*Params) ParamSetPairs

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

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

func (*Params) ProtoMessage

func (*Params) ProtoMessage()

func (*Params) Reset

func (m *Params) Reset()

func (*Params) Size

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

func (Params) String

func (p Params) String() string

String implements fmt.Stringer interface

func (*Params) Unmarshal

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

func (Params) Validate

func (p Params) Validate() error

Validate performs basic validation on oracle parameters.

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 QueryActivesRequest

type QueryActivesRequest struct {
}

QueryActivesRequest is the request type for the Query/Actives RPC method.

func (*QueryActivesRequest) Descriptor

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

func (*QueryActivesRequest) Marshal

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

func (*QueryActivesRequest) MarshalTo

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

func (*QueryActivesRequest) MarshalToSizedBuffer

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

func (*QueryActivesRequest) ProtoMessage

func (*QueryActivesRequest) ProtoMessage()

func (*QueryActivesRequest) Reset

func (m *QueryActivesRequest) Reset()

func (*QueryActivesRequest) Size

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

func (*QueryActivesRequest) String

func (m *QueryActivesRequest) String() string

func (*QueryActivesRequest) Unmarshal

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

func (*QueryActivesRequest) XXX_DiscardUnknown

func (m *QueryActivesRequest) XXX_DiscardUnknown()

func (*QueryActivesRequest) XXX_Marshal

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

func (*QueryActivesRequest) XXX_Merge

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

func (*QueryActivesRequest) XXX_Size

func (m *QueryActivesRequest) XXX_Size() int

func (*QueryActivesRequest) XXX_Unmarshal

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

type QueryActivesResponse

type QueryActivesResponse struct {
	// actives defines a list of the denomination which oracle prices aggreed
	// upon.
	Actives []string `protobuf:"bytes,1,rep,name=actives,proto3" json:"actives,omitempty"`
}

QueryActivesResponse is response type for the Query/Actives RPC method.

func (*QueryActivesResponse) Descriptor

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

func (*QueryActivesResponse) GetActives

func (m *QueryActivesResponse) GetActives() []string

func (*QueryActivesResponse) Marshal

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

func (*QueryActivesResponse) MarshalTo

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

func (*QueryActivesResponse) MarshalToSizedBuffer

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

func (*QueryActivesResponse) ProtoMessage

func (*QueryActivesResponse) ProtoMessage()

func (*QueryActivesResponse) Reset

func (m *QueryActivesResponse) Reset()

func (*QueryActivesResponse) Size

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

func (*QueryActivesResponse) String

func (m *QueryActivesResponse) String() string

func (*QueryActivesResponse) Unmarshal

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

func (*QueryActivesResponse) XXX_DiscardUnknown

func (m *QueryActivesResponse) XXX_DiscardUnknown()

func (*QueryActivesResponse) XXX_Marshal

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

func (*QueryActivesResponse) XXX_Merge

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

func (*QueryActivesResponse) XXX_Size

func (m *QueryActivesResponse) XXX_Size() int

func (*QueryActivesResponse) XXX_Unmarshal

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

type QueryAggregatePrevoteParams

type QueryAggregatePrevoteParams struct {
	Validator sdk.ValAddress
}

QueryAggregatePrevoteParams defines the params for the following queries: - 'custom/oracle/aggregatePrevote'

func NewQueryAggregatePrevoteParams

func NewQueryAggregatePrevoteParams(validator sdk.ValAddress) QueryAggregatePrevoteParams

NewQueryAggregatePrevoteParams returns params for feeder delegation query

type QueryAggregatePrevoteRequest

type QueryAggregatePrevoteRequest struct {
	// validator defines the validator address to query for.
	ValidatorAddr string `protobuf:"bytes,1,opt,name=validator_addr,json=validatorAddr,proto3" json:"validator_addr,omitempty"`
}

QueryAggregatePrevoteRequest is the request type for the Query/AggregatePrevote RPC method.

func (*QueryAggregatePrevoteRequest) Descriptor

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

func (*QueryAggregatePrevoteRequest) Marshal

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

func (*QueryAggregatePrevoteRequest) MarshalTo

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

func (*QueryAggregatePrevoteRequest) MarshalToSizedBuffer

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

func (*QueryAggregatePrevoteRequest) ProtoMessage

func (*QueryAggregatePrevoteRequest) ProtoMessage()

func (*QueryAggregatePrevoteRequest) Reset

func (m *QueryAggregatePrevoteRequest) Reset()

func (*QueryAggregatePrevoteRequest) Size

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

func (*QueryAggregatePrevoteRequest) String

func (*QueryAggregatePrevoteRequest) Unmarshal

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

func (*QueryAggregatePrevoteRequest) XXX_DiscardUnknown

func (m *QueryAggregatePrevoteRequest) XXX_DiscardUnknown()

func (*QueryAggregatePrevoteRequest) XXX_Marshal

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

func (*QueryAggregatePrevoteRequest) XXX_Merge

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

func (*QueryAggregatePrevoteRequest) XXX_Size

func (m *QueryAggregatePrevoteRequest) XXX_Size() int

func (*QueryAggregatePrevoteRequest) XXX_Unmarshal

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

type QueryAggregatePrevoteResponse

type QueryAggregatePrevoteResponse struct {
	// aggregate_prevote defines oracle aggregate prevote submitted by a validator
	// in the current vote period
	AggregatePrevote AggregateExchangeRatePrevote `protobuf:"bytes,1,opt,name=aggregate_prevote,json=aggregatePrevote,proto3" json:"aggregate_prevote"`
}

QueryAggregatePrevoteResponse is response type for the Query/AggregatePrevote RPC method.

func (*QueryAggregatePrevoteResponse) Descriptor

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

func (*QueryAggregatePrevoteResponse) GetAggregatePrevote

func (*QueryAggregatePrevoteResponse) Marshal

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

func (*QueryAggregatePrevoteResponse) MarshalTo

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

func (*QueryAggregatePrevoteResponse) MarshalToSizedBuffer

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

func (*QueryAggregatePrevoteResponse) ProtoMessage

func (*QueryAggregatePrevoteResponse) ProtoMessage()

func (*QueryAggregatePrevoteResponse) Reset

func (m *QueryAggregatePrevoteResponse) Reset()

func (*QueryAggregatePrevoteResponse) Size

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

func (*QueryAggregatePrevoteResponse) String

func (*QueryAggregatePrevoteResponse) Unmarshal

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

func (*QueryAggregatePrevoteResponse) XXX_DiscardUnknown

func (m *QueryAggregatePrevoteResponse) XXX_DiscardUnknown()

func (*QueryAggregatePrevoteResponse) XXX_Marshal

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

func (*QueryAggregatePrevoteResponse) XXX_Merge

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

func (*QueryAggregatePrevoteResponse) XXX_Size

func (m *QueryAggregatePrevoteResponse) XXX_Size() int

func (*QueryAggregatePrevoteResponse) XXX_Unmarshal

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

type QueryAggregatePrevotesRequest

type QueryAggregatePrevotesRequest struct {
}

QueryAggregatePrevotesRequest is the request type for the Query/AggregatePrevotes RPC method.

func (*QueryAggregatePrevotesRequest) Descriptor

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

func (*QueryAggregatePrevotesRequest) Marshal

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

func (*QueryAggregatePrevotesRequest) MarshalTo

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

func (*QueryAggregatePrevotesRequest) MarshalToSizedBuffer

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

func (*QueryAggregatePrevotesRequest) ProtoMessage

func (*QueryAggregatePrevotesRequest) ProtoMessage()

func (*QueryAggregatePrevotesRequest) Reset

func (m *QueryAggregatePrevotesRequest) Reset()

func (*QueryAggregatePrevotesRequest) Size

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

func (*QueryAggregatePrevotesRequest) String

func (*QueryAggregatePrevotesRequest) Unmarshal

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

func (*QueryAggregatePrevotesRequest) XXX_DiscardUnknown

func (m *QueryAggregatePrevotesRequest) XXX_DiscardUnknown()

func (*QueryAggregatePrevotesRequest) XXX_Marshal

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

func (*QueryAggregatePrevotesRequest) XXX_Merge

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

func (*QueryAggregatePrevotesRequest) XXX_Size

func (m *QueryAggregatePrevotesRequest) XXX_Size() int

func (*QueryAggregatePrevotesRequest) XXX_Unmarshal

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

type QueryAggregatePrevotesResponse

type QueryAggregatePrevotesResponse struct {
	// aggregate_prevotes defines all oracle aggregate prevotes submitted in the
	// current vote period
	AggregatePrevotes []AggregateExchangeRatePrevote `protobuf:"bytes,1,rep,name=aggregate_prevotes,json=aggregatePrevotes,proto3" json:"aggregate_prevotes"`
}

QueryAggregatePrevotesResponse is response type for the Query/AggregatePrevotes RPC method.

func (*QueryAggregatePrevotesResponse) Descriptor

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

func (*QueryAggregatePrevotesResponse) GetAggregatePrevotes

func (*QueryAggregatePrevotesResponse) Marshal

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

func (*QueryAggregatePrevotesResponse) MarshalTo

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

func (*QueryAggregatePrevotesResponse) MarshalToSizedBuffer

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

func (*QueryAggregatePrevotesResponse) ProtoMessage

func (*QueryAggregatePrevotesResponse) ProtoMessage()

func (*QueryAggregatePrevotesResponse) Reset

func (m *QueryAggregatePrevotesResponse) Reset()

func (*QueryAggregatePrevotesResponse) Size

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

func (*QueryAggregatePrevotesResponse) String

func (*QueryAggregatePrevotesResponse) Unmarshal

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

func (*QueryAggregatePrevotesResponse) XXX_DiscardUnknown

func (m *QueryAggregatePrevotesResponse) XXX_DiscardUnknown()

func (*QueryAggregatePrevotesResponse) XXX_Marshal

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

func (*QueryAggregatePrevotesResponse) XXX_Merge

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

func (*QueryAggregatePrevotesResponse) XXX_Size

func (m *QueryAggregatePrevotesResponse) XXX_Size() int

func (*QueryAggregatePrevotesResponse) XXX_Unmarshal

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

type QueryAggregateVoteParams

type QueryAggregateVoteParams struct {
	Validator sdk.ValAddress
}

QueryAggregateVoteParams defines the params for the following queries: - 'custom/oracle/aggregateVote'

func NewQueryAggregateVoteParams

func NewQueryAggregateVoteParams(validator sdk.ValAddress) QueryAggregateVoteParams

NewQueryAggregateVoteParams returns params for feeder delegation query

type QueryAggregateVoteRequest

type QueryAggregateVoteRequest struct {
	// validator defines the validator address to query for.
	ValidatorAddr string `protobuf:"bytes,1,opt,name=validator_addr,json=validatorAddr,proto3" json:"validator_addr,omitempty"`
}

QueryAggregateVoteRequest is the request type for the Query/AggregateVote RPC method.

func (*QueryAggregateVoteRequest) Descriptor

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

func (*QueryAggregateVoteRequest) Marshal

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

func (*QueryAggregateVoteRequest) MarshalTo

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

func (*QueryAggregateVoteRequest) MarshalToSizedBuffer

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

func (*QueryAggregateVoteRequest) ProtoMessage

func (*QueryAggregateVoteRequest) ProtoMessage()

func (*QueryAggregateVoteRequest) Reset

func (m *QueryAggregateVoteRequest) Reset()

func (*QueryAggregateVoteRequest) Size

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

func (*QueryAggregateVoteRequest) String

func (m *QueryAggregateVoteRequest) String() string

func (*QueryAggregateVoteRequest) Unmarshal

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

func (*QueryAggregateVoteRequest) XXX_DiscardUnknown

func (m *QueryAggregateVoteRequest) XXX_DiscardUnknown()

func (*QueryAggregateVoteRequest) XXX_Marshal

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

func (*QueryAggregateVoteRequest) XXX_Merge

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

func (*QueryAggregateVoteRequest) XXX_Size

func (m *QueryAggregateVoteRequest) XXX_Size() int

func (*QueryAggregateVoteRequest) XXX_Unmarshal

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

type QueryAggregateVoteResponse

type QueryAggregateVoteResponse struct {
	// aggregate_vote defines oracle aggregate vote submitted by a validator in
	// the current vote period
	AggregateVote AggregateExchangeRateVote `protobuf:"bytes,1,opt,name=aggregate_vote,json=aggregateVote,proto3" json:"aggregate_vote"`
}

QueryAggregateVoteResponse is response type for the Query/AggregateVote RPC method.

func (*QueryAggregateVoteResponse) Descriptor

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

func (*QueryAggregateVoteResponse) GetAggregateVote

func (*QueryAggregateVoteResponse) Marshal

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

func (*QueryAggregateVoteResponse) MarshalTo

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

func (*QueryAggregateVoteResponse) MarshalToSizedBuffer

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

func (*QueryAggregateVoteResponse) ProtoMessage

func (*QueryAggregateVoteResponse) ProtoMessage()

func (*QueryAggregateVoteResponse) Reset

func (m *QueryAggregateVoteResponse) Reset()

func (*QueryAggregateVoteResponse) Size

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

func (*QueryAggregateVoteResponse) String

func (m *QueryAggregateVoteResponse) String() string

func (*QueryAggregateVoteResponse) Unmarshal

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

func (*QueryAggregateVoteResponse) XXX_DiscardUnknown

func (m *QueryAggregateVoteResponse) XXX_DiscardUnknown()

func (*QueryAggregateVoteResponse) XXX_Marshal

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

func (*QueryAggregateVoteResponse) XXX_Merge

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

func (*QueryAggregateVoteResponse) XXX_Size

func (m *QueryAggregateVoteResponse) XXX_Size() int

func (*QueryAggregateVoteResponse) XXX_Unmarshal

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

type QueryAggregateVotesRequest

type QueryAggregateVotesRequest struct {
}

QueryAggregateVotesRequest is the request type for the Query/AggregateVotes RPC method.

func (*QueryAggregateVotesRequest) Descriptor

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

func (*QueryAggregateVotesRequest) Marshal

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

func (*QueryAggregateVotesRequest) MarshalTo

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

func (*QueryAggregateVotesRequest) MarshalToSizedBuffer

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

func (*QueryAggregateVotesRequest) ProtoMessage

func (*QueryAggregateVotesRequest) ProtoMessage()

func (*QueryAggregateVotesRequest) Reset

func (m *QueryAggregateVotesRequest) Reset()

func (*QueryAggregateVotesRequest) Size

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

func (*QueryAggregateVotesRequest) String

func (m *QueryAggregateVotesRequest) String() string

func (*QueryAggregateVotesRequest) Unmarshal

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

func (*QueryAggregateVotesRequest) XXX_DiscardUnknown

func (m *QueryAggregateVotesRequest) XXX_DiscardUnknown()

func (*QueryAggregateVotesRequest) XXX_Marshal

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

func (*QueryAggregateVotesRequest) XXX_Merge

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

func (*QueryAggregateVotesRequest) XXX_Size

func (m *QueryAggregateVotesRequest) XXX_Size() int

func (*QueryAggregateVotesRequest) XXX_Unmarshal

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

type QueryAggregateVotesResponse

type QueryAggregateVotesResponse struct {
	// aggregate_votes defines all oracle aggregate votes submitted in the current
	// vote period
	AggregateVotes []AggregateExchangeRateVote `protobuf:"bytes,1,rep,name=aggregate_votes,json=aggregateVotes,proto3" json:"aggregate_votes"`
}

QueryAggregateVotesResponse is response type for the Query/AggregateVotes RPC method.

func (*QueryAggregateVotesResponse) Descriptor

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

func (*QueryAggregateVotesResponse) GetAggregateVotes

func (m *QueryAggregateVotesResponse) GetAggregateVotes() []AggregateExchangeRateVote

func (*QueryAggregateVotesResponse) Marshal

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

func (*QueryAggregateVotesResponse) MarshalTo

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

func (*QueryAggregateVotesResponse) MarshalToSizedBuffer

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

func (*QueryAggregateVotesResponse) ProtoMessage

func (*QueryAggregateVotesResponse) ProtoMessage()

func (*QueryAggregateVotesResponse) Reset

func (m *QueryAggregateVotesResponse) Reset()

func (*QueryAggregateVotesResponse) Size

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

func (*QueryAggregateVotesResponse) String

func (m *QueryAggregateVotesResponse) String() string

func (*QueryAggregateVotesResponse) Unmarshal

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

func (*QueryAggregateVotesResponse) XXX_DiscardUnknown

func (m *QueryAggregateVotesResponse) XXX_DiscardUnknown()

func (*QueryAggregateVotesResponse) XXX_Marshal

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

func (*QueryAggregateVotesResponse) XXX_Merge

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

func (*QueryAggregateVotesResponse) XXX_Size

func (m *QueryAggregateVotesResponse) XXX_Size() int

func (*QueryAggregateVotesResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	// ExchangeRate returns exchange rate of a denom
	ExchangeRate(ctx context.Context, in *QueryExchangeRateRequest, opts ...grpc.CallOption) (*QueryExchangeRateResponse, error)
	// ExchangeRates returns exchange rates of all denoms
	ExchangeRates(ctx context.Context, in *QueryExchangeRatesRequest, opts ...grpc.CallOption) (*QueryExchangeRatesResponse, error)
	// TobinTax returns tobin tax of a denom
	TobinTax(ctx context.Context, in *QueryTobinTaxRequest, opts ...grpc.CallOption) (*QueryTobinTaxResponse, error)
	// TobinTaxes returns tobin taxes of all denoms
	TobinTaxes(ctx context.Context, in *QueryTobinTaxesRequest, opts ...grpc.CallOption) (*QueryTobinTaxesResponse, error)
	// Actives returns all active denoms
	Actives(ctx context.Context, in *QueryActivesRequest, opts ...grpc.CallOption) (*QueryActivesResponse, error)
	// VoteTargets returns all vote target denoms
	VoteTargets(ctx context.Context, in *QueryVoteTargetsRequest, opts ...grpc.CallOption) (*QueryVoteTargetsResponse, error)
	// FeederDelegation returns feeder delegation of a validator
	FeederDelegation(ctx context.Context, in *QueryFeederDelegationRequest, opts ...grpc.CallOption) (*QueryFeederDelegationResponse, error)
	// MissCounter returns oracle miss counter of a validator
	MissCounter(ctx context.Context, in *QueryMissCounterRequest, opts ...grpc.CallOption) (*QueryMissCounterResponse, error)
	// AggregatePrevote returns an aggregate prevote of a validator
	AggregatePrevote(ctx context.Context, in *QueryAggregatePrevoteRequest, opts ...grpc.CallOption) (*QueryAggregatePrevoteResponse, error)
	// AggregatePrevotes returns aggregate prevotes of all validators
	AggregatePrevotes(ctx context.Context, in *QueryAggregatePrevotesRequest, opts ...grpc.CallOption) (*QueryAggregatePrevotesResponse, error)
	// AggregateVote returns an aggregate vote of a validator
	AggregateVote(ctx context.Context, in *QueryAggregateVoteRequest, opts ...grpc.CallOption) (*QueryAggregateVoteResponse, error)
	// AggregateVotes returns aggregate votes of all validators
	AggregateVotes(ctx context.Context, in *QueryAggregateVotesRequest, opts ...grpc.CallOption) (*QueryAggregateVotesResponse, error)
	// Params queries all parameters.
	Params(ctx context.Context, in *QueryParamsRequest, opts ...grpc.CallOption) (*QueryParamsResponse, error)
}

QueryClient is the client API for Query service.

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

func NewQueryClient

func NewQueryClient(cc grpc1.ClientConn) QueryClient

type QueryExchangeRateParams

type QueryExchangeRateParams struct {
	Denom string
}

QueryExchangeRateParams defines the params for the following queries: - 'custom/oracle/exchange_rate'

func NewQueryExchangeRateParams

func NewQueryExchangeRateParams(denom string) QueryExchangeRateParams

NewQueryExchangeRateParams returns params for exchange_rate query

type QueryExchangeRateRequest

type QueryExchangeRateRequest struct {
	// denom defines the denomination to query for.
	Denom string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
}

QueryExchangeRateRequest is the request type for the Query/ExchangeRate RPC method.

func (*QueryExchangeRateRequest) Descriptor

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

func (*QueryExchangeRateRequest) Marshal

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

func (*QueryExchangeRateRequest) MarshalTo

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

func (*QueryExchangeRateRequest) MarshalToSizedBuffer

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

func (*QueryExchangeRateRequest) ProtoMessage

func (*QueryExchangeRateRequest) ProtoMessage()

func (*QueryExchangeRateRequest) Reset

func (m *QueryExchangeRateRequest) Reset()

func (*QueryExchangeRateRequest) Size

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

func (*QueryExchangeRateRequest) String

func (m *QueryExchangeRateRequest) String() string

func (*QueryExchangeRateRequest) Unmarshal

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

func (*QueryExchangeRateRequest) XXX_DiscardUnknown

func (m *QueryExchangeRateRequest) XXX_DiscardUnknown()

func (*QueryExchangeRateRequest) XXX_Marshal

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

func (*QueryExchangeRateRequest) XXX_Merge

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

func (*QueryExchangeRateRequest) XXX_Size

func (m *QueryExchangeRateRequest) XXX_Size() int

func (*QueryExchangeRateRequest) XXX_Unmarshal

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

type QueryExchangeRateResponse

type QueryExchangeRateResponse struct {
	// exchange_rate defines the exchange rate of USD denominated in various crypto
	ExchangeRate github_com_cosmos_cosmos_sdk_types.Dec `` /* 137-byte string literal not displayed */
}

QueryExchangeRateResponse is response type for the Query/ExchangeRate RPC method.

func (*QueryExchangeRateResponse) Descriptor

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

func (*QueryExchangeRateResponse) Marshal

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

func (*QueryExchangeRateResponse) MarshalTo

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

func (*QueryExchangeRateResponse) MarshalToSizedBuffer

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

func (*QueryExchangeRateResponse) ProtoMessage

func (*QueryExchangeRateResponse) ProtoMessage()

func (*QueryExchangeRateResponse) Reset

func (m *QueryExchangeRateResponse) Reset()

func (*QueryExchangeRateResponse) Size

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

func (*QueryExchangeRateResponse) String

func (m *QueryExchangeRateResponse) String() string

func (*QueryExchangeRateResponse) Unmarshal

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

func (*QueryExchangeRateResponse) XXX_DiscardUnknown

func (m *QueryExchangeRateResponse) XXX_DiscardUnknown()

func (*QueryExchangeRateResponse) XXX_Marshal

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

func (*QueryExchangeRateResponse) XXX_Merge

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

func (*QueryExchangeRateResponse) XXX_Size

func (m *QueryExchangeRateResponse) XXX_Size() int

func (*QueryExchangeRateResponse) XXX_Unmarshal

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

type QueryExchangeRatesRequest

type QueryExchangeRatesRequest struct {
}

QueryExchangeRatesRequest is the request type for the Query/ExchangeRates RPC method.

func (*QueryExchangeRatesRequest) Descriptor

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

func (*QueryExchangeRatesRequest) Marshal

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

func (*QueryExchangeRatesRequest) MarshalTo

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

func (*QueryExchangeRatesRequest) MarshalToSizedBuffer

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

func (*QueryExchangeRatesRequest) ProtoMessage

func (*QueryExchangeRatesRequest) ProtoMessage()

func (*QueryExchangeRatesRequest) Reset

func (m *QueryExchangeRatesRequest) Reset()

func (*QueryExchangeRatesRequest) Size

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

func (*QueryExchangeRatesRequest) String

func (m *QueryExchangeRatesRequest) String() string

func (*QueryExchangeRatesRequest) Unmarshal

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

func (*QueryExchangeRatesRequest) XXX_DiscardUnknown

func (m *QueryExchangeRatesRequest) XXX_DiscardUnknown()

func (*QueryExchangeRatesRequest) XXX_Marshal

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

func (*QueryExchangeRatesRequest) XXX_Merge

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

func (*QueryExchangeRatesRequest) XXX_Size

func (m *QueryExchangeRatesRequest) XXX_Size() int

func (*QueryExchangeRatesRequest) XXX_Unmarshal

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

type QueryExchangeRatesResponse

type QueryExchangeRatesResponse struct {
	// exchange_rates defines a list of the exchange rate for all whitelisted
	// denoms.
	ExchangeRates github_com_cosmos_cosmos_sdk_types.DecCoins `` /* 147-byte string literal not displayed */
}

QueryExchangeRatesResponse is response type for the Query/ExchangeRates RPC method.

func (*QueryExchangeRatesResponse) Descriptor

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

func (*QueryExchangeRatesResponse) GetExchangeRates

func (*QueryExchangeRatesResponse) Marshal

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

func (*QueryExchangeRatesResponse) MarshalTo

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

func (*QueryExchangeRatesResponse) MarshalToSizedBuffer

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

func (*QueryExchangeRatesResponse) ProtoMessage

func (*QueryExchangeRatesResponse) ProtoMessage()

func (*QueryExchangeRatesResponse) Reset

func (m *QueryExchangeRatesResponse) Reset()

func (*QueryExchangeRatesResponse) Size

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

func (*QueryExchangeRatesResponse) String

func (m *QueryExchangeRatesResponse) String() string

func (*QueryExchangeRatesResponse) Unmarshal

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

func (*QueryExchangeRatesResponse) XXX_DiscardUnknown

func (m *QueryExchangeRatesResponse) XXX_DiscardUnknown()

func (*QueryExchangeRatesResponse) XXX_Marshal

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

func (*QueryExchangeRatesResponse) XXX_Merge

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

func (*QueryExchangeRatesResponse) XXX_Size

func (m *QueryExchangeRatesResponse) XXX_Size() int

func (*QueryExchangeRatesResponse) XXX_Unmarshal

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

type QueryFeederDelegationParams

type QueryFeederDelegationParams struct {
	Validator sdk.ValAddress
}

QueryFeederDelegationParams defeins the params for the following queries: - 'custom/oracle/feederDelegation'

func NewQueryFeederDelegationParams

func NewQueryFeederDelegationParams(validator sdk.ValAddress) QueryFeederDelegationParams

NewQueryFeederDelegationParams returns params for feeder delegation query

type QueryFeederDelegationRequest

type QueryFeederDelegationRequest struct {
	// validator defines the validator address to query for.
	ValidatorAddr string `protobuf:"bytes,1,opt,name=validator_addr,json=validatorAddr,proto3" json:"validator_addr,omitempty"`
}

QueryFeederDelegationRequest is the request type for the Query/FeederDelegation RPC method.

func (*QueryFeederDelegationRequest) Descriptor

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

func (*QueryFeederDelegationRequest) Marshal

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

func (*QueryFeederDelegationRequest) MarshalTo

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

func (*QueryFeederDelegationRequest) MarshalToSizedBuffer

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

func (*QueryFeederDelegationRequest) ProtoMessage

func (*QueryFeederDelegationRequest) ProtoMessage()

func (*QueryFeederDelegationRequest) Reset

func (m *QueryFeederDelegationRequest) Reset()

func (*QueryFeederDelegationRequest) Size

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

func (*QueryFeederDelegationRequest) String

func (*QueryFeederDelegationRequest) Unmarshal

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

func (*QueryFeederDelegationRequest) XXX_DiscardUnknown

func (m *QueryFeederDelegationRequest) XXX_DiscardUnknown()

func (*QueryFeederDelegationRequest) XXX_Marshal

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

func (*QueryFeederDelegationRequest) XXX_Merge

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

func (*QueryFeederDelegationRequest) XXX_Size

func (m *QueryFeederDelegationRequest) XXX_Size() int

func (*QueryFeederDelegationRequest) XXX_Unmarshal

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

type QueryFeederDelegationResponse

type QueryFeederDelegationResponse struct {
	// feeder_addr defines the feeder delegation of a validator
	FeederAddr string `protobuf:"bytes,1,opt,name=feeder_addr,json=feederAddr,proto3" json:"feeder_addr,omitempty"`
}

QueryFeederDelegationResponse is response type for the Query/FeederDelegation RPC method.

func (*QueryFeederDelegationResponse) Descriptor

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

func (*QueryFeederDelegationResponse) GetFeederAddr

func (m *QueryFeederDelegationResponse) GetFeederAddr() string

func (*QueryFeederDelegationResponse) Marshal

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

func (*QueryFeederDelegationResponse) MarshalTo

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

func (*QueryFeederDelegationResponse) MarshalToSizedBuffer

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

func (*QueryFeederDelegationResponse) ProtoMessage

func (*QueryFeederDelegationResponse) ProtoMessage()

func (*QueryFeederDelegationResponse) Reset

func (m *QueryFeederDelegationResponse) Reset()

func (*QueryFeederDelegationResponse) Size

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

func (*QueryFeederDelegationResponse) String

func (*QueryFeederDelegationResponse) Unmarshal

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

func (*QueryFeederDelegationResponse) XXX_DiscardUnknown

func (m *QueryFeederDelegationResponse) XXX_DiscardUnknown()

func (*QueryFeederDelegationResponse) XXX_Marshal

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

func (*QueryFeederDelegationResponse) XXX_Merge

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

func (*QueryFeederDelegationResponse) XXX_Size

func (m *QueryFeederDelegationResponse) XXX_Size() int

func (*QueryFeederDelegationResponse) XXX_Unmarshal

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

type QueryMissCounterParams

type QueryMissCounterParams struct {
	Validator sdk.ValAddress
}

QueryMissCounterParams defines the params for the following queries: - 'custom/oracle/missCounter'

func NewQueryMissCounterParams

func NewQueryMissCounterParams(validator sdk.ValAddress) QueryMissCounterParams

NewQueryMissCounterParams returns params for feeder delegation query

type QueryMissCounterRequest

type QueryMissCounterRequest struct {
	// validator defines the validator address to query for.
	ValidatorAddr string `protobuf:"bytes,1,opt,name=validator_addr,json=validatorAddr,proto3" json:"validator_addr,omitempty"`
}

QueryMissCounterRequest is the request type for the Query/MissCounter RPC method.

func (*QueryMissCounterRequest) Descriptor

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

func (*QueryMissCounterRequest) Marshal

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

func (*QueryMissCounterRequest) MarshalTo

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

func (*QueryMissCounterRequest) MarshalToSizedBuffer

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

func (*QueryMissCounterRequest) ProtoMessage

func (*QueryMissCounterRequest) ProtoMessage()

func (*QueryMissCounterRequest) Reset

func (m *QueryMissCounterRequest) Reset()

func (*QueryMissCounterRequest) Size

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

func (*QueryMissCounterRequest) String

func (m *QueryMissCounterRequest) String() string

func (*QueryMissCounterRequest) Unmarshal

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

func (*QueryMissCounterRequest) XXX_DiscardUnknown

func (m *QueryMissCounterRequest) XXX_DiscardUnknown()

func (*QueryMissCounterRequest) XXX_Marshal

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

func (*QueryMissCounterRequest) XXX_Merge

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

func (*QueryMissCounterRequest) XXX_Size

func (m *QueryMissCounterRequest) XXX_Size() int

func (*QueryMissCounterRequest) XXX_Unmarshal

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

type QueryMissCounterResponse

type QueryMissCounterResponse struct {
	// miss_counter defines the oracle miss counter of a validator
	MissCounter uint64 `protobuf:"varint,1,opt,name=miss_counter,json=missCounter,proto3" json:"miss_counter,omitempty"`
}

QueryMissCounterResponse is response type for the Query/MissCounter RPC method.

func (*QueryMissCounterResponse) Descriptor

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

func (*QueryMissCounterResponse) GetMissCounter

func (m *QueryMissCounterResponse) GetMissCounter() uint64

func (*QueryMissCounterResponse) Marshal

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

func (*QueryMissCounterResponse) MarshalTo

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

func (*QueryMissCounterResponse) MarshalToSizedBuffer

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

func (*QueryMissCounterResponse) ProtoMessage

func (*QueryMissCounterResponse) ProtoMessage()

func (*QueryMissCounterResponse) Reset

func (m *QueryMissCounterResponse) Reset()

func (*QueryMissCounterResponse) Size

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

func (*QueryMissCounterResponse) String

func (m *QueryMissCounterResponse) String() string

func (*QueryMissCounterResponse) Unmarshal

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

func (*QueryMissCounterResponse) XXX_DiscardUnknown

func (m *QueryMissCounterResponse) XXX_DiscardUnknown()

func (*QueryMissCounterResponse) XXX_Marshal

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

func (*QueryMissCounterResponse) XXX_Merge

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

func (*QueryMissCounterResponse) XXX_Size

func (m *QueryMissCounterResponse) XXX_Size() int

func (*QueryMissCounterResponse) XXX_Unmarshal

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

type QueryParamsRequest

type QueryParamsRequest struct {
}

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

func (*QueryParamsRequest) Descriptor

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

func (*QueryParamsRequest) Marshal

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

func (*QueryParamsRequest) MarshalTo

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

func (*QueryParamsRequest) MarshalToSizedBuffer

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

func (*QueryParamsRequest) ProtoMessage

func (*QueryParamsRequest) ProtoMessage()

func (*QueryParamsRequest) Reset

func (m *QueryParamsRequest) Reset()

func (*QueryParamsRequest) Size

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

func (*QueryParamsRequest) String

func (m *QueryParamsRequest) String() string

func (*QueryParamsRequest) Unmarshal

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

func (*QueryParamsRequest) XXX_DiscardUnknown

func (m *QueryParamsRequest) XXX_DiscardUnknown()

func (*QueryParamsRequest) XXX_Marshal

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

func (*QueryParamsRequest) XXX_Merge

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

func (*QueryParamsRequest) XXX_Size

func (m *QueryParamsRequest) XXX_Size() int

func (*QueryParamsRequest) XXX_Unmarshal

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

type QueryParamsResponse

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

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

func (*QueryParamsResponse) Descriptor

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

func (*QueryParamsResponse) GetParams

func (m *QueryParamsResponse) GetParams() Params

func (*QueryParamsResponse) Marshal

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

func (*QueryParamsResponse) MarshalTo

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

func (*QueryParamsResponse) MarshalToSizedBuffer

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

func (*QueryParamsResponse) ProtoMessage

func (*QueryParamsResponse) ProtoMessage()

func (*QueryParamsResponse) Reset

func (m *QueryParamsResponse) Reset()

func (*QueryParamsResponse) Size

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

func (*QueryParamsResponse) String

func (m *QueryParamsResponse) String() string

func (*QueryParamsResponse) Unmarshal

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

func (*QueryParamsResponse) XXX_DiscardUnknown

func (m *QueryParamsResponse) XXX_DiscardUnknown()

func (*QueryParamsResponse) XXX_Marshal

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

func (*QueryParamsResponse) XXX_Merge

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

func (*QueryParamsResponse) XXX_Size

func (m *QueryParamsResponse) XXX_Size() int

func (*QueryParamsResponse) XXX_Unmarshal

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

type QueryPrevotesParams

type QueryPrevotesParams struct {
	Voter sdk.ValAddress
	Denom string
}

QueryPrevotesParams defines the params for the following queries: - 'custom/oracle/prevotes'

func NewQueryPrevotesParams

func NewQueryPrevotesParams(voter sdk.ValAddress, denom string) QueryPrevotesParams

NewQueryPrevotesParams returns params for exchange_rate prevotes query

type QueryServer

type QueryServer interface {
	// ExchangeRate returns exchange rate of a denom
	ExchangeRate(context.Context, *QueryExchangeRateRequest) (*QueryExchangeRateResponse, error)
	// ExchangeRates returns exchange rates of all denoms
	ExchangeRates(context.Context, *QueryExchangeRatesRequest) (*QueryExchangeRatesResponse, error)
	// TobinTax returns tobin tax of a denom
	TobinTax(context.Context, *QueryTobinTaxRequest) (*QueryTobinTaxResponse, error)
	// TobinTaxes returns tobin taxes of all denoms
	TobinTaxes(context.Context, *QueryTobinTaxesRequest) (*QueryTobinTaxesResponse, error)
	// Actives returns all active denoms
	Actives(context.Context, *QueryActivesRequest) (*QueryActivesResponse, error)
	// VoteTargets returns all vote target denoms
	VoteTargets(context.Context, *QueryVoteTargetsRequest) (*QueryVoteTargetsResponse, error)
	// FeederDelegation returns feeder delegation of a validator
	FeederDelegation(context.Context, *QueryFeederDelegationRequest) (*QueryFeederDelegationResponse, error)
	// MissCounter returns oracle miss counter of a validator
	MissCounter(context.Context, *QueryMissCounterRequest) (*QueryMissCounterResponse, error)
	// AggregatePrevote returns an aggregate prevote of a validator
	AggregatePrevote(context.Context, *QueryAggregatePrevoteRequest) (*QueryAggregatePrevoteResponse, error)
	// AggregatePrevotes returns aggregate prevotes of all validators
	AggregatePrevotes(context.Context, *QueryAggregatePrevotesRequest) (*QueryAggregatePrevotesResponse, error)
	// AggregateVote returns an aggregate vote of a validator
	AggregateVote(context.Context, *QueryAggregateVoteRequest) (*QueryAggregateVoteResponse, error)
	// AggregateVotes returns aggregate votes of all validators
	AggregateVotes(context.Context, *QueryAggregateVotesRequest) (*QueryAggregateVotesResponse, error)
	// Params queries all parameters.
	Params(context.Context, *QueryParamsRequest) (*QueryParamsResponse, error)
}

QueryServer is the server API for Query service.

type QueryTobinTaxParams

type QueryTobinTaxParams struct {
	Denom string
}

QueryTobinTaxParams defines the params for the following queries: - 'custom/oracle/tobinTax'

func NewQueryTobinTaxParams

func NewQueryTobinTaxParams(denom string) QueryTobinTaxParams

NewQueryTobinTaxParams returns params for tobin tax query

type QueryTobinTaxRequest

type QueryTobinTaxRequest struct {
	// denom defines the denomination to query for.
	Denom string `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
}

QueryTobinTaxRequest is the request type for the Query/TobinTax RPC method.

func (*QueryTobinTaxRequest) Descriptor

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

func (*QueryTobinTaxRequest) Marshal

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

func (*QueryTobinTaxRequest) MarshalTo

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

func (*QueryTobinTaxRequest) MarshalToSizedBuffer

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

func (*QueryTobinTaxRequest) ProtoMessage

func (*QueryTobinTaxRequest) ProtoMessage()

func (*QueryTobinTaxRequest) Reset

func (m *QueryTobinTaxRequest) Reset()

func (*QueryTobinTaxRequest) Size

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

func (*QueryTobinTaxRequest) String

func (m *QueryTobinTaxRequest) String() string

func (*QueryTobinTaxRequest) Unmarshal

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

func (*QueryTobinTaxRequest) XXX_DiscardUnknown

func (m *QueryTobinTaxRequest) XXX_DiscardUnknown()

func (*QueryTobinTaxRequest) XXX_Marshal

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

func (*QueryTobinTaxRequest) XXX_Merge

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

func (*QueryTobinTaxRequest) XXX_Size

func (m *QueryTobinTaxRequest) XXX_Size() int

func (*QueryTobinTaxRequest) XXX_Unmarshal

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

type QueryTobinTaxResponse

type QueryTobinTaxResponse struct {
	// tobin_taxe defines the tobin tax of a denom
	TobinTax github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,1,opt,name=tobin_tax,json=tobinTax,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"tobin_tax"`
}

QueryTobinTaxResponse is response type for the Query/TobinTax RPC method.

func (*QueryTobinTaxResponse) Descriptor

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

func (*QueryTobinTaxResponse) Marshal

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

func (*QueryTobinTaxResponse) MarshalTo

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

func (*QueryTobinTaxResponse) MarshalToSizedBuffer

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

func (*QueryTobinTaxResponse) ProtoMessage

func (*QueryTobinTaxResponse) ProtoMessage()

func (*QueryTobinTaxResponse) Reset

func (m *QueryTobinTaxResponse) Reset()

func (*QueryTobinTaxResponse) Size

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

func (*QueryTobinTaxResponse) String

func (m *QueryTobinTaxResponse) String() string

func (*QueryTobinTaxResponse) Unmarshal

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

func (*QueryTobinTaxResponse) XXX_DiscardUnknown

func (m *QueryTobinTaxResponse) XXX_DiscardUnknown()

func (*QueryTobinTaxResponse) XXX_Marshal

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

func (*QueryTobinTaxResponse) XXX_Merge

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

func (*QueryTobinTaxResponse) XXX_Size

func (m *QueryTobinTaxResponse) XXX_Size() int

func (*QueryTobinTaxResponse) XXX_Unmarshal

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

type QueryTobinTaxesRequest

type QueryTobinTaxesRequest struct {
}

QueryTobinTaxesRequest is the request type for the Query/TobinTaxes RPC method.

func (*QueryTobinTaxesRequest) Descriptor

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

func (*QueryTobinTaxesRequest) Marshal

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

func (*QueryTobinTaxesRequest) MarshalTo

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

func (*QueryTobinTaxesRequest) MarshalToSizedBuffer

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

func (*QueryTobinTaxesRequest) ProtoMessage

func (*QueryTobinTaxesRequest) ProtoMessage()

func (*QueryTobinTaxesRequest) Reset

func (m *QueryTobinTaxesRequest) Reset()

func (*QueryTobinTaxesRequest) Size

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

func (*QueryTobinTaxesRequest) String

func (m *QueryTobinTaxesRequest) String() string

func (*QueryTobinTaxesRequest) Unmarshal

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

func (*QueryTobinTaxesRequest) XXX_DiscardUnknown

func (m *QueryTobinTaxesRequest) XXX_DiscardUnknown()

func (*QueryTobinTaxesRequest) XXX_Marshal

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

func (*QueryTobinTaxesRequest) XXX_Merge

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

func (*QueryTobinTaxesRequest) XXX_Size

func (m *QueryTobinTaxesRequest) XXX_Size() int

func (*QueryTobinTaxesRequest) XXX_Unmarshal

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

type QueryTobinTaxesResponse

type QueryTobinTaxesResponse struct {
	// tobin_taxes defines a list of the tobin tax of all whitelisted denoms
	TobinTaxes DenomList `protobuf:"bytes,1,rep,name=tobin_taxes,json=tobinTaxes,proto3,castrepeated=DenomList" json:"tobin_taxes" yaml:"tobin_taxes"`
}

QueryTobinTaxesResponse is response type for the Query/TobinTaxes RPC method.

func (*QueryTobinTaxesResponse) Descriptor

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

func (*QueryTobinTaxesResponse) GetTobinTaxes

func (m *QueryTobinTaxesResponse) GetTobinTaxes() DenomList

func (*QueryTobinTaxesResponse) Marshal

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

func (*QueryTobinTaxesResponse) MarshalTo

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

func (*QueryTobinTaxesResponse) MarshalToSizedBuffer

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

func (*QueryTobinTaxesResponse) ProtoMessage

func (*QueryTobinTaxesResponse) ProtoMessage()

func (*QueryTobinTaxesResponse) Reset

func (m *QueryTobinTaxesResponse) Reset()

func (*QueryTobinTaxesResponse) Size

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

func (*QueryTobinTaxesResponse) String

func (m *QueryTobinTaxesResponse) String() string

func (*QueryTobinTaxesResponse) Unmarshal

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

func (*QueryTobinTaxesResponse) XXX_DiscardUnknown

func (m *QueryTobinTaxesResponse) XXX_DiscardUnknown()

func (*QueryTobinTaxesResponse) XXX_Marshal

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

func (*QueryTobinTaxesResponse) XXX_Merge

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

func (*QueryTobinTaxesResponse) XXX_Size

func (m *QueryTobinTaxesResponse) XXX_Size() int

func (*QueryTobinTaxesResponse) XXX_Unmarshal

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

type QueryVoteTargetsRequest

type QueryVoteTargetsRequest struct {
}

QueryVoteTargetsRequest is the request type for the Query/VoteTargets RPC method.

func (*QueryVoteTargetsRequest) Descriptor

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

func (*QueryVoteTargetsRequest) Marshal

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

func (*QueryVoteTargetsRequest) MarshalTo

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

func (*QueryVoteTargetsRequest) MarshalToSizedBuffer

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

func (*QueryVoteTargetsRequest) ProtoMessage

func (*QueryVoteTargetsRequest) ProtoMessage()

func (*QueryVoteTargetsRequest) Reset

func (m *QueryVoteTargetsRequest) Reset()

func (*QueryVoteTargetsRequest) Size

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

func (*QueryVoteTargetsRequest) String

func (m *QueryVoteTargetsRequest) String() string

func (*QueryVoteTargetsRequest) Unmarshal

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

func (*QueryVoteTargetsRequest) XXX_DiscardUnknown

func (m *QueryVoteTargetsRequest) XXX_DiscardUnknown()

func (*QueryVoteTargetsRequest) XXX_Marshal

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

func (*QueryVoteTargetsRequest) XXX_Merge

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

func (*QueryVoteTargetsRequest) XXX_Size

func (m *QueryVoteTargetsRequest) XXX_Size() int

func (*QueryVoteTargetsRequest) XXX_Unmarshal

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

type QueryVoteTargetsResponse

type QueryVoteTargetsResponse struct {
	// vote_targets defines a list of the denomination in which everyone
	// should vote in the current vote period.
	VoteTargets []string `protobuf:"bytes,1,rep,name=vote_targets,json=voteTargets,proto3" json:"vote_targets,omitempty"`
}

QueryVoteTargetsResponse is response type for the Query/VoteTargets RPC method.

func (*QueryVoteTargetsResponse) Descriptor

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

func (*QueryVoteTargetsResponse) GetVoteTargets

func (m *QueryVoteTargetsResponse) GetVoteTargets() []string

func (*QueryVoteTargetsResponse) Marshal

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

func (*QueryVoteTargetsResponse) MarshalTo

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

func (*QueryVoteTargetsResponse) MarshalToSizedBuffer

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

func (*QueryVoteTargetsResponse) ProtoMessage

func (*QueryVoteTargetsResponse) ProtoMessage()

func (*QueryVoteTargetsResponse) Reset

func (m *QueryVoteTargetsResponse) Reset()

func (*QueryVoteTargetsResponse) Size

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

func (*QueryVoteTargetsResponse) String

func (m *QueryVoteTargetsResponse) String() string

func (*QueryVoteTargetsResponse) Unmarshal

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

func (*QueryVoteTargetsResponse) XXX_DiscardUnknown

func (m *QueryVoteTargetsResponse) XXX_DiscardUnknown()

func (*QueryVoteTargetsResponse) XXX_Marshal

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

func (*QueryVoteTargetsResponse) XXX_Merge

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

func (*QueryVoteTargetsResponse) XXX_Size

func (m *QueryVoteTargetsResponse) XXX_Size() int

func (*QueryVoteTargetsResponse) XXX_Unmarshal

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

type QueryVotesParams

type QueryVotesParams struct {
	Voter sdk.ValAddress
	Denom string
}

QueryVotesParams defines the params for the following queries: - 'custom/oracle/votes'

func NewQueryVotesParams

func NewQueryVotesParams(voter sdk.ValAddress, denom string) QueryVotesParams

NewQueryVotesParams returns params for exchange_rate votes query

type StakingKeeper

type StakingKeeper interface {
	Validator(ctx sdk.Context, address sdk.ValAddress) stakingtypes.ValidatorI
	TotalBondedTokens(sdk.Context) sdk.Int
	Slash(sdk.Context, sdk.ConsAddress, int64, int64, sdk.Dec)
	Jail(sdk.Context, sdk.ConsAddress)
	ValidatorsPowerStoreIterator(ctx sdk.Context) sdk.Iterator
	MaxValidators(sdk.Context) uint32
	PowerReduction(ctx sdk.Context) (res sdk.Int)
}

StakingKeeper defines the expected interface contract defined by the x/staking module.

type TobinTax

type TobinTax struct {
	Denom    string                                 `protobuf:"bytes,1,opt,name=denom,proto3" json:"denom,omitempty"`
	TobinTax github_com_cosmos_cosmos_sdk_types.Dec `protobuf:"bytes,2,opt,name=tobin_tax,json=tobinTax,proto3,customtype=github.com/cosmos/cosmos-sdk/types.Dec" json:"tobin_tax"`
}

TobinTax defines an denom and tobin_tax pair used in oracle module's genesis state

func (*TobinTax) Descriptor

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

func (*TobinTax) GetDenom

func (m *TobinTax) GetDenom() string

func (*TobinTax) Marshal

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

func (*TobinTax) MarshalTo

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

func (*TobinTax) MarshalToSizedBuffer

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

func (*TobinTax) ProtoMessage

func (*TobinTax) ProtoMessage()

func (*TobinTax) Reset

func (m *TobinTax) Reset()

func (*TobinTax) Size

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

func (*TobinTax) String

func (m *TobinTax) String() string

func (*TobinTax) Unmarshal

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

func (*TobinTax) XXX_DiscardUnknown

func (m *TobinTax) XXX_DiscardUnknown()

func (*TobinTax) XXX_Marshal

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

func (*TobinTax) XXX_Merge

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

func (*TobinTax) XXX_Size

func (m *TobinTax) XXX_Size() int

func (*TobinTax) XXX_Unmarshal

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

type UnimplementedMsgServer

type UnimplementedMsgServer struct {
}

UnimplementedMsgServer can be embedded to have forward compatible implementations.

func (*UnimplementedMsgServer) AggregateExchangeRateVote

func (*UnimplementedMsgServer) DelegateFeedConsent

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) Actives

func (*UnimplementedQueryServer) AggregatePrevote

func (*UnimplementedQueryServer) AggregatePrevotes

func (*UnimplementedQueryServer) AggregateVote

func (*UnimplementedQueryServer) AggregateVotes

func (*UnimplementedQueryServer) ExchangeRate

func (*UnimplementedQueryServer) ExchangeRates

func (*UnimplementedQueryServer) FeederDelegation

func (*UnimplementedQueryServer) MissCounter

func (*UnimplementedQueryServer) Params

func (*UnimplementedQueryServer) TobinTax

func (*UnimplementedQueryServer) TobinTaxes

func (*UnimplementedQueryServer) VoteTargets

type VoteForTally

type VoteForTally struct {
	Denom        string
	ExchangeRate sdk.Dec
	Voter        sdk.ValAddress
	Power        int64
}

VoteForTally is a convenience wrapper to reduce redundant lookup cost.

func NewVoteForTally

func NewVoteForTally(rate sdk.Dec, denom string, voter sdk.ValAddress, power int64) VoteForTally

NewVoteForTally returns a new VoteForTally instance.

type VoteHash

type VoteHash []byte

VoteHash defines a hash value to hide vote exchange rate which is formatted as hex string in SHA256("{salt}:{exchange_rate}:{denom}:{voter}")

Jump to

Keyboard shortcuts

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