diff --git a/proto/oracle/v1/oracle.proto b/proto/oracle/v1/oracle.proto index 95e702ed2..ea07eec9f 100644 --- a/proto/oracle/v1/oracle.proto +++ b/proto/oracle/v1/oracle.proto @@ -351,3 +351,23 @@ message ReportersPerValidator { // validator repeated string reporters = 2 [ (gogoproto.nullable) = false ]; } + +// RequestVerification is a message that is constructed and signed by a reporter +// to be used as a part of verification of oracle request. +message RequestVerification { + option (gogoproto.equal) = true; + // ChainID is the ID of targeted chain + string chain_id = 1 [ (gogoproto.customname) = "ChainID" ]; + // Validator is an validator address + string validator = 2; + // RequestID is the targeted request ID + int64 request_id = 3 [ + (gogoproto.customname) = "RequestID", + (gogoproto.casttype) = "RequestID" + ]; + // ExternalID is the oracle's external ID of data source + int64 external_id = 4 [ + (gogoproto.customname) = "ExternalID", + (gogoproto.casttype) = "ExternalID" + ]; +} diff --git a/proto/oracle/v1/query.proto b/proto/oracle/v1/query.proto index 771a4b3e5..2152a4eb8 100644 --- a/proto/oracle/v1/query.proto +++ b/proto/oracle/v1/query.proto @@ -72,6 +72,13 @@ service Query { option (google.api.http).post = "/oracle/request_prices"; } + // RequestVerification verifies a request to make sure that + // all information that will be used to report the data is valid + rpc RequestVerification(QueryRequestVerificationRequest) + returns (QueryRequestVerificationResponse) { + option (google.api.http).get = "/oracle/v1/verify_request"; + } + // RequestPool queries the request pool information corresponding to the given // port, channel, and request key. rpc RequestPool(QueryRequestPoolRequest) returns (QueryRequestPoolResponse) { @@ -235,6 +242,42 @@ message QueryRequestPriceResponse { int64 min_count = 4; } +// QueryRequestVerificationRequest is request type for the +// Query/RequestVerification RPC +message QueryRequestVerificationRequest { + // ChainID is the chain ID to identify which chain ID is used for the + // verification + string chain_id = 1; + // Validator is a validator address + string validator = 2; + // RequestID is oracle request ID + int64 request_id = 3; + // ExternalID is an oracle's external ID + int64 external_id = 4; + // Reporter is an bech32-encoded public key of the reporter authorized by the + // validator + string reporter = 5; + // Signature is a signature signed by the reporter using reporter's private + // key + bytes signature = 6; +} + +// QueryRequestVerificationResponse is response type for the +// Query/RequestVerification RPC +message QueryRequestVerificationResponse { + // ChainID is the targeted chain ID + string chain_id = 1; + // Validator is the targeted validator address + string validator = 2; + // RequestID is the ID of targeted request + int64 request_id = 3; + // ExternalID is the ID of targeted oracle's external data source + int64 external_id = 4; + // DataSourceID is the ID of a data source that relates to the targeted + // external ID + int64 data_source_id = 5; +} + // QueryRequestPoolRequest is request type for the Query/RequestPool RPC method. message QueryRequestPoolRequest { // RequestKey is a user-generated key for each request pool diff --git a/x/oracle/client/cli/query.go b/x/oracle/client/cli/query.go index e358cd115..ba4b86cbb 100644 --- a/x/oracle/client/cli/query.go +++ b/x/oracle/client/cli/query.go @@ -6,6 +6,8 @@ import ( // "net/http" "context" + "encoding/hex" + "fmt" "strconv" "github.com/cosmos/cosmos-sdk/client" @@ -38,6 +40,7 @@ func GetQueryCmd() *cobra.Command { GetQueryCmdReporters(), GetQueryActiveValidators(), // GetQueryPendingRequests(storeKey, cdc), + GetQueryRequestVerification(), GetQueryRequestPool(), ) return oracleCmd @@ -224,7 +227,7 @@ func GetQueryCmdReporters() *cobra.Command { return err } queryClient := types.NewQueryClient(clientCtx) - r, err := queryClient.Reporters(context.Background(), &types.QueryReportersRequest{ValidatorAddress: args[1]}) + r, err := queryClient.Reporters(context.Background(), &types.QueryReportersRequest{ValidatorAddress: args[0]}) if err != nil { return err } @@ -284,6 +287,51 @@ func GetQueryActiveValidators() *cobra.Command { // } // } +// GetQueryRequestVerification implements the query request verification command. +func GetQueryRequestVerification() *cobra.Command { + cmd := &cobra.Command{ + Use: "verify-request [chain-id] [validator-addr] [request-id] [data-source-external-id] [reporter-pubkey] [reporter-signature-hex]", + Args: cobra.ExactArgs(6), + RunE: func(cmd *cobra.Command, args []string) error { + clientCtx, err := client.GetClientQueryContext(cmd) + if err != nil { + return err + } + queryClient := types.NewQueryClient(clientCtx) + requestID, err := strconv.ParseInt(args[2], 10, 64) + if err != nil { + return fmt.Errorf("unable to parse request ID: %w", err) + } + externalID, err := strconv.ParseInt(args[3], 10, 64) + if err != nil { + return fmt.Errorf("unable to parse external ID: %w", err) + } + + signature, err := hex.DecodeString(args[5]) + if err != nil { + return fmt.Errorf("unable to parse signature: %w", err) + } + + r, err := queryClient.RequestVerification(context.Background(), &types.QueryRequestVerificationRequest{ + ChainId: args[0], + Validator: args[1], + RequestId: requestID, + ExternalId: externalID, + Reporter: args[4], + Signature: signature, + }) + if err != nil { + return err + } + + return clientCtx.PrintProto(r) + }, + } + flags.AddQueryFlagsToCmd(cmd) + + return cmd +} + // GetQueryRequestPool implements the query request pool command. func GetQueryRequestPool() *cobra.Command { cmd := &cobra.Command{ diff --git a/x/oracle/keeper/grpc_query.go b/x/oracle/keeper/grpc_query.go index 867d32a96..db7a7e82c 100644 --- a/x/oracle/keeper/grpc_query.go +++ b/x/oracle/keeper/grpc_query.go @@ -2,6 +2,7 @@ package keeper import ( "context" + "fmt" "github.com/bandprotocol/chain/x/oracle/types" sdk "github.com/cosmos/cosmos-sdk/types" @@ -156,6 +157,110 @@ func (k Querier) RequestPrice(c context.Context, req *types.QueryRequestPriceReq return &types.QueryRequestPriceResponse{}, nil } +// RequestVerification verifies oracle request for validation before executing data sources +func (k Querier) RequestVerification(c context.Context, req *types.QueryRequestVerificationRequest) (*types.QueryRequestVerificationResponse, error) { + // Request should not be empty + if req == nil { + return nil, status.Error(codes.InvalidArgument, "empty request") + } + + ctx := sdk.UnwrapSDKContext(c) + + // Provided chain ID should match current chain ID + if ctx.ChainID() != req.ChainId { + return nil, status.Error(codes.FailedPrecondition, fmt.Sprintf("provided chain ID does not match the validator's chain ID; expected %s, got %s", ctx.ChainID(), req.ChainId)) + } + + // Provided validator's address should be valid + validator, err := sdk.ValAddressFromBech32(req.Validator) + if err != nil { + return nil, status.Error(codes.InvalidArgument, fmt.Sprintf("unable to parse validator address: %s", err.Error())) + } + + // Provided signature should be valid, which means this query request should be signed by the provided reporter + reporterPubKey, err := sdk.GetPubKeyFromBech32(sdk.Bech32PubKeyTypeAccPub, req.Reporter) + if err != nil { + return nil, status.Error(codes.InvalidArgument, fmt.Sprintf("unable to get reporter's public key: %s", err.Error())) + } + requestVerificationContent := types.NewRequestVerification(req.ChainId, validator, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signByte := requestVerificationContent.GetSignBytes() + if !reporterPubKey.VerifySignature(signByte, req.Signature) { + return nil, status.Error(codes.Unauthenticated, "invalid reporter's signature") + } + + // Provided reporter should be authorized by the provided validator + reporters := k.GetReporters(ctx, validator) + reporter := sdk.AccAddress(reporterPubKey.Address().Bytes()) + isReporterAuthorizedByValidator := false + for _, existingReporter := range reporters { + if reporter.Equals(existingReporter) { + isReporterAuthorizedByValidator = true + break + } + } + if !isReporterAuthorizedByValidator { + return nil, status.Error(codes.PermissionDenied, fmt.Sprintf("%s is not an authorized reporter of %s", reporter, req.Validator)) + } + + // Provided request should exist on chain + request, err := k.GetRequest(ctx, types.RequestID(req.RequestId)) + if err != nil { + return nil, status.Error(codes.NotFound, fmt.Sprintf("unable to get request from chain: %s", err.Error())) + } + + // Provided validator should be assigned to response to the request + isValidatorAssigned := false + for _, requestedValidator := range request.RequestedValidators { + v, _ := sdk.ValAddressFromBech32(requestedValidator) + if validator.Equals(v) { + isValidatorAssigned = true + break + } + } + if !isValidatorAssigned { + return nil, status.Error(codes.PermissionDenied, fmt.Sprintf("%s is not assigned for request ID %d", validator, req.RequestId)) + } + + // Provided external ID should be required by the request determined by oracle script + var dataSourceID *types.DataSourceID + for _, rawRequest := range request.RawRequests { + if rawRequest.ExternalID == types.ExternalID(req.ExternalId) { + dataSourceID = &rawRequest.DataSourceID + break + } + } + if dataSourceID == nil { + return nil, status.Error(codes.InvalidArgument, fmt.Sprintf("no data source required by the request %d found which relates to the external data source with ID %d.", req.RequestId, req.ExternalId)) + } + + // Provided validator should not have reported data for the request + reports := k.GetReports(ctx, types.RequestID(req.RequestId)) + isValidatorReported := false + for _, report := range reports { + reportVal, _ := sdk.ValAddressFromBech32(report.Validator) + if reportVal.Equals(validator) { + isValidatorReported = true + break + } + } + if isValidatorReported { + return nil, status.Error(codes.AlreadyExists, fmt.Sprintf("validator %s already submitted data report for this request", validator)) + } + + // The request should not be expired + if request.RequestHeight+int64(k.ExpirationBlockCount(ctx)) < ctx.BlockHeader().Height { + return nil, status.Error(codes.DeadlineExceeded, fmt.Sprintf("Request with ID %d is already expired", req.RequestId)) + } + + return &types.QueryRequestVerificationResponse{ + ChainId: req.ChainId, + Validator: req.Validator, + RequestId: req.RequestId, + ExternalId: req.ExternalId, + DataSourceId: int64(*dataSourceID), + }, nil +} + // RequestPool queries the request pool information func (k Querier) RequestPool(c context.Context, req *types.QueryRequestPoolRequest) (*types.QueryRequestPoolResponse, error) { if req == nil { diff --git a/x/oracle/keeper/grpc_query_test.go b/x/oracle/keeper/grpc_query_test.go new file mode 100644 index 000000000..038b30c4b --- /dev/null +++ b/x/oracle/keeper/grpc_query_test.go @@ -0,0 +1,292 @@ +package keeper_test + +import ( + "testing" + + "github.com/bandprotocol/chain/x/oracle/keeper" + "github.com/bandprotocol/chain/x/oracle/testapp" + "github.com/bandprotocol/chain/x/oracle/types" + "github.com/cosmos/cosmos-sdk/crypto/keys/secp256k1" + cryptotypes "github.com/cosmos/cosmos-sdk/crypto/types" + sdk "github.com/cosmos/cosmos-sdk/types" + "github.com/stretchr/testify/require" + "github.com/stretchr/testify/suite" +) + +type RequestVerificationTestSuite struct { + suite.Suite + + assert *require.Assertions + querier keeper.Querier + request types.Request + + reporterPrivKey cryptotypes.PrivKey + reporterAddr sdk.AccAddress + + ctx sdk.Context +} + +func (suite *RequestVerificationTestSuite) SetupTest() { + suite.assert = require.New(suite.T()) + _, ctx, k := testapp.CreateTestInput(true) + + suite.querier = keeper.Querier{ + Keeper: k, + } + suite.ctx = ctx + + suite.request = types.NewRequest( + 1, + BasicCalldata, + []sdk.ValAddress{testapp.Validators[0].ValAddress}, + 1, + 1, + testapp.ParseTime(0), + "", + []types.RawRequest{ + types.NewRawRequest(1, 1, []byte("testdata")), + types.NewRawRequest(2, 2, []byte("testdata")), + types.NewRawRequest(3, 3, []byte("testdata")), + }, + nil, + 0, + ) + suite.reporterPrivKey = secp256k1.GenPrivKey() + suite.reporterAddr = sdk.AccAddress(suite.reporterPrivKey.PubKey().Address()) + + k.SetRequest(ctx, types.RequestID(1), suite.request) + if err := k.AddReporter(ctx, testapp.Validators[0].ValAddress, suite.reporterAddr); err != nil { + panic(err) + } +} + +func (suite *RequestVerificationTestSuite) TestSuccess() { + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + expectedResult := &types.QueryRequestVerificationResponse{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + DataSourceId: 1, + } + suite.assert.NoError(err, "RequestVerification should success") + suite.assert.Equal(expectedResult, res, "Expected result should be matched") +} + +func (suite *RequestVerificationTestSuite) TestFailedEmptyRequest() { + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), nil) + + suite.assert.Contains(err.Error(), "empty request", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedChainIDNotMatch() { + req := &types.QueryRequestVerificationRequest{ + ChainId: "other-chain-id", + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "provided chain ID does not match the validator's chain ID", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedInvalidValidatorAddr() { + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: "someRandomString", + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "unable to parse validator address", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedInvalidReporterPubKey() { + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: "someRandomString", + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "unable to get reporter's public key", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedEmptySignature() { + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "invalid reporter's signature", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedReporterUnauthorized() { + err := suite.querier.Keeper.RemoveReporter(suite.ctx, testapp.Validators[0].ValAddress, suite.reporterAddr) + suite.assert.NoError(err) + + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "is not an authorized reporter of", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedUnselectedValidator() { + suite.request.RequestedValidators = []string{testapp.Validators[1].ValAddress.String()} + suite.querier.Keeper.SetRequest(suite.ctx, types.RequestID(1), suite.request) + + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "is not assigned for request ID", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedNoDataSourceFound() { + suite.request.RawRequests = []types.RawRequest{} + suite.querier.Keeper.SetRequest(suite.ctx, types.RequestID(1), suite.request) + + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "no data source required by the request", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedValidatorAlreadyReported() { + err := suite.querier.Keeper.AddReport(suite.ctx, types.RequestID(1), types.NewReport(testapp.Validators[0].ValAddress, true, []types.RawReport{ + types.NewRawReport(1, 0, []byte("testdata")), + types.NewRawReport(2, 0, []byte("testdata")), + types.NewRawReport(3, 0, []byte("testdata")), + })) + suite.assert.NoError(err) + + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "already submitted data report", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func (suite *RequestVerificationTestSuite) TestFailedRequestAlreadyExpired() { + req := &types.QueryRequestVerificationRequest{ + ChainId: suite.ctx.ChainID(), + Validator: testapp.Validators[0].ValAddress.String(), + RequestId: 1, + ExternalId: 1, + Reporter: sdk.MustBech32ifyPubKey(sdk.Bech32PubKeyTypeAccPub, suite.reporterPrivKey.PubKey()), + } + + suite.ctx = suite.ctx.WithBlockHeight(1000) + + requestVerification := types.NewRequestVerification(req.ChainId, testapp.Validators[0].ValAddress, types.RequestID(req.RequestId), types.ExternalID(req.ExternalId)) + signature, err := suite.reporterPrivKey.Sign(requestVerification.GetSignBytes()) + suite.assert.NoError(err) + req.Signature = signature + + res, err := suite.querier.RequestVerification(sdk.WrapSDKContext(suite.ctx), req) + + suite.assert.Contains(err.Error(), "Request with ID 1 is already expired", "RequestVerification should failed") + suite.assert.Nil(res, "response should be nil") +} + +func TestRequestVerification(t *testing.T) { + suite.Run(t, new(RequestVerificationTestSuite)) +} diff --git a/x/oracle/types/oracle.pb.go b/x/oracle/types/oracle.pb.go index 3edd1dd2d..31d758200 100644 --- a/x/oracle/types/oracle.pb.go +++ b/x/oracle/types/oracle.pb.go @@ -1362,6 +1362,80 @@ func (m *ReportersPerValidator) GetReporters() []string { return nil } +// RequestVerification is a message that is constructed and signed by a reporter +// to be used as a part of verification of oracle request. +type RequestVerification struct { + // ChainID is the ID of targeted chain + ChainID string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"` + // Validator is an validator address + Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"` + // RequestID is the targeted request ID + RequestID RequestID `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3,casttype=RequestID" json:"request_id,omitempty"` + // ExternalID is the oracle's external ID of data source + ExternalID ExternalID `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3,casttype=ExternalID" json:"external_id,omitempty"` +} + +func (m *RequestVerification) Reset() { *m = RequestVerification{} } +func (m *RequestVerification) String() string { return proto.CompactTextString(m) } +func (*RequestVerification) ProtoMessage() {} +func (*RequestVerification) Descriptor() ([]byte, []int) { + return fileDescriptor_652b57db11528d07, []int{15} +} +func (m *RequestVerification) XXX_Unmarshal(b []byte) error { + return m.Unmarshal(b) +} +func (m *RequestVerification) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + if deterministic { + return xxx_messageInfo_RequestVerification.Marshal(b, m, deterministic) + } else { + b = b[:cap(b)] + n, err := m.MarshalToSizedBuffer(b) + if err != nil { + return nil, err + } + return b[:n], nil + } +} +func (m *RequestVerification) XXX_Merge(src proto.Message) { + xxx_messageInfo_RequestVerification.Merge(m, src) +} +func (m *RequestVerification) XXX_Size() int { + return m.Size() +} +func (m *RequestVerification) XXX_DiscardUnknown() { + xxx_messageInfo_RequestVerification.DiscardUnknown(m) +} + +var xxx_messageInfo_RequestVerification proto.InternalMessageInfo + +func (m *RequestVerification) GetChainID() string { + if m != nil { + return m.ChainID + } + return "" +} + +func (m *RequestVerification) GetValidator() string { + if m != nil { + return m.Validator + } + return "" +} + +func (m *RequestVerification) GetRequestID() RequestID { + if m != nil { + return m.RequestID + } + return 0 +} + +func (m *RequestVerification) GetExternalID() ExternalID { + if m != nil { + return m.ExternalID + } + return 0 +} + func init() { proto.RegisterEnum("oracle.v1.ResolveStatus", ResolveStatus_name, ResolveStatus_value) proto.RegisterType((*DataSource)(nil), "oracle.v1.DataSource") @@ -1379,113 +1453,117 @@ func init() { proto.RegisterType((*PendingResolveList)(nil), "oracle.v1.PendingResolveList") proto.RegisterType((*IBCChannel)(nil), "oracle.v1.IBCChannel") proto.RegisterType((*ReportersPerValidator)(nil), "oracle.v1.ReportersPerValidator") + proto.RegisterType((*RequestVerification)(nil), "oracle.v1.RequestVerification") } func init() { proto.RegisterFile("oracle/v1/oracle.proto", fileDescriptor_652b57db11528d07) } var fileDescriptor_652b57db11528d07 = []byte{ - // 1601 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xdc, 0x57, 0x3b, 0x6c, 0x2b, 0x59, - 0x19, 0xce, 0x78, 0x1c, 0xc7, 0xf3, 0xdb, 0xc9, 0x4d, 0xe6, 0xe6, 0xe1, 0x78, 0x17, 0xdb, 0x44, - 0x8b, 0x14, 0x56, 0x8b, 0x4d, 0x02, 0x42, 0xdc, 0x2c, 0x0f, 0xc5, 0x8e, 0xb3, 0x18, 0xa2, 0x1b, - 0xeb, 0x38, 0x59, 0x01, 0x12, 0x1a, 0x1d, 0xcf, 0x9c, 0x38, 0x47, 0x99, 0x87, 0x39, 0x67, 0x9c, - 0xc4, 0x25, 0x1d, 0xda, 0x6a, 0x1b, 0x24, 0x9a, 0x95, 0x56, 0xa2, 0xa3, 0xa7, 0xa4, 0xa1, 0xda, - 0x8e, 0xad, 0x10, 0x95, 0x17, 0xf9, 0x36, 0x20, 0x6a, 0x1a, 0x68, 0xd0, 0x79, 0x8c, 0x5f, 0xf2, - 0xe5, 0xc2, 0xe5, 0x51, 0x50, 0x79, 0xfe, 0xd7, 0xcc, 0xff, 0xff, 0xdf, 0x77, 0xfe, 0xf3, 0x1b, - 0x76, 0x23, 0x86, 0x5d, 0x9f, 0xd4, 0xee, 0x8f, 0x6a, 0xea, 0xa9, 0xda, 0x67, 0x51, 0x1c, 0xd9, - 0x96, 0x96, 0xee, 0x8f, 0x8a, 0xdb, 0xbd, 0xa8, 0x17, 0x49, 0x6d, 0x4d, 0x3c, 0x29, 0x87, 0x62, - 0xb9, 0x17, 0x45, 0x3d, 0x9f, 0xd4, 0xa4, 0xd4, 0x1d, 0xdc, 0xd4, 0x62, 0x1a, 0x10, 0x1e, 0xe3, - 0xa0, 0xaf, 0x1d, 0xf6, 0x17, 0x1d, 0x70, 0x38, 0xd4, 0xa6, 0x92, 0x1b, 0xf1, 0x20, 0xe2, 0xb5, - 0x2e, 0xe6, 0xe2, 0xcb, 0x5d, 0x12, 0xe3, 0xa3, 0x9a, 0x1b, 0xd1, 0x50, 0xd9, 0x0f, 0xfe, 0x62, - 0x00, 0x9c, 0xe1, 0x18, 0x77, 0xa2, 0x01, 0x73, 0x89, 0xbd, 0x0d, 0xab, 0xd1, 0x43, 0x48, 0x58, - 0xc1, 0xa8, 0x18, 0x87, 0x16, 0x52, 0x82, 0x6d, 0x43, 0x3a, 0xc4, 0x01, 0x29, 0xa4, 0xa4, 0x52, - 0x3e, 0xdb, 0x15, 0xc8, 0x79, 0x84, 0xbb, 0x8c, 0xf6, 0x63, 0x1a, 0x85, 0x05, 0x53, 0x9a, 0x66, - 0x55, 0x76, 0x11, 0xb2, 0x37, 0xd4, 0x27, 0x32, 0x32, 0x2d, 0xcd, 0x13, 0x59, 0xd8, 0x62, 0x46, - 0x30, 0x1f, 0xb0, 0x61, 0x61, 0x55, 0xd9, 0x12, 0xd9, 0xfe, 0x11, 0x98, 0x37, 0x84, 0x14, 0x32, - 0x15, 0xf3, 0x30, 0x77, 0xbc, 0x5f, 0x55, 0x05, 0x54, 0x45, 0x01, 0x55, 0x5d, 0x40, 0xb5, 0x11, - 0xd1, 0xb0, 0xfe, 0xe5, 0x4f, 0x46, 0xe5, 0x95, 0x5f, 0x7e, 0x56, 0x3e, 0xec, 0xd1, 0xf8, 0x76, - 0xd0, 0xad, 0xba, 0x51, 0x50, 0xd3, 0xd5, 0xaa, 0x9f, 0x2f, 0x71, 0xef, 0xae, 0x16, 0x0f, 0xfb, - 0x84, 0xcb, 0x00, 0x8e, 0xc4, 0x7b, 0x4f, 0xd2, 0x7f, 0xfc, 0xb8, 0x6c, 0x1c, 0xfc, 0xd6, 0x80, - 0xfc, 0xa5, 0xec, 0x7b, 0x47, 0x26, 0xfc, 0x3f, 0xab, 0x7c, 0x17, 0x32, 0xdc, 0xbd, 0x25, 0x01, - 0xd6, 0x75, 0x6b, 0xc9, 0x7e, 0x06, 0x4f, 0xb8, 0xc4, 0xc0, 0x71, 0x23, 0x8f, 0x38, 0x03, 0xe6, - 0x17, 0x32, 0xc2, 0xa1, 0xbe, 0x35, 0x1e, 0x95, 0xd7, 0x15, 0x3c, 0x8d, 0xc8, 0x23, 0xd7, 0xe8, - 0x02, 0xad, 0xf3, 0xa9, 0xc8, 0x7c, 0x5d, 0xd1, 0xaf, 0x0c, 0x00, 0x84, 0x1f, 0x10, 0xf9, 0xf1, - 0x80, 0xf0, 0xd8, 0xfe, 0x26, 0xe4, 0xc8, 0x63, 0x4c, 0x58, 0x88, 0x7d, 0x87, 0x7a, 0xb2, 0x2a, - 0xb3, 0xfe, 0xe6, 0x78, 0x54, 0x86, 0xa6, 0x56, 0xb7, 0xce, 0xfe, 0x3a, 0x27, 0x21, 0x48, 0x02, - 0x5a, 0x9e, 0x7d, 0x0e, 0x1b, 0x1e, 0x8e, 0xb1, 0xa3, 0x73, 0xa2, 0x9e, 0x6c, 0x81, 0x59, 0xaf, - 0x8c, 0x47, 0xe5, 0xfc, 0x94, 0x30, 0xf2, 0x1d, 0x73, 0x32, 0xca, 0x7b, 0x53, 0xc9, 0x13, 0xad, - 0x70, 0xb1, 0xef, 0x0b, 0x9d, 0xec, 0x54, 0x1e, 0x4d, 0x64, 0x9d, 0xf7, 0x4f, 0x0c, 0xb0, 0x64, - 0xde, 0xfd, 0x88, 0xfd, 0xdb, 0x69, 0xbf, 0x01, 0x16, 0x79, 0xa4, 0xb1, 0xec, 0xa1, 0xcc, 0x78, - 0x1d, 0x65, 0x85, 0x42, 0xb4, 0x4a, 0x80, 0x39, 0x93, 0x47, 0x7a, 0x26, 0x87, 0x3f, 0x99, 0xb0, - 0x96, 0x34, 0xee, 0x39, 0x6c, 0xaa, 0x03, 0xe9, 0x28, 0x40, 0xa7, 0x69, 0xbc, 0x35, 0x1e, 0x95, - 0x37, 0x66, 0x49, 0x23, 0x53, 0x59, 0xd0, 0xa0, 0x8d, 0x68, 0x56, 0x9e, 0xef, 0x40, 0x6a, 0xbe, - 0x03, 0xf6, 0x11, 0x6c, 0x33, 0xf5, 0x59, 0xe2, 0x39, 0xf7, 0xd8, 0xa7, 0x1e, 0x8e, 0x23, 0xc6, - 0x0b, 0x66, 0xc5, 0x3c, 0xb4, 0xd0, 0xd3, 0x89, 0xed, 0xfd, 0x89, 0x49, 0x54, 0x18, 0xd0, 0xd0, - 0x71, 0xa3, 0x41, 0x18, 0x4b, 0x72, 0xa5, 0x51, 0x36, 0xa0, 0x61, 0x43, 0xc8, 0xf6, 0x17, 0x60, - 0x43, 0xc7, 0x38, 0xb7, 0x84, 0xf6, 0x6e, 0x63, 0x49, 0x32, 0x13, 0xad, 0x6b, 0xed, 0x77, 0xa4, - 0xd2, 0xfe, 0x3c, 0xe4, 0x13, 0x37, 0x31, 0x4a, 0x24, 0xd1, 0xd2, 0x28, 0xa7, 0x75, 0x57, 0x34, - 0x20, 0xf6, 0x17, 0xc1, 0x72, 0x7d, 0x4a, 0x42, 0x59, 0xfe, 0x9a, 0x24, 0x62, 0x7e, 0x3c, 0x2a, - 0x67, 0x1b, 0x52, 0xd9, 0x3a, 0x43, 0x59, 0x65, 0x6e, 0x79, 0xf6, 0xb7, 0x20, 0xcf, 0xf0, 0x83, - 0xa3, 0xa3, 0x79, 0x21, 0x2b, 0x0f, 0xee, 0x4e, 0x75, 0x32, 0xd6, 0xaa, 0x53, 0x5a, 0xd6, 0xd3, - 0xe2, 0xd0, 0xa2, 0x1c, 0x9b, 0x68, 0xb8, 0x7d, 0x0e, 0x39, 0xda, 0x75, 0x1d, 0xf7, 0x16, 0x87, - 0x21, 0xf1, 0x0b, 0x56, 0xc5, 0x58, 0x08, 0x6f, 0xd5, 0x1b, 0x0d, 0x65, 0xac, 0x6f, 0x08, 0x26, - 0x4c, 0x65, 0x04, 0xb4, 0xeb, 0xea, 0x67, 0xbb, 0x2c, 0xa8, 0x43, 0xdc, 0x41, 0x4c, 0x9c, 0x1e, - 0xe6, 0x05, 0x90, 0x45, 0x81, 0x56, 0xbd, 0x87, 0xb9, 0xc6, 0xfa, 0x67, 0x06, 0x64, 0x34, 0xd9, - 0xde, 0x04, 0x6b, 0xd2, 0x74, 0x7d, 0xee, 0xa7, 0x0a, 0xfb, 0x6d, 0xd8, 0xa2, 0xa1, 0xd3, 0x25, - 0x37, 0x11, 0x23, 0x0e, 0x23, 0x3c, 0xf2, 0xef, 0x15, 0xa7, 0xb2, 0xe8, 0x09, 0x0d, 0xeb, 0x52, - 0x8f, 0x94, 0xda, 0x7e, 0x17, 0x72, 0xaa, 0x07, 0xe2, 0xbd, 0x0a, 0xbf, 0xdc, 0xf1, 0xf6, 0x62, - 0x0b, 0x84, 0x51, 0x77, 0x00, 0x58, 0xa2, 0x48, 0xf2, 0xfa, 0xb5, 0x09, 0x7b, 0x8a, 0x4a, 0xba, - 0x33, 0x6d, 0xec, 0xde, 0x91, 0x58, 0x9c, 0xad, 0x79, 0x34, 0x8c, 0x7f, 0x88, 0xc6, 0x32, 0xfa, - 0xa6, 0xfe, 0x43, 0xf4, 0x5d, 0x38, 0xc0, 0x82, 0x8b, 0x98, 0xdf, 0xcd, 0x73, 0x11, 0xf3, 0x3b, - 0xc5, 0xc5, 0x39, 0xa2, 0xae, 0x2e, 0x10, 0xf5, 0x16, 0xac, 0x1b, 0x42, 0x1c, 0x9f, 0x06, 0x34, - 0xfe, 0x6f, 0x4c, 0xfa, 0xec, 0x0d, 0x21, 0x17, 0xe2, 0xe5, 0x82, 0x15, 0x09, 0xd7, 0xef, 0xc8, - 0x50, 0x51, 0x19, 0x81, 0x56, 0x7d, 0x8f, 0x0c, 0x85, 0x43, 0x9f, 0x91, 0x3e, 0x66, 0x8a, 0x36, - 0x59, 0x45, 0x1b, 0xad, 0x7a, 0x0f, 0xf3, 0x45, 0x5e, 0x59, 0x2f, 0xe1, 0x15, 0x81, 0x83, 0x25, - 0xf0, 0x9d, 0xba, 0x77, 0x61, 0xf4, 0xe0, 0x13, 0xaf, 0x47, 0x02, 0x12, 0xc6, 0xf6, 0x33, 0x48, - 0xbe, 0x3d, 0x9d, 0x2b, 0xc5, 0xf1, 0xa8, 0x6c, 0xe9, 0x28, 0x89, 0xc9, 0x54, 0x40, 0x96, 0xf6, - 0x6e, 0x79, 0xfa, 0x33, 0xbf, 0x49, 0x41, 0x21, 0xf9, 0x0e, 0xef, 0x47, 0x21, 0x27, 0xaf, 0xc7, - 0x93, 0xf9, 0x44, 0x52, 0xff, 0x42, 0x22, 0x12, 0xf6, 0x90, 0x6b, 0x64, 0x4d, 0x0d, 0x7b, 0xc8, - 0x15, 0xb2, 0x8b, 0xb3, 0x25, 0x2d, 0x07, 0xd0, 0xdc, 0x6c, 0x91, 0x2e, 0xf2, 0xdc, 0x28, 0x97, - 0xd5, 0xc4, 0x45, 0xea, 0xa4, 0xcb, 0xb7, 0xc5, 0x20, 0x53, 0x2e, 0x3c, 0xc6, 0xf1, 0x80, 0xcb, - 0x19, 0xb5, 0x71, 0x5c, 0x98, 0x3d, 0x52, 0xca, 0xa1, 0x23, 0xed, 0x62, 0xc4, 0xcd, 0x88, 0xe2, - 0x9a, 0x65, 0x84, 0x0f, 0xfc, 0x58, 0x22, 0x9e, 0x47, 0x5a, 0xd2, 0x4d, 0xfc, 0x9d, 0x29, 0x66, - 0x80, 0x50, 0xfc, 0xff, 0x1d, 0xad, 0x79, 0x60, 0x33, 0xaf, 0x0d, 0xec, 0xda, 0x2b, 0x80, 0xcd, - 0xbe, 0x1a, 0x58, 0xeb, 0x9f, 0x01, 0x16, 0x5e, 0x17, 0xd8, 0xdc, 0x12, 0x60, 0xfb, 0xf0, 0x64, - 0x72, 0x57, 0xea, 0x80, 0x37, 0xc0, 0xa2, 0xdc, 0xc1, 0x6e, 0x4c, 0xef, 0x89, 0x04, 0x38, 0x8b, - 0xb2, 0x94, 0x9f, 0x4a, 0xd9, 0x3e, 0x81, 0x55, 0x4e, 0x43, 0x57, 0xcd, 0xf5, 0xdc, 0x71, 0xb1, - 0xaa, 0x36, 0xe9, 0x6a, 0xb2, 0x49, 0x57, 0xaf, 0x92, 0x55, 0xbb, 0x9e, 0x15, 0x43, 0xe8, 0xc3, - 0xcf, 0xca, 0x06, 0x52, 0x21, 0xfa, 0x8b, 0x7f, 0x36, 0x21, 0xd3, 0xc6, 0x0c, 0x07, 0xdc, 0x3e, - 0x82, 0x9d, 0x00, 0x3f, 0x3a, 0x33, 0x97, 0xa1, 0x6e, 0xa5, 0x21, 0x5b, 0x69, 0x07, 0xf8, 0x71, - 0x7a, 0x13, 0xaa, 0xa6, 0x1e, 0xc0, 0xba, 0x08, 0x99, 0x42, 0x9d, 0x52, 0x57, 0x71, 0x80, 0x1f, - 0x4f, 0x13, 0xb4, 0xbf, 0x0a, 0xbb, 0xe4, 0xb1, 0x4f, 0x19, 0x16, 0xbb, 0xa5, 0xd3, 0xf5, 0x23, - 0xf7, 0x6e, 0xee, 0xec, 0x6d, 0x4f, 0xad, 0x75, 0x61, 0x54, 0x51, 0x6f, 0xc1, 0x86, 0x18, 0xa4, - 0x4e, 0xf4, 0x80, 0x79, 0x20, 0x07, 0x97, 0x62, 0x51, 0x5e, 0x68, 0x2f, 0x85, 0x52, 0xcc, 0xb6, - 0x67, 0xb0, 0xdf, 0x27, 0x6c, 0xba, 0x7a, 0x4c, 0x12, 0x17, 0x01, 0x8a, 0x59, 0xbb, 0x7d, 0xc2, - 0x26, 0x3d, 0xd5, 0xc9, 0x8b, 0xd0, 0x77, 0xc0, 0xe6, 0x38, 0xe8, 0xfb, 0x34, 0xec, 0x39, 0x31, - 0x1b, 0xea, 0x94, 0xd4, 0x2a, 0xb1, 0x99, 0x58, 0xae, 0xd8, 0x50, 0xa5, 0xf3, 0x75, 0x28, 0xe8, - 0xb3, 0xc3, 0xc8, 0x03, 0x66, 0x9e, 0xd3, 0x27, 0xcc, 0x25, 0x61, 0x8c, 0x7b, 0x44, 0x33, 0x4d, - 0xff, 0x3d, 0x42, 0xd2, 0xdc, 0x9e, 0x58, 0xed, 0x13, 0xd8, 0xa7, 0xa1, 0x82, 0xcf, 0xe9, 0x93, - 0x10, 0xfb, 0xf1, 0xd0, 0xf1, 0x06, 0xaa, 0x5e, 0x3d, 0xad, 0xf7, 0x12, 0x87, 0xb6, 0xb2, 0x9f, - 0x69, 0xb3, 0xdd, 0x84, 0xa7, 0x62, 0xb5, 0x48, 0x8a, 0x22, 0x21, 0xee, 0xfa, 0xc4, 0x93, 0xbc, - 0xcc, 0xd6, 0x77, 0xc6, 0xa3, 0xf2, 0x56, 0xab, 0xde, 0xd0, 0x35, 0x35, 0x95, 0x11, 0x6d, 0xd1, - 0xae, 0x3b, 0xaf, 0x3a, 0xc9, 0xfe, 0xfc, 0xe3, 0xf2, 0x8a, 0x44, 0xfb, 0x5d, 0xb0, 0xdb, 0x24, - 0xf4, 0x68, 0xd8, 0xd3, 0x24, 0xbd, 0xa0, 0x7c, 0xee, 0x8e, 0xa1, 0x1e, 0x2f, 0x18, 0x15, 0xf3, - 0xd0, 0x9c, 0xdc, 0x31, 0x2d, 0x2f, 0xb9, 0x21, 0xbe, 0x0b, 0x33, 0xab, 0x8b, 0xbd, 0x07, 0x6b, - 0xe2, 0xfa, 0x9f, 0x8c, 0x1d, 0x94, 0x11, 0x62, 0xcb, 0xb3, 0x3f, 0x07, 0xa0, 0x77, 0xa1, 0x64, - 0xc0, 0x58, 0xc8, 0xd2, 0x9a, 0xc9, 0x35, 0xf0, 0x03, 0xd8, 0x51, 0xeb, 0x03, 0x61, 0xbc, 0x3d, - 0x03, 0xd0, 0x2b, 0x76, 0x9a, 0x03, 0xb0, 0x58, 0x12, 0x56, 0x48, 0x89, 0x2d, 0x53, 0xef, 0x23, - 0x53, 0xf5, 0xdb, 0x7f, 0x33, 0x60, 0x7d, 0xee, 0x08, 0xda, 0xdf, 0x80, 0x32, 0x6a, 0x76, 0x2e, - 0x2f, 0xde, 0x6f, 0x3a, 0x9d, 0xab, 0xd3, 0xab, 0xeb, 0x8e, 0x73, 0xd9, 0x6e, 0x3e, 0x77, 0xae, - 0x9f, 0x77, 0xda, 0xcd, 0x46, 0xeb, 0xbc, 0xd5, 0x3c, 0xdb, 0x5c, 0x29, 0xee, 0x7d, 0xf0, 0x51, - 0xe5, 0xe9, 0x12, 0x37, 0xfb, 0x6b, 0xb0, 0xbb, 0xa0, 0xee, 0x5c, 0x37, 0x1a, 0xcd, 0x4e, 0x67, - 0xd3, 0x28, 0x16, 0x3f, 0xf8, 0xa8, 0xf2, 0x12, 0xeb, 0x92, 0xb8, 0xf3, 0xd3, 0xd6, 0xc5, 0x35, - 0x6a, 0x6e, 0xa6, 0x96, 0xc6, 0x69, 0xeb, 0x92, 0xb8, 0xe6, 0xf7, 0xdb, 0x2d, 0xd4, 0x3c, 0xdb, - 0x34, 0x97, 0xc6, 0x69, 0x6b, 0x31, 0xfd, 0xd3, 0x5f, 0x94, 0x56, 0xea, 0xe7, 0x9f, 0x8c, 0x4b, - 0xc6, 0xa7, 0xe3, 0x92, 0xf1, 0x87, 0x71, 0xc9, 0xf8, 0xf0, 0x45, 0x69, 0xe5, 0xd3, 0x17, 0xa5, - 0x95, 0xdf, 0xbf, 0x28, 0xad, 0xfc, 0xf0, 0x9d, 0x99, 0xed, 0xa3, 0x8b, 0x43, 0x4f, 0xce, 0x08, - 0x37, 0xf2, 0x6b, 0xee, 0x2d, 0xa6, 0x61, 0xed, 0x51, 0xff, 0xab, 0x57, 0x7b, 0x48, 0x37, 0x23, - 0xcd, 0x5f, 0xf9, 0x7b, 0x00, 0x00, 0x00, 0xff, 0xff, 0x34, 0x8d, 0x61, 0xea, 0xf6, 0x0f, 0x00, - 0x00, + // 1661 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xdc, 0x58, 0x4d, 0x6c, 0x23, 0x49, + 0x15, 0x4e, 0xbb, 0x9d, 0xa4, 0xfb, 0xd9, 0xc9, 0x64, 0x7a, 0x32, 0x19, 0x8f, 0x77, 0x49, 0x9b, + 0x68, 0x41, 0x61, 0xb5, 0xd8, 0x64, 0x40, 0x88, 0x99, 0xe5, 0x47, 0xb1, 0xe3, 0x2c, 0x86, 0x68, + 0x62, 0x95, 0x93, 0x11, 0x20, 0xa1, 0x56, 0xb9, 0xbb, 0xe2, 0x94, 0xd2, 0x3f, 0xa6, 0xaa, 0x9d, + 0x9f, 0x23, 0x37, 0xb4, 0xa7, 0xbd, 0x20, 0x71, 0x59, 0x69, 0x25, 0x6e, 0xdc, 0x39, 0x72, 0xe1, + 0xb4, 0x37, 0xf6, 0x84, 0x90, 0x90, 0xbc, 0xc8, 0x73, 0x01, 0x71, 0xe6, 0x02, 0x17, 0x54, 0x3f, + 0x6d, 0xbb, 0xad, 0x0c, 0xc3, 0x0c, 0x3f, 0x87, 0x3d, 0xa5, 0xdf, 0x5f, 0xf7, 0x7b, 0xef, 0xfb, + 0xea, 0xd5, 0x73, 0x60, 0x2b, 0x61, 0xd8, 0x0f, 0x49, 0xe3, 0x72, 0xaf, 0xa1, 0x9e, 0xea, 0x43, + 0x96, 0xa4, 0x89, 0x63, 0x6b, 0xe9, 0x72, 0xaf, 0xba, 0x39, 0x48, 0x06, 0x89, 0xd4, 0x36, 0xc4, + 0x93, 0x72, 0xa8, 0xba, 0x83, 0x24, 0x19, 0x84, 0xa4, 0x21, 0xa5, 0xfe, 0xe8, 0xac, 0x91, 0xd2, + 0x88, 0xf0, 0x14, 0x47, 0x43, 0xed, 0xf0, 0x70, 0xd1, 0x01, 0xc7, 0x37, 0xda, 0xb4, 0xed, 0x27, + 0x3c, 0x4a, 0x78, 0xa3, 0x8f, 0xb9, 0xf8, 0x72, 0x9f, 0xa4, 0x78, 0xaf, 0xe1, 0x27, 0x34, 0x56, + 0xf6, 0x9d, 0xbf, 0x19, 0x00, 0x07, 0x38, 0xc5, 0xbd, 0x64, 0xc4, 0x7c, 0xe2, 0x6c, 0xc2, 0x72, + 0x72, 0x15, 0x13, 0x56, 0x31, 0x6a, 0xc6, 0xae, 0x8d, 0x94, 0xe0, 0x38, 0x50, 0x8c, 0x71, 0x44, + 0x2a, 0x05, 0xa9, 0x94, 0xcf, 0x4e, 0x0d, 0x4a, 0x01, 0xe1, 0x3e, 0xa3, 0xc3, 0x94, 0x26, 0x71, + 0xc5, 0x94, 0xa6, 0x79, 0x95, 0x53, 0x05, 0xeb, 0x8c, 0x86, 0x44, 0x46, 0x16, 0xa5, 0x79, 0x2a, + 0x0b, 0x5b, 0xca, 0x08, 0xe6, 0x23, 0x76, 0x53, 0x59, 0x56, 0xb6, 0x4c, 0x76, 0x7e, 0x0c, 0xe6, + 0x19, 0x21, 0x95, 0x95, 0x9a, 0xb9, 0x5b, 0x7a, 0xf4, 0xb0, 0xae, 0x0a, 0xa8, 0x8b, 0x02, 0xea, + 0xba, 0x80, 0x7a, 0x2b, 0xa1, 0x71, 0xf3, 0x2b, 0x1f, 0x8f, 0xdd, 0xa5, 0x5f, 0x7d, 0xea, 0xee, + 0x0e, 0x68, 0x7a, 0x3e, 0xea, 0xd7, 0xfd, 0x24, 0x6a, 0xe8, 0x6a, 0xd5, 0x9f, 0x2f, 0xf3, 0xe0, + 0xa2, 0x91, 0xde, 0x0c, 0x09, 0x97, 0x01, 0x1c, 0x89, 0xf7, 0x3e, 0x29, 0xfe, 0xf9, 0x23, 0xd7, + 0xd8, 0xf9, 0x9d, 0x01, 0xe5, 0x63, 0xd9, 0xf7, 0x9e, 0x4c, 0xf8, 0xff, 0x56, 0xf9, 0x16, 0xac, + 0x70, 0xff, 0x9c, 0x44, 0x58, 0xd7, 0xad, 0x25, 0xe7, 0x31, 0xdc, 0xe1, 0x12, 0x03, 0xcf, 0x4f, + 0x02, 0xe2, 0x8d, 0x58, 0x58, 0x59, 0x11, 0x0e, 0xcd, 0xbb, 0x93, 0xb1, 0xbb, 0xa6, 0xe0, 0x69, + 0x25, 0x01, 0x39, 0x45, 0x47, 0x68, 0x8d, 0xcf, 0x44, 0x16, 0xea, 0x8a, 0x7e, 0x6d, 0x00, 0x20, + 0x7c, 0x85, 0xc8, 0x4f, 0x46, 0x84, 0xa7, 0xce, 0xb7, 0xa0, 0x44, 0xae, 0x53, 0xc2, 0x62, 0x1c, + 0x7a, 0x34, 0x90, 0x55, 0x99, 0xcd, 0x37, 0x27, 0x63, 0x17, 0xda, 0x5a, 0xdd, 0x39, 0xf8, 0x7b, + 0x4e, 0x42, 0x90, 0x05, 0x74, 0x02, 0xe7, 0x10, 0xd6, 0x03, 0x9c, 0x62, 0x4f, 0xe7, 0x44, 0x03, + 0xd9, 0x02, 0xb3, 0x59, 0x9b, 0x8c, 0xdd, 0xf2, 0x8c, 0x30, 0xf2, 0x1d, 0x39, 0x19, 0x95, 0x83, + 0x99, 0x14, 0x88, 0x56, 0xf8, 0x38, 0x0c, 0x85, 0x4e, 0x76, 0xaa, 0x8c, 0xa6, 0xb2, 0xce, 0xfb, + 0xa7, 0x06, 0xd8, 0x32, 0xef, 0x61, 0xc2, 0xfe, 0xe3, 0xb4, 0xdf, 0x00, 0x9b, 0x5c, 0xd3, 0x54, + 0xf6, 0x50, 0x66, 0xbc, 0x86, 0x2c, 0xa1, 0x10, 0xad, 0x12, 0x60, 0xce, 0xe5, 0x51, 0x9c, 0xcb, + 0xe1, 0x2f, 0x26, 0xac, 0x66, 0x8d, 0x7b, 0x0a, 0x1b, 0xea, 0x40, 0x7a, 0x0a, 0xd0, 0x59, 0x1a, + 0x6f, 0x4d, 0xc6, 0xee, 0xfa, 0x3c, 0x69, 0x64, 0x2a, 0x0b, 0x1a, 0xb4, 0x9e, 0xcc, 0xcb, 0xf9, + 0x0e, 0x14, 0xf2, 0x1d, 0x70, 0xf6, 0x60, 0x93, 0xa9, 0xcf, 0x92, 0xc0, 0xbb, 0xc4, 0x21, 0x0d, + 0x70, 0x9a, 0x30, 0x5e, 0x31, 0x6b, 0xe6, 0xae, 0x8d, 0xee, 0x4d, 0x6d, 0xcf, 0xa6, 0x26, 0x51, + 0x61, 0x44, 0x63, 0xcf, 0x4f, 0x46, 0x71, 0x2a, 0xc9, 0x55, 0x44, 0x56, 0x44, 0xe3, 0x96, 0x90, + 0x9d, 0x2f, 0xc0, 0xba, 0x8e, 0xf1, 0xce, 0x09, 0x1d, 0x9c, 0xa7, 0x92, 0x64, 0x26, 0x5a, 0xd3, + 0xda, 0xef, 0x4a, 0xa5, 0xf3, 0x79, 0x28, 0x67, 0x6e, 0x62, 0x94, 0x48, 0xa2, 0x15, 0x51, 0x49, + 0xeb, 0x4e, 0x68, 0x44, 0x9c, 0x2f, 0x81, 0xed, 0x87, 0x94, 0xc4, 0xb2, 0xfc, 0x55, 0x49, 0xc4, + 0xf2, 0x64, 0xec, 0x5a, 0x2d, 0xa9, 0xec, 0x1c, 0x20, 0x4b, 0x99, 0x3b, 0x81, 0xf3, 0x6d, 0x28, + 0x33, 0x7c, 0xe5, 0xe9, 0x68, 0x5e, 0xb1, 0xe4, 0xc1, 0xbd, 0x5f, 0x9f, 0x8e, 0xb5, 0xfa, 0x8c, + 0x96, 0xcd, 0xa2, 0x38, 0xb4, 0xa8, 0xc4, 0xa6, 0x1a, 0xee, 0x1c, 0x42, 0x89, 0xf6, 0x7d, 0xcf, + 0x3f, 0xc7, 0x71, 0x4c, 0xc2, 0x8a, 0x5d, 0x33, 0x16, 0xc2, 0x3b, 0xcd, 0x56, 0x4b, 0x19, 0x9b, + 0xeb, 0x82, 0x09, 0x33, 0x19, 0x01, 0xed, 0xfb, 0xfa, 0xd9, 0x71, 0x05, 0x75, 0x88, 0x3f, 0x4a, + 0x89, 0x37, 0xc0, 0xbc, 0x02, 0xb2, 0x28, 0xd0, 0xaa, 0xf7, 0x30, 0xd7, 0x58, 0xff, 0xdc, 0x80, + 0x15, 0x4d, 0xb6, 0x37, 0xc1, 0x9e, 0x36, 0x5d, 0x9f, 0xfb, 0x99, 0xc2, 0x79, 0x1b, 0xee, 0xd2, + 0xd8, 0xeb, 0x93, 0xb3, 0x84, 0x11, 0x8f, 0x11, 0x9e, 0x84, 0x97, 0x8a, 0x53, 0x16, 0xba, 0x43, + 0xe3, 0xa6, 0xd4, 0x23, 0xa5, 0x76, 0xde, 0x85, 0x92, 0xea, 0x81, 0x78, 0xaf, 0xc2, 0xaf, 0xf4, + 0x68, 0x73, 0xb1, 0x05, 0xc2, 0xa8, 0x3b, 0x00, 0x2c, 0x53, 0x64, 0x79, 0xfd, 0xc6, 0x84, 0x07, + 0x8a, 0x4a, 0xba, 0x33, 0x5d, 0xec, 0x5f, 0x90, 0x54, 0x9c, 0xad, 0x3c, 0x1a, 0xc6, 0xbf, 0x44, + 0xe3, 0x36, 0xfa, 0x16, 0xfe, 0x4b, 0xf4, 0x5d, 0x38, 0xc0, 0x82, 0x8b, 0x98, 0x5f, 0xe4, 0xb9, + 0x88, 0xf9, 0x85, 0xe2, 0x62, 0x8e, 0xa8, 0xcb, 0x0b, 0x44, 0x3d, 0x07, 0xfb, 0x8c, 0x10, 0x2f, + 0xa4, 0x11, 0x4d, 0xff, 0x17, 0x93, 0xde, 0x3a, 0x23, 0xe4, 0x48, 0xbc, 0x5c, 0xb0, 0x22, 0xe3, + 0xfa, 0x05, 0xb9, 0x51, 0x54, 0x46, 0xa0, 0x55, 0xdf, 0x27, 0x37, 0xc2, 0x61, 0xc8, 0xc8, 0x10, + 0x33, 0x45, 0x1b, 0x4b, 0xd1, 0x46, 0xab, 0xde, 0xc3, 0x7c, 0x91, 0x57, 0xf6, 0x0b, 0x78, 0x45, + 0x60, 0xe7, 0x16, 0xf8, 0xf6, 0xfd, 0x8b, 0x38, 0xb9, 0x0a, 0x49, 0x30, 0x20, 0x11, 0x89, 0x53, + 0xe7, 0x31, 0x64, 0xdf, 0x9e, 0xcd, 0x95, 0xea, 0x64, 0xec, 0xda, 0x3a, 0x4a, 0x62, 0x32, 0x13, + 0x90, 0xad, 0xbd, 0x3b, 0x81, 0xfe, 0xcc, 0x6f, 0x0b, 0x50, 0xc9, 0xbe, 0xc3, 0x87, 0x49, 0xcc, + 0xc9, 0xeb, 0xf1, 0x24, 0x9f, 0x48, 0xe1, 0x15, 0x12, 0x91, 0xb0, 0xc7, 0x5c, 0x23, 0x6b, 0x6a, + 0xd8, 0x63, 0xae, 0x90, 0x5d, 0x9c, 0x2d, 0x45, 0x39, 0x80, 0x72, 0xb3, 0x45, 0xba, 0xc8, 0x73, + 0xa3, 0x5c, 0x96, 0x33, 0x17, 0xa9, 0x93, 0x2e, 0xdf, 0x11, 0x83, 0x4c, 0xb9, 0xf0, 0x14, 0xa7, + 0x23, 0x2e, 0x67, 0xd4, 0xfa, 0xa3, 0xca, 0xfc, 0x91, 0x52, 0x0e, 0x3d, 0x69, 0x17, 0x23, 0x6e, + 0x4e, 0x14, 0xd7, 0x2c, 0x23, 0x7c, 0x14, 0xa6, 0x12, 0xf1, 0x32, 0xd2, 0x92, 0x6e, 0xe2, 0xef, + 0x4d, 0x31, 0x03, 0x84, 0xe2, 0xb3, 0x77, 0xb4, 0xf2, 0xc0, 0xae, 0xbc, 0x36, 0xb0, 0xab, 0x2f, + 0x01, 0xd6, 0x7a, 0x39, 0xb0, 0xf6, 0xbf, 0x03, 0x2c, 0xbc, 0x2e, 0xb0, 0xa5, 0x5b, 0x80, 0x1d, + 0xc2, 0x9d, 0xe9, 0x5d, 0xa9, 0x03, 0xde, 0x00, 0x9b, 0x72, 0x0f, 0xfb, 0x29, 0xbd, 0x24, 0x12, + 0x60, 0x0b, 0x59, 0x94, 0xef, 0x4b, 0xd9, 0x79, 0x02, 0xcb, 0x9c, 0xc6, 0xbe, 0x9a, 0xeb, 0xa5, + 0x47, 0xd5, 0xba, 0xda, 0xa4, 0xeb, 0xd9, 0x26, 0x5d, 0x3f, 0xc9, 0x56, 0xed, 0xa6, 0x25, 0x86, + 0xd0, 0x07, 0x9f, 0xba, 0x06, 0x52, 0x21, 0xfa, 0x8b, 0x7f, 0x35, 0x61, 0xa5, 0x8b, 0x19, 0x8e, + 0xb8, 0xb3, 0x07, 0xf7, 0x23, 0x7c, 0xed, 0xcd, 0x5d, 0x86, 0xba, 0x95, 0x86, 0x6c, 0xa5, 0x13, + 0xe1, 0xeb, 0xd9, 0x4d, 0xa8, 0x9a, 0xba, 0x03, 0x6b, 0x22, 0x64, 0x06, 0x75, 0x41, 0x5d, 0xc5, + 0x11, 0xbe, 0xde, 0xcf, 0xd0, 0xfe, 0x1a, 0x6c, 0x91, 0xeb, 0x21, 0x65, 0x58, 0xec, 0x96, 0x5e, + 0x3f, 0x4c, 0xfc, 0x8b, 0xdc, 0xd9, 0xdb, 0x9c, 0x59, 0x9b, 0xc2, 0xa8, 0xa2, 0xde, 0x82, 0x75, + 0x31, 0x48, 0xbd, 0xe4, 0x0a, 0xf3, 0x48, 0x0e, 0x2e, 0xc5, 0xa2, 0xb2, 0xd0, 0x1e, 0x0b, 0xa5, + 0x98, 0x6d, 0x8f, 0xe1, 0xe1, 0x90, 0xb0, 0xd9, 0xea, 0x31, 0x4d, 0x5c, 0x04, 0x28, 0x66, 0x6d, + 0x0d, 0x09, 0x9b, 0xf6, 0x54, 0x27, 0x2f, 0x42, 0xdf, 0x01, 0x87, 0xe3, 0x68, 0x18, 0xd2, 0x78, + 0xe0, 0xa5, 0xec, 0x46, 0xa7, 0xa4, 0x56, 0x89, 0x8d, 0xcc, 0x72, 0xc2, 0x6e, 0x54, 0x3a, 0xdf, + 0x80, 0x8a, 0x3e, 0x3b, 0x8c, 0x5c, 0x61, 0x16, 0x78, 0x43, 0xc2, 0x7c, 0x12, 0xa7, 0x78, 0x40, + 0x34, 0xd3, 0xf4, 0xcf, 0x23, 0x24, 0xcd, 0xdd, 0xa9, 0xd5, 0x79, 0x02, 0x0f, 0x69, 0xac, 0xe0, + 0xf3, 0x86, 0x24, 0xc6, 0x61, 0x7a, 0xe3, 0x05, 0x23, 0x55, 0xaf, 0x9e, 0xd6, 0x0f, 0x32, 0x87, + 0xae, 0xb2, 0x1f, 0x68, 0xb3, 0xd3, 0x86, 0x7b, 0x62, 0xb5, 0xc8, 0x8a, 0x22, 0x31, 0xee, 0x87, + 0x24, 0x90, 0xbc, 0xb4, 0x9a, 0xf7, 0x27, 0x63, 0xf7, 0x6e, 0xa7, 0xd9, 0xd2, 0x35, 0xb5, 0x95, + 0x11, 0xdd, 0xa5, 0x7d, 0x3f, 0xaf, 0x7a, 0x62, 0xfd, 0xe2, 0x23, 0x77, 0x49, 0xa2, 0xfd, 0x2e, + 0x38, 0x5d, 0x12, 0x07, 0x34, 0x1e, 0x68, 0x92, 0x1e, 0x51, 0x9e, 0xbb, 0x63, 0x68, 0xc0, 0x2b, + 0x46, 0xcd, 0xdc, 0x35, 0xa7, 0x77, 0x4c, 0x27, 0xc8, 0x6e, 0x88, 0xef, 0xc1, 0xdc, 0xea, 0xe2, + 0x3c, 0x80, 0x55, 0x71, 0xfd, 0x4f, 0xc7, 0x0e, 0x5a, 0x11, 0x62, 0x27, 0x70, 0x3e, 0x07, 0xa0, + 0x77, 0xa1, 0x6c, 0xc0, 0xd8, 0xc8, 0xd6, 0x9a, 0xe9, 0x35, 0xf0, 0x43, 0xb8, 0xaf, 0xd6, 0x07, + 0xc2, 0x78, 0x77, 0x0e, 0xa0, 0x97, 0xec, 0x34, 0x3b, 0x60, 0xb3, 0x2c, 0xac, 0x52, 0x10, 0x5b, + 0xa6, 0xde, 0x47, 0x66, 0xea, 0x9d, 0x3f, 0x1a, 0x70, 0x4f, 0x37, 0xe0, 0x19, 0x61, 0xf4, 0x8c, + 0xfa, 0xaa, 0x99, 0x5f, 0x04, 0xcb, 0x3f, 0xc7, 0x34, 0x9e, 0x0d, 0xca, 0xd2, 0x64, 0xec, 0xae, + 0xb6, 0x84, 0xae, 0x73, 0x80, 0x56, 0xa5, 0xb1, 0x13, 0xe4, 0x33, 0x28, 0x2c, 0x66, 0x90, 0x1f, + 0x4f, 0xe6, 0xab, 0x8c, 0xa7, 0x85, 0xdf, 0x06, 0xc5, 0x57, 0xfb, 0x6d, 0xa0, 0x1a, 0xf7, 0xf6, + 0x3f, 0x0c, 0x58, 0xcb, 0x0d, 0x18, 0xe7, 0x9b, 0xe0, 0xa2, 0x76, 0xef, 0xf8, 0xe8, 0x59, 0xdb, + 0xeb, 0x9d, 0xec, 0x9f, 0x9c, 0xf6, 0xbc, 0xe3, 0x6e, 0xfb, 0xa9, 0x77, 0xfa, 0xb4, 0xd7, 0x6d, + 0xb7, 0x3a, 0x87, 0x9d, 0xf6, 0xc1, 0xc6, 0x52, 0xf5, 0xc1, 0xfb, 0x1f, 0xd6, 0xee, 0xdd, 0xe2, + 0xe6, 0x7c, 0x1d, 0xb6, 0x16, 0xd4, 0xbd, 0xd3, 0x56, 0xab, 0xdd, 0xeb, 0x6d, 0x18, 0xd5, 0xea, + 0xfb, 0x1f, 0xd6, 0x5e, 0x60, 0xbd, 0x25, 0xee, 0x70, 0xbf, 0x73, 0x74, 0x8a, 0xda, 0x1b, 0x85, + 0x5b, 0xe3, 0xb4, 0xf5, 0x96, 0xb8, 0xf6, 0x0f, 0xba, 0x1d, 0xd4, 0x3e, 0xd8, 0x30, 0x6f, 0x8d, + 0xd3, 0xd6, 0x6a, 0xf1, 0x67, 0xbf, 0xdc, 0x5e, 0x6a, 0x1e, 0x7e, 0x3c, 0xd9, 0x36, 0x3e, 0x99, + 0x6c, 0x1b, 0x7f, 0x9a, 0x6c, 0x1b, 0x1f, 0x3c, 0xdf, 0x5e, 0xfa, 0xe4, 0xf9, 0xf6, 0xd2, 0x1f, + 0x9e, 0x6f, 0x2f, 0xfd, 0xe8, 0x9d, 0xb9, 0xdd, 0xaa, 0x8f, 0xe3, 0x40, 0x4e, 0x40, 0x3f, 0x09, + 0x1b, 0x12, 0xd6, 0xc6, 0xb5, 0xfe, 0x9f, 0x85, 0xda, 0xb2, 0xfa, 0x2b, 0xd2, 0xfc, 0xd5, 0x7f, + 0x06, 0x00, 0x00, 0xff, 0xff, 0x4e, 0x48, 0x9f, 0x7e, 0xd4, 0x10, 0x00, 0x00, } func (this *DataSource) Equal(that interface{}) bool { @@ -2031,6 +2109,39 @@ func (this *IBCChannel) Equal(that interface{}) bool { } return true } +func (this *RequestVerification) Equal(that interface{}) bool { + if that == nil { + return this == nil + } + + that1, ok := that.(*RequestVerification) + if !ok { + that2, ok := that.(RequestVerification) + if ok { + that1 = &that2 + } else { + return false + } + } + if that1 == nil { + return this == nil + } else if this == nil { + return false + } + if this.ChainID != that1.ChainID { + return false + } + if this.Validator != that1.Validator { + return false + } + if this.RequestID != that1.RequestID { + return false + } + if this.ExternalID != that1.ExternalID { + return false + } + return true +} func (m *DataSource) Marshal() (dAtA []byte, err error) { size := m.Size() dAtA = make([]byte, size) @@ -2888,6 +2999,53 @@ func (m *ReportersPerValidator) MarshalToSizedBuffer(dAtA []byte) (int, error) { return len(dAtA) - i, nil } +func (m *RequestVerification) Marshal() (dAtA []byte, err error) { + size := m.Size() + dAtA = make([]byte, size) + n, err := m.MarshalToSizedBuffer(dAtA[:size]) + if err != nil { + return nil, err + } + return dAtA[:n], nil +} + +func (m *RequestVerification) MarshalTo(dAtA []byte) (int, error) { + size := m.Size() + return m.MarshalToSizedBuffer(dAtA[:size]) +} + +func (m *RequestVerification) MarshalToSizedBuffer(dAtA []byte) (int, error) { + i := len(dAtA) + _ = i + var l int + _ = l + if m.ExternalID != 0 { + i = encodeVarintOracle(dAtA, i, uint64(m.ExternalID)) + i-- + dAtA[i] = 0x20 + } + if m.RequestID != 0 { + i = encodeVarintOracle(dAtA, i, uint64(m.RequestID)) + i-- + dAtA[i] = 0x18 + } + if len(m.Validator) > 0 { + i -= len(m.Validator) + copy(dAtA[i:], m.Validator) + i = encodeVarintOracle(dAtA, i, uint64(len(m.Validator))) + i-- + dAtA[i] = 0x12 + } + if len(m.ChainID) > 0 { + i -= len(m.ChainID) + copy(dAtA[i:], m.ChainID) + i = encodeVarintOracle(dAtA, i, uint64(len(m.ChainID))) + i-- + dAtA[i] = 0xa + } + return len(dAtA) - i, nil +} + func encodeVarintOracle(dAtA []byte, offset int, v uint64) int { offset -= sovOracle(v) base := offset @@ -3308,6 +3466,29 @@ func (m *ReportersPerValidator) Size() (n int) { return n } +func (m *RequestVerification) Size() (n int) { + if m == nil { + return 0 + } + var l int + _ = l + l = len(m.ChainID) + if l > 0 { + n += 1 + l + sovOracle(uint64(l)) + } + l = len(m.Validator) + if l > 0 { + n += 1 + l + sovOracle(uint64(l)) + } + if m.RequestID != 0 { + n += 1 + sovOracle(uint64(m.RequestID)) + } + if m.ExternalID != 0 { + n += 1 + sovOracle(uint64(m.ExternalID)) + } + return n +} + func sovOracle(x uint64) (n int) { return (math_bits.Len64(x|1) + 6) / 7 } @@ -6031,6 +6212,158 @@ func (m *ReportersPerValidator) Unmarshal(dAtA []byte) error { } return nil } +func (m *RequestVerification) Unmarshal(dAtA []byte) error { + l := len(dAtA) + iNdEx := 0 + for iNdEx < l { + preIndex := iNdEx + var wire uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowOracle + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + wire |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + fieldNum := int32(wire >> 3) + wireType := int(wire & 0x7) + if wireType == 4 { + return fmt.Errorf("proto: RequestVerification: wiretype end group for non-group") + } + if fieldNum <= 0 { + return fmt.Errorf("proto: RequestVerification: illegal tag %d (wire type %d)", fieldNum, wire) + } + switch fieldNum { + case 1: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field ChainID", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowOracle + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthOracle + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthOracle + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.ChainID = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 2: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field Validator", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowOracle + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthOracle + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthOracle + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.Validator = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 3: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field RequestID", wireType) + } + m.RequestID = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowOracle + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.RequestID |= RequestID(b&0x7F) << shift + if b < 0x80 { + break + } + } + case 4: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field ExternalID", wireType) + } + m.ExternalID = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowOracle + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.ExternalID |= ExternalID(b&0x7F) << shift + if b < 0x80 { + break + } + } + default: + iNdEx = preIndex + skippy, err := skipOracle(dAtA[iNdEx:]) + if err != nil { + return err + } + if (skippy < 0) || (iNdEx+skippy) < 0 { + return ErrInvalidLengthOracle + } + if (iNdEx + skippy) > l { + return io.ErrUnexpectedEOF + } + iNdEx += skippy + } + } + + if iNdEx > l { + return io.ErrUnexpectedEOF + } + return nil +} func skipOracle(dAtA []byte) (n int, err error) { l := len(dAtA) iNdEx := 0 diff --git a/x/oracle/types/query.pb.go b/x/oracle/types/query.pb.go index 25a6567e6..804018929 100644 --- a/x/oracle/types/query.pb.go +++ b/x/oracle/types/query.pb.go @@ -1117,6 +1117,185 @@ func (m *QueryRequestPriceResponse) GetMinCount() int64 { return 0 } +// QueryRequestVerificationRequest is request type for the +// Query/RequestVerification RPC +type QueryRequestVerificationRequest struct { + // ChainID is the chain ID to identify which chain ID is used for the + // verification + ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"` + // Validator is a validator address + Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"` + // RequestID is oracle request ID + RequestId int64 `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"` + // ExternalID is an oracle's external ID + ExternalId int64 `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"` + // Reporter is an bech32-encoded public key of the reporter authorized by the + // validator + Reporter string `protobuf:"bytes,5,opt,name=reporter,proto3" json:"reporter,omitempty"` + // Signature is a signature signed by the reporter using reporter's private + // key + Signature []byte `protobuf:"bytes,6,opt,name=signature,proto3" json:"signature,omitempty"` +} + +func (m *QueryRequestVerificationRequest) Reset() { *m = QueryRequestVerificationRequest{} } +func (m *QueryRequestVerificationRequest) String() string { return proto.CompactTextString(m) } +func (*QueryRequestVerificationRequest) ProtoMessage() {} +func (*QueryRequestVerificationRequest) Descriptor() ([]byte, []int) { + return fileDescriptor_34238c8dfdfcd7ec, []int{22} +} +func (m *QueryRequestVerificationRequest) XXX_Unmarshal(b []byte) error { + return m.Unmarshal(b) +} +func (m *QueryRequestVerificationRequest) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + if deterministic { + return xxx_messageInfo_QueryRequestVerificationRequest.Marshal(b, m, deterministic) + } else { + b = b[:cap(b)] + n, err := m.MarshalToSizedBuffer(b) + if err != nil { + return nil, err + } + return b[:n], nil + } +} +func (m *QueryRequestVerificationRequest) XXX_Merge(src proto.Message) { + xxx_messageInfo_QueryRequestVerificationRequest.Merge(m, src) +} +func (m *QueryRequestVerificationRequest) XXX_Size() int { + return m.Size() +} +func (m *QueryRequestVerificationRequest) XXX_DiscardUnknown() { + xxx_messageInfo_QueryRequestVerificationRequest.DiscardUnknown(m) +} + +var xxx_messageInfo_QueryRequestVerificationRequest proto.InternalMessageInfo + +func (m *QueryRequestVerificationRequest) GetChainId() string { + if m != nil { + return m.ChainId + } + return "" +} + +func (m *QueryRequestVerificationRequest) GetValidator() string { + if m != nil { + return m.Validator + } + return "" +} + +func (m *QueryRequestVerificationRequest) GetRequestId() int64 { + if m != nil { + return m.RequestId + } + return 0 +} + +func (m *QueryRequestVerificationRequest) GetExternalId() int64 { + if m != nil { + return m.ExternalId + } + return 0 +} + +func (m *QueryRequestVerificationRequest) GetReporter() string { + if m != nil { + return m.Reporter + } + return "" +} + +func (m *QueryRequestVerificationRequest) GetSignature() []byte { + if m != nil { + return m.Signature + } + return nil +} + +// QueryRequestVerificationResponse is response type for the +// Query/RequestVerification RPC +type QueryRequestVerificationResponse struct { + // ChainID is the targeted chain ID + ChainId string `protobuf:"bytes,1,opt,name=chain_id,json=chainId,proto3" json:"chain_id,omitempty"` + // Validator is the targeted validator address + Validator string `protobuf:"bytes,2,opt,name=validator,proto3" json:"validator,omitempty"` + // RequestID is the ID of targeted request + RequestId int64 `protobuf:"varint,3,opt,name=request_id,json=requestId,proto3" json:"request_id,omitempty"` + // ExternalID is the ID of targeted oracle's external data source + ExternalId int64 `protobuf:"varint,4,opt,name=external_id,json=externalId,proto3" json:"external_id,omitempty"` + // DataSourceID is the ID of a data source that relates to the targeted + // external ID + DataSourceId int64 `protobuf:"varint,5,opt,name=data_source_id,json=dataSourceId,proto3" json:"data_source_id,omitempty"` +} + +func (m *QueryRequestVerificationResponse) Reset() { *m = QueryRequestVerificationResponse{} } +func (m *QueryRequestVerificationResponse) String() string { return proto.CompactTextString(m) } +func (*QueryRequestVerificationResponse) ProtoMessage() {} +func (*QueryRequestVerificationResponse) Descriptor() ([]byte, []int) { + return fileDescriptor_34238c8dfdfcd7ec, []int{23} +} +func (m *QueryRequestVerificationResponse) XXX_Unmarshal(b []byte) error { + return m.Unmarshal(b) +} +func (m *QueryRequestVerificationResponse) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { + if deterministic { + return xxx_messageInfo_QueryRequestVerificationResponse.Marshal(b, m, deterministic) + } else { + b = b[:cap(b)] + n, err := m.MarshalToSizedBuffer(b) + if err != nil { + return nil, err + } + return b[:n], nil + } +} +func (m *QueryRequestVerificationResponse) XXX_Merge(src proto.Message) { + xxx_messageInfo_QueryRequestVerificationResponse.Merge(m, src) +} +func (m *QueryRequestVerificationResponse) XXX_Size() int { + return m.Size() +} +func (m *QueryRequestVerificationResponse) XXX_DiscardUnknown() { + xxx_messageInfo_QueryRequestVerificationResponse.DiscardUnknown(m) +} + +var xxx_messageInfo_QueryRequestVerificationResponse proto.InternalMessageInfo + +func (m *QueryRequestVerificationResponse) GetChainId() string { + if m != nil { + return m.ChainId + } + return "" +} + +func (m *QueryRequestVerificationResponse) GetValidator() string { + if m != nil { + return m.Validator + } + return "" +} + +func (m *QueryRequestVerificationResponse) GetRequestId() int64 { + if m != nil { + return m.RequestId + } + return 0 +} + +func (m *QueryRequestVerificationResponse) GetExternalId() int64 { + if m != nil { + return m.ExternalId + } + return 0 +} + +func (m *QueryRequestVerificationResponse) GetDataSourceId() int64 { + if m != nil { + return m.DataSourceId + } + return 0 +} + // QueryRequestPoolRequest is request type for the Query/RequestPool RPC method. type QueryRequestPoolRequest struct { // RequestKey is a user-generated key for each request pool @@ -1131,7 +1310,7 @@ func (m *QueryRequestPoolRequest) Reset() { *m = QueryRequestPoolRequest func (m *QueryRequestPoolRequest) String() string { return proto.CompactTextString(m) } func (*QueryRequestPoolRequest) ProtoMessage() {} func (*QueryRequestPoolRequest) Descriptor() ([]byte, []int) { - return fileDescriptor_34238c8dfdfcd7ec, []int{22} + return fileDescriptor_34238c8dfdfcd7ec, []int{24} } func (m *QueryRequestPoolRequest) XXX_Unmarshal(b []byte) error { return m.Unmarshal(b) @@ -1193,7 +1372,7 @@ func (m *QueryRequestPoolResponse) Reset() { *m = QueryRequestPoolRespon func (m *QueryRequestPoolResponse) String() string { return proto.CompactTextString(m) } func (*QueryRequestPoolResponse) ProtoMessage() {} func (*QueryRequestPoolResponse) Descriptor() ([]byte, []int) { - return fileDescriptor_34238c8dfdfcd7ec, []int{23} + return fileDescriptor_34238c8dfdfcd7ec, []int{25} } func (m *QueryRequestPoolResponse) XXX_Unmarshal(b []byte) error { return m.Unmarshal(b) @@ -1259,6 +1438,8 @@ func init() { proto.RegisterType((*QueryRequestSearchResponse)(nil), "oracle.v1.QueryRequestSearchResponse") proto.RegisterType((*QueryRequestPriceRequest)(nil), "oracle.v1.QueryRequestPriceRequest") proto.RegisterType((*QueryRequestPriceResponse)(nil), "oracle.v1.QueryRequestPriceResponse") + proto.RegisterType((*QueryRequestVerificationRequest)(nil), "oracle.v1.QueryRequestVerificationRequest") + proto.RegisterType((*QueryRequestVerificationResponse)(nil), "oracle.v1.QueryRequestVerificationResponse") proto.RegisterType((*QueryRequestPoolRequest)(nil), "oracle.v1.QueryRequestPoolRequest") proto.RegisterType((*QueryRequestPoolResponse)(nil), "oracle.v1.QueryRequestPoolResponse") } @@ -1266,88 +1447,96 @@ func init() { func init() { proto.RegisterFile("oracle/v1/query.proto", fileDescriptor_34238c8dfdfcd7ec) } var fileDescriptor_34238c8dfdfcd7ec = []byte{ - // 1291 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x57, 0x4f, 0x6f, 0x1b, 0x45, - 0x14, 0xcf, 0xc6, 0x69, 0x5a, 0x3f, 0xbb, 0x25, 0x9e, 0xa6, 0xa9, 0xbb, 0x49, 0x9d, 0x74, 0x93, - 0x52, 0xab, 0x50, 0x6f, 0x1b, 0x0a, 0xa7, 0xaa, 0x52, 0xdb, 0xa8, 0x22, 0x02, 0x89, 0xd6, 0x11, - 0x48, 0x70, 0xb1, 0xc6, 0xbb, 0xab, 0x78, 0xe5, 0xf5, 0x8e, 0xbb, 0xb3, 0x8e, 0xb0, 0x8c, 0x05, - 0xea, 0x09, 0x89, 0x0b, 0x12, 0x12, 0x17, 0xf8, 0x04, 0x5c, 0xf9, 0x04, 0xdc, 0x7a, 0xac, 0xc4, - 0x05, 0x71, 0x00, 0xd4, 0xf0, 0x41, 0xd0, 0xce, 0xbc, 0xd9, 0xbf, 0xb6, 0x2b, 0xb8, 0x70, 0x4a, - 0xf6, 0xbd, 0x37, 0xbf, 0xf7, 0x9b, 0x37, 0xf3, 0xde, 0x6f, 0x0c, 0x97, 0x58, 0x40, 0x2d, 0xcf, - 0x31, 0x4f, 0xee, 0x98, 0xcf, 0x46, 0x4e, 0x30, 0x6e, 0x0d, 0x03, 0x16, 0x32, 0x52, 0x96, 0xe6, - 0xd6, 0xc9, 0x1d, 0x7d, 0xfd, 0x98, 0x1d, 0x33, 0x61, 0x35, 0xa3, 0xff, 0x64, 0x80, 0xbe, 0x75, - 0xcc, 0xd8, 0xb1, 0xe7, 0x98, 0x74, 0xe8, 0x9a, 0xd4, 0xf7, 0x59, 0x48, 0x43, 0x97, 0xf9, 0x1c, - 0xbd, 0x1b, 0x09, 0x2a, 0x02, 0x49, 0x7b, 0xc3, 0x62, 0x7c, 0xc0, 0xb8, 0xd9, 0xa5, 0x3c, 0x72, - 0x76, 0x9d, 0x90, 0xde, 0x31, 0x2d, 0xe6, 0xfa, 0xd2, 0x6f, 0xac, 0x03, 0x79, 0x1a, 0xb1, 0x78, - 0xc4, 0x46, 0x7e, 0xc8, 0xdb, 0xce, 0xb3, 0x91, 0xc3, 0x43, 0xe3, 0x7b, 0x0d, 0x2e, 0x66, 0xcc, - 0x7c, 0xc8, 0x7c, 0xee, 0x90, 0x9b, 0x50, 0xb3, 0x69, 0x48, 0x3b, 0x9c, 0x8d, 0x02, 0xcb, 0xe9, - 0x58, 0x91, 0xb7, 0xae, 0xed, 0x68, 0xcd, 0x52, 0xfb, 0x8d, 0xc8, 0x71, 0x24, 0xec, 0x62, 0x11, - 0x69, 0xc1, 0x45, 0xc9, 0xa4, 0xc3, 0xad, 0xc0, 0x1d, 0x86, 0x18, 0xbd, 0x2c, 0xa2, 0x6b, 0xd2, - 0x75, 0x24, 0x3c, 0x32, 0x7e, 0x17, 0xce, 0x07, 0x32, 0x3d, 0x46, 0x96, 0x44, 0x64, 0x15, 0x8d, - 0x22, 0xc8, 0x30, 0x61, 0x4d, 0xf0, 0x3a, 0xa0, 0x21, 0x45, 0xb2, 0x64, 0x13, 0xca, 0x82, 0x54, - 0x8f, 0xf2, 0x9e, 0x20, 0x53, 0x6e, 0x9f, 0x8b, 0x0c, 0xef, 0x53, 0xde, 0x33, 0x6e, 0x40, 0x2d, - 0xb5, 0x00, 0xb7, 0x41, 0x60, 0x25, 0x0a, 0x10, 0xc1, 0xd5, 0xb6, 0xf8, 0xdf, 0xb8, 0x0f, 0x1b, - 0x71, 0xa0, 0xdc, 0x86, 0xc2, 0xdf, 0x83, 0x0b, 0xe9, 0x4d, 0xbb, 0x36, 0xee, 0xb8, 0x9a, 0xec, - 0xf8, 0xd0, 0x36, 0x9e, 0xc2, 0xe5, 0xc2, 0x7a, 0x4c, 0xf7, 0x1e, 0x54, 0x52, 0x00, 0x62, 0x75, - 0x65, 0xff, 0x52, 0x2b, 0x3e, 0xf0, 0x56, 0x6a, 0x0d, 0x24, 0xa0, 0xc6, 0x01, 0xd4, 0x05, 0xe4, - 0x47, 0xa9, 0x5a, 0x29, 0x52, 0x4d, 0x58, 0xcb, 0x56, 0x37, 0xa6, 0x75, 0x21, 0x5d, 0xda, 0x43, - 0xdb, 0xf8, 0x14, 0xae, 0xcc, 0x40, 0x41, 0x6a, 0xf7, 0xe0, 0x7c, 0x06, 0x06, 0xc9, 0x5d, 0x4e, - 0x91, 0xcb, 0xac, 0xab, 0xa6, 0xc1, 0x8d, 0xbb, 0x78, 0x4b, 0x90, 0x94, 0xe2, 0x76, 0x15, 0x40, - 0x9d, 0x64, 0xcc, 0xaa, 0x8c, 0x96, 0x43, 0xdb, 0xf8, 0x45, 0x83, 0xf5, 0xec, 0x32, 0x24, 0xd3, - 0x86, 0x8b, 0x6a, 0xdd, 0x90, 0x5a, 0x7d, 0x27, 0xec, 0xc4, 0xa7, 0x54, 0xd9, 0x37, 0x0a, 0x94, - 0x70, 0xf9, 0x13, 0x11, 0x2a, 0xce, 0xb7, 0x16, 0xe4, 0x4d, 0xe4, 0x63, 0x58, 0x0f, 0x10, 0x3f, - 0x03, 0xba, 0x2c, 0x40, 0x77, 0x67, 0x80, 0xca, 0xe0, 0x14, 0x2a, 0x09, 0x0a, 0xb6, 0xb8, 0x6d, - 0x9e, 0xd0, 0x80, 0x0e, 0xe2, 0xb6, 0x79, 0x8c, 0xf5, 0x50, 0x56, 0xdc, 0x97, 0x09, 0xab, 0x43, - 0x61, 0xc1, 0xad, 0xd4, 0x52, 0x59, 0x65, 0xe8, 0xc3, 0x95, 0x17, 0x7f, 0x6c, 0x2f, 0xb5, 0x31, - 0xcc, 0x38, 0x80, 0x4b, 0x02, 0xe7, 0x13, 0xea, 0xb9, 0x36, 0x0d, 0x59, 0xa0, 0x2a, 0xfb, 0x16, - 0xd4, 0x4e, 0x94, 0xad, 0x43, 0x6d, 0x3b, 0x70, 0x38, 0xc7, 0x2b, 0xbf, 0x16, 0x3b, 0x1e, 0x48, - 0xbb, 0xf1, 0x21, 0xde, 0xe8, 0x14, 0x0a, 0x12, 0xda, 0x87, 0x55, 0x1e, 0xd2, 0x70, 0xa4, 0x08, - 0xe9, 0x29, 0x42, 0x71, 0xf4, 0x91, 0x88, 0x68, 0x63, 0x64, 0xcc, 0xa9, 0xed, 0x0c, 0x59, 0x10, - 0x3a, 0x01, 0xff, 0x4f, 0x9c, 0xee, 0x22, 0xa7, 0x14, 0x0a, 0x72, 0xd2, 0xe1, 0x5c, 0x80, 0xc6, - 0xba, 0xb6, 0x53, 0x8a, 0x9a, 0x58, 0x7d, 0x1b, 0x0d, 0xd8, 0x12, 0xab, 0x1e, 0x58, 0xa1, 0x7b, - 0xe2, 0xc4, 0x0c, 0xe3, 0xba, 0xbf, 0x0b, 0x57, 0xe7, 0xf8, 0x11, 0x7c, 0x1d, 0xce, 0xa4, 0x67, - 0x95, 0xfc, 0x30, 0x7e, 0xd0, 0xb0, 0x35, 0x10, 0xe7, 0xc8, 0xa1, 0x81, 0xd5, 0xfb, 0xd7, 0x1d, - 0x16, 0x51, 0xb7, 0xa8, 0xe7, 0xc5, 0xf7, 0xaa, 0xda, 0x8e, 0xbf, 0xa3, 0xe1, 0x44, 0x79, 0x3f, - 0x33, 0xd1, 0xce, 0x51, 0xde, 0x97, 0x23, 0x6f, 0x13, 0xca, 0x03, 0xd7, 0x47, 0xe7, 0x8a, 0x74, - 0x0e, 0x5c, 0x5f, 0x8e, 0xba, 0x2d, 0xd0, 0x67, 0x91, 0x93, 0x3b, 0x32, 0x3c, 0x9c, 0x0d, 0xaa, - 0x09, 0x02, 0x37, 0x19, 0x58, 0x1b, 0xb0, 0xca, 0xc7, 0x83, 0x2e, 0xf3, 0xf0, 0x18, 0xf0, 0x2b, - 0xcb, 0x65, 0x79, 0x11, 0x97, 0x52, 0x8e, 0x4b, 0xbe, 0x52, 0x98, 0x0e, 0xab, 0xfb, 0x7f, 0x57, - 0x2a, 0xc0, 0xd1, 0xab, 0xc8, 0x31, 0xe6, 0xa9, 0x52, 0x6c, 0x43, 0x45, 0x8d, 0x94, 0xbe, 0x33, - 0xc6, 0x7a, 0xa8, 0xe9, 0xf4, 0x81, 0x33, 0x26, 0x97, 0xe1, 0x6c, 0x74, 0xc9, 0x22, 0xca, 0xcb, - 0xb2, 0x58, 0xd1, 0xe7, 0xa1, 0x1d, 0x0d, 0x31, 0xab, 0x47, 0x7d, 0xdf, 0xf1, 0x22, 0x5f, 0x49, - 0xf8, 0xca, 0x68, 0x39, 0xb4, 0x8d, 0x9f, 0xb5, 0xdc, 0x01, 0x88, 0xa4, 0x58, 0x90, 0xdb, 0xd1, - 0xd0, 0xc1, 0x41, 0xc6, 0x98, 0x97, 0xeb, 0x0a, 0x12, 0x24, 0x4b, 0xb0, 0x2f, 0x88, 0x03, 0x67, - 0xbb, 0xd4, 0xa3, 0xbe, 0xe5, 0xd4, 0x97, 0x77, 0x4a, 0xcd, 0xca, 0xfe, 0x95, 0x96, 0x14, 0xee, - 0x56, 0x24, 0xdc, 0x2d, 0x14, 0xee, 0xd6, 0x23, 0xe6, 0xfa, 0x0f, 0x6f, 0x47, 0xb3, 0xe2, 0xa7, - 0x3f, 0xb7, 0x9b, 0xc7, 0x6e, 0xd8, 0x1b, 0x75, 0x5b, 0x16, 0x1b, 0x98, 0xa8, 0xf2, 0xf2, 0xcf, - 0x2d, 0x6e, 0xf7, 0xcd, 0x70, 0x3c, 0x74, 0xb8, 0x58, 0xc0, 0xdb, 0x0a, 0x7b, 0xff, 0xf7, 0x0a, - 0x9c, 0x11, 0xac, 0x49, 0x07, 0x56, 0xa5, 0xb6, 0x93, 0xab, 0xa9, 0xe6, 0x2f, 0x3e, 0x05, 0xf4, - 0xc6, 0x3c, 0x37, 0x5e, 0xc4, 0x8d, 0xe7, 0xbf, 0xfe, 0xfd, 0xdd, 0xf2, 0x1a, 0xb9, 0x80, 0xef, - 0x0e, 0xd3, 0x92, 0xb0, 0x16, 0xac, 0x88, 0x01, 0xbc, 0x99, 0x5f, 0x9f, 0x92, 0x6e, 0x7d, 0x6b, - 0xb6, 0x13, 0xa1, 0x77, 0x04, 0xb4, 0x4e, 0xea, 0x0a, 0x3a, 0xba, 0x27, 0xe6, 0x24, 0x16, 0xfb, - 0x29, 0x79, 0xae, 0x01, 0x24, 0xe2, 0x49, 0xae, 0xcd, 0x82, 0xcb, 0x88, 0xb9, 0x6e, 0x2c, 0x0a, - 0xc1, 0xbc, 0xb7, 0x44, 0xde, 0x1b, 0xe4, 0x7a, 0x3a, 0x2f, 0xaa, 0x37, 0xc7, 0xfc, 0xf1, 0x63, - 0x60, 0x4a, 0xbe, 0xd1, 0xa0, 0x9a, 0x16, 0x49, 0xb2, 0x9b, 0xcf, 0x31, 0x43, 0xc0, 0xf5, 0xbd, - 0xc5, 0x41, 0x48, 0xe5, 0xb6, 0xa0, 0x72, 0x93, 0x34, 0x15, 0x95, 0x4c, 0xa3, 0x99, 0x93, 0x7c, - 0xdf, 0x4d, 0xc9, 0x10, 0xce, 0xaa, 0xcb, 0x5f, 0x38, 0xba, 0xac, 0x4e, 0xeb, 0xdb, 0x73, 0xfd, - 0x98, 0x7d, 0x4f, 0x64, 0x6f, 0x90, 0x2d, 0x95, 0x1d, 0x6f, 0xae, 0x39, 0x49, 0xf4, 0x7d, 0x4a, - 0xbe, 0xd2, 0xa0, 0x1c, 0xcf, 0x5c, 0xb2, 0x93, 0x07, 0xcd, 0x8b, 0x98, 0x7e, 0x6d, 0x41, 0x04, - 0x26, 0x6e, 0x89, 0xc4, 0x4d, 0xf2, 0xa6, 0x4a, 0x1c, 0x0b, 0x09, 0x37, 0x27, 0x05, 0xb5, 0x99, - 0x92, 0x2f, 0xa1, 0x1c, 0x2b, 0x4a, 0x91, 0x41, 0x5e, 0xb2, 0x8a, 0x0c, 0x0a, 0x72, 0x54, 0xbc, - 0x03, 0x4a, 0x8c, 0x66, 0x13, 0xf8, 0x5a, 0x83, 0xb5, 0xbc, 0xfa, 0x90, 0x1b, 0xf9, 0x34, 0x73, - 0xf4, 0x4b, 0x6f, 0xbe, 0x3e, 0x10, 0x69, 0x5d, 0x13, 0xb4, 0x36, 0xc9, 0x15, 0x45, 0x8b, 0x8a, - 0xc8, 0x4e, 0x52, 0x9f, 0xa8, 0xb3, 0xe5, 0xa3, 0xa2, 0xd8, 0xd9, 0x99, 0xd7, 0x4a, 0xb1, 0xb3, - 0xb3, 0xcf, 0x96, 0x62, 0x67, 0xcb, 0xd7, 0x09, 0xf9, 0x02, 0xce, 0x67, 0x34, 0x89, 0xec, 0xcd, - 0xb9, 0x47, 0x19, 0x3d, 0xd5, 0xaf, 0xbf, 0x26, 0x0a, 0xb3, 0x36, 0x44, 0xd6, 0x3a, 0xd9, 0xc8, - 0xdd, 0xb9, 0x0e, 0x97, 0xc9, 0xc6, 0x50, 0x4d, 0x8b, 0x50, 0xb1, 0xd9, 0x66, 0x28, 0xa2, 0xbe, - 0xb7, 0x38, 0x28, 0x9b, 0xda, 0x28, 0xa4, 0x1e, 0x46, 0x61, 0x9c, 0xfc, 0xa8, 0x41, 0x25, 0x35, - 0xee, 0x89, 0x31, 0x0f, 0x35, 0x11, 0x20, 0x7d, 0x77, 0x61, 0x0c, 0x26, 0x3e, 0x10, 0x89, 0xef, - 0x93, 0x7b, 0x66, 0xf2, 0x2b, 0x2e, 0x2d, 0x20, 0x49, 0xbf, 0xf5, 0x9d, 0xf1, 0xd4, 0x9c, 0xa0, - 0x62, 0x4d, 0xcd, 0x49, 0x22, 0x51, 0xd3, 0x87, 0x8f, 0x5f, 0xbc, 0x6a, 0x68, 0x2f, 0x5f, 0x35, - 0xb4, 0xbf, 0x5e, 0x35, 0xb4, 0x6f, 0x4f, 0x1b, 0x4b, 0x2f, 0x4f, 0x1b, 0x4b, 0xbf, 0x9d, 0x36, - 0x96, 0x3e, 0x7b, 0x3b, 0xa5, 0x14, 0x5d, 0xea, 0xdb, 0xe2, 0xa7, 0x9f, 0xc5, 0x3c, 0xd3, 0xea, - 0x51, 0xd7, 0x37, 0x3f, 0x57, 0x69, 0x85, 0x66, 0x74, 0x57, 0x85, 0xfb, 0x9d, 0x7f, 0x02, 0x00, - 0x00, 0xff, 0xff, 0xdb, 0x8b, 0x6c, 0x21, 0xa9, 0x0e, 0x00, 0x00, + // 1424 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x58, 0x4f, 0x6f, 0x1b, 0x45, + 0x14, 0xcf, 0xe6, 0x8f, 0x13, 0x3f, 0xbb, 0x25, 0x99, 0xa4, 0xa9, 0xb3, 0x49, 0x9d, 0x74, 0x93, + 0x52, 0xab, 0xa5, 0xde, 0x26, 0x14, 0x4e, 0x55, 0xa5, 0xb6, 0x51, 0x45, 0x04, 0x12, 0xad, 0x23, + 0x2a, 0xc1, 0xc5, 0x1a, 0xef, 0x2e, 0xf1, 0x2a, 0x9b, 0x1d, 0x77, 0x67, 0x1d, 0xd5, 0x0a, 0x16, + 0xa8, 0x27, 0x24, 0x2e, 0x20, 0x24, 0x2e, 0xf0, 0x09, 0xb8, 0xf2, 0x09, 0xb8, 0xf5, 0x58, 0x09, + 0x0e, 0x9c, 0x00, 0x35, 0x9c, 0xf9, 0x0c, 0x68, 0x67, 0xde, 0xec, 0x5f, 0x3b, 0x05, 0x2e, 0x3d, + 0xc5, 0xfb, 0xde, 0x9b, 0xdf, 0xfb, 0xcd, 0x9b, 0x99, 0xf7, 0x7e, 0x0a, 0x5c, 0x60, 0x01, 0xb5, + 0x3c, 0xc7, 0x3c, 0xde, 0x36, 0x9f, 0xf4, 0x9d, 0x60, 0xd0, 0xec, 0x05, 0x2c, 0x64, 0xa4, 0x2c, + 0xcd, 0xcd, 0xe3, 0x6d, 0x7d, 0xe9, 0x80, 0x1d, 0x30, 0x61, 0x35, 0xa3, 0x5f, 0x32, 0x40, 0x5f, + 0x3b, 0x60, 0xec, 0xc0, 0x73, 0x4c, 0xda, 0x73, 0x4d, 0xea, 0xfb, 0x2c, 0xa4, 0xa1, 0xcb, 0x7c, + 0x8e, 0xde, 0xe5, 0x04, 0x15, 0x81, 0xa4, 0xbd, 0x6e, 0x31, 0x7e, 0xc4, 0xb8, 0xd9, 0xa1, 0x3c, + 0x72, 0x76, 0x9c, 0x90, 0x6e, 0x9b, 0x16, 0x73, 0x7d, 0xe9, 0x37, 0x96, 0x80, 0x3c, 0x8a, 0x58, + 0xdc, 0x67, 0x7d, 0x3f, 0xe4, 0x2d, 0xe7, 0x49, 0xdf, 0xe1, 0xa1, 0xf1, 0x9d, 0x06, 0x8b, 0x19, + 0x33, 0xef, 0x31, 0x9f, 0x3b, 0xe4, 0x1a, 0x2c, 0xd8, 0x34, 0xa4, 0x6d, 0xce, 0xfa, 0x81, 0xe5, + 0xb4, 0xad, 0xc8, 0x5b, 0xd3, 0x36, 0xb4, 0xc6, 0x54, 0xeb, 0x8d, 0xc8, 0xb1, 0x2f, 0xec, 0x62, + 0x11, 0x69, 0xc2, 0xa2, 0x64, 0xd2, 0xe6, 0x56, 0xe0, 0xf6, 0x42, 0x8c, 0x9e, 0x14, 0xd1, 0x0b, + 0xd2, 0xb5, 0x2f, 0x3c, 0x32, 0x7e, 0x13, 0xce, 0x05, 0x32, 0x3d, 0x46, 0x4e, 0x89, 0xc8, 0x2a, + 0x1a, 0x45, 0x90, 0x61, 0xc2, 0xbc, 0xe0, 0xb5, 0x4b, 0x43, 0x8a, 0x64, 0xc9, 0x2a, 0x94, 0x05, + 0xa9, 0x2e, 0xe5, 0x5d, 0x41, 0xa6, 0xdc, 0x9a, 0x8b, 0x0c, 0xef, 0x51, 0xde, 0x35, 0xae, 0xc2, + 0x42, 0x6a, 0x01, 0x6e, 0x83, 0xc0, 0x74, 0x14, 0x20, 0x82, 0xab, 0x2d, 0xf1, 0xdb, 0xb8, 0x03, + 0xcb, 0x71, 0xa0, 0xdc, 0x86, 0xc2, 0xdf, 0x82, 0xf3, 0xe9, 0x4d, 0xbb, 0x36, 0xee, 0xb8, 0x9a, + 0xec, 0x78, 0xcf, 0x36, 0x1e, 0xc1, 0xc5, 0xc2, 0x7a, 0x4c, 0xf7, 0x2e, 0x54, 0x52, 0x00, 0x62, + 0x75, 0x65, 0xe7, 0x42, 0x33, 0x3e, 0xf0, 0x66, 0x6a, 0x0d, 0x24, 0xa0, 0xc6, 0x2e, 0xd4, 0x04, + 0xe4, 0x87, 0xa9, 0x5a, 0x29, 0x52, 0x0d, 0x98, 0xcf, 0x56, 0x37, 0xa6, 0x75, 0x3e, 0x5d, 0xda, + 0x3d, 0xdb, 0xf8, 0x18, 0x56, 0x46, 0xa0, 0x20, 0xb5, 0xdb, 0x70, 0x2e, 0x03, 0x83, 0xe4, 0x2e, + 0xa6, 0xc8, 0x65, 0xd6, 0x55, 0xd3, 0xe0, 0xc6, 0x2d, 0xbc, 0x25, 0x48, 0x4a, 0x71, 0xbb, 0x04, + 0xa0, 0x4e, 0x32, 0x66, 0x55, 0x46, 0xcb, 0x9e, 0x6d, 0xfc, 0xac, 0xc1, 0x52, 0x76, 0x19, 0x92, + 0x69, 0xc1, 0xa2, 0x5a, 0xd7, 0xa3, 0xd6, 0xa1, 0x13, 0xb6, 0xe3, 0x53, 0xaa, 0xec, 0x18, 0x05, + 0x4a, 0xb8, 0xfc, 0xa1, 0x08, 0x15, 0xe7, 0xbb, 0x10, 0xe4, 0x4d, 0xe4, 0x23, 0x58, 0x0a, 0x10, + 0x3f, 0x03, 0x3a, 0x29, 0x40, 0x37, 0x47, 0x80, 0xca, 0xe0, 0x14, 0x2a, 0x09, 0x0a, 0xb6, 0xf8, + 0xd9, 0x3c, 0xa4, 0x01, 0x3d, 0x8a, 0x9f, 0xcd, 0x03, 0xac, 0x87, 0xb2, 0xe2, 0xbe, 0x4c, 0x28, + 0xf5, 0x84, 0x05, 0xb7, 0xb2, 0x90, 0xca, 0x2a, 0x43, 0xef, 0x4d, 0x3f, 0xff, 0x7d, 0x7d, 0xa2, + 0x85, 0x61, 0xc6, 0x2e, 0x5c, 0x10, 0x38, 0x8f, 0xa9, 0xe7, 0xda, 0x34, 0x64, 0x81, 0xaa, 0xec, + 0x75, 0x58, 0x38, 0x56, 0xb6, 0x36, 0xb5, 0xed, 0xc0, 0xe1, 0x1c, 0xaf, 0xfc, 0x7c, 0xec, 0xb8, + 0x2b, 0xed, 0xc6, 0x07, 0x78, 0xa3, 0x53, 0x28, 0x48, 0x68, 0x07, 0x4a, 0x3c, 0xa4, 0x61, 0x5f, + 0x11, 0xd2, 0x53, 0x84, 0xe2, 0xe8, 0x7d, 0x11, 0xd1, 0xc2, 0xc8, 0x98, 0x53, 0xcb, 0xe9, 0xb1, + 0x20, 0x74, 0x02, 0xfe, 0xbf, 0x38, 0xdd, 0x42, 0x4e, 0x29, 0x14, 0xe4, 0xa4, 0xc3, 0x5c, 0x80, + 0xc6, 0x9a, 0xb6, 0x31, 0x15, 0x3d, 0x62, 0xf5, 0x6d, 0xd4, 0x61, 0x4d, 0xac, 0xba, 0x6b, 0x85, + 0xee, 0xb1, 0x13, 0x33, 0x8c, 0xeb, 0xfe, 0x0e, 0x5c, 0x1a, 0xe3, 0x47, 0xf0, 0x25, 0x98, 0x49, + 0xf7, 0x2a, 0xf9, 0x61, 0x7c, 0xaf, 0xe1, 0xd3, 0x40, 0x9c, 0x7d, 0x87, 0x06, 0x56, 0xf7, 0x3f, + 0xbf, 0xb0, 0x88, 0xba, 0x45, 0x3d, 0x2f, 0xbe, 0x57, 0xd5, 0x56, 0xfc, 0x1d, 0x35, 0x27, 0xca, + 0x0f, 0x33, 0x1d, 0x6d, 0x8e, 0xf2, 0x43, 0xd9, 0xf2, 0x56, 0xa1, 0x7c, 0xe4, 0xfa, 0xe8, 0x9c, + 0x96, 0xce, 0x23, 0xd7, 0x97, 0xad, 0x6e, 0x0d, 0xf4, 0x51, 0xe4, 0xe4, 0x8e, 0x0c, 0x0f, 0x7b, + 0x83, 0x7a, 0x04, 0x81, 0x9b, 0x34, 0xac, 0x65, 0x28, 0xf1, 0xc1, 0x51, 0x87, 0x79, 0x78, 0x0c, + 0xf8, 0x95, 0xe5, 0x32, 0x79, 0x16, 0x97, 0xa9, 0x1c, 0x97, 0x7c, 0xa5, 0x30, 0x1d, 0x56, 0xf7, + 0x75, 0x57, 0xea, 0x57, 0x0d, 0xd6, 0xd3, 0xec, 0x1e, 0x3b, 0x81, 0xfb, 0xa9, 0x6b, 0x89, 0xf9, + 0xa8, 0x6a, 0xb2, 0x02, 0x73, 0x56, 0x97, 0xba, 0xbe, 0xe2, 0x56, 0x6e, 0xcd, 0x8a, 0xef, 0x3d, + 0x9b, 0xac, 0x41, 0x39, 0xbe, 0xa7, 0x82, 0x55, 0xb9, 0x95, 0x18, 0x72, 0xcd, 0x6c, 0x2a, 0xd7, + 0xcc, 0xc8, 0x3a, 0x54, 0x9c, 0xa7, 0xa1, 0x13, 0xf8, 0xd4, 0x8b, 0xfc, 0x92, 0x1a, 0x28, 0x93, + 0xdc, 0x72, 0x7c, 0xaf, 0x67, 0xe4, 0x70, 0x52, 0xdf, 0x51, 0x66, 0xee, 0x1e, 0xf8, 0x34, 0xec, + 0x07, 0x4e, 0xad, 0x24, 0xea, 0x91, 0x18, 0xa2, 0x3e, 0xb9, 0x31, 0x7e, 0x5b, 0x58, 0xfb, 0xd7, + 0xb6, 0xaf, 0xe2, 0x54, 0x9c, 0x19, 0x31, 0x15, 0x03, 0x9c, 0x8a, 0xea, 0xde, 0x30, 0xe6, 0xa9, + 0x13, 0x59, 0x87, 0x8a, 0x22, 0x70, 0xe8, 0x0c, 0x90, 0xbc, 0xe2, 0xf4, 0xbe, 0x33, 0x20, 0x17, + 0x61, 0x36, 0xaa, 0x53, 0x04, 0x2d, 0xd9, 0x97, 0xa2, 0xcf, 0x3d, 0x3b, 0xa2, 0x6e, 0x75, 0xa9, + 0xef, 0x3b, 0x9e, 0xa2, 0x5e, 0x6e, 0x95, 0xd1, 0xb2, 0x67, 0x1b, 0x3f, 0x69, 0xb9, 0xb7, 0x21, + 0x92, 0x62, 0xbd, 0x6e, 0x46, 0xf3, 0x00, 0x67, 0x0c, 0x63, 0x5e, 0xae, 0x61, 0x91, 0x20, 0x59, + 0x82, 0x2d, 0x8b, 0x38, 0x30, 0xdb, 0xa1, 0x1e, 0xf5, 0x2d, 0xa7, 0x36, 0xb9, 0x31, 0xd5, 0xa8, + 0xec, 0xac, 0x34, 0xa5, 0xa6, 0x6a, 0x46, 0x9a, 0xaa, 0x89, 0x9a, 0xaa, 0x79, 0x9f, 0xb9, 0xfe, + 0xbd, 0x9b, 0x51, 0x1b, 0xff, 0xf1, 0x8f, 0xf5, 0xc6, 0x81, 0x1b, 0x76, 0xfb, 0x9d, 0xa6, 0xc5, + 0x8e, 0x4c, 0x14, 0x60, 0xf2, 0xcf, 0x0d, 0x6e, 0x1f, 0x9a, 0xe1, 0xa0, 0xe7, 0x70, 0xb1, 0x80, + 0xb7, 0x14, 0xf6, 0xce, 0xdf, 0x55, 0x98, 0x11, 0xac, 0x49, 0x1b, 0x4a, 0x52, 0x76, 0x91, 0x4b, + 0xa9, 0xbe, 0x5c, 0x54, 0x69, 0x7a, 0x7d, 0x9c, 0x1b, 0x7b, 0xc4, 0xf2, 0xb3, 0x5f, 0xfe, 0xfa, + 0x76, 0x72, 0x9e, 0x9c, 0x47, 0x49, 0x68, 0x5a, 0x12, 0xd6, 0x82, 0x69, 0x31, 0x1b, 0x57, 0xf3, + 0xeb, 0x53, 0xaa, 0x4a, 0x5f, 0x1b, 0xed, 0x44, 0xe8, 0x0d, 0x01, 0xad, 0x93, 0x9a, 0x82, 0x8e, + 0x4e, 0xdd, 0x3c, 0x89, 0x75, 0xd8, 0x90, 0x3c, 0xd3, 0x00, 0x12, 0x5d, 0x43, 0x2e, 0x8f, 0x82, + 0xcb, 0xe8, 0x2c, 0xdd, 0x38, 0x2b, 0x04, 0xf3, 0xde, 0x10, 0x79, 0xaf, 0x92, 0x2b, 0xe9, 0xbc, + 0x78, 0x07, 0x39, 0xe6, 0x8f, 0x6f, 0xe4, 0x90, 0x7c, 0xa5, 0x41, 0x35, 0xad, 0x5f, 0xc8, 0x66, + 0x3e, 0xc7, 0x08, 0x6d, 0xa5, 0x6f, 0x9d, 0x1d, 0x84, 0x54, 0x6e, 0x0a, 0x2a, 0xd7, 0x48, 0x43, + 0x51, 0xc9, 0xf4, 0x40, 0xf3, 0x24, 0xdf, 0x12, 0x87, 0xa4, 0x07, 0xb3, 0xea, 0xf2, 0x17, 0x8e, + 0x2e, 0x2b, 0xa1, 0xf4, 0xf5, 0xb1, 0x7e, 0xcc, 0xbe, 0x25, 0xb2, 0xd7, 0xc9, 0x9a, 0xca, 0x8e, + 0x37, 0xd7, 0x3c, 0x49, 0x5e, 0xf5, 0x90, 0x7c, 0xa1, 0x41, 0x39, 0x1e, 0x87, 0x64, 0x23, 0x0f, + 0x9a, 0xd7, 0x17, 0xfa, 0xe5, 0x33, 0x22, 0x30, 0x71, 0x53, 0x24, 0x6e, 0x90, 0x37, 0x55, 0xe2, + 0xb8, 0xa5, 0x70, 0xf3, 0xa4, 0x20, 0x04, 0x86, 0xe4, 0x73, 0x28, 0xc7, 0xc3, 0xbe, 0xc8, 0x20, + 0xaf, 0x26, 0x8a, 0x0c, 0x0a, 0x4a, 0xa1, 0x78, 0x07, 0x54, 0x3f, 0x1d, 0x4d, 0xe0, 0x4b, 0x0d, + 0xe6, 0xf3, 0xc2, 0x80, 0x5c, 0xcd, 0xa7, 0x19, 0x23, 0x2d, 0xf4, 0xc6, 0xab, 0x03, 0x91, 0xd6, + 0x65, 0x41, 0x6b, 0x95, 0xac, 0x28, 0x5a, 0x54, 0x44, 0xb6, 0x93, 0xfa, 0x44, 0x2f, 0x5b, 0xea, + 0xbd, 0xe2, 0xcb, 0xce, 0x08, 0xc9, 0xe2, 0xcb, 0xce, 0x2a, 0xca, 0xe2, 0xcb, 0x96, 0xc2, 0x91, + 0x7c, 0x06, 0xe7, 0x32, 0x72, 0x81, 0x6c, 0x8d, 0xb9, 0x47, 0x19, 0xa9, 0xa3, 0x5f, 0x79, 0x45, + 0x14, 0x66, 0xad, 0x8b, 0xac, 0x35, 0xb2, 0x9c, 0xbb, 0x73, 0x6d, 0x2e, 0x93, 0x0d, 0xa0, 0x9a, + 0xd6, 0x07, 0xc5, 0xc7, 0x36, 0x42, 0xac, 0xe8, 0x5b, 0x67, 0x07, 0x65, 0x53, 0x1b, 0x85, 0xd4, + 0xbd, 0x28, 0x8c, 0x93, 0x6f, 0x34, 0x58, 0x1c, 0x31, 0x26, 0xc9, 0xb5, 0x31, 0xe8, 0x23, 0x24, + 0x82, 0x7e, 0xfd, 0x5f, 0xc5, 0x8e, 0x3b, 0xed, 0xe3, 0x6d, 0xf3, 0x38, 0x0a, 0x1c, 0xb4, 0x91, + 0x1a, 0xf9, 0x41, 0x83, 0x4a, 0x6a, 0x04, 0x11, 0x63, 0xdc, 0x4e, 0x93, 0xa1, 0xa8, 0x6f, 0x9e, + 0x19, 0x83, 0xb9, 0x77, 0x45, 0xee, 0x3b, 0xe4, 0x76, 0x2a, 0x77, 0x7a, 0xa8, 0x25, 0x3d, 0xe0, + 0xd0, 0x19, 0x0c, 0xcd, 0x13, 0x9c, 0xa2, 0x43, 0xf3, 0x24, 0x19, 0x9b, 0xc3, 0x7b, 0x0f, 0x9e, + 0xbf, 0xac, 0x6b, 0x2f, 0x5e, 0xd6, 0xb5, 0x3f, 0x5f, 0xd6, 0xb5, 0xaf, 0x4f, 0xeb, 0x13, 0x2f, + 0x4e, 0xeb, 0x13, 0xbf, 0x9d, 0xd6, 0x27, 0x3e, 0x79, 0x2b, 0x35, 0xbd, 0x3a, 0xd4, 0xb7, 0xc5, + 0x7f, 0x0a, 0x2c, 0xe6, 0x99, 0x42, 0x59, 0x98, 0x4f, 0x55, 0x5a, 0x31, 0xc7, 0x3a, 0x25, 0xe1, + 0x7e, 0xfb, 0x9f, 0x00, 0x00, 0x00, 0xff, 0xff, 0x23, 0x72, 0xdc, 0x44, 0xd8, 0x10, 0x00, 0x00, } // Reference imports to suppress errors if they are not otherwise used. @@ -1387,6 +1576,9 @@ type QueryClient interface { // RequestPrice queries the latest price on standard price reference oracle // script. RequestPrice(ctx context.Context, in *QueryRequestPriceRequest, opts ...grpc.CallOption) (*QueryRequestPriceResponse, error) + // RequestVerification verifies a request to make sure that + // all information that will be used to report the data is valid + RequestVerification(ctx context.Context, in *QueryRequestVerificationRequest, opts ...grpc.CallOption) (*QueryRequestVerificationResponse, error) // RequestPool queries the request pool information corresponding to the given // port, channel, and request key. RequestPool(ctx context.Context, in *QueryRequestPoolRequest, opts ...grpc.CallOption) (*QueryRequestPoolResponse, error) @@ -1499,6 +1691,15 @@ func (c *queryClient) RequestPrice(ctx context.Context, in *QueryRequestPriceReq return out, nil } +func (c *queryClient) RequestVerification(ctx context.Context, in *QueryRequestVerificationRequest, opts ...grpc.CallOption) (*QueryRequestVerificationResponse, error) { + out := new(QueryRequestVerificationResponse) + err := c.cc.Invoke(ctx, "/oracle.v1.Query/RequestVerification", in, out, opts...) + if err != nil { + return nil, err + } + return out, nil +} + func (c *queryClient) RequestPool(ctx context.Context, in *QueryRequestPoolRequest, opts ...grpc.CallOption) (*QueryRequestPoolResponse, error) { out := new(QueryRequestPoolResponse) err := c.cc.Invoke(ctx, "/oracle.v1.Query/RequestPool", in, out, opts...) @@ -1535,6 +1736,9 @@ type QueryServer interface { // RequestPrice queries the latest price on standard price reference oracle // script. RequestPrice(context.Context, *QueryRequestPriceRequest) (*QueryRequestPriceResponse, error) + // RequestVerification verifies a request to make sure that + // all information that will be used to report the data is valid + RequestVerification(context.Context, *QueryRequestVerificationRequest) (*QueryRequestVerificationResponse, error) // RequestPool queries the request pool information corresponding to the given // port, channel, and request key. RequestPool(context.Context, *QueryRequestPoolRequest) (*QueryRequestPoolResponse, error) @@ -1577,6 +1781,9 @@ func (*UnimplementedQueryServer) RequestSearch(ctx context.Context, req *QueryRe func (*UnimplementedQueryServer) RequestPrice(ctx context.Context, req *QueryRequestPriceRequest) (*QueryRequestPriceResponse, error) { return nil, status.Errorf(codes.Unimplemented, "method RequestPrice not implemented") } +func (*UnimplementedQueryServer) RequestVerification(ctx context.Context, req *QueryRequestVerificationRequest) (*QueryRequestVerificationResponse, error) { + return nil, status.Errorf(codes.Unimplemented, "method RequestVerification not implemented") +} func (*UnimplementedQueryServer) RequestPool(ctx context.Context, req *QueryRequestPoolRequest) (*QueryRequestPoolResponse, error) { return nil, status.Errorf(codes.Unimplemented, "method RequestPool not implemented") } @@ -1783,6 +1990,24 @@ func _Query_RequestPrice_Handler(srv interface{}, ctx context.Context, dec func( return interceptor(ctx, in, info, handler) } +func _Query_RequestVerification_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { + in := new(QueryRequestVerificationRequest) + if err := dec(in); err != nil { + return nil, err + } + if interceptor == nil { + return srv.(QueryServer).RequestVerification(ctx, in) + } + info := &grpc.UnaryServerInfo{ + Server: srv, + FullMethod: "/oracle.v1.Query/RequestVerification", + } + handler := func(ctx context.Context, req interface{}) (interface{}, error) { + return srv.(QueryServer).RequestVerification(ctx, req.(*QueryRequestVerificationRequest)) + } + return interceptor(ctx, in, info, handler) +} + func _Query_RequestPool_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { in := new(QueryRequestPoolRequest) if err := dec(in); err != nil { @@ -1849,6 +2074,10 @@ var _Query_serviceDesc = grpc.ServiceDesc{ MethodName: "RequestPrice", Handler: _Query_RequestPrice_Handler, }, + { + MethodName: "RequestVerification", + Handler: _Query_RequestVerification_Handler, + }, { MethodName: "RequestPool", Handler: _Query_RequestPool_Handler, @@ -2567,6 +2796,119 @@ func (m *QueryRequestPriceResponse) MarshalToSizedBuffer(dAtA []byte) (int, erro return len(dAtA) - i, nil } +func (m *QueryRequestVerificationRequest) Marshal() (dAtA []byte, err error) { + size := m.Size() + dAtA = make([]byte, size) + n, err := m.MarshalToSizedBuffer(dAtA[:size]) + if err != nil { + return nil, err + } + return dAtA[:n], nil +} + +func (m *QueryRequestVerificationRequest) MarshalTo(dAtA []byte) (int, error) { + size := m.Size() + return m.MarshalToSizedBuffer(dAtA[:size]) +} + +func (m *QueryRequestVerificationRequest) MarshalToSizedBuffer(dAtA []byte) (int, error) { + i := len(dAtA) + _ = i + var l int + _ = l + if len(m.Signature) > 0 { + i -= len(m.Signature) + copy(dAtA[i:], m.Signature) + i = encodeVarintQuery(dAtA, i, uint64(len(m.Signature))) + i-- + dAtA[i] = 0x32 + } + if len(m.Reporter) > 0 { + i -= len(m.Reporter) + copy(dAtA[i:], m.Reporter) + i = encodeVarintQuery(dAtA, i, uint64(len(m.Reporter))) + i-- + dAtA[i] = 0x2a + } + if m.ExternalId != 0 { + i = encodeVarintQuery(dAtA, i, uint64(m.ExternalId)) + i-- + dAtA[i] = 0x20 + } + if m.RequestId != 0 { + i = encodeVarintQuery(dAtA, i, uint64(m.RequestId)) + i-- + dAtA[i] = 0x18 + } + if len(m.Validator) > 0 { + i -= len(m.Validator) + copy(dAtA[i:], m.Validator) + i = encodeVarintQuery(dAtA, i, uint64(len(m.Validator))) + i-- + dAtA[i] = 0x12 + } + if len(m.ChainId) > 0 { + i -= len(m.ChainId) + copy(dAtA[i:], m.ChainId) + i = encodeVarintQuery(dAtA, i, uint64(len(m.ChainId))) + i-- + dAtA[i] = 0xa + } + return len(dAtA) - i, nil +} + +func (m *QueryRequestVerificationResponse) Marshal() (dAtA []byte, err error) { + size := m.Size() + dAtA = make([]byte, size) + n, err := m.MarshalToSizedBuffer(dAtA[:size]) + if err != nil { + return nil, err + } + return dAtA[:n], nil +} + +func (m *QueryRequestVerificationResponse) MarshalTo(dAtA []byte) (int, error) { + size := m.Size() + return m.MarshalToSizedBuffer(dAtA[:size]) +} + +func (m *QueryRequestVerificationResponse) MarshalToSizedBuffer(dAtA []byte) (int, error) { + i := len(dAtA) + _ = i + var l int + _ = l + if m.DataSourceId != 0 { + i = encodeVarintQuery(dAtA, i, uint64(m.DataSourceId)) + i-- + dAtA[i] = 0x28 + } + if m.ExternalId != 0 { + i = encodeVarintQuery(dAtA, i, uint64(m.ExternalId)) + i-- + dAtA[i] = 0x20 + } + if m.RequestId != 0 { + i = encodeVarintQuery(dAtA, i, uint64(m.RequestId)) + i-- + dAtA[i] = 0x18 + } + if len(m.Validator) > 0 { + i -= len(m.Validator) + copy(dAtA[i:], m.Validator) + i = encodeVarintQuery(dAtA, i, uint64(len(m.Validator))) + i-- + dAtA[i] = 0x12 + } + if len(m.ChainId) > 0 { + i -= len(m.ChainId) + copy(dAtA[i:], m.ChainId) + i = encodeVarintQuery(dAtA, i, uint64(len(m.ChainId))) + i-- + dAtA[i] = 0xa + } + return len(dAtA) - i, nil +} + func (m *QueryRequestPoolRequest) Marshal() (dAtA []byte, err error) { size := m.Size() dAtA = make([]byte, size) @@ -2965,6 +3307,63 @@ func (m *QueryRequestPriceResponse) Size() (n int) { return n } +func (m *QueryRequestVerificationRequest) Size() (n int) { + if m == nil { + return 0 + } + var l int + _ = l + l = len(m.ChainId) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + l = len(m.Validator) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + if m.RequestId != 0 { + n += 1 + sovQuery(uint64(m.RequestId)) + } + if m.ExternalId != 0 { + n += 1 + sovQuery(uint64(m.ExternalId)) + } + l = len(m.Reporter) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + l = len(m.Signature) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + return n +} + +func (m *QueryRequestVerificationResponse) Size() (n int) { + if m == nil { + return 0 + } + var l int + _ = l + l = len(m.ChainId) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + l = len(m.Validator) + if l > 0 { + n += 1 + l + sovQuery(uint64(l)) + } + if m.RequestId != 0 { + n += 1 + sovQuery(uint64(m.RequestId)) + } + if m.ExternalId != 0 { + n += 1 + sovQuery(uint64(m.ExternalId)) + } + if m.DataSourceId != 0 { + n += 1 + sovQuery(uint64(m.DataSourceId)) + } + return n +} + func (m *QueryRequestPoolRequest) Size() (n int) { if m == nil { return 0 @@ -4871,6 +5270,395 @@ func (m *QueryRequestPriceResponse) Unmarshal(dAtA []byte) error { } return nil } +func (m *QueryRequestVerificationRequest) Unmarshal(dAtA []byte) error { + l := len(dAtA) + iNdEx := 0 + for iNdEx < l { + preIndex := iNdEx + var wire uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + wire |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + fieldNum := int32(wire >> 3) + wireType := int(wire & 0x7) + if wireType == 4 { + return fmt.Errorf("proto: QueryRequestVerificationRequest: wiretype end group for non-group") + } + if fieldNum <= 0 { + return fmt.Errorf("proto: QueryRequestVerificationRequest: illegal tag %d (wire type %d)", fieldNum, wire) + } + switch fieldNum { + case 1: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field ChainId", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.ChainId = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 2: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field Validator", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.Validator = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 3: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field RequestId", wireType) + } + m.RequestId = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.RequestId |= int64(b&0x7F) << shift + if b < 0x80 { + break + } + } + case 4: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field ExternalId", wireType) + } + m.ExternalId = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.ExternalId |= int64(b&0x7F) << shift + if b < 0x80 { + break + } + } + case 5: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field Reporter", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.Reporter = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 6: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field Signature", wireType) + } + var byteLen int + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + byteLen |= int(b&0x7F) << shift + if b < 0x80 { + break + } + } + if byteLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + byteLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.Signature = append(m.Signature[:0], dAtA[iNdEx:postIndex]...) + if m.Signature == nil { + m.Signature = []byte{} + } + iNdEx = postIndex + default: + iNdEx = preIndex + skippy, err := skipQuery(dAtA[iNdEx:]) + if err != nil { + return err + } + if (skippy < 0) || (iNdEx+skippy) < 0 { + return ErrInvalidLengthQuery + } + if (iNdEx + skippy) > l { + return io.ErrUnexpectedEOF + } + iNdEx += skippy + } + } + + if iNdEx > l { + return io.ErrUnexpectedEOF + } + return nil +} +func (m *QueryRequestVerificationResponse) Unmarshal(dAtA []byte) error { + l := len(dAtA) + iNdEx := 0 + for iNdEx < l { + preIndex := iNdEx + var wire uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + wire |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + fieldNum := int32(wire >> 3) + wireType := int(wire & 0x7) + if wireType == 4 { + return fmt.Errorf("proto: QueryRequestVerificationResponse: wiretype end group for non-group") + } + if fieldNum <= 0 { + return fmt.Errorf("proto: QueryRequestVerificationResponse: illegal tag %d (wire type %d)", fieldNum, wire) + } + switch fieldNum { + case 1: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field ChainId", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.ChainId = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 2: + if wireType != 2 { + return fmt.Errorf("proto: wrong wireType = %d for field Validator", wireType) + } + var stringLen uint64 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + stringLen |= uint64(b&0x7F) << shift + if b < 0x80 { + break + } + } + intStringLen := int(stringLen) + if intStringLen < 0 { + return ErrInvalidLengthQuery + } + postIndex := iNdEx + intStringLen + if postIndex < 0 { + return ErrInvalidLengthQuery + } + if postIndex > l { + return io.ErrUnexpectedEOF + } + m.Validator = string(dAtA[iNdEx:postIndex]) + iNdEx = postIndex + case 3: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field RequestId", wireType) + } + m.RequestId = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.RequestId |= int64(b&0x7F) << shift + if b < 0x80 { + break + } + } + case 4: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field ExternalId", wireType) + } + m.ExternalId = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.ExternalId |= int64(b&0x7F) << shift + if b < 0x80 { + break + } + } + case 5: + if wireType != 0 { + return fmt.Errorf("proto: wrong wireType = %d for field DataSourceId", wireType) + } + m.DataSourceId = 0 + for shift := uint(0); ; shift += 7 { + if shift >= 64 { + return ErrIntOverflowQuery + } + if iNdEx >= l { + return io.ErrUnexpectedEOF + } + b := dAtA[iNdEx] + iNdEx++ + m.DataSourceId |= int64(b&0x7F) << shift + if b < 0x80 { + break + } + } + default: + iNdEx = preIndex + skippy, err := skipQuery(dAtA[iNdEx:]) + if err != nil { + return err + } + if (skippy < 0) || (iNdEx+skippy) < 0 { + return ErrInvalidLengthQuery + } + if (iNdEx + skippy) > l { + return io.ErrUnexpectedEOF + } + iNdEx += skippy + } + } + + if iNdEx > l { + return io.ErrUnexpectedEOF + } + return nil +} func (m *QueryRequestPoolRequest) Unmarshal(dAtA []byte) error { l := len(dAtA) iNdEx := 0 diff --git a/x/oracle/types/query.pb.gw.go b/x/oracle/types/query.pb.gw.go index a9b4fe5be..d556532e0 100644 --- a/x/oracle/types/query.pb.gw.go +++ b/x/oracle/types/query.pb.gw.go @@ -481,6 +481,42 @@ func local_request_Query_RequestPrice_0(ctx context.Context, marshaler runtime.M } +var ( + filter_Query_RequestVerification_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} +) + +func request_Query_RequestVerification_0(ctx context.Context, marshaler runtime.Marshaler, client QueryClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { + var protoReq QueryRequestVerificationRequest + var metadata runtime.ServerMetadata + + if err := req.ParseForm(); err != nil { + return nil, metadata, status.Errorf(codes.InvalidArgument, "%v", err) + } + if err := runtime.PopulateQueryParameters(&protoReq, req.Form, filter_Query_RequestVerification_0); err != nil { + return nil, metadata, status.Errorf(codes.InvalidArgument, "%v", err) + } + + msg, err := client.RequestVerification(ctx, &protoReq, grpc.Header(&metadata.HeaderMD), grpc.Trailer(&metadata.TrailerMD)) + return msg, metadata, err + +} + +func local_request_Query_RequestVerification_0(ctx context.Context, marshaler runtime.Marshaler, server QueryServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { + var protoReq QueryRequestVerificationRequest + var metadata runtime.ServerMetadata + + if err := req.ParseForm(); err != nil { + return nil, metadata, status.Errorf(codes.InvalidArgument, "%v", err) + } + if err := runtime.PopulateQueryParameters(&protoReq, req.Form, filter_Query_RequestVerification_0); err != nil { + return nil, metadata, status.Errorf(codes.InvalidArgument, "%v", err) + } + + msg, err := server.RequestVerification(ctx, &protoReq) + return msg, metadata, err + +} + func request_Query_RequestPool_0(ctx context.Context, marshaler runtime.Marshaler, client QueryClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { var protoReq QueryRequestPoolRequest var metadata runtime.ServerMetadata @@ -805,6 +841,26 @@ func RegisterQueryHandlerServer(ctx context.Context, mux *runtime.ServeMux, serv }) + mux.Handle("GET", pattern_Query_RequestVerification_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { + ctx, cancel := context.WithCancel(req.Context()) + defer cancel() + inboundMarshaler, outboundMarshaler := runtime.MarshalerForRequest(mux, req) + rctx, err := runtime.AnnotateIncomingContext(ctx, mux, req) + if err != nil { + runtime.HTTPError(ctx, mux, outboundMarshaler, w, req, err) + return + } + resp, md, err := local_request_Query_RequestVerification_0(rctx, inboundMarshaler, server, req, pathParams) + ctx = runtime.NewServerMetadataContext(ctx, md) + if err != nil { + runtime.HTTPError(ctx, mux, outboundMarshaler, w, req, err) + return + } + + forward_Query_RequestVerification_0(ctx, mux, outboundMarshaler, w, req, resp, mux.GetForwardResponseOptions()...) + + }) + mux.Handle("GET", pattern_Query_RequestPool_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { ctx, cancel := context.WithCancel(req.Context()) defer cancel() @@ -1086,6 +1142,26 @@ func RegisterQueryHandlerClient(ctx context.Context, mux *runtime.ServeMux, clie }) + mux.Handle("GET", pattern_Query_RequestVerification_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { + ctx, cancel := context.WithCancel(req.Context()) + defer cancel() + inboundMarshaler, outboundMarshaler := runtime.MarshalerForRequest(mux, req) + rctx, err := runtime.AnnotateContext(ctx, mux, req) + if err != nil { + runtime.HTTPError(ctx, mux, outboundMarshaler, w, req, err) + return + } + resp, md, err := request_Query_RequestVerification_0(rctx, inboundMarshaler, client, req, pathParams) + ctx = runtime.NewServerMetadataContext(ctx, md) + if err != nil { + runtime.HTTPError(ctx, mux, outboundMarshaler, w, req, err) + return + } + + forward_Query_RequestVerification_0(ctx, mux, outboundMarshaler, w, req, resp, mux.GetForwardResponseOptions()...) + + }) + mux.Handle("GET", pattern_Query_RequestPool_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { ctx, cancel := context.WithCancel(req.Context()) defer cancel() @@ -1132,6 +1208,8 @@ var ( pattern_Query_RequestPrice_0 = runtime.MustPattern(runtime.NewPattern(1, []int{2, 0, 2, 1}, []string{"oracle", "request_prices"}, "", runtime.AssumeColonVerbOpt(true))) + pattern_Query_RequestVerification_0 = runtime.MustPattern(runtime.NewPattern(1, []int{2, 0, 2, 1, 2, 2}, []string{"oracle", "v1", "verify_request"}, "", runtime.AssumeColonVerbOpt(true))) + pattern_Query_RequestPool_0 = runtime.MustPattern(runtime.NewPattern(1, []int{2, 0, 2, 1, 2, 2, 1, 0, 4, 1, 5, 3, 1, 0, 4, 1, 5, 4, 1, 0, 4, 1, 5, 5}, []string{"oracle", "v1", "request_pool", "request_key", "port_id", "channel_id"}, "", runtime.AssumeColonVerbOpt(true))) ) @@ -1158,5 +1236,7 @@ var ( forward_Query_RequestPrice_0 = runtime.ForwardResponseMessage + forward_Query_RequestVerification_0 = runtime.ForwardResponseMessage + forward_Query_RequestPool_0 = runtime.ForwardResponseMessage ) diff --git a/x/oracle/types/verify_request.go b/x/oracle/types/verify_request.go new file mode 100644 index 000000000..198992ef3 --- /dev/null +++ b/x/oracle/types/verify_request.go @@ -0,0 +1,21 @@ +package types + +import ( + "encoding/json" + + sdk "github.com/cosmos/cosmos-sdk/types" +) + +func NewRequestVerification(chainID string, validator sdk.ValAddress, requestID RequestID, externalID ExternalID) RequestVerification { + return RequestVerification{ + ChainID: chainID, + Validator: validator.String(), + RequestID: requestID, + ExternalID: externalID, + } +} + +func (msg RequestVerification) GetSignBytes() []byte { + bz, _ := json.Marshal(msg) + return sdk.MustSortJSON(bz) +}