types

package
v0.4.0-dev.10 Latest Latest
Warning

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

Go to latest
Published: Dec 12, 2024 License: GPL-3.0 Imports: 33 Imported by: 0

Documentation

Overview

Package types is a reverse proxy.

It translates gRPC into RESTful JSON APIs.

Index

Constants

View Source
const (
	TallyExitCodeNotEnoughCommits uint32 = 200
	TallyExitCodeNotEnoughReveals uint32 = 201
	TallyExitCodeFailedToExecute  uint32 = 255
)
View Source
const (
	// ModuleName defines the module name.
	ModuleName = "batching"

	// StoreKey defines the primary module store key.
	StoreKey = "batching"
)

Variables

View Source
var (
	ErrInvalidLengthBatching        = fmt.Errorf("proto: negative length found during unmarshaling")
	ErrIntOverflowBatching          = fmt.Errorf("proto: integer overflow")
	ErrUnexpectedEndOfGroupBatching = fmt.Errorf("proto: unexpected end of group")
)
View Source
var (
	ErrBatchingHasNotStarted = errors.Register("batching", 2, "batching has not begun - there is no batch in the store")
	ErrInvalidBatchNumber    = errors.Register("batching", 3, "invalid batch number")
	ErrBatchAlreadyExists    = errors.Register("batching", 4, "batch already exists at the given block height")
	ErrInvalidPublicKey      = errors.Register("batching", 5, "invalid public key")
	ErrNoBatchingUpdate      = errors.Register("batching", 6, "no change from previous data result and validator roots")
	ErrNoSignedBatches       = errors.Register("batching", 7, "there is no signed batch yet")
)
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 (
	DataResultsPrefix              = collections.NewPrefix(0)
	BatchAssignmentsPrefix         = collections.NewPrefix(1)
	CurrentBatchNumberKey          = collections.NewPrefix(2)
	BatchesKeyPrefix               = collections.NewPrefix(3)
	BatchNumberKeyPrefix           = collections.NewPrefix(4)
	ValidatorTreeEntriesKeyPrefix  = collections.NewPrefix(5)
	DataResultTreeEntriesKeyPrefix = collections.NewPrefix(6)
	BatchSignaturesKeyPrefix       = collections.NewPrefix(7)
)
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 Query_serviceDesc = _Query_serviceDesc

Functions

func RegisterCodec

func RegisterCodec(_ *codec.LegacyAmino)

func RegisterQueryHandler

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

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

func RegisterQueryHandlerClient

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

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

func RegisterQueryHandlerFromEndpoint

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

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

func RegisterQueryHandlerServer

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

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

func RegisterQueryServer

func RegisterQueryServer(s grpc1.Server, srv QueryServer)

func ValidateGenesis

func ValidateGenesis(_ GenesisState) error

ValidateGenesis validates batching genesis data.

Types

type Batch

type Batch struct {
	// batch_number is a unique identifier of the batch incremented
	// every time a batch is created.
	BatchNumber uint64 `protobuf:"varint,1,opt,name=batch_number,json=batchNumber,proto3" json:"batch_number,omitempty"`
	// block_height is the height at which the batch was created.
	BlockHeight int64 `protobuf:"varint,2,opt,name=block_height,json=blockHeight,proto3" json:"block_height,omitempty"`
	// current_data_result_root is the hex-encoded root of the data result
	// merkle tree.
	CurrentDataResultRoot string `` /* 128-byte string literal not displayed */
	// data_result_root is the hex-encoded "super root" of the previous
	// data result and current data result roots.
	DataResultRoot string `protobuf:"bytes,4,opt,name=data_result_root,json=dataResultRoot,proto3" json:"data_result_root,omitempty"`
	// validator_root is the hex-encoded root of the validator merkle
	// tree.
	ValidatorRoot string `protobuf:"bytes,5,opt,name=validator_root,json=validatorRoot,proto3" json:"validator_root,omitempty"`
	// batch_id is the Keccack-256 hash of the batch content.
	BatchId []byte `protobuf:"bytes,6,opt,name=batch_id,json=batchId,proto3" json:"batch_id,omitempty"`
	// proving_metadata is a field for additional proving data.
	ProvingMetadata []byte `protobuf:"bytes,7,opt,name=proving_metadata,json=provingMetadata,proto3" json:"proving_metadata,omitempty"`
}

Batch is an aggregation of data request results along with validator signatures used to prove these results on destination chains.

func (*Batch) Descriptor

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

func (*Batch) GetBatchId

func (m *Batch) GetBatchId() []byte

func (*Batch) GetBatchNumber

func (m *Batch) GetBatchNumber() uint64

func (*Batch) GetBlockHeight

func (m *Batch) GetBlockHeight() int64

func (*Batch) GetCurrentDataResultRoot

func (m *Batch) GetCurrentDataResultRoot() string

func (*Batch) GetDataResultRoot

func (m *Batch) GetDataResultRoot() string

func (*Batch) GetProvingMetadata

func (m *Batch) GetProvingMetadata() []byte

func (*Batch) GetValidatorRoot

func (m *Batch) GetValidatorRoot() string

func (*Batch) Marshal

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

func (*Batch) MarshalTo

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

func (*Batch) MarshalToSizedBuffer

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

func (*Batch) ProtoMessage

func (*Batch) ProtoMessage()

func (*Batch) Reset

func (m *Batch) Reset()

func (*Batch) Size

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

func (*Batch) String

func (m *Batch) String() string

func (*Batch) Unmarshal

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

func (*Batch) XXX_DiscardUnknown

func (m *Batch) XXX_DiscardUnknown()

func (*Batch) XXX_Marshal

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

func (*Batch) XXX_Merge

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

func (*Batch) XXX_Size

func (m *Batch) XXX_Size() int

func (*Batch) XXX_Unmarshal

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

type BatchAssignment

type BatchAssignment struct {
	BatchNumber       uint64 `protobuf:"varint,1,opt,name=batch_number,json=batchNumber,proto3" json:"batch_number,omitempty"`
	DataRequestId     string `protobuf:"bytes,2,opt,name=data_request_id,json=dataRequestId,proto3" json:"data_request_id,omitempty"`
	DataRequestHeight uint64 `protobuf:"varint,3,opt,name=data_request_height,json=dataRequestHeight,proto3" json:"data_request_height,omitempty"`
}

BatchAssignment represents a batch assignment for genesis export and import.

func (*BatchAssignment) Descriptor

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

func (*BatchAssignment) GetBatchNumber

func (m *BatchAssignment) GetBatchNumber() uint64

func (*BatchAssignment) GetDataRequestHeight

func (m *BatchAssignment) GetDataRequestHeight() uint64

func (*BatchAssignment) GetDataRequestId

func (m *BatchAssignment) GetDataRequestId() string

func (*BatchAssignment) Marshal

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

func (*BatchAssignment) MarshalTo

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

func (*BatchAssignment) MarshalToSizedBuffer

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

func (*BatchAssignment) ProtoMessage

func (*BatchAssignment) ProtoMessage()

func (*BatchAssignment) Reset

func (m *BatchAssignment) Reset()

func (*BatchAssignment) Size

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

func (*BatchAssignment) String

func (m *BatchAssignment) String() string

func (*BatchAssignment) Unmarshal

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

func (*BatchAssignment) XXX_DiscardUnknown

func (m *BatchAssignment) XXX_DiscardUnknown()

func (*BatchAssignment) XXX_Marshal

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

func (*BatchAssignment) XXX_Merge

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

func (*BatchAssignment) XXX_Size

func (m *BatchAssignment) XXX_Size() int

func (*BatchAssignment) XXX_Unmarshal

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

type BatchData

type BatchData struct {
	BatchNumber       uint64                `protobuf:"varint,1,opt,name=batch_number,json=batchNumber,proto3" json:"batch_number,omitempty"`
	DataResultEntries DataResultTreeEntries `protobuf:"bytes,2,opt,name=data_result_entries,json=dataResultEntries,proto3" json:"data_result_entries"`
	ValidatorEntries  []ValidatorTreeEntry  `protobuf:"bytes,3,rep,name=validator_entries,json=validatorEntries,proto3" json:"validator_entries"`
	BatchSignatures   []BatchSignatures     `protobuf:"bytes,4,rep,name=batch_signatures,json=batchSignatures,proto3" json:"batch_signatures"`
}

BatchData represents a given batch's full data.

func (*BatchData) Descriptor

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

func (*BatchData) GetBatchNumber

func (m *BatchData) GetBatchNumber() uint64

func (*BatchData) GetBatchSignatures

func (m *BatchData) GetBatchSignatures() []BatchSignatures

func (*BatchData) GetDataResultEntries

func (m *BatchData) GetDataResultEntries() DataResultTreeEntries

func (*BatchData) GetValidatorEntries

func (m *BatchData) GetValidatorEntries() []ValidatorTreeEntry

func (*BatchData) Marshal

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

func (*BatchData) MarshalTo

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

func (*BatchData) MarshalToSizedBuffer

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

func (*BatchData) ProtoMessage

func (*BatchData) ProtoMessage()

func (*BatchData) Reset

func (m *BatchData) Reset()

func (*BatchData) Size

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

func (*BatchData) String

func (m *BatchData) String() string

func (*BatchData) Unmarshal

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

func (*BatchData) XXX_DiscardUnknown

func (m *BatchData) XXX_DiscardUnknown()

func (*BatchData) XXX_Marshal

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

func (*BatchData) XXX_Merge

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

func (*BatchData) XXX_Size

func (m *BatchData) XXX_Size() int

func (*BatchData) XXX_Unmarshal

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

type BatchSignatures

type BatchSignatures struct {
	ValidatorAddress   github_com_cosmos_cosmos_sdk_types.ValAddress `` /* 164-byte string literal not displayed */
	Secp256K1Signature []byte                                        `protobuf:"bytes,2,opt,name=secp256k1_signature,json=secp256k1Signature,proto3" json:"secp256k1_signature,omitempty"`
}

BatchSignatures contains basic validator data and its batch signatures under various cryptographic schemes.

func (*BatchSignatures) Descriptor

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

func (*BatchSignatures) GetSecp256K1Signature

func (m *BatchSignatures) GetSecp256K1Signature() []byte

func (*BatchSignatures) GetValidatorAddress

func (*BatchSignatures) Marshal

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

func (*BatchSignatures) MarshalTo

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

func (*BatchSignatures) MarshalToSizedBuffer

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

func (*BatchSignatures) ProtoMessage

func (*BatchSignatures) ProtoMessage()

func (*BatchSignatures) Reset

func (m *BatchSignatures) Reset()

func (*BatchSignatures) Size

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

func (*BatchSignatures) String

func (m *BatchSignatures) String() string

func (*BatchSignatures) Unmarshal

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

func (*BatchSignatures) XXX_DiscardUnknown

func (m *BatchSignatures) XXX_DiscardUnknown()

func (*BatchSignatures) XXX_Marshal

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

func (*BatchSignatures) XXX_Merge

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

func (*BatchSignatures) XXX_Size

func (m *BatchSignatures) XXX_Size() int

func (*BatchSignatures) XXX_Unmarshal

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

type DataResult

type DataResult struct {
	// id is the Keccack-256 hash of the data result.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id"`
	// dr_id is the data request identifier.
	DrId string `protobuf:"bytes,2,opt,name=dr_id,json=drId,proto3" json:"dr_id"`
	// dr_block_height is the height at which the data request was submitted.
	DrBlockHeight uint64 `protobuf:"varint,3,opt,name=dr_block_height,json=drBlockHeight,proto3" json:"dr_block_height"`
	// version is a semantic version string.
	Version string `protobuf:"bytes,4,opt,name=version,proto3" json:"version"`
	// block_height is the height at which the data request was tallied.
	BlockHeight uint64 `protobuf:"varint,5,opt,name=block_height,json=blockHeight,proto3" json:"block_height"`
	// block_timestamp is the unix timestamp in seconds of when the data request
	// was tallied.
	BlockTimestamp uint64 `protobuf:"varint,6,opt,name=block_timestamp,json=blockTimestamp,proto3" json:"block_timestamp"`
	// exit_code is the exit code of the tally wasm binary execution.
	ExitCode uint32 `protobuf:"varint,7,opt,name=exit_code,json=exitCode,proto3" json:"exit_code"`
	// gas_used is the gas used by the data request execution.
	GasUsed uint64 `protobuf:"varint,8,opt,name=gas_used,json=gasUsed,proto3" json:"gas_used"`
	// result is the result of the tally wasm binary execution.
	Result []byte `protobuf:"bytes,9,opt,name=result,proto3" json:"result"`
	// payback_address is the payback address set by the relayer.
	PaybackAddress string `protobuf:"bytes,10,opt,name=payback_address,json=paybackAddress,proto3" json:"payback_address"`
	// seda_payload is the payload set by SEDA Protocol (e.g. OEV-enabled
	// data requests)
	SedaPayload string `protobuf:"bytes,11,opt,name=seda_payload,json=sedaPayload,proto3" json:"seda_payload"`
	// consensus indicates whether consensus was reached in the tally
	// process.
	Consensus bool `protobuf:"varint,12,opt,name=consensus,proto3" json:"consensus"`
}

DataResult represents the result of a resolved data request.

func (*DataResult) Descriptor

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

func (*DataResult) GetBlockHeight

func (m *DataResult) GetBlockHeight() uint64

func (*DataResult) GetBlockTimestamp

func (m *DataResult) GetBlockTimestamp() uint64

func (*DataResult) GetConsensus

func (m *DataResult) GetConsensus() bool

func (*DataResult) GetDrBlockHeight

func (m *DataResult) GetDrBlockHeight() uint64

func (*DataResult) GetDrId

func (m *DataResult) GetDrId() string

func (*DataResult) GetExitCode

func (m *DataResult) GetExitCode() uint32

func (*DataResult) GetGasUsed

func (m *DataResult) GetGasUsed() uint64

func (*DataResult) GetId

func (m *DataResult) GetId() string

func (*DataResult) GetPaybackAddress

func (m *DataResult) GetPaybackAddress() string

func (*DataResult) GetResult

func (m *DataResult) GetResult() []byte

func (*DataResult) GetSedaPayload

func (m *DataResult) GetSedaPayload() string

func (*DataResult) GetVersion

func (m *DataResult) GetVersion() string

func (*DataResult) Marshal

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

func (*DataResult) MarshalTo

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

func (*DataResult) MarshalToSizedBuffer

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

func (*DataResult) ProtoMessage

func (*DataResult) ProtoMessage()

func (*DataResult) Reset

func (m *DataResult) Reset()

func (*DataResult) Size

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

func (*DataResult) String

func (m *DataResult) String() string

func (*DataResult) TryHash

func (dr *DataResult) TryHash() (string, error)

TryHash returns a hex-encoded hash of the DataResult.

func (*DataResult) Unmarshal

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

func (*DataResult) XXX_DiscardUnknown

func (m *DataResult) XXX_DiscardUnknown()

func (*DataResult) XXX_Marshal

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

func (*DataResult) XXX_Merge

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

func (*DataResult) XXX_Size

func (m *DataResult) XXX_Size() int

func (*DataResult) XXX_Unmarshal

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

type DataResultTreeEntries

type DataResultTreeEntries struct {
	Entries [][]byte `protobuf:"bytes,1,rep,name=entries,proto3" json:"entries,omitempty"`
}

DataResultTreeEntries is a list of data result tree entries for a given batch.

func (*DataResultTreeEntries) Descriptor

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

func (*DataResultTreeEntries) GetEntries

func (m *DataResultTreeEntries) GetEntries() [][]byte

func (*DataResultTreeEntries) Marshal

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

func (*DataResultTreeEntries) MarshalTo

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

func (*DataResultTreeEntries) MarshalToSizedBuffer

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

func (*DataResultTreeEntries) ProtoMessage

func (*DataResultTreeEntries) ProtoMessage()

func (*DataResultTreeEntries) Reset

func (m *DataResultTreeEntries) Reset()

func (*DataResultTreeEntries) Size

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

func (*DataResultTreeEntries) String

func (m *DataResultTreeEntries) String() string

func (*DataResultTreeEntries) Unmarshal

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

func (*DataResultTreeEntries) XXX_DiscardUnknown

func (m *DataResultTreeEntries) XXX_DiscardUnknown()

func (*DataResultTreeEntries) XXX_Marshal

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

func (*DataResultTreeEntries) XXX_Merge

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

func (*DataResultTreeEntries) XXX_Size

func (m *DataResultTreeEntries) XXX_Size() int

func (*DataResultTreeEntries) XXX_Unmarshal

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

type GenesisDataResult

type GenesisDataResult struct {
	Batched    bool       `protobuf:"varint,1,opt,name=batched,proto3" json:"batched,omitempty"`
	DataResult DataResult `protobuf:"bytes,2,opt,name=data_result,json=dataResult,proto3" json:"data_result"`
}

GenesisDataResult includes a data result and its batching status.

func (*GenesisDataResult) Descriptor

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

func (*GenesisDataResult) GetBatched

func (m *GenesisDataResult) GetBatched() bool

func (*GenesisDataResult) GetDataResult

func (m *GenesisDataResult) GetDataResult() DataResult

func (*GenesisDataResult) Marshal

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

func (*GenesisDataResult) MarshalTo

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

func (*GenesisDataResult) MarshalToSizedBuffer

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

func (*GenesisDataResult) ProtoMessage

func (*GenesisDataResult) ProtoMessage()

func (*GenesisDataResult) Reset

func (m *GenesisDataResult) Reset()

func (*GenesisDataResult) Size

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

func (*GenesisDataResult) String

func (m *GenesisDataResult) String() string

func (*GenesisDataResult) Unmarshal

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

func (*GenesisDataResult) XXX_DiscardUnknown

func (m *GenesisDataResult) XXX_DiscardUnknown()

func (*GenesisDataResult) XXX_Marshal

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

func (*GenesisDataResult) XXX_Merge

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

func (*GenesisDataResult) XXX_Size

func (m *GenesisDataResult) XXX_Size() int

func (*GenesisDataResult) XXX_Unmarshal

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

type GenesisState

type GenesisState struct {
	// current_batch_number is the batch number of the most recently-
	// created batch.
	CurrentBatchNumber uint64              `protobuf:"varint,1,opt,name=current_batch_number,json=currentBatchNumber,proto3" json:"current_batch_number,omitempty"`
	Batches            []Batch             `protobuf:"bytes,2,rep,name=batches,proto3" json:"batches"`
	BatchData          []BatchData         `protobuf:"bytes,3,rep,name=batch_data,json=batchData,proto3" json:"batch_data"`
	DataResults        []GenesisDataResult `protobuf:"bytes,4,rep,name=data_results,json=dataResults,proto3" json:"data_results"`
	BatchAssignments   []BatchAssignment   `protobuf:"bytes,5,rep,name=batch_assignments,json=batchAssignments,proto3" json:"batch_assignments"`
}

GenesisState defines the batching module's genesis state.

func DefaultGenesisState

func DefaultGenesisState() *GenesisState

DefaultGenesisState creates a default GenesisState object.

func NewGenesisState

func NewGenesisState(
	curBatchNum uint64,
	batches []Batch,
	batchData []BatchData,
	dataResults []GenesisDataResult,
	batchAssignments []BatchAssignment,
) GenesisState

NewGenesisState constructs a GenesisState object.

func (*GenesisState) Descriptor

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

func (*GenesisState) GetBatchAssignments

func (m *GenesisState) GetBatchAssignments() []BatchAssignment

func (*GenesisState) GetBatchData

func (m *GenesisState) GetBatchData() []BatchData

func (*GenesisState) GetBatches

func (m *GenesisState) GetBatches() []Batch

func (*GenesisState) GetCurrentBatchNumber

func (m *GenesisState) GetCurrentBatchNumber() uint64

func (*GenesisState) GetDataResults

func (m *GenesisState) GetDataResults() []GenesisDataResult

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 PubKeyKeeper

type PubKeyKeeper interface {
	GetValidatorKeyAtIndex(ctx context.Context, validatorAddr sdk.ValAddress, index utils.SEDAKeyIndex) ([]byte, error)
	IsProvingSchemeActivated(ctx context.Context, index utils.SEDAKeyIndex) (bool, error)
}

type QueryBatchForHeightRequest

type QueryBatchForHeightRequest struct {
	BlockHeight int64 `protobuf:"varint,1,opt,name=block_height,json=blockHeight,proto3" json:"block_height,omitempty"`
}

The request message for BatchForHeight RPC.

func (*QueryBatchForHeightRequest) Descriptor

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

func (*QueryBatchForHeightRequest) GetBlockHeight

func (m *QueryBatchForHeightRequest) GetBlockHeight() int64

func (*QueryBatchForHeightRequest) Marshal

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

func (*QueryBatchForHeightRequest) MarshalTo

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

func (*QueryBatchForHeightRequest) MarshalToSizedBuffer

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

func (*QueryBatchForHeightRequest) ProtoMessage

func (*QueryBatchForHeightRequest) ProtoMessage()

func (*QueryBatchForHeightRequest) Reset

func (m *QueryBatchForHeightRequest) Reset()

func (*QueryBatchForHeightRequest) Size

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

func (*QueryBatchForHeightRequest) String

func (m *QueryBatchForHeightRequest) String() string

func (*QueryBatchForHeightRequest) Unmarshal

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

func (*QueryBatchForHeightRequest) XXX_DiscardUnknown

func (m *QueryBatchForHeightRequest) XXX_DiscardUnknown()

func (*QueryBatchForHeightRequest) XXX_Marshal

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

func (*QueryBatchForHeightRequest) XXX_Merge

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

func (*QueryBatchForHeightRequest) XXX_Size

func (m *QueryBatchForHeightRequest) XXX_Size() int

func (*QueryBatchForHeightRequest) XXX_Unmarshal

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

type QueryBatchForHeightResponse

type QueryBatchForHeightResponse struct {
	Batch Batch `protobuf:"bytes,1,opt,name=batch,proto3" json:"batch"`
}

The response message for BatchForHeight RPC.

func (*QueryBatchForHeightResponse) Descriptor

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

func (*QueryBatchForHeightResponse) GetBatch

func (m *QueryBatchForHeightResponse) GetBatch() Batch

func (*QueryBatchForHeightResponse) Marshal

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

func (*QueryBatchForHeightResponse) MarshalTo

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

func (*QueryBatchForHeightResponse) MarshalToSizedBuffer

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

func (*QueryBatchForHeightResponse) ProtoMessage

func (*QueryBatchForHeightResponse) ProtoMessage()

func (*QueryBatchForHeightResponse) Reset

func (m *QueryBatchForHeightResponse) Reset()

func (*QueryBatchForHeightResponse) Size

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

func (*QueryBatchForHeightResponse) String

func (m *QueryBatchForHeightResponse) String() string

func (*QueryBatchForHeightResponse) Unmarshal

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

func (*QueryBatchForHeightResponse) XXX_DiscardUnknown

func (m *QueryBatchForHeightResponse) XXX_DiscardUnknown()

func (*QueryBatchForHeightResponse) XXX_Marshal

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

func (*QueryBatchForHeightResponse) XXX_Merge

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

func (*QueryBatchForHeightResponse) XXX_Size

func (m *QueryBatchForHeightResponse) XXX_Size() int

func (*QueryBatchForHeightResponse) XXX_Unmarshal

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

type QueryBatchRequest

type QueryBatchRequest struct {
	BatchNumber uint64 `protobuf:"varint,1,opt,name=batch_number,json=batchNumber,proto3" json:"batch_number,omitempty"`
}

The request message for QueryBatch RPC.

func (*QueryBatchRequest) Descriptor

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

func (*QueryBatchRequest) GetBatchNumber

func (m *QueryBatchRequest) GetBatchNumber() uint64

func (*QueryBatchRequest) Marshal

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

func (*QueryBatchRequest) MarshalTo

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

func (*QueryBatchRequest) MarshalToSizedBuffer

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

func (*QueryBatchRequest) ProtoMessage

func (*QueryBatchRequest) ProtoMessage()

func (*QueryBatchRequest) Reset

func (m *QueryBatchRequest) Reset()

func (*QueryBatchRequest) Size

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

func (*QueryBatchRequest) String

func (m *QueryBatchRequest) String() string

func (*QueryBatchRequest) Unmarshal

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

func (*QueryBatchRequest) XXX_DiscardUnknown

func (m *QueryBatchRequest) XXX_DiscardUnknown()

func (*QueryBatchRequest) XXX_Marshal

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

func (*QueryBatchRequest) XXX_Merge

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

func (*QueryBatchRequest) XXX_Size

func (m *QueryBatchRequest) XXX_Size() int

func (*QueryBatchRequest) XXX_Unmarshal

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

type QueryBatchResponse

type QueryBatchResponse struct {
	Batch             Batch                 `protobuf:"bytes,1,opt,name=batch,proto3" json:"batch"`
	DataResultEntries DataResultTreeEntries `protobuf:"bytes,2,opt,name=data_result_entries,json=dataResultEntries,proto3" json:"data_result_entries"`
	ValidatorEntries  []ValidatorTreeEntry  `protobuf:"bytes,3,rep,name=validator_entries,json=validatorEntries,proto3" json:"validator_entries"`
	BatchSignatures   []BatchSignatures     `protobuf:"bytes,4,rep,name=batch_signatures,json=batchSignatures,proto3" json:"batch_signatures"`
}

The response message for QueryBatch RPC.

func (*QueryBatchResponse) Descriptor

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

func (*QueryBatchResponse) GetBatch

func (m *QueryBatchResponse) GetBatch() Batch

func (*QueryBatchResponse) GetBatchSignatures

func (m *QueryBatchResponse) GetBatchSignatures() []BatchSignatures

func (*QueryBatchResponse) GetDataResultEntries

func (m *QueryBatchResponse) GetDataResultEntries() DataResultTreeEntries

func (*QueryBatchResponse) GetValidatorEntries

func (m *QueryBatchResponse) GetValidatorEntries() []ValidatorTreeEntry

func (*QueryBatchResponse) Marshal

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

func (*QueryBatchResponse) MarshalTo

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

func (*QueryBatchResponse) MarshalToSizedBuffer

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

func (*QueryBatchResponse) ProtoMessage

func (*QueryBatchResponse) ProtoMessage()

func (*QueryBatchResponse) Reset

func (m *QueryBatchResponse) Reset()

func (*QueryBatchResponse) Size

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

func (*QueryBatchResponse) String

func (m *QueryBatchResponse) String() string

func (*QueryBatchResponse) Unmarshal

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

func (*QueryBatchResponse) XXX_DiscardUnknown

func (m *QueryBatchResponse) XXX_DiscardUnknown()

func (*QueryBatchResponse) XXX_Marshal

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

func (*QueryBatchResponse) XXX_Merge

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

func (*QueryBatchResponse) XXX_Size

func (m *QueryBatchResponse) XXX_Size() int

func (*QueryBatchResponse) XXX_Unmarshal

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

type QueryBatchesRequest

type QueryBatchesRequest struct {
	// pagination defines an optional pagination for the request.
	Pagination *query.PageRequest `protobuf:"bytes,1,opt,name=pagination,proto3" json:"pagination,omitempty"`
	// with_unsigned indicates whether to return batches without
	// signatures or not.
	WithUnsigned bool `protobuf:"varint,2,opt,name=with_unsigned,json=withUnsigned,proto3" json:"with_unsigned,omitempty"`
}

The request message for QueryBatches RPC.

func (*QueryBatchesRequest) Descriptor

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

func (*QueryBatchesRequest) GetPagination

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

func (*QueryBatchesRequest) GetWithUnsigned

func (m *QueryBatchesRequest) GetWithUnsigned() bool

func (*QueryBatchesRequest) Marshal

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

func (*QueryBatchesRequest) MarshalTo

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

func (*QueryBatchesRequest) MarshalToSizedBuffer

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

func (*QueryBatchesRequest) ProtoMessage

func (*QueryBatchesRequest) ProtoMessage()

func (*QueryBatchesRequest) Reset

func (m *QueryBatchesRequest) Reset()

func (*QueryBatchesRequest) Size

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

func (*QueryBatchesRequest) String

func (m *QueryBatchesRequest) String() string

func (*QueryBatchesRequest) Unmarshal

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

func (*QueryBatchesRequest) XXX_DiscardUnknown

func (m *QueryBatchesRequest) XXX_DiscardUnknown()

func (*QueryBatchesRequest) XXX_Marshal

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

func (*QueryBatchesRequest) XXX_Merge

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

func (*QueryBatchesRequest) XXX_Size

func (m *QueryBatchesRequest) XXX_Size() int

func (*QueryBatchesRequest) XXX_Unmarshal

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

type QueryBatchesResponse

type QueryBatchesResponse struct {
	Batches    []Batch             `protobuf:"bytes,1,rep,name=batches,proto3" json:"batches"`
	Pagination *query.PageResponse `protobuf:"bytes,2,opt,name=pagination,proto3" json:"pagination,omitempty"`
}

The response message for QueryBatches RPC.

func (*QueryBatchesResponse) Descriptor

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

func (*QueryBatchesResponse) GetBatches

func (m *QueryBatchesResponse) GetBatches() []Batch

func (*QueryBatchesResponse) GetPagination

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

func (*QueryBatchesResponse) Marshal

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

func (*QueryBatchesResponse) MarshalTo

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

func (*QueryBatchesResponse) MarshalToSizedBuffer

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

func (*QueryBatchesResponse) ProtoMessage

func (*QueryBatchesResponse) ProtoMessage()

func (*QueryBatchesResponse) Reset

func (m *QueryBatchesResponse) Reset()

func (*QueryBatchesResponse) Size

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

func (*QueryBatchesResponse) String

func (m *QueryBatchesResponse) String() string

func (*QueryBatchesResponse) Unmarshal

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

func (*QueryBatchesResponse) XXX_DiscardUnknown

func (m *QueryBatchesResponse) XXX_DiscardUnknown()

func (*QueryBatchesResponse) XXX_Marshal

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

func (*QueryBatchesResponse) XXX_Merge

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

func (*QueryBatchesResponse) XXX_Size

func (m *QueryBatchesResponse) XXX_Size() int

func (*QueryBatchesResponse) XXX_Unmarshal

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

type QueryClient

type QueryClient interface {
	// Batch returns a batch given the batch number.
	Batch(ctx context.Context, in *QueryBatchRequest, opts ...grpc.CallOption) (*QueryBatchResponse, error)
	// BatchForHeight returns a batch created at a given block height.
	BatchForHeight(ctx context.Context, in *QueryBatchForHeightRequest, opts ...grpc.CallOption) (*QueryBatchForHeightResponse, error)
	// Batch returns all batches in the store.
	Batches(ctx context.Context, in *QueryBatchesRequest, opts ...grpc.CallOption) (*QueryBatchesResponse, error)
	// DataResult returns a data result given its associated data request's
	// ID.
	DataResult(ctx context.Context, in *QueryDataResultRequest, opts ...grpc.CallOption) (*QueryDataResultResponse, 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 QueryDataResultRequest

type QueryDataResultRequest struct {
	DataRequestId     string `protobuf:"bytes,1,opt,name=data_request_id,json=dataRequestId,proto3" json:"data_request_id,omitempty"`
	DataRequestHeight uint64 `protobuf:"varint,2,opt,name=data_request_height,json=dataRequestHeight,proto3" json:"data_request_height,omitempty"`
}

The request message for QueryDataResult RPC.

func (*QueryDataResultRequest) Descriptor

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

func (*QueryDataResultRequest) GetDataRequestHeight

func (m *QueryDataResultRequest) GetDataRequestHeight() uint64

func (*QueryDataResultRequest) GetDataRequestId

func (m *QueryDataResultRequest) GetDataRequestId() string

func (*QueryDataResultRequest) Marshal

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

func (*QueryDataResultRequest) MarshalTo

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

func (*QueryDataResultRequest) MarshalToSizedBuffer

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

func (*QueryDataResultRequest) ProtoMessage

func (*QueryDataResultRequest) ProtoMessage()

func (*QueryDataResultRequest) Reset

func (m *QueryDataResultRequest) Reset()

func (*QueryDataResultRequest) Size

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

func (*QueryDataResultRequest) String

func (m *QueryDataResultRequest) String() string

func (*QueryDataResultRequest) Unmarshal

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

func (*QueryDataResultRequest) XXX_DiscardUnknown

func (m *QueryDataResultRequest) XXX_DiscardUnknown()

func (*QueryDataResultRequest) XXX_Marshal

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

func (*QueryDataResultRequest) XXX_Merge

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

func (*QueryDataResultRequest) XXX_Size

func (m *QueryDataResultRequest) XXX_Size() int

func (*QueryDataResultRequest) XXX_Unmarshal

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

type QueryDataResultResponse

type QueryDataResultResponse struct {
	DataResult      *DataResult      `protobuf:"bytes,1,opt,name=data_result,json=dataResult,proto3" json:"data_result,omitempty"`
	BatchAssignment *BatchAssignment `protobuf:"bytes,2,opt,name=batch_assignment,json=batchAssignment,proto3" json:"batch_assignment,omitempty"`
}

The response message for QueryDataResult RPC.

func (*QueryDataResultResponse) Descriptor

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

func (*QueryDataResultResponse) GetBatchAssignment

func (m *QueryDataResultResponse) GetBatchAssignment() *BatchAssignment

func (*QueryDataResultResponse) GetDataResult

func (m *QueryDataResultResponse) GetDataResult() *DataResult

func (*QueryDataResultResponse) Marshal

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

func (*QueryDataResultResponse) MarshalTo

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

func (*QueryDataResultResponse) MarshalToSizedBuffer

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

func (*QueryDataResultResponse) ProtoMessage

func (*QueryDataResultResponse) ProtoMessage()

func (*QueryDataResultResponse) Reset

func (m *QueryDataResultResponse) Reset()

func (*QueryDataResultResponse) Size

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

func (*QueryDataResultResponse) String

func (m *QueryDataResultResponse) String() string

func (*QueryDataResultResponse) Unmarshal

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

func (*QueryDataResultResponse) XXX_DiscardUnknown

func (m *QueryDataResultResponse) XXX_DiscardUnknown()

func (*QueryDataResultResponse) XXX_Marshal

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

func (*QueryDataResultResponse) XXX_Merge

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

func (*QueryDataResultResponse) XXX_Size

func (m *QueryDataResultResponse) XXX_Size() int

func (*QueryDataResultResponse) XXX_Unmarshal

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

type QueryServer

type QueryServer interface {
	// Batch returns a batch given the batch number.
	Batch(context.Context, *QueryBatchRequest) (*QueryBatchResponse, error)
	// BatchForHeight returns a batch created at a given block height.
	BatchForHeight(context.Context, *QueryBatchForHeightRequest) (*QueryBatchForHeightResponse, error)
	// Batch returns all batches in the store.
	Batches(context.Context, *QueryBatchesRequest) (*QueryBatchesResponse, error)
	// DataResult returns a data result given its associated data request's
	// ID.
	DataResult(context.Context, *QueryDataResultRequest) (*QueryDataResultResponse, error)
}

QueryServer is the server API for Query service.

type StakingKeeper

type StakingKeeper interface {
	GetBondedValidatorsByPower(ctx context.Context) ([]stakingtypes.Validator, error)
	GetValidatorUpdates(ctx context.Context) ([]abci.ValidatorUpdate, error)
	IterateLastValidatorPowers(ctx context.Context, handler func(operator sdk.ValAddress, power int64) (stop bool)) error
	GetLastTotalPower(ctx context.Context) (math.Int, error)
}

type UnimplementedQueryServer

type UnimplementedQueryServer struct {
}

UnimplementedQueryServer can be embedded to have forward compatible implementations.

func (*UnimplementedQueryServer) Batch

func (*UnimplementedQueryServer) BatchForHeight

func (*UnimplementedQueryServer) Batches

func (*UnimplementedQueryServer) DataResult

type ValidatorTreeEntry

type ValidatorTreeEntry struct {
	ValidatorAddress   github_com_cosmos_cosmos_sdk_types.ValAddress `` /* 164-byte string literal not displayed */
	VotingPowerPercent uint32                                        `protobuf:"varint,2,opt,name=voting_power_percent,json=votingPowerPercent,proto3" json:"voting_power_percent,omitempty"`
	EthAddress         []byte                                        `protobuf:"bytes,3,opt,name=eth_address,json=ethAddress,proto3" json:"eth_address,omitempty"`
}

ValidatorTreeEntry is an entry in the validator tree.

func (*ValidatorTreeEntry) Descriptor

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

func (*ValidatorTreeEntry) GetEthAddress

func (m *ValidatorTreeEntry) GetEthAddress() []byte

func (*ValidatorTreeEntry) GetValidatorAddress

func (*ValidatorTreeEntry) GetVotingPowerPercent

func (m *ValidatorTreeEntry) GetVotingPowerPercent() uint32

func (*ValidatorTreeEntry) Marshal

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

func (*ValidatorTreeEntry) MarshalTo

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

func (*ValidatorTreeEntry) MarshalToSizedBuffer

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

func (*ValidatorTreeEntry) ProtoMessage

func (*ValidatorTreeEntry) ProtoMessage()

func (*ValidatorTreeEntry) Reset

func (m *ValidatorTreeEntry) Reset()

func (*ValidatorTreeEntry) Size

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

func (*ValidatorTreeEntry) String

func (m *ValidatorTreeEntry) String() string

func (*ValidatorTreeEntry) Unmarshal

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

func (*ValidatorTreeEntry) XXX_DiscardUnknown

func (m *ValidatorTreeEntry) XXX_DiscardUnknown()

func (*ValidatorTreeEntry) XXX_Marshal

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

func (*ValidatorTreeEntry) XXX_Merge

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

func (*ValidatorTreeEntry) XXX_Size

func (m *ValidatorTreeEntry) XXX_Size() int

func (*ValidatorTreeEntry) XXX_Unmarshal

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

type WasmStorageKeeper

type WasmStorageKeeper interface {
	GetCoreContractAddr(ctx context.Context) (sdk.AccAddress, error)
}

Jump to

Keyboard shortcuts

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