diff --git a/cmd/layotto_multiple_api/main.go b/cmd/layotto_multiple_api/main.go index 1856926a2c..22c673121b 100644 --- a/cmd/layotto_multiple_api/main.go +++ b/cmd/layotto_multiple_api/main.go @@ -81,7 +81,7 @@ import ( "mosn.io/layotto/components/file/qiniu" "mosn.io/layotto/components/file/tencentcloud" "mosn.io/layotto/components/sequencer" - "mosn.io/layotto/pkg/grpc/dapr" + "mosn.io/layotto/pkg/runtime/bindings" runtime_sequencer "mosn.io/layotto/pkg/runtime/sequencer" @@ -281,11 +281,6 @@ func NewRuntimeGrpcServer(data json.RawMessage, opts ...grpc.ServerOption) (mgrp // a demo to show how to register your own gRPC API helloworld_api.NewHelloWorldAPI, - - // support Dapr API - // Currently it only support Dapr's InvokeService,secret API,state API and InvokeBinding API. - // Note: this feature is still in Alpha state and we don't recommend that you use it in your production environment. - dapr.NewDaprAPI_Alpha, ), runtime.WithExtensionGrpcAPI(), // Hello diff --git a/pkg/grpc/dapr/dapr_api.go b/pkg/grpc/dapr/dapr_api.go deleted file mode 100644 index df7ddbe122..0000000000 --- a/pkg/grpc/dapr/dapr_api.go +++ /dev/null @@ -1,218 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - "errors" - "strings" - - "github.com/dapr/components-contrib/bindings" - "github.com/dapr/components-contrib/pubsub" - "github.com/dapr/components-contrib/secretstores" - "github.com/dapr/components-contrib/state" - jsoniter "github.com/json-iterator/go" - "google.golang.org/grpc" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/metadata" - "google.golang.org/grpc/status" - "google.golang.org/protobuf/types/known/anypb" - "mosn.io/pkg/log" - - "mosn.io/layotto/components/configstores" - "mosn.io/layotto/components/file" - "mosn.io/layotto/components/hello" - "mosn.io/layotto/components/lock" - runtime_common "mosn.io/layotto/components/pkg/common" - "mosn.io/layotto/components/rpc" - mosninvoker "mosn.io/layotto/components/rpc/invoker/mosn" - "mosn.io/layotto/components/sequencer" - grpc_api "mosn.io/layotto/pkg/grpc" - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "mosn.io/layotto/pkg/messages" -) - -type DaprGrpcAPI interface { - dapr_v1pb.DaprServer - grpc_api.GrpcAPI -} - -type daprGrpcAPI struct { - appId string - hellos map[string]hello.HelloService - configStores map[string]configstores.Store - rpcs map[string]rpc.Invoker - pubSubs map[string]pubsub.PubSub - stateStores map[string]state.Store - transactionalStateStores map[string]state.TransactionalStore - fileOps map[string]file.File - lockStores map[string]lock.LockStore - sequencers map[string]sequencer.Store - sendToOutputBindingFn func(name string, req *bindings.InvokeRequest) (*bindings.InvokeResponse, error) - secretStores map[string]secretstores.SecretStore - // app callback - AppCallbackConn *grpc.ClientConn - topicPerComponent map[string]TopicSubscriptions - // json - json jsoniter.API -} - -func (d *daprGrpcAPI) Init(conn *grpc.ClientConn) error { - // 1. set connection - d.AppCallbackConn = conn - return d.startSubscribing() -} - -func (d *daprGrpcAPI) Register(rawGrpcServer *grpc.Server) error { - dapr_v1pb.RegisterDaprServer(rawGrpcServer, d) - return nil -} - -func (d *daprGrpcAPI) InvokeService(ctx context.Context, in *dapr_v1pb.InvokeServiceRequest) (*dapr_common_v1pb.InvokeResponse, error) { - // 1. convert request to RPCRequest,which is the parameter for RPC components - msg := in.GetMessage() - req := &rpc.RPCRequest{ - Ctx: ctx, - Id: in.GetId(), - Method: msg.GetMethod(), - ContentType: msg.GetContentType(), - Data: msg.GetData().GetValue(), - } - if md, ok := metadata.FromIncomingContext(ctx); ok { - req.Header = rpc.RPCHeader(md) - } else { - req.Header = rpc.RPCHeader(map[string][]string{}) - } - if ext := msg.GetHttpExtension(); ext != nil { - req.Header["verb"] = []string{ext.Verb.String()} - req.Header["query_string"] = []string{ext.GetQuerystring()} - } - - // 2. route to the specific rpc.Invoker component. - // Only support mosn component now. - invoker, ok := d.rpcs[mosninvoker.Name] - if !ok { - return nil, errors.New("invoker not init") - } - - // 3. delegate to the rpc.Invoker component - resp, err := invoker.Invoke(ctx, req) - - // 4. convert result - if err != nil { - return nil, runtime_common.ToGrpcError(err) - } - // 5. convert result - if !resp.Success && resp.Error != nil { - return nil, runtime_common.ToGrpcError(resp.Error) - } - - if resp.Header != nil { - header := metadata.Pairs() - for k, values := range resp.Header { - // fix https://github.com/mosn/layotto/issues/285 - if strings.EqualFold("content-length", k) { - continue - } - header.Set(k, values...) - } - grpc.SetHeader(ctx, header) - } - return &dapr_common_v1pb.InvokeResponse{ - ContentType: resp.ContentType, - Data: &anypb.Any{Value: resp.Data}, - }, nil -} - -func (d *daprGrpcAPI) InvokeBinding(ctx context.Context, in *dapr_v1pb.InvokeBindingRequest) (*dapr_v1pb.InvokeBindingResponse, error) { - req := &bindings.InvokeRequest{ - Metadata: in.Metadata, - Operation: bindings.OperationKind(in.Operation), - } - if in.Data != nil { - req.Data = in.Data - } - - r := &dapr_v1pb.InvokeBindingResponse{} - resp, err := d.sendToOutputBindingFn(in.Name, req) - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrInvokeOutputBinding, in.Name, err.Error()) - log.DefaultLogger.Errorf("call out binding fail, err:%+v", err) - return r, err - } - - if resp != nil { - r.Data = resp.Data - r.Metadata = resp.Metadata - } - return r, nil -} - -func (d *daprGrpcAPI) isSecretAllowed(storeName string, key string) bool { - // TODO: add permission control - return true -} - -// NewDaprAPI_Alpha construct a grpc_api.GrpcAPI which implements DaprServer. -// Currently it only support Dapr's InvokeService and InvokeBinding API. -// Note: this feature is still in Alpha state and we don't recommend that you use it in your production environment. -func NewDaprAPI_Alpha(ac *grpc_api.ApplicationContext) grpc_api.GrpcAPI { - // filter out transactionalStateStores - transactionalStateStores := map[string]state.TransactionalStore{} - for key, store := range ac.StateStores { - if state.FeatureTransactional.IsPresent(store.Features()) { - transactionalStateStores[key] = store.(state.TransactionalStore) - } - } - return NewDaprServer(ac.AppId, - ac.Hellos, ac.ConfigStores, ac.Rpcs, ac.PubSubs, ac.StateStores, transactionalStateStores, - ac.Files, ac.LockStores, ac.Sequencers, - ac.SendToOutputBindingFn, ac.SecretStores) -} - -func NewDaprServer( - appId string, - hellos map[string]hello.HelloService, - configStores map[string]configstores.Store, - rpcs map[string]rpc.Invoker, - pubSubs map[string]pubsub.PubSub, - stateStores map[string]state.Store, - transactionalStateStores map[string]state.TransactionalStore, - files map[string]file.File, - lockStores map[string]lock.LockStore, - sequencers map[string]sequencer.Store, - sendToOutputBindingFn func(name string, req *bindings.InvokeRequest) (*bindings.InvokeResponse, error), - secretStores map[string]secretstores.SecretStore, -) DaprGrpcAPI { - // construct - return &daprGrpcAPI{ - appId: appId, - hellos: hellos, - configStores: configStores, - rpcs: rpcs, - pubSubs: pubSubs, - stateStores: stateStores, - transactionalStateStores: transactionalStateStores, - fileOps: files, - lockStores: lockStores, - sequencers: sequencers, - sendToOutputBindingFn: sendToOutputBindingFn, - json: jsoniter.ConfigFastest, - secretStores: secretStores, - } -} diff --git a/pkg/grpc/dapr/dapr_api_pubsub.go b/pkg/grpc/dapr/dapr_api_pubsub.go deleted file mode 100644 index a8c40cf113..0000000000 --- a/pkg/grpc/dapr/dapr_api_pubsub.go +++ /dev/null @@ -1,308 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - "encoding/base64" - "fmt" - - "github.com/dapr/components-contrib/contenttype" - "github.com/dapr/components-contrib/pubsub" - "github.com/google/uuid" - jsoniter "github.com/json-iterator/go" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/status" - "google.golang.org/protobuf/types/known/emptypb" - "mosn.io/pkg/log" - - l8_comp_pubsub "mosn.io/layotto/components/pubsub" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "mosn.io/layotto/pkg/messages" -) - -const ( - Metadata_key_pubsubName = "pubsubName" -) - -type Details struct { - metadata map[string]string -} - -type TopicSubscriptions struct { - topic2Details map[string]Details -} - -func (d *daprGrpcAPI) PublishEvent(ctx context.Context, in *dapr_v1pb.PublishEventRequest) (*emptypb.Empty, error) { - // 1. validate - result, err := d.doPublishEvent(ctx, in.PubsubName, in.Topic, in.Data, in.DataContentType, in.Metadata) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) - } - return result, err -} - -// doPublishEvent is a protocal irrelevant function to do event publishing. -// It's easy to add APIs for other protocals(e.g. for http api). Just move this func to a separate layer if you need. -func (d *daprGrpcAPI) doPublishEvent(ctx context.Context, pubsubName string, topic string, data []byte, contentType string, metadata map[string]string) (*emptypb.Empty, error) { - // 1. validate - if pubsubName == "" { - err := status.Error(codes.InvalidArgument, messages.ErrPubsubEmpty) - return &emptypb.Empty{}, err - } - if topic == "" { - err := status.Errorf(codes.InvalidArgument, messages.ErrTopicEmpty, pubsubName) - return &emptypb.Empty{}, err - } - // 2. get component - component, ok := d.pubSubs[pubsubName] - if !ok { - err := status.Errorf(codes.InvalidArgument, messages.ErrPubsubNotFound, pubsubName) - return &emptypb.Empty{}, err - } - - // 3. new cloudevent request - if data == nil { - data = []byte{} - } - var envelope map[string]interface{} - var err error - if contenttype.IsCloudEventContentType(contentType) { - envelope, err = pubsub.FromCloudEvent(data, topic, pubsubName, "") - if err != nil { - err = status.Errorf(codes.InvalidArgument, messages.ErrPubsubCloudEventCreation, err.Error()) - return &emptypb.Empty{}, err - } - } else { - envelope = pubsub.NewCloudEventsEnvelope(uuid.New().String(), l8_comp_pubsub.DefaultCloudEventSource, l8_comp_pubsub.DefaultCloudEventType, "", topic, pubsubName, - contentType, data, "") - } - features := component.Features() - pubsub.ApplyMetadata(envelope, features, metadata) - - b, err := jsoniter.ConfigFastest.Marshal(envelope) - if err != nil { - err = status.Errorf(codes.InvalidArgument, messages.ErrPubsubCloudEventsSer, topic, pubsubName, err.Error()) - return &emptypb.Empty{}, err - } - // 4. publish - req := pubsub.PublishRequest{ - PubsubName: pubsubName, - Topic: topic, - Data: b, - Metadata: metadata, - } - - // TODO limit topic scope - err = component.Publish(&req) - if err != nil { - nerr := status.Errorf(codes.Internal, messages.ErrPubsubPublishMessage, topic, pubsubName, err.Error()) - return &emptypb.Empty{}, nerr - } - return &emptypb.Empty{}, nil -} - -func (d *daprGrpcAPI) startSubscribing() error { - // 1. check if there is no need to do it - if len(d.pubSubs) == 0 { - return nil - } - // 2. list topics - topicRoutes, err := d.getInterestedTopics() - if err != nil { - return err - } - // return if no need to dosubscription - if len(topicRoutes) == 0 { - return nil - } - // 3. loop subscribe - for name, pubsub := range d.pubSubs { - if err := d.beginPubSub(name, pubsub, topicRoutes); err != nil { - return err - } - } - return nil -} - -func (d *daprGrpcAPI) getInterestedTopics() (map[string]TopicSubscriptions, error) { - // 1. check - if d.topicPerComponent != nil { - return d.topicPerComponent, nil - } - if d.AppCallbackConn == nil { - return make(map[string]TopicSubscriptions), nil - } - comp2Topic := make(map[string]TopicSubscriptions) - var subscriptions []*dapr_v1pb.TopicSubscription - - // 2. handle app subscriptions - client := dapr_v1pb.NewAppCallbackClient(d.AppCallbackConn) - subscriptions = listTopicSubscriptions(client, log.DefaultLogger) - // TODO handle declarative subscriptions - - // 3. prepare result - for _, s := range subscriptions { - if s == nil { - continue - } - if _, ok := comp2Topic[s.PubsubName]; !ok { - comp2Topic[s.PubsubName] = TopicSubscriptions{make(map[string]Details)} - } - comp2Topic[s.PubsubName].topic2Details[s.Topic] = Details{metadata: s.Metadata} - } - - // 4. log - if len(comp2Topic) > 0 { - for pubsubName, v := range comp2Topic { - topics := []string{} - for topic := range v.topic2Details { - topics = append(topics, topic) - } - log.DefaultLogger.Infof("[runtime][getInterestedTopics]app is subscribed to the following topics: %v through pubsub=%s", topics, pubsubName) - } - } - - // 5. cache the result - d.topicPerComponent = comp2Topic - - return comp2Topic, nil -} - -func (d *daprGrpcAPI) beginPubSub(pubsubName string, ps pubsub.PubSub, topicRoutes map[string]TopicSubscriptions) error { - // 1. call app to find topic topic2Details. - v, ok := topicRoutes[pubsubName] - if !ok { - return nil - } - // 2. loop subscribing every - for topic, route := range v.topic2Details { - // TODO limit topic scope - log.DefaultLogger.Debugf("[runtime][beginPubSub]subscribing to topic=%s on pubsub=%s", topic, pubsubName) - // ask component to subscribe - if err := ps.Subscribe(pubsub.SubscribeRequest{ - Topic: topic, - Metadata: route.metadata, - }, func(ctx context.Context, msg *pubsub.NewMessage) error { - if msg.Metadata == nil { - msg.Metadata = make(map[string]string, 1) - } - msg.Metadata[Metadata_key_pubsubName] = pubsubName - return d.publishMessageGRPC(ctx, msg) - }); err != nil { - log.DefaultLogger.Warnf("[runtime][beginPubSub]failed to subscribe to topic %s: %s", topic, err) - return err - } - } - return nil -} - -func (d *daprGrpcAPI) publishMessageGRPC(ctx context.Context, msg *pubsub.NewMessage) error { - // 1. unmarshal to cloudEvent model - var cloudEvent map[string]interface{} - err := d.json.Unmarshal(msg.Data, &cloudEvent) - if err != nil { - log.DefaultLogger.Debugf("[runtime]error deserializing cloud events proto: %s", err) - return err - } - - // 2. drop msg if the current cloud event has expired - if pubsub.HasExpired(cloudEvent) { - log.DefaultLogger.Warnf("[runtime]dropping expired pub/sub event %v as of %v", cloudEvent[pubsub.IDField].(string), cloudEvent[pubsub.ExpirationField].(string)) - return nil - } - - // 3. convert request - envelope := &dapr_v1pb.TopicEventRequest{ - Id: cloudEvent[pubsub.IDField].(string), - Source: cloudEvent[pubsub.SourceField].(string), - DataContentType: cloudEvent[pubsub.DataContentTypeField].(string), - Type: cloudEvent[pubsub.TypeField].(string), - SpecVersion: cloudEvent[pubsub.SpecVersionField].(string), - Topic: msg.Topic, - PubsubName: msg.Metadata[Metadata_key_pubsubName], - } - - // set data field - if data, ok := cloudEvent[pubsub.DataBase64Field]; ok && data != nil { - decoded, decodeErr := base64.StdEncoding.DecodeString(data.(string)) - if decodeErr != nil { - log.DefaultLogger.Debugf("unable to base64 decode cloudEvent field data_base64: %s", decodeErr) - return err - } - - envelope.Data = decoded - } else if data, ok := cloudEvent[pubsub.DataField]; ok && data != nil { - envelope.Data = nil - - if contenttype.IsStringContentType(envelope.DataContentType) { - envelope.Data = []byte(data.(string)) - } else if contenttype.IsJSONContentType(envelope.DataContentType) { - envelope.Data, _ = d.json.Marshal(data) - } - } - - // 4. call appcallback - clientV1 := dapr_v1pb.NewAppCallbackClient(d.AppCallbackConn) - res, err := clientV1.OnTopicEvent(ctx, envelope) - - // 5. check result - return retryStrategy(err, res, cloudEvent) -} - -func retryStrategy(err error, res *dapr_v1pb.TopicEventResponse, cloudEvent map[string]interface{}) error { - if err != nil { - errStatus, hasErrStatus := status.FromError(err) - if hasErrStatus && (errStatus.Code() == codes.Unimplemented) { - // DROP - log.DefaultLogger.Warnf("[runtime]non-retriable error returned from app while processing pub/sub event %v: %s", cloudEvent[pubsub.IDField].(string), err) - return nil - } - - err = fmt.Errorf("error returned from app while processing pub/sub event %v: %s", cloudEvent[pubsub.IDField].(string), err) - log.DefaultLogger.Debugf("%s", err) - // on error from application, return error for redelivery of event - return err - } - - switch res.GetStatus() { - case dapr_v1pb.TopicEventResponse_SUCCESS: - // on uninitialized status, this is the case it defaults to as an uninitialized status defaults to 0 which is - // success from protobuf definition - return nil - case dapr_v1pb.TopicEventResponse_RETRY: - return fmt.Errorf("RETRY status returned from app while processing pub/sub event %v", cloudEvent[pubsub.IDField].(string)) - case dapr_v1pb.TopicEventResponse_DROP: - log.DefaultLogger.Warnf("[runtime]DROP status returned from app while processing pub/sub event %v", cloudEvent[pubsub.IDField].(string)) - return nil - } - // Consider unknown status field as error and retry - return fmt.Errorf("unknown status returned from app while processing pub/sub event %v: %v", cloudEvent[pubsub.IDField].(string), res.GetStatus()) -} - -func listTopicSubscriptions(client dapr_v1pb.AppCallbackClient, log log.ErrorLogger) []*dapr_v1pb.TopicSubscription { - resp, err := client.ListTopicSubscriptions(context.Background(), &emptypb.Empty{}) - if err != nil { - log.Errorf("[runtime][listTopicSubscriptions]error after callback: %s", err) - return make([]*dapr_v1pb.TopicSubscription, 0) - } - - if resp != nil && len(resp.Subscriptions) > 0 { - return resp.Subscriptions - } - return make([]*dapr_v1pb.TopicSubscription, 0) -} diff --git a/pkg/grpc/dapr/dapr_api_pubsub_test.go b/pkg/grpc/dapr/dapr_api_pubsub_test.go deleted file mode 100644 index 5d17d106de..0000000000 --- a/pkg/grpc/dapr/dapr_api_pubsub_test.go +++ /dev/null @@ -1,218 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package dapr - -import ( - "context" - "encoding/json" - "fmt" - "net" - "testing" - "time" - - "github.com/dapr/components-contrib/pubsub" - "github.com/golang/mock/gomock" - "github.com/golang/protobuf/ptypes/empty" - jsoniter "github.com/json-iterator/go" - "github.com/stretchr/testify/assert" - "google.golang.org/grpc" - rawGRPC "google.golang.org/grpc" - "google.golang.org/grpc/test/bufconn" - "mosn.io/pkg/log" - - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - mock_pubsub "mosn.io/layotto/pkg/mock/components/pubsub" - mock_appcallback "mosn.io/layotto/pkg/mock/runtime/appcallback" -) - -func TestDaprGrpcAPIPublishEvent(t *testing.T) { - t.Run("invalid pubsub name", func(t *testing.T) { - ctrl := gomock.NewController(t) - mockPubSub := mock_pubsub.NewMockPubSub(ctrl) - api := NewDaprServer("", nil, - nil, nil, map[string]pubsub.PubSub{"mock": mockPubSub}, nil, - nil, nil, nil, nil, nil, nil) - _, err := api.PublishEvent(context.Background(), &dapr_v1pb.PublishEventRequest{}) - assert.Equal(t, "rpc error: code = InvalidArgument desc = pubsub name is empty", err.Error()) - }) - - t.Run("invalid topic", func(t *testing.T) { - ctrl := gomock.NewController(t) - mockPubSub := mock_pubsub.NewMockPubSub(ctrl) - api := NewDaprServer("", nil, nil, nil, map[string]pubsub.PubSub{"mock": mockPubSub}, nil, - nil, nil, nil, nil, nil, nil) - req := &dapr_v1pb.PublishEventRequest{ - PubsubName: "mock", - } - _, err := api.PublishEvent(context.Background(), req) - assert.Equal(t, "rpc error: code = InvalidArgument desc = topic is empty in pubsub mock", err.Error()) - }) - - t.Run("component not found", func(t *testing.T) { - ctrl := gomock.NewController(t) - mockPubSub := mock_pubsub.NewMockPubSub(ctrl) - api := NewDaprServer("", nil, nil, nil, map[string]pubsub.PubSub{"mock": mockPubSub}, nil, - nil, nil, nil, nil, nil, nil) - req := &dapr_v1pb.PublishEventRequest{ - PubsubName: "abc", - Topic: "abc", - } - _, err := api.PublishEvent(context.Background(), req) - assert.Equal(t, "rpc error: code = InvalidArgument desc = pubsub abc not found", err.Error()) - }) - - t.Run("publish success", func(t *testing.T) { - ctrl := gomock.NewController(t) - mockPubSub := mock_pubsub.NewMockPubSub(ctrl) - mockPubSub.EXPECT().Publish(gomock.Any()).Return(nil) - mockPubSub.EXPECT().Features().Return(nil) - api := NewDaprServer("", nil, nil, nil, map[string]pubsub.PubSub{"mock": mockPubSub}, nil, - nil, nil, nil, nil, nil, nil) - req := &dapr_v1pb.PublishEventRequest{ - PubsubName: "mock", - Topic: "abc", - } - _, err := api.PublishEvent(context.Background(), req) - assert.Nil(t, err) - }) - - t.Run("publish net error", func(t *testing.T) { - ctrl := gomock.NewController(t) - mockPubSub := mock_pubsub.NewMockPubSub(ctrl) - mockPubSub.EXPECT().Publish(gomock.Any()).Return(fmt.Errorf("net error")) - mockPubSub.EXPECT().Features().Return(nil) - api := NewDaprServer("", nil, nil, nil, map[string]pubsub.PubSub{"mock": mockPubSub}, nil, - nil, nil, nil, nil, nil, nil) - req := &dapr_v1pb.PublishEventRequest{ - PubsubName: "mock", - Topic: "abc", - } - _, err := api.PublishEvent(context.Background(), req) - assert.NotNil(t, err) - assert.Equal(t, "rpc error: code = Internal desc = error when publish to topic abc in pubsub mock: net error", err.Error()) - }) -} - -func TestMosnRuntime_publishMessageGRPC(t *testing.T) { - t.Run("publish success", func(t *testing.T) { - subResp := &dapr_v1pb.TopicEventResponse{ - Status: dapr_v1pb.TopicEventResponse_SUCCESS, - } - // init grpc server - mockAppCallbackServer := mock_appcallback.NewMockDaprAppCallbackServer(gomock.NewController(t)) - mockAppCallbackServer.EXPECT().OnTopicEvent(gomock.Any(), gomock.Any()).Return(subResp, nil) - - lis := bufconn.Listen(1024 * 1024) - s := grpc.NewServer() - dapr_v1pb.RegisterAppCallbackServer(s, mockAppCallbackServer) - go func() { - s.Serve(lis) - }() - - // init callback client - callbackClient, err := grpc.DialContext(context.Background(), "bufnet", rawGRPC.WithInsecure(), rawGRPC.WithContextDialer(func(ctx context.Context, s string) (net.Conn, error) { - return lis.Dial() - })) - assert.Nil(t, err) - - cloudEvent := map[string]interface{}{ - pubsub.IDField: "id", - pubsub.SourceField: "source", - pubsub.DataContentTypeField: "content-type", - pubsub.TypeField: "type", - pubsub.SpecVersionField: "v1.0.0", - pubsub.DataBase64Field: "bGF5b3R0bw==", - } - - data, err := json.Marshal(cloudEvent) - assert.Nil(t, err) - - msg := &pubsub.NewMessage{ - Data: data, - Topic: "layotto", - Metadata: make(map[string]string), - } - a := NewDaprServer("", nil, nil, nil, nil, - nil, nil, nil, nil, nil, nil, nil) - - var apiForTest = a.(*daprGrpcAPI) - //apiForTest.errInt = func(err error, format string, args ...interface{}) { - // log.DefaultLogger.Errorf("[runtime] occurs an error: "+err.Error()+", "+format, args...) - //} - apiForTest.AppCallbackConn = callbackClient - apiForTest.json = jsoniter.ConfigFastest - err = apiForTest.publishMessageGRPC(context.Background(), msg) - assert.Nil(t, err) - }) - t.Run("drop it when publishing an expired message", func(t *testing.T) { - cloudEvent := map[string]interface{}{ - pubsub.IDField: "id", - pubsub.SourceField: "source", - pubsub.DataContentTypeField: "content-type", - pubsub.TypeField: "type", - pubsub.SpecVersionField: "v1.0.0", - pubsub.DataBase64Field: "bGF5b3R0bw==", - pubsub.ExpirationField: time.Now().Add(-time.Minute).Format(time.RFC3339), - } - - data, err := json.Marshal(cloudEvent) - assert.Nil(t, err) - - msg := &pubsub.NewMessage{ - Data: data, - Topic: "layotto", - Metadata: make(map[string]string), - } - a := NewDaprServer("", nil, nil, nil, nil, nil, - nil, nil, nil, nil, nil, nil) - - var apiForTest = a.(*daprGrpcAPI) - apiForTest.json = jsoniter.ConfigFastest - // execute - err = apiForTest.publishMessageGRPC(context.Background(), msg) - // validate - assert.Nil(t, err) - }) -} - -type mockClient struct { -} - -func (m *mockClient) OnInvoke(ctx context.Context, in *dapr_common_v1pb.InvokeRequest, opts ...grpc.CallOption) (*dapr_common_v1pb.InvokeResponse, error) { - return nil, nil -} - -func (m *mockClient) ListInputBindings(ctx context.Context, in *empty.Empty, opts ...grpc.CallOption) (*dapr_v1pb.ListInputBindingsResponse, error) { - return nil, nil -} - -func (m *mockClient) OnBindingEvent(ctx context.Context, in *dapr_v1pb.BindingEventRequest, opts ...grpc.CallOption) (*dapr_v1pb.BindingEventResponse, error) { - return nil, nil -} - -func (m *mockClient) ListTopicSubscriptions(arg0 context.Context, arg1 *empty.Empty, opts ...grpc.CallOption) (*dapr_v1pb.ListTopicSubscriptionsResponse, error) { - return nil, nil -} - -func (m *mockClient) OnTopicEvent(ctx context.Context, in *dapr_v1pb.TopicEventRequest, opts ...grpc.CallOption) (*dapr_v1pb.TopicEventResponse, error) { - return nil, nil -} - -func Test_listTopicSubscriptions(t *testing.T) { - topics := listTopicSubscriptions(&mockClient{}, log.DefaultLogger) - assert.True(t, topics != nil && len(topics) == 0) -} diff --git a/pkg/grpc/dapr/dapr_api_secret.go b/pkg/grpc/dapr/dapr_api_secret.go deleted file mode 100644 index d4e6f05bf5..0000000000 --- a/pkg/grpc/dapr/dapr_api_secret.go +++ /dev/null @@ -1,116 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - - "github.com/dapr/components-contrib/secretstores" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/status" - "mosn.io/pkg/log" - - "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "mosn.io/layotto/pkg/messages" -) - -func (d *daprGrpcAPI) GetSecret(ctx context.Context, request *runtime.GetSecretRequest) (*runtime.GetSecretResponse, error) { - // 1. check parameters - if d.secretStores == nil || len(d.secretStores) == 0 { - err := status.Error(codes.FailedPrecondition, messages.ErrSecretStoreNotConfigured) - log.DefaultLogger.Errorf("GetSecret fail,not configured err:%+v", err) - return &runtime.GetSecretResponse{}, err - } - secretStoreName := request.StoreName - - if d.secretStores[secretStoreName] == nil { - err := status.Errorf(codes.InvalidArgument, messages.ErrSecretStoreNotFound, secretStoreName) - log.DefaultLogger.Errorf("GetSecret fail,not find err:%+v", err) - return &runtime.GetSecretResponse{}, err - } - - // 2. TODO permission control - if !d.isSecretAllowed(request.StoreName, request.Key) { - err := status.Errorf(codes.PermissionDenied, messages.ErrPermissionDenied, request.Key, request.StoreName) - return &runtime.GetSecretResponse{}, err - } - - // 3. delegate to components - req := secretstores.GetSecretRequest{ - Name: request.Key, - Metadata: request.Metadata, - } - getResponse, err := d.secretStores[secretStoreName].GetSecret(req) - // 4. parse result - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrSecretGet, req.Name, secretStoreName, err.Error()) - log.DefaultLogger.Errorf("GetSecret fail,get secret err:%+v", err) - return &runtime.GetSecretResponse{}, err - } - - response := &runtime.GetSecretResponse{} - if getResponse.Data != nil { - response.Data = getResponse.Data - } - return response, nil -} - -func (d *daprGrpcAPI) GetBulkSecret(ctx context.Context, in *runtime.GetBulkSecretRequest) (*runtime.GetBulkSecretResponse, error) { - // 1. check parameters - if d.secretStores == nil || len(d.secretStores) == 0 { - err := status.Error(codes.FailedPrecondition, messages.ErrSecretStoreNotConfigured) - log.DefaultLogger.Errorf("GetBulkSecret fail,not configured err:%+v", err) - return &runtime.GetBulkSecretResponse{}, err - } - secretStoreName := in.StoreName - - if d.secretStores[secretStoreName] == nil { - err := status.Errorf(codes.InvalidArgument, messages.ErrSecretStoreNotFound, secretStoreName) - log.DefaultLogger.Errorf("GetBulkSecret fail,not find err:%+v", err) - return &runtime.GetBulkSecretResponse{}, err - } - // 2. delegate to components - req := secretstores.BulkGetSecretRequest{ - Metadata: in.Metadata, - } - getResponse, err := d.secretStores[secretStoreName].BulkGetSecret(req) - // 3. parse result - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrBulkSecretGet, secretStoreName, err.Error()) - log.DefaultLogger.Errorf("GetBulkSecret fail,bulk secret err:%+v", err) - return &runtime.GetBulkSecretResponse{}, err - } - - // 4. filter result - filteredSecrets := map[string]map[string]string{} - for key, v := range getResponse.Data { - // TODO: permission control - if d.isSecretAllowed(secretStoreName, key) { - filteredSecrets[key] = v - } else { - log.DefaultLogger.Debugf(messages.ErrPermissionDenied, key, in.StoreName) - } - } - response := &runtime.GetBulkSecretResponse{} - if getResponse.Data != nil { - response.Data = map[string]*runtime.SecretResponse{} - for key, v := range filteredSecrets { - response.Data[key] = &runtime.SecretResponse{Secrets: v} - } - } - return response, nil -} diff --git a/pkg/grpc/dapr/dapr_api_secret_test.go b/pkg/grpc/dapr/dapr_api_secret_test.go deleted file mode 100644 index d9ad9bd0e2..0000000000 --- a/pkg/grpc/dapr/dapr_api_secret_test.go +++ /dev/null @@ -1,236 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package dapr - -import ( - "context" - "testing" - - "github.com/dapr/components-contrib/secretstores" - "github.com/phayes/freeport" - "github.com/stretchr/testify/assert" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/status" - - grpc_api "mosn.io/layotto/pkg/grpc" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "mosn.io/layotto/pkg/mock/components/secret" -) - -func TestNewDaprAPI_GetSecretStores(t *testing.T) { - fakeStore := secret.FakeSecretStore{} - fakeStores := map[string]secretstores.SecretStore{ - "store1": fakeStore, - "store2": fakeStore, - "store3": fakeStore, - "store4": fakeStore, - } - - expectedResponse := "life is good" - storeName := "store1" - //deniedStoreName := "store2" - restrictedStore := "store3" - unrestrictedStore := "store4" // No configuration defined for the store - nonExistingStore := "nonexistent" // Non-existing store - - testCases := []struct { - testName string - storeName string - key string - errorExcepted bool - expectedResponse string - expectedError codes.Code - }{ - { - testName: "Good Key from unrestricted store", - storeName: unrestrictedStore, - key: "good-key", - errorExcepted: false, - expectedResponse: expectedResponse, - }, - { - testName: "Good Key default access", - storeName: storeName, - key: "good-key", - errorExcepted: false, - expectedResponse: expectedResponse, - }, - { - testName: "Good Key restricted store access", - storeName: restrictedStore, - key: "good-key", - errorExcepted: false, - expectedResponse: expectedResponse, - }, - //{ - // testName: "Error Key restricted store access", - // storeName: restrictedStore, - // key: "error-key", - // errorExcepted: true, - // expectedResponse: "", - // expectedError: codes.PermissionDenied, - //}, - //{ - // testName: "Random Key restricted store access", - // storeName: restrictedStore, - // key: "random", - // errorExcepted: true, - // expectedResponse: "", - // expectedError: codes.PermissionDenied, - //}, - //{ - // testName: "Random Key accessing a store denied access by default", - // storeName: deniedStoreName, - // key: "random", - // errorExcepted: true, - // expectedResponse: "", - // expectedError: codes.PermissionDenied, - //}, - //{ - // testName: "Random Key accessing a store denied access by default", - // storeName: deniedStoreName, - // key: "random", - // errorExcepted: true, - // expectedResponse: "", - // expectedError: codes.PermissionDenied, - //}, - { - testName: "Store doesn't exist", - storeName: nonExistingStore, - key: "key", - errorExcepted: true, - expectedResponse: "", - expectedError: codes.InvalidArgument, - }, - } - // Setup Dapr API server - grpcAPI := NewDaprAPI_Alpha(&grpc_api.ApplicationContext{ - SecretStores: fakeStores}) - err := grpcAPI.Init(nil) - if err != nil { - t.Errorf("grpcAPI.Init error") - return - } - // test type assertion - _, ok := grpcAPI.(dapr_v1pb.DaprServer) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - srv, ok := grpcAPI.(DaprGrpcAPI) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - port, _ := freeport.GetFreePort() - server := startDaprServerForTest(port, srv) - defer server.Stop() - - clientConn := createTestClient(port) - defer clientConn.Close() - - client := dapr_v1pb.NewDaprClient(clientConn) - for _, tt := range testCases { - t.Run(tt.testName, func(t *testing.T) { - request := &dapr_v1pb.GetSecretRequest{ - StoreName: tt.storeName, - Key: tt.key, - } - resp, err := client.GetSecret(context.Background(), request) - - if !tt.errorExcepted { - assert.NoError(t, err, "Expected no error") - assert.Equal(t, resp.Data[tt.key], tt.expectedResponse, "Expected responses to be same") - } else { - assert.Error(t, err, "Expected error") - assert.Equal(t, tt.expectedError, status.Code(err)) - } - - }) - } -} - -func TestGetBulkSecret(t *testing.T) { - fakeStore := secret.FakeSecretStore{} - fakeStores := map[string]secretstores.SecretStore{ - "store1": fakeStore, - } - - expectedResponse := "life is good" - - testCases := []struct { - testName string - storeName string - key string - errorExcepted bool - expectedResponse string - expectedError codes.Code - }{ - { - testName: "Good Key from unrestricted store", - storeName: "store1", - key: "good-key", - errorExcepted: false, - expectedResponse: expectedResponse, - }, - } - // Setup Dapr API server - // Setup Dapr API server - grpcAPI := NewDaprAPI_Alpha(&grpc_api.ApplicationContext{ - SecretStores: fakeStores}) - // Run test server - err := grpcAPI.Init(nil) - if err != nil { - t.Errorf("grpcAPI.Init error") - return - } - // test type assertion - _, ok := grpcAPI.(dapr_v1pb.DaprServer) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - srv, ok := grpcAPI.(DaprGrpcAPI) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - port, _ := freeport.GetFreePort() - server := startDaprServerForTest(port, srv) - defer server.Stop() - - clientConn := createTestClient(port) - defer clientConn.Close() - - client := dapr_v1pb.NewDaprClient(clientConn) - - for _, tt := range testCases { - t.Run(tt.testName, func(t *testing.T) { - req := &dapr_v1pb.GetBulkSecretRequest{ - StoreName: tt.storeName, - } - resp, err := client.GetBulkSecret(context.Background(), req) - - if !tt.errorExcepted { - assert.NoError(t, err, "Expected no error") - assert.Equal(t, resp.Data[tt.key].Secrets[tt.key], tt.expectedResponse, "Expected responses to be same") - } else { - assert.Error(t, err, "Expected error") - assert.Equal(t, tt.expectedError, status.Code(err)) - } - }) - } -} diff --git a/pkg/grpc/dapr/dapr_api_state.go b/pkg/grpc/dapr/dapr_api_state.go deleted file mode 100644 index f8ec1f1374..0000000000 --- a/pkg/grpc/dapr/dapr_api_state.go +++ /dev/null @@ -1,509 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - - "github.com/dapr/components-contrib/state" - "github.com/gammazero/workerpool" - "github.com/golang/protobuf/ptypes/empty" - jsoniter "github.com/json-iterator/go" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/status" - "google.golang.org/protobuf/types/known/emptypb" - "mosn.io/pkg/log" - - "mosn.io/layotto/pkg/common" - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "mosn.io/layotto/pkg/messages" - state2 "mosn.io/layotto/pkg/runtime/state" -) - -func (d *daprGrpcAPI) SaveState(ctx context.Context, in *dapr_v1pb.SaveStateRequest) (*emptypb.Empty, error) { - // 1. get store - store, err := d.getStateStore(in.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.SaveState] error: %v", err) - return &emptypb.Empty{}, err - } - // 2. convert requests - reqs := []state.SetRequest{} - for _, s := range in.States { - key, err := state2.GetModifiedStateKey(s.Key, in.StoreName, d.appId) - if err != nil { - return &emptypb.Empty{}, err - } - reqs = append(reqs, *StateItem2SetRequest(s, key)) - } - // 3. query - err = store.BulkSet(reqs) - // 4. check result - if err != nil { - err = d.wrapDaprComponentError(err, messages.ErrStateSave, in.StoreName, err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.SaveState] error: %v", err) - return &emptypb.Empty{}, err - } - return &emptypb.Empty{}, nil -} - -// GetState obtains the state for a specific key. -func (d *daprGrpcAPI) GetState(ctx context.Context, request *dapr_v1pb.GetStateRequest) (*dapr_v1pb.GetStateResponse, error) { - // 1. get store - store, err := d.getStateStore(request.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.GetState] error: %v", err) - return nil, err - } - // 2. generate the actual key - key, err := state2.GetModifiedStateKey(request.Key, request.StoreName, d.appId) - if err != nil { - return &dapr_v1pb.GetStateResponse{}, err - } - req := &state.GetRequest{ - Key: key, - Metadata: request.GetMetadata(), - Options: state.GetStateOption{ - Consistency: StateConsistencyToString(request.Consistency), - }, - } - // 3. query - compResp, err := store.Get(req) - // 4. check result - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrStateGet, request.Key, request.StoreName, err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.GetState] %v", err) - return &dapr_v1pb.GetStateResponse{}, err - } - return GetResponse2GetStateResponse(compResp), nil -} - -func (d *daprGrpcAPI) GetBulkState(ctx context.Context, request *dapr_v1pb.GetBulkStateRequest) (*dapr_v1pb.GetBulkStateResponse, error) { - // 1. get store - store, err := d.getStateStore(request.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.GetBulkState] error: %v", err) - return &dapr_v1pb.GetBulkStateResponse{}, err - } - - bulkResp := &dapr_v1pb.GetBulkStateResponse{} - if len(request.Keys) == 0 { - return bulkResp, nil - } - - // 2. store.BulkGet - // 2.1. convert reqs - reqs := make([]state.GetRequest, len(request.Keys)) - for i, k := range request.Keys { - key, err := state2.GetModifiedStateKey(k, request.StoreName, d.appId) - if err != nil { - return &dapr_v1pb.GetBulkStateResponse{}, err - } - r := state.GetRequest{ - Key: key, - Metadata: request.GetMetadata(), - } - reqs[i] = r - } - // 2.2. query - support, responses, err := store.BulkGet(reqs) - if err != nil { - return bulkResp, err - } - // 2.3. parse and return result if store supports this method - if support { - for i := 0; i < len(responses); i++ { - bulkResp.Items = append(bulkResp.Items, BulkGetResponse2BulkStateItem(&responses[i])) - } - return bulkResp, nil - } - - // 3. Simulate the method if the store doesn't support it - n := len(reqs) - pool := workerpool.New(int(request.Parallelism)) - resultCh := make(chan *dapr_v1pb.BulkStateItem, n) - for i := 0; i < n; i++ { - pool.Submit(generateGetStateTask(store, &reqs[i], resultCh)) - } - pool.StopWait() - for { - select { - case item, ok := <-resultCh: - if !ok { - return bulkResp, nil - } - bulkResp.Items = append(bulkResp.Items, item) - default: - return bulkResp, nil - } - } -} - -func (d *daprGrpcAPI) QueryStateAlpha1(ctx context.Context, request *dapr_v1pb.QueryStateRequest) (*dapr_v1pb.QueryStateResponse, error) { - ret := &dapr_v1pb.QueryStateResponse{} - - // 1. get state store component - store, err := d.getStateStore(request.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.QueryStateAlpha1] error: %v", err) - return ret, err - } - - // 2. check if this store has the query feature - querier, ok := store.(state.Querier) - if !ok { - err = status.Errorf(codes.Unimplemented, messages.ErrNotFound, "Query") - log.DefaultLogger.Errorf("[runtime] [grpc.QueryStateAlpha1] error: %v", err) - return ret, err - } - - // 3. Unmarshal query dsl - var req state.QueryRequest - if err = jsoniter.Unmarshal([]byte(request.GetQuery()), &req.Query); err != nil { - err = status.Errorf(codes.InvalidArgument, messages.ErrMalformedRequest, err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.QueryStateAlpha1] error: %v", err) - return ret, err - } - req.Metadata = request.GetMetadata() - - // 4. delegate to the store - resp, err := querier.Query(&req) - // 5. convert response - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrStateQuery, request.GetStoreName(), err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.QueryStateAlpha1] error: %v", err) - return ret, err - } - if resp == nil || len(resp.Results) == 0 { - return ret, nil - } - - ret.Results = make([]*dapr_v1pb.QueryStateItem, len(resp.Results)) - ret.Token = resp.Token - ret.Metadata = resp.Metadata - - for i := range resp.Results { - ret.Results[i] = &dapr_v1pb.QueryStateItem{ - Key: state2.GetOriginalStateKey(resp.Results[i].Key), - Data: resp.Results[i].Data, - } - } - return ret, nil -} - -func (d *daprGrpcAPI) DeleteState(ctx context.Context, request *dapr_v1pb.DeleteStateRequest) (*emptypb.Empty, error) { - // 1. get store - store, err := d.getStateStore(request.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.DeleteState] error: %v", err) - return &emptypb.Empty{}, err - } - // 2. generate the actual key - key, err := state2.GetModifiedStateKey(request.Key, request.StoreName, d.appId) - if err != nil { - return &empty.Empty{}, err - } - // 3. convert and send request - err = store.Delete(DeleteStateRequest2DeleteRequest(request, key)) - // 4. check result - if err != nil { - err = d.wrapDaprComponentError(err, messages.ErrStateDelete, request.Key, err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.DeleteState] error: %v", err) - return &empty.Empty{}, err - } - return &empty.Empty{}, nil -} - -func (d *daprGrpcAPI) DeleteBulkState(ctx context.Context, request *dapr_v1pb.DeleteBulkStateRequest) (*emptypb.Empty, error) { - // 1. get store - store, err := d.getStateStore(request.StoreName) - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.DeleteBulkState] error: %v", err) - return &empty.Empty{}, err - } - // 2. convert request - reqs := make([]state.DeleteRequest, 0, len(request.States)) - for _, item := range request.States { - key, err := state2.GetModifiedStateKey(item.Key, request.StoreName, d.appId) - if err != nil { - return &empty.Empty{}, err - } - reqs = append(reqs, *StateItem2DeleteRequest(item, key)) - } - // 3. send request - err = store.BulkDelete(reqs) - // 4. check result - if err != nil { - log.DefaultLogger.Errorf("[runtime] [grpc.DeleteBulkState] error: %v", err) - return &emptypb.Empty{}, err - } - return &emptypb.Empty{}, nil -} - -func (d *daprGrpcAPI) ExecuteStateTransaction(ctx context.Context, request *dapr_v1pb.ExecuteStateTransactionRequest) (*emptypb.Empty, error) { - // 1. check params - if d.stateStores == nil || len(d.stateStores) == 0 { - err := status.Error(codes.FailedPrecondition, messages.ErrStateStoresNotConfigured) - log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) - return &emptypb.Empty{}, err - } - storeName := request.StoreName - if d.stateStores[storeName] == nil { - err := status.Errorf(codes.InvalidArgument, messages.ErrStateStoreNotFound, storeName) - log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) - return &emptypb.Empty{}, err - } - // 2. find store - store, ok := d.transactionalStateStores[storeName] - if !ok { - err := status.Errorf(codes.Unimplemented, messages.ErrStateStoreNotSupported, storeName) - log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) - return &emptypb.Empty{}, err - } - // 3. convert request - operations := []state.TransactionalStateOperation{} - for _, op := range request.Operations { - // 3.1. extract and validate fields - var operation state.TransactionalStateOperation - var req = op.Request - // tolerant npe - if req == nil { - log.DefaultLogger.Warnf("[runtime] [grpc.ExecuteStateTransaction] one of TransactionalStateOperation.Request is nil") - continue - } - key, err := state2.GetModifiedStateKey(req.Key, request.StoreName, d.appId) - if err != nil { - return &emptypb.Empty{}, err - } - // 3.2. prepare TransactionalStateOperation struct according to the operation type - switch state.OperationType(op.OperationType) { - case state.Upsert: - operation = state.TransactionalStateOperation{ - Operation: state.Upsert, - Request: *StateItem2SetRequest(req, key), - } - case state.Delete: - operation = state.TransactionalStateOperation{ - Operation: state.Delete, - Request: *StateItem2DeleteRequest(req, key), - } - default: - err := status.Errorf(codes.Unimplemented, messages.ErrNotSupportedStateOperation, op.OperationType) - log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) - return &emptypb.Empty{}, err - } - operations = append(operations, operation) - } - // 4. submit transactional request - err := store.Multi(&state.TransactionalStateRequest{ - Operations: operations, - Metadata: request.Metadata, - }) - // 5. check result - if err != nil { - err = status.Errorf(codes.Internal, messages.ErrStateTransaction, err.Error()) - log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) - return &emptypb.Empty{}, err - } - return &emptypb.Empty{}, nil -} - -func (d *daprGrpcAPI) getStateStore(name string) (state.Store, error) { - // check if the stateStores exists - if d.stateStores == nil || len(d.stateStores) == 0 { - return nil, status.Error(codes.FailedPrecondition, messages.ErrStateStoresNotConfigured) - } - // check name - if d.stateStores[name] == nil { - return nil, status.Errorf(codes.InvalidArgument, messages.ErrStateStoreNotFound, name) - } - return d.stateStores[name], nil -} - -func StateItem2SetRequest(grpcReq *dapr_common_v1pb.StateItem, key string) *state.SetRequest { - // Set the key for the request - req := &state.SetRequest{ - Key: key, - } - // check if the grpcReq exists - if grpcReq == nil { - return req - } - // Assign the value of grpcReq property to req - req.Metadata = grpcReq.Metadata - req.Value = grpcReq.Value - // Check grpcReq.Etag - if grpcReq.Etag != nil { - req.ETag = &grpcReq.Etag.Value - } - // Check grpcReq.Options - if grpcReq.Options != nil { - req.Options = state.SetStateOption{ - Consistency: StateConsistencyToString(grpcReq.Options.Consistency), - Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), - } - } - return req -} - -func GetResponse2GetStateResponse(compResp *state.GetResponse) *dapr_v1pb.GetStateResponse { - // Initialize an element of type GetStateResponse - resp := &dapr_v1pb.GetStateResponse{} - // check if the compResp exists - if compResp != nil { - resp.Etag = common.PointerToString(compResp.ETag) - resp.Data = compResp.Data - resp.Metadata = compResp.Metadata - } - return resp -} - -func StateConsistencyToString(c dapr_common_v1pb.StateOptions_StateConsistency) string { - // check - switch c { - case dapr_common_v1pb.StateOptions_CONSISTENCY_EVENTUAL: - return "eventual" - case dapr_common_v1pb.StateOptions_CONSISTENCY_STRONG: - return "strong" - } - return "" -} - -func StateConcurrencyToString(c dapr_common_v1pb.StateOptions_StateConcurrency) string { - // check the StateOptions of StateOptions_StateConcurrency - switch c { - case dapr_common_v1pb.StateOptions_CONCURRENCY_FIRST_WRITE: - return "first-write" - case dapr_common_v1pb.StateOptions_CONCURRENCY_LAST_WRITE: - return "last-write" - } - - return "" -} - -// wrapDaprComponentError parse and wrap error from dapr component -func (d *daprGrpcAPI) wrapDaprComponentError(err error, format string, args ...interface{}) error { - e, ok := err.(*state.ETagError) - if !ok { - return status.Errorf(codes.Internal, format, args...) - } - // check the Kind of error - switch e.Kind() { - case state.ETagMismatch: - return status.Errorf(codes.Aborted, format, args...) - case state.ETagInvalid: - return status.Errorf(codes.InvalidArgument, format, args...) - } - - return status.Errorf(codes.Internal, format, args...) -} - -func generateGetStateTask(store state.Store, req *state.GetRequest, resultCh chan *dapr_v1pb.BulkStateItem) func() { - return func() { - // get - r, err := store.Get(req) - // convert - var item *dapr_v1pb.BulkStateItem - if err != nil { - item = &dapr_v1pb.BulkStateItem{ - Key: state2.GetOriginalStateKey(req.Key), - Error: err.Error(), - } - } else { - item = GetResponse2BulkStateItem(r, state2.GetOriginalStateKey(req.Key)) - } - // collect result - select { - case resultCh <- item: - default: - //never happen - log.DefaultLogger.Errorf("[api.generateGetStateTask] can not push result to the resultCh. item: %+v", item) - } - } -} - -// converting from BulkGetResponse to BulkStateItem -func BulkGetResponse2BulkStateItem(compResp *state.BulkGetResponse) *dapr_v1pb.BulkStateItem { - if compResp == nil { - return &dapr_v1pb.BulkStateItem{} - } - return &dapr_v1pb.BulkStateItem{ - Key: state2.GetOriginalStateKey(compResp.Key), - Data: compResp.Data, - Etag: common.PointerToString(compResp.ETag), - Metadata: compResp.Metadata, - Error: compResp.Error, - } -} - -// converting from GetResponse to BulkStateItem -func GetResponse2BulkStateItem(compResp *state.GetResponse, key string) *dapr_v1pb.BulkStateItem { - // convert - resp := &dapr_v1pb.BulkStateItem{} - resp.Key = key - if compResp != nil { - resp.Data = compResp.Data - resp.Etag = common.PointerToString(compResp.ETag) - resp.Metadata = compResp.Metadata - } - return resp -} - -// converting from DeleteStateRequest to DeleteRequest -func DeleteStateRequest2DeleteRequest(grpcReq *dapr_v1pb.DeleteStateRequest, key string) *state.DeleteRequest { - // convert - req := &state.DeleteRequest{ - Key: key, - } - if grpcReq == nil { - return req - } - req.Metadata = grpcReq.Metadata - if grpcReq.Etag != nil { - req.ETag = &grpcReq.Etag.Value - } - if grpcReq.Options != nil { - req.Options = state.DeleteStateOption{ - Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), - Consistency: StateConsistencyToString(grpcReq.Options.Consistency), - } - } - return req -} - -// converting from StateItem to DeleteRequest -func StateItem2DeleteRequest(grpcReq *dapr_common_v1pb.StateItem, key string) *state.DeleteRequest { - //convert - req := &state.DeleteRequest{ - Key: key, - } - if grpcReq == nil { - return req - } - req.Metadata = grpcReq.Metadata - if grpcReq.Etag != nil { - req.ETag = &grpcReq.Etag.Value - } - if grpcReq.Options != nil { - req.Options = state.DeleteStateOption{ - Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), - Consistency: StateConsistencyToString(grpcReq.Options.Consistency), - } - } - return req -} diff --git a/pkg/grpc/dapr/dapr_api_state_test.go b/pkg/grpc/dapr/dapr_api_state_test.go deleted file mode 100644 index e4767b37df..0000000000 --- a/pkg/grpc/dapr/dapr_api_state_test.go +++ /dev/null @@ -1,130 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ -package dapr - -import ( - "testing" - - "github.com/dapr/components-contrib/state" - "github.com/stretchr/testify/assert" - - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" -) - -func TestGetResponse2GetStateResponse(t *testing.T) { - resp := GetResponse2GetStateResponse(&state.GetResponse{ - Data: []byte("v"), - ETag: nil, - Metadata: make(map[string]string), - }) - assert.Equal(t, resp.Data, []byte("v")) - assert.Equal(t, resp.Etag, "") - assert.True(t, len(resp.Metadata) == 0) -} - -func TestGetResponse2BulkStateItem(t *testing.T) { - itm := GetResponse2BulkStateItem(&state.GetResponse{ - Data: []byte("v"), - ETag: nil, - Metadata: make(map[string]string), - }, "key") - assert.Equal(t, itm.Key, "key") - assert.Equal(t, itm.Data, []byte("v")) - assert.Equal(t, itm.Etag, "") - assert.Equal(t, itm.Error, "") - assert.True(t, len(itm.Metadata) == 0) -} - -func TestBulkGetResponse2BulkStateItem(t *testing.T) { - t.Run("convert nil", func(t *testing.T) { - itm := BulkGetResponse2BulkStateItem(nil) - assert.NotNil(t, itm) - }) - t.Run("normal", func(t *testing.T) { - itm := BulkGetResponse2BulkStateItem(&state.BulkGetResponse{ - Key: "key", - Data: []byte("v"), - ETag: nil, - Metadata: nil, - Error: "", - }) - assert.Equal(t, itm.Key, "key") - assert.Equal(t, itm.Data, []byte("v")) - assert.Equal(t, itm.Etag, "") - assert.Equal(t, itm.Error, "") - assert.True(t, len(itm.Metadata) == 0) - }) -} - -func TestStateItem2SetRequest(t *testing.T) { - req := StateItem2SetRequest(&dapr_common_v1pb.StateItem{ - Key: "", - Value: []byte("v"), - Etag: nil, - Metadata: nil, - Options: &dapr_common_v1pb.StateOptions{ - Concurrency: dapr_common_v1pb.StateOptions_CONCURRENCY_UNSPECIFIED, - Consistency: dapr_common_v1pb.StateOptions_CONSISTENCY_UNSPECIFIED, - }, - }, "appid||key") - assert.Equal(t, req.Key, "appid||key") - assert.Equal(t, req.Value, []byte("v")) - assert.Nil(t, req.ETag) - assert.Equal(t, req.Options.Consistency, "") - assert.Equal(t, req.Options.Concurrency, "") -} - -func TestDeleteStateRequest2DeleteRequest(t *testing.T) { - t.Run("nil", func(t *testing.T) { - req := DeleteStateRequest2DeleteRequest(nil, "") - assert.NotNil(t, req) - }) - t.Run("normal", func(t *testing.T) { - req := DeleteStateRequest2DeleteRequest(&dapr_v1pb.DeleteStateRequest{ - StoreName: "redis", - Key: "", - Etag: nil, - Options: &dapr_common_v1pb.StateOptions{ - Concurrency: dapr_common_v1pb.StateOptions_CONCURRENCY_LAST_WRITE, - Consistency: dapr_common_v1pb.StateOptions_CONSISTENCY_EVENTUAL, - }, - Metadata: nil, - }, "appid||key") - assert.Equal(t, req.Key, "appid||key") - assert.Nil(t, req.ETag) - assert.Equal(t, req.Options.Consistency, "eventual") - assert.Equal(t, req.Options.Concurrency, "last-write") - }) -} - -func TestStateItem2DeleteRequest(t *testing.T) { - req := StateItem2DeleteRequest(&dapr_common_v1pb.StateItem{ - Key: "", - Value: []byte("v"), - Etag: nil, - Metadata: nil, - Options: &dapr_common_v1pb.StateOptions{ - Concurrency: dapr_common_v1pb.StateOptions_CONCURRENCY_LAST_WRITE, - Consistency: dapr_common_v1pb.StateOptions_CONSISTENCY_EVENTUAL, - }, - }, "appid||key") - assert.Equal(t, req.Key, "appid||key") - assert.Nil(t, req.ETag) - assert.Nil(t, req.ETag) - assert.Equal(t, req.Options.Consistency, "eventual") - assert.Equal(t, req.Options.Concurrency, "last-write") -} diff --git a/pkg/grpc/dapr/dapr_api_test.go b/pkg/grpc/dapr/dapr_api_test.go deleted file mode 100644 index e5dd396912..0000000000 --- a/pkg/grpc/dapr/dapr_api_test.go +++ /dev/null @@ -1,131 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - "fmt" - "net" - "testing" - - "github.com/dapr/components-contrib/bindings" - "github.com/dapr/components-contrib/state" - "github.com/golang/mock/gomock" - "github.com/phayes/freeport" - "github.com/stretchr/testify/assert" - - grpc_api "mosn.io/layotto/pkg/grpc" - mock_state "mosn.io/layotto/pkg/mock/components/state" - - "errors" - "time" - - "google.golang.org/grpc" - "google.golang.org/grpc/codes" - "google.golang.org/grpc/status" - - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" -) - -const ( - maxGRPCServerUptime = 100 * time.Millisecond -) - -type MockTxStore struct { - state.Store - state.TransactionalStore -} - -func (m *MockTxStore) Init(metadata state.Metadata) error { - return m.Store.Init(metadata) -} - -func TestNewDaprAPI_Alpha(t *testing.T) { - port, _ := freeport.GetFreePort() - ctrl := gomock.NewController(t) - mockStore := mock_state.NewMockStore(ctrl) - mockStore.EXPECT().Features().Return([]state.Feature{state.FeatureTransactional}) - - mockTxStore := mock_state.NewMockTransactionalStore(gomock.NewController(t)) - - store := &MockTxStore{ - mockStore, - mockTxStore, - } - // construct API - grpcAPI := NewDaprAPI_Alpha(&grpc_api.ApplicationContext{ - StateStores: map[string]state.Store{"mock": store}, - SendToOutputBindingFn: func(name string, req *bindings.InvokeRequest) (*bindings.InvokeResponse, error) { - if name == "error-binding" { - return nil, errors.New("error when invoke binding") - } - return &bindings.InvokeResponse{Data: []byte("ok")}, nil - }}) - err := grpcAPI.Init(nil) - if err != nil { - t.Errorf("grpcAPI.Init error") - return - } - // test type assertion - _, ok := grpcAPI.(dapr_v1pb.DaprServer) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - srv, ok := grpcAPI.(DaprGrpcAPI) - if !ok { - t.Errorf("Can not cast grpcAPI to DaprServer") - return - } - // test invokeBinding - server := startDaprServerForTest(port, srv) - defer server.Stop() - - clientConn := createTestClient(port) - defer clientConn.Close() - - client := dapr_v1pb.NewDaprClient(clientConn) - _, err = client.InvokeBinding(context.Background(), &dapr_v1pb.InvokeBindingRequest{}) - assert.Nil(t, err) - _, err = client.InvokeBinding(context.Background(), &dapr_v1pb.InvokeBindingRequest{Name: "error-binding"}) - assert.Equal(t, codes.Internal, status.Code(err)) -} - -func startDaprServerForTest(port int, srv DaprGrpcAPI) *grpc.Server { - lis, _ := net.Listen("tcp", fmt.Sprintf(":%d", port)) - - server := grpc.NewServer() - go func() { - srv.Register(server) - if err := server.Serve(lis); err != nil { - panic(err) - } - }() - - // wait until server starts - time.Sleep(maxGRPCServerUptime) - - return server -} - -func createTestClient(port int) *grpc.ClientConn { - conn, err := grpc.Dial(fmt.Sprintf("localhost:%d", port), grpc.WithInsecure()) - if err != nil { - panic(err) - } - return conn -} diff --git a/pkg/grpc/dapr/dapr_api_unimplement.go b/pkg/grpc/dapr/dapr_api_unimplement.go deleted file mode 100644 index 0d5bb828f5..0000000000 --- a/pkg/grpc/dapr/dapr_api_unimplement.go +++ /dev/null @@ -1,73 +0,0 @@ -/* - * Copyright 2021 Layotto Authors - * - * Licensed under the Apache License, Version 2.0 (the "License"); - * you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package dapr - -import ( - "context" - - "google.golang.org/protobuf/types/known/emptypb" - - "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" -) - -func (d *daprGrpcAPI) RegisterActorTimer(ctx context.Context, request *runtime.RegisterActorTimerRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) UnregisterActorTimer(ctx context.Context, request *runtime.UnregisterActorTimerRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) RegisterActorReminder(ctx context.Context, request *runtime.RegisterActorReminderRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) UnregisterActorReminder(ctx context.Context, request *runtime.UnregisterActorReminderRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) GetActorState(ctx context.Context, request *runtime.GetActorStateRequest) (*runtime.GetActorStateResponse, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) ExecuteActorStateTransaction(ctx context.Context, request *runtime.ExecuteActorStateTransactionRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) InvokeActor(ctx context.Context, request *runtime.InvokeActorRequest) (*runtime.InvokeActorResponse, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) GetConfigurationAlpha1(ctx context.Context, request *runtime.GetConfigurationRequest) (*runtime.GetConfigurationResponse, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) SubscribeConfigurationAlpha1(request *runtime.SubscribeConfigurationRequest, server runtime.Dapr_SubscribeConfigurationAlpha1Server) error { - panic("implement me") -} - -func (d *daprGrpcAPI) GetMetadata(ctx context.Context, empty *emptypb.Empty) (*runtime.GetMetadataResponse, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) SetMetadata(ctx context.Context, request *runtime.SetMetadataRequest) (*emptypb.Empty, error) { - panic("implement me") -} - -func (d *daprGrpcAPI) Shutdown(ctx context.Context, empty *emptypb.Empty) (*emptypb.Empty, error) { - panic("implement me") -} diff --git a/pkg/grpc/dapr/proto/common/v1/common.pb.go b/pkg/grpc/dapr/proto/common/v1/common.pb.go deleted file mode 100644 index aeb41142cf..0000000000 --- a/pkg/grpc/dapr/proto/common/v1/common.pb.go +++ /dev/null @@ -1,952 +0,0 @@ -// ------------------------------------------------------------ -// Copyright (c) Microsoft Corporation and Dapr Contributors. -// Licensed under the MIT License. -// ------------------------------------------------------------ - -// Code generated by protoc-gen-go. DO NOT EDIT. -// versions: -// protoc-gen-go v1.25.0 -// protoc v3.14.0 -// source: dapr/proto/common/v1/common.proto - -package common - -import ( - reflect "reflect" - sync "sync" - - proto "github.com/golang/protobuf/proto" - protoreflect "google.golang.org/protobuf/reflect/protoreflect" - protoimpl "google.golang.org/protobuf/runtime/protoimpl" - anypb "google.golang.org/protobuf/types/known/anypb" -) - -const ( - // Verify that this generated code is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(20 - protoimpl.MinVersion) - // Verify that runtime/protoimpl is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(protoimpl.MaxVersion - 20) -) - -// This is a compile-time assertion that a sufficiently up-to-date version -// of the legacy proto package is being used. -const _ = proto.ProtoPackageIsVersion4 - -// Type of HTTP 1.1 Methods -// RFC 7231: https://tools.ietf.org/html/rfc7231#page-24 -// RFC 5789: https://datatracker.ietf.org/doc/html/rfc5789 -type HTTPExtension_Verb int32 - -const ( - HTTPExtension_NONE HTTPExtension_Verb = 0 - HTTPExtension_GET HTTPExtension_Verb = 1 - HTTPExtension_HEAD HTTPExtension_Verb = 2 - HTTPExtension_POST HTTPExtension_Verb = 3 - HTTPExtension_PUT HTTPExtension_Verb = 4 - HTTPExtension_DELETE HTTPExtension_Verb = 5 - HTTPExtension_CONNECT HTTPExtension_Verb = 6 - HTTPExtension_OPTIONS HTTPExtension_Verb = 7 - HTTPExtension_TRACE HTTPExtension_Verb = 8 - HTTPExtension_PATCH HTTPExtension_Verb = 9 -) - -// Enum value maps for HTTPExtension_Verb. -var ( - HTTPExtension_Verb_name = map[int32]string{ - 0: "NONE", - 1: "GET", - 2: "HEAD", - 3: "POST", - 4: "PUT", - 5: "DELETE", - 6: "CONNECT", - 7: "OPTIONS", - 8: "TRACE", - 9: "PATCH", - } - HTTPExtension_Verb_value = map[string]int32{ - "NONE": 0, - "GET": 1, - "HEAD": 2, - "POST": 3, - "PUT": 4, - "DELETE": 5, - "CONNECT": 6, - "OPTIONS": 7, - "TRACE": 8, - "PATCH": 9, - } -) - -func (x HTTPExtension_Verb) Enum() *HTTPExtension_Verb { - p := new(HTTPExtension_Verb) - *p = x - return p -} - -func (x HTTPExtension_Verb) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (HTTPExtension_Verb) Descriptor() protoreflect.EnumDescriptor { - return file_dapr_proto_common_v1_common_proto_enumTypes[0].Descriptor() -} - -func (HTTPExtension_Verb) Type() protoreflect.EnumType { - return &file_dapr_proto_common_v1_common_proto_enumTypes[0] -} - -func (x HTTPExtension_Verb) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use HTTPExtension_Verb.Descriptor instead. -func (HTTPExtension_Verb) EnumDescriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{0, 0} -} - -// Enum describing the supported concurrency for state. -type StateOptions_StateConcurrency int32 - -const ( - StateOptions_CONCURRENCY_UNSPECIFIED StateOptions_StateConcurrency = 0 - StateOptions_CONCURRENCY_FIRST_WRITE StateOptions_StateConcurrency = 1 - StateOptions_CONCURRENCY_LAST_WRITE StateOptions_StateConcurrency = 2 -) - -// Enum value maps for StateOptions_StateConcurrency. -var ( - StateOptions_StateConcurrency_name = map[int32]string{ - 0: "CONCURRENCY_UNSPECIFIED", - 1: "CONCURRENCY_FIRST_WRITE", - 2: "CONCURRENCY_LAST_WRITE", - } - StateOptions_StateConcurrency_value = map[string]int32{ - "CONCURRENCY_UNSPECIFIED": 0, - "CONCURRENCY_FIRST_WRITE": 1, - "CONCURRENCY_LAST_WRITE": 2, - } -) - -func (x StateOptions_StateConcurrency) Enum() *StateOptions_StateConcurrency { - p := new(StateOptions_StateConcurrency) - *p = x - return p -} - -func (x StateOptions_StateConcurrency) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (StateOptions_StateConcurrency) Descriptor() protoreflect.EnumDescriptor { - return file_dapr_proto_common_v1_common_proto_enumTypes[1].Descriptor() -} - -func (StateOptions_StateConcurrency) Type() protoreflect.EnumType { - return &file_dapr_proto_common_v1_common_proto_enumTypes[1] -} - -func (x StateOptions_StateConcurrency) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use StateOptions_StateConcurrency.Descriptor instead. -func (StateOptions_StateConcurrency) EnumDescriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{5, 0} -} - -// Enum describing the supported consistency for state. -type StateOptions_StateConsistency int32 - -const ( - StateOptions_CONSISTENCY_UNSPECIFIED StateOptions_StateConsistency = 0 - StateOptions_CONSISTENCY_EVENTUAL StateOptions_StateConsistency = 1 - StateOptions_CONSISTENCY_STRONG StateOptions_StateConsistency = 2 -) - -// Enum value maps for StateOptions_StateConsistency. -var ( - StateOptions_StateConsistency_name = map[int32]string{ - 0: "CONSISTENCY_UNSPECIFIED", - 1: "CONSISTENCY_EVENTUAL", - 2: "CONSISTENCY_STRONG", - } - StateOptions_StateConsistency_value = map[string]int32{ - "CONSISTENCY_UNSPECIFIED": 0, - "CONSISTENCY_EVENTUAL": 1, - "CONSISTENCY_STRONG": 2, - } -) - -func (x StateOptions_StateConsistency) Enum() *StateOptions_StateConsistency { - p := new(StateOptions_StateConsistency) - *p = x - return p -} - -func (x StateOptions_StateConsistency) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (StateOptions_StateConsistency) Descriptor() protoreflect.EnumDescriptor { - return file_dapr_proto_common_v1_common_proto_enumTypes[2].Descriptor() -} - -func (StateOptions_StateConsistency) Type() protoreflect.EnumType { - return &file_dapr_proto_common_v1_common_proto_enumTypes[2] -} - -func (x StateOptions_StateConsistency) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use StateOptions_StateConsistency.Descriptor instead. -func (StateOptions_StateConsistency) EnumDescriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{5, 1} -} - -// HTTPExtension includes HTTP verb and querystring -// when Dapr runtime delivers HTTP content. -// -// For example, when callers calls http invoke api -// POST http://localhost:3500/v1.0/invoke//method/?query1=value1&query2=value2 -// -// Dapr runtime will parse POST as a verb and extract querystring to quersytring map. -type HTTPExtension struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. HTTP verb. - Verb HTTPExtension_Verb `protobuf:"varint,1,opt,name=verb,proto3,enum=dapr.proto.common.v1.HTTPExtension_Verb" json:"verb,omitempty"` - // Optional. querystring represents an encoded HTTP url query string in the following format: name=value&name2=value2 - Querystring string `protobuf:"bytes,2,opt,name=querystring,proto3" json:"querystring,omitempty"` -} - -func (x *HTTPExtension) Reset() { - *x = HTTPExtension{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[0] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *HTTPExtension) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*HTTPExtension) ProtoMessage() {} - -func (x *HTTPExtension) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[0] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use HTTPExtension.ProtoReflect.Descriptor instead. -func (*HTTPExtension) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{0} -} - -func (x *HTTPExtension) GetVerb() HTTPExtension_Verb { - if x != nil { - return x.Verb - } - return HTTPExtension_NONE -} - -func (x *HTTPExtension) GetQuerystring() string { - if x != nil { - return x.Querystring - } - return "" -} - -// InvokeRequest is the message to invoke a method with the data. -// This message is used in InvokeService of Dapr gRPC Service and OnInvoke -// of AppCallback gRPC service. -type InvokeRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. method is a method name which will be invoked by caller. - Method string `protobuf:"bytes,1,opt,name=method,proto3" json:"method,omitempty"` - // Required. Bytes value or Protobuf message which caller sent. - // Dapr treats Any.value as bytes type if Any.type_url is unset. - Data *anypb.Any `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` - // The type of data content. - // - // This field is required if data delivers http request body - // Otherwise, this is optional. - ContentType string `protobuf:"bytes,3,opt,name=content_type,json=contentType,proto3" json:"content_type,omitempty"` - // HTTP specific fields if request conveys http-compatible request. - // - // This field is required for http-compatible request. Otherwise, - // this field is optional. - HttpExtension *HTTPExtension `protobuf:"bytes,4,opt,name=http_extension,json=httpExtension,proto3" json:"http_extension,omitempty"` -} - -func (x *InvokeRequest) Reset() { - *x = InvokeRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[1] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeRequest) ProtoMessage() {} - -func (x *InvokeRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[1] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeRequest.ProtoReflect.Descriptor instead. -func (*InvokeRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{1} -} - -func (x *InvokeRequest) GetMethod() string { - if x != nil { - return x.Method - } - return "" -} - -func (x *InvokeRequest) GetData() *anypb.Any { - if x != nil { - return x.Data - } - return nil -} - -func (x *InvokeRequest) GetContentType() string { - if x != nil { - return x.ContentType - } - return "" -} - -func (x *InvokeRequest) GetHttpExtension() *HTTPExtension { - if x != nil { - return x.HttpExtension - } - return nil -} - -// InvokeResponse is the response message inclduing data and its content type -// from app callback. -// This message is used in InvokeService of Dapr gRPC Service and OnInvoke -// of AppCallback gRPC service. -type InvokeResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The content body of InvokeService response. - Data *anypb.Any `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"` - // Required. The type of data content. - ContentType string `protobuf:"bytes,2,opt,name=content_type,json=contentType,proto3" json:"content_type,omitempty"` -} - -func (x *InvokeResponse) Reset() { - *x = InvokeResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[2] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeResponse) ProtoMessage() {} - -func (x *InvokeResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[2] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeResponse.ProtoReflect.Descriptor instead. -func (*InvokeResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{2} -} - -func (x *InvokeResponse) GetData() *anypb.Any { - if x != nil { - return x.Data - } - return nil -} - -func (x *InvokeResponse) GetContentType() string { - if x != nil { - return x.ContentType - } - return "" -} - -// StateItem represents state key, value, and additional options to save state. -type StateItem struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The state key - Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` - // Required. The state data for key - Value []byte `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"` - // The entity tag which represents the specific version of data. - // The exact ETag format is defined by the corresponding data store. - Etag *Etag `protobuf:"bytes,3,opt,name=etag,proto3" json:"etag,omitempty"` - // The metadata which will be passed to state store component. - Metadata map[string]string `protobuf:"bytes,4,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` - // Options for concurrency and consistency to save the state. - Options *StateOptions `protobuf:"bytes,5,opt,name=options,proto3" json:"options,omitempty"` -} - -func (x *StateItem) Reset() { - *x = StateItem{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[3] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *StateItem) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*StateItem) ProtoMessage() {} - -func (x *StateItem) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[3] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use StateItem.ProtoReflect.Descriptor instead. -func (*StateItem) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{3} -} - -func (x *StateItem) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *StateItem) GetValue() []byte { - if x != nil { - return x.Value - } - return nil -} - -func (x *StateItem) GetEtag() *Etag { - if x != nil { - return x.Etag - } - return nil -} - -func (x *StateItem) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -func (x *StateItem) GetOptions() *StateOptions { - if x != nil { - return x.Options - } - return nil -} - -// Etag represents a state item version -type Etag struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // value sets the etag value - Value string `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"` -} - -func (x *Etag) Reset() { - *x = Etag{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[4] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *Etag) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*Etag) ProtoMessage() {} - -func (x *Etag) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[4] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use Etag.ProtoReflect.Descriptor instead. -func (*Etag) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{4} -} - -func (x *Etag) GetValue() string { - if x != nil { - return x.Value - } - return "" -} - -// StateOptions configures concurrency and consistency for state operations -type StateOptions struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Concurrency StateOptions_StateConcurrency `protobuf:"varint,1,opt,name=concurrency,proto3,enum=dapr.proto.common.v1.StateOptions_StateConcurrency" json:"concurrency,omitempty"` - Consistency StateOptions_StateConsistency `protobuf:"varint,2,opt,name=consistency,proto3,enum=dapr.proto.common.v1.StateOptions_StateConsistency" json:"consistency,omitempty"` -} - -func (x *StateOptions) Reset() { - *x = StateOptions{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[5] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *StateOptions) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*StateOptions) ProtoMessage() {} - -func (x *StateOptions) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[5] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use StateOptions.ProtoReflect.Descriptor instead. -func (*StateOptions) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{5} -} - -func (x *StateOptions) GetConcurrency() StateOptions_StateConcurrency { - if x != nil { - return x.Concurrency - } - return StateOptions_CONCURRENCY_UNSPECIFIED -} - -func (x *StateOptions) GetConsistency() StateOptions_StateConsistency { - if x != nil { - return x.Consistency - } - return StateOptions_CONSISTENCY_UNSPECIFIED -} - -// ConfigurationItem represents all the configuration with its name(key). -type ConfigurationItem struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The name of configuration item - Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` - // Required. The value of configuration item. - Value string `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"` - // Version is response only and cannot be fetched. Store is not expected to keep all versions available - Version string `protobuf:"bytes,3,opt,name=version,proto3" json:"version,omitempty"` - // the metadata which will be passed to/from configuration store component. - Metadata map[string]string `protobuf:"bytes,4,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *ConfigurationItem) Reset() { - *x = ConfigurationItem{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[6] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ConfigurationItem) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ConfigurationItem) ProtoMessage() {} - -func (x *ConfigurationItem) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_common_v1_common_proto_msgTypes[6] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ConfigurationItem.ProtoReflect.Descriptor instead. -func (*ConfigurationItem) Descriptor() ([]byte, []int) { - return file_dapr_proto_common_v1_common_proto_rawDescGZIP(), []int{6} -} - -func (x *ConfigurationItem) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *ConfigurationItem) GetValue() string { - if x != nil { - return x.Value - } - return "" -} - -func (x *ConfigurationItem) GetVersion() string { - if x != nil { - return x.Version - } - return "" -} - -func (x *ConfigurationItem) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -var File_dapr_proto_common_v1_common_proto protoreflect.FileDescriptor - -var file_dapr_proto_common_v1_common_proto_rawDesc = []byte{ - 0x0a, 0x21, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x63, 0x6f, 0x6d, - 0x6d, 0x6f, 0x6e, 0x2f, 0x76, 0x31, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x12, 0x14, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, - 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x1a, 0x19, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x61, 0x6e, 0x79, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x22, 0xe3, 0x01, 0x0a, 0x0d, 0x48, 0x54, 0x54, 0x50, 0x45, 0x78, 0x74, - 0x65, 0x6e, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x3c, 0x0a, 0x04, 0x76, 0x65, 0x72, 0x62, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x0e, 0x32, 0x28, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x48, 0x54, 0x54, 0x50, - 0x45, 0x78, 0x74, 0x65, 0x6e, 0x73, 0x69, 0x6f, 0x6e, 0x2e, 0x56, 0x65, 0x72, 0x62, 0x52, 0x04, - 0x76, 0x65, 0x72, 0x62, 0x12, 0x20, 0x0a, 0x0b, 0x71, 0x75, 0x65, 0x72, 0x79, 0x73, 0x74, 0x72, - 0x69, 0x6e, 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x71, 0x75, 0x65, 0x72, 0x79, - 0x73, 0x74, 0x72, 0x69, 0x6e, 0x67, 0x22, 0x72, 0x0a, 0x04, 0x56, 0x65, 0x72, 0x62, 0x12, 0x08, - 0x0a, 0x04, 0x4e, 0x4f, 0x4e, 0x45, 0x10, 0x00, 0x12, 0x07, 0x0a, 0x03, 0x47, 0x45, 0x54, 0x10, - 0x01, 0x12, 0x08, 0x0a, 0x04, 0x48, 0x45, 0x41, 0x44, 0x10, 0x02, 0x12, 0x08, 0x0a, 0x04, 0x50, - 0x4f, 0x53, 0x54, 0x10, 0x03, 0x12, 0x07, 0x0a, 0x03, 0x50, 0x55, 0x54, 0x10, 0x04, 0x12, 0x0a, - 0x0a, 0x06, 0x44, 0x45, 0x4c, 0x45, 0x54, 0x45, 0x10, 0x05, 0x12, 0x0b, 0x0a, 0x07, 0x43, 0x4f, - 0x4e, 0x4e, 0x45, 0x43, 0x54, 0x10, 0x06, 0x12, 0x0b, 0x0a, 0x07, 0x4f, 0x50, 0x54, 0x49, 0x4f, - 0x4e, 0x53, 0x10, 0x07, 0x12, 0x09, 0x0a, 0x05, 0x54, 0x52, 0x41, 0x43, 0x45, 0x10, 0x08, 0x12, - 0x09, 0x0a, 0x05, 0x50, 0x41, 0x54, 0x43, 0x48, 0x10, 0x09, 0x22, 0xc0, 0x01, 0x0a, 0x0d, 0x49, - 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x16, 0x0a, 0x06, - 0x6d, 0x65, 0x74, 0x68, 0x6f, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x6d, 0x65, - 0x74, 0x68, 0x6f, 0x64, 0x12, 0x28, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x0b, 0x32, 0x14, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x41, 0x6e, 0x79, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x21, - 0x0a, 0x0c, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x03, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, - 0x65, 0x12, 0x4a, 0x0a, 0x0e, 0x68, 0x74, 0x74, 0x70, 0x5f, 0x65, 0x78, 0x74, 0x65, 0x6e, 0x73, - 0x69, 0x6f, 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x23, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, - 0x2e, 0x48, 0x54, 0x54, 0x50, 0x45, 0x78, 0x74, 0x65, 0x6e, 0x73, 0x69, 0x6f, 0x6e, 0x52, 0x0d, - 0x68, 0x74, 0x74, 0x70, 0x45, 0x78, 0x74, 0x65, 0x6e, 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x5d, 0x0a, - 0x0e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, - 0x28, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x14, 0x2e, - 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, - 0x41, 0x6e, 0x79, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x21, 0x0a, 0x0c, 0x63, 0x6f, 0x6e, - 0x74, 0x65, 0x6e, 0x74, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x0b, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x22, 0xa9, 0x02, 0x0a, - 0x09, 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x12, 0x2e, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, - 0x32, 0x1a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, - 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x45, 0x74, 0x61, 0x67, 0x52, 0x04, 0x65, 0x74, - 0x61, 0x67, 0x12, 0x49, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, - 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2d, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, - 0x65, 0x49, 0x74, 0x65, 0x6d, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x3c, 0x0a, - 0x07, 0x6f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x22, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, - 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, 0x74, 0x69, 0x6f, - 0x6e, 0x73, 0x52, 0x07, 0x6f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, - 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x1c, 0x0a, 0x04, 0x45, 0x74, 0x61, 0x67, - 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x22, 0x89, 0x03, 0x0a, 0x0c, 0x53, 0x74, 0x61, 0x74, 0x65, - 0x4f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x55, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x63, 0x75, - 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, - 0x79, 0x52, 0x0b, 0x63, 0x6f, 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, 0x12, 0x55, - 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x73, 0x69, 0x73, 0x74, 0x65, 0x6e, 0x63, 0x79, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, - 0x4f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, - 0x73, 0x69, 0x73, 0x74, 0x65, 0x6e, 0x63, 0x79, 0x52, 0x0b, 0x63, 0x6f, 0x6e, 0x73, 0x69, 0x73, - 0x74, 0x65, 0x6e, 0x63, 0x79, 0x22, 0x68, 0x0a, 0x10, 0x53, 0x74, 0x61, 0x74, 0x65, 0x43, 0x6f, - 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, 0x12, 0x1b, 0x0a, 0x17, 0x43, 0x4f, 0x4e, - 0x43, 0x55, 0x52, 0x52, 0x45, 0x4e, 0x43, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, - 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, 0x12, 0x1b, 0x0a, 0x17, 0x43, 0x4f, 0x4e, 0x43, 0x55, 0x52, - 0x52, 0x45, 0x4e, 0x43, 0x59, 0x5f, 0x46, 0x49, 0x52, 0x53, 0x54, 0x5f, 0x57, 0x52, 0x49, 0x54, - 0x45, 0x10, 0x01, 0x12, 0x1a, 0x0a, 0x16, 0x43, 0x4f, 0x4e, 0x43, 0x55, 0x52, 0x52, 0x45, 0x4e, - 0x43, 0x59, 0x5f, 0x4c, 0x41, 0x53, 0x54, 0x5f, 0x57, 0x52, 0x49, 0x54, 0x45, 0x10, 0x02, 0x22, - 0x61, 0x0a, 0x10, 0x53, 0x74, 0x61, 0x74, 0x65, 0x43, 0x6f, 0x6e, 0x73, 0x69, 0x73, 0x74, 0x65, - 0x6e, 0x63, 0x79, 0x12, 0x1b, 0x0a, 0x17, 0x43, 0x4f, 0x4e, 0x53, 0x49, 0x53, 0x54, 0x45, 0x4e, - 0x43, 0x59, 0x5f, 0x55, 0x4e, 0x53, 0x50, 0x45, 0x43, 0x49, 0x46, 0x49, 0x45, 0x44, 0x10, 0x00, - 0x12, 0x18, 0x0a, 0x14, 0x43, 0x4f, 0x4e, 0x53, 0x49, 0x53, 0x54, 0x45, 0x4e, 0x43, 0x59, 0x5f, - 0x45, 0x56, 0x45, 0x4e, 0x54, 0x55, 0x41, 0x4c, 0x10, 0x01, 0x12, 0x16, 0x0a, 0x12, 0x43, 0x4f, - 0x4e, 0x53, 0x49, 0x53, 0x54, 0x45, 0x4e, 0x43, 0x59, 0x5f, 0x53, 0x54, 0x52, 0x4f, 0x4e, 0x47, - 0x10, 0x02, 0x22, 0xe5, 0x01, 0x0a, 0x11, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, - 0x74, 0x69, 0x6f, 0x6e, 0x49, 0x74, 0x65, 0x6d, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, - 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, - 0x12, 0x18, 0x0a, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x07, 0x76, 0x65, 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x51, 0x0a, 0x08, 0x6d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x35, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x49, 0x74, 0x65, 0x6d, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, - 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, - 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, - 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x42, 0x69, 0x0a, 0x0a, 0x69, 0x6f, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x76, 0x31, 0x42, 0x0c, 0x43, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x50, 0x72, 0x6f, 0x74, 0x6f, 0x73, 0x5a, 0x2f, 0x67, 0x69, 0x74, 0x68, 0x75, 0x62, 0x2e, 0x63, - 0x6f, 0x6d, 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x6b, 0x67, - 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2f, 0x76, 0x31, - 0x3b, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0xaa, 0x02, 0x1b, 0x44, 0x61, 0x70, 0x72, 0x2e, 0x43, - 0x6c, 0x69, 0x65, 0x6e, 0x74, 0x2e, 0x41, 0x75, 0x74, 0x6f, 0x67, 0x65, 0x6e, 0x2e, 0x47, 0x72, - 0x70, 0x63, 0x2e, 0x76, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, -} - -var ( - file_dapr_proto_common_v1_common_proto_rawDescOnce sync.Once - file_dapr_proto_common_v1_common_proto_rawDescData = file_dapr_proto_common_v1_common_proto_rawDesc -) - -func file_dapr_proto_common_v1_common_proto_rawDescGZIP() []byte { - file_dapr_proto_common_v1_common_proto_rawDescOnce.Do(func() { - file_dapr_proto_common_v1_common_proto_rawDescData = protoimpl.X.CompressGZIP(file_dapr_proto_common_v1_common_proto_rawDescData) - }) - return file_dapr_proto_common_v1_common_proto_rawDescData -} - -var file_dapr_proto_common_v1_common_proto_enumTypes = make([]protoimpl.EnumInfo, 3) -var file_dapr_proto_common_v1_common_proto_msgTypes = make([]protoimpl.MessageInfo, 9) -var file_dapr_proto_common_v1_common_proto_goTypes = []interface{}{ - (HTTPExtension_Verb)(0), // 0: dapr.proto.common.v1.HTTPExtension.Verb - (StateOptions_StateConcurrency)(0), // 1: dapr.proto.common.v1.StateOptions.StateConcurrency - (StateOptions_StateConsistency)(0), // 2: dapr.proto.common.v1.StateOptions.StateConsistency - (*HTTPExtension)(nil), // 3: dapr.proto.common.v1.HTTPExtension - (*InvokeRequest)(nil), // 4: dapr.proto.common.v1.InvokeRequest - (*InvokeResponse)(nil), // 5: dapr.proto.common.v1.InvokeResponse - (*StateItem)(nil), // 6: dapr.proto.common.v1.StateItem - (*Etag)(nil), // 7: dapr.proto.common.v1.Etag - (*StateOptions)(nil), // 8: dapr.proto.common.v1.StateOptions - (*ConfigurationItem)(nil), // 9: dapr.proto.common.v1.ConfigurationItem - nil, // 10: dapr.proto.common.v1.StateItem.MetadataEntry - nil, // 11: dapr.proto.common.v1.ConfigurationItem.MetadataEntry - (*anypb.Any)(nil), // 12: google.protobuf.Any -} -var file_dapr_proto_common_v1_common_proto_depIdxs = []int32{ - 0, // 0: dapr.proto.common.v1.HTTPExtension.verb:type_name -> dapr.proto.common.v1.HTTPExtension.Verb - 12, // 1: dapr.proto.common.v1.InvokeRequest.data:type_name -> google.protobuf.Any - 3, // 2: dapr.proto.common.v1.InvokeRequest.http_extension:type_name -> dapr.proto.common.v1.HTTPExtension - 12, // 3: dapr.proto.common.v1.InvokeResponse.data:type_name -> google.protobuf.Any - 7, // 4: dapr.proto.common.v1.StateItem.etag:type_name -> dapr.proto.common.v1.Etag - 10, // 5: dapr.proto.common.v1.StateItem.metadata:type_name -> dapr.proto.common.v1.StateItem.MetadataEntry - 8, // 6: dapr.proto.common.v1.StateItem.options:type_name -> dapr.proto.common.v1.StateOptions - 1, // 7: dapr.proto.common.v1.StateOptions.concurrency:type_name -> dapr.proto.common.v1.StateOptions.StateConcurrency - 2, // 8: dapr.proto.common.v1.StateOptions.consistency:type_name -> dapr.proto.common.v1.StateOptions.StateConsistency - 11, // 9: dapr.proto.common.v1.ConfigurationItem.metadata:type_name -> dapr.proto.common.v1.ConfigurationItem.MetadataEntry - 10, // [10:10] is the sub-list for method output_type - 10, // [10:10] is the sub-list for method input_type - 10, // [10:10] is the sub-list for extension type_name - 10, // [10:10] is the sub-list for extension extendee - 0, // [0:10] is the sub-list for field type_name -} - -func init() { file_dapr_proto_common_v1_common_proto_init() } -func file_dapr_proto_common_v1_common_proto_init() { - if File_dapr_proto_common_v1_common_proto != nil { - return - } - if !protoimpl.UnsafeEnabled { - file_dapr_proto_common_v1_common_proto_msgTypes[0].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*HTTPExtension); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[1].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[2].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[3].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*StateItem); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[4].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*Etag); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[5].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*StateOptions); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_common_v1_common_proto_msgTypes[6].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ConfigurationItem); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - } - type x struct{} - out := protoimpl.TypeBuilder{ - File: protoimpl.DescBuilder{ - GoPackagePath: reflect.TypeOf(x{}).PkgPath(), - RawDescriptor: file_dapr_proto_common_v1_common_proto_rawDesc, - NumEnums: 3, - NumMessages: 9, - NumExtensions: 0, - NumServices: 0, - }, - GoTypes: file_dapr_proto_common_v1_common_proto_goTypes, - DependencyIndexes: file_dapr_proto_common_v1_common_proto_depIdxs, - EnumInfos: file_dapr_proto_common_v1_common_proto_enumTypes, - MessageInfos: file_dapr_proto_common_v1_common_proto_msgTypes, - }.Build() - File_dapr_proto_common_v1_common_proto = out.File - file_dapr_proto_common_v1_common_proto_rawDesc = nil - file_dapr_proto_common_v1_common_proto_goTypes = nil - file_dapr_proto_common_v1_common_proto_depIdxs = nil -} diff --git a/pkg/grpc/dapr/proto/runtime/v1/appcallback.pb.go b/pkg/grpc/dapr/proto/runtime/v1/appcallback.pb.go deleted file mode 100644 index db8df6b38a..0000000000 --- a/pkg/grpc/dapr/proto/runtime/v1/appcallback.pb.go +++ /dev/null @@ -1,1109 +0,0 @@ -// ------------------------------------------------------------ -// Copyright (c) Microsoft Corporation and Dapr Contributors. -// Licensed under the MIT License. -// ------------------------------------------------------------ - -// Code generated by protoc-gen-go. DO NOT EDIT. -// versions: -// protoc-gen-go v1.25.0 -// protoc v3.14.0 -// source: dapr/proto/runtime/v1/appcallback.proto - -package runtime - -import ( - reflect "reflect" - sync "sync" - - proto "github.com/golang/protobuf/proto" - protoreflect "google.golang.org/protobuf/reflect/protoreflect" - protoimpl "google.golang.org/protobuf/runtime/protoimpl" - emptypb "google.golang.org/protobuf/types/known/emptypb" - - v1 "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" -) - -const ( - // Verify that this generated code is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(20 - protoimpl.MinVersion) - // Verify that runtime/protoimpl is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(protoimpl.MaxVersion - 20) -) - -// This is a compile-time assertion that a sufficiently up-to-date version -// of the legacy proto package is being used. -const _ = proto.ProtoPackageIsVersion4 - -// TopicEventResponseStatus allows apps to have finer control over handling of the message. -type TopicEventResponse_TopicEventResponseStatus int32 - -const ( - // SUCCESS is the default behavior: message is acknowledged and not retried or logged. - TopicEventResponse_SUCCESS TopicEventResponse_TopicEventResponseStatus = 0 - // RETRY status signals Dapr to retry the message as part of an expected scenario (no warning is logged). - TopicEventResponse_RETRY TopicEventResponse_TopicEventResponseStatus = 1 - // DROP status signals Dapr to drop the message as part of an unexpected scenario (warning is logged). - TopicEventResponse_DROP TopicEventResponse_TopicEventResponseStatus = 2 -) - -// Enum value maps for TopicEventResponse_TopicEventResponseStatus. -var ( - TopicEventResponse_TopicEventResponseStatus_name = map[int32]string{ - 0: "SUCCESS", - 1: "RETRY", - 2: "DROP", - } - TopicEventResponse_TopicEventResponseStatus_value = map[string]int32{ - "SUCCESS": 0, - "RETRY": 1, - "DROP": 2, - } -) - -func (x TopicEventResponse_TopicEventResponseStatus) Enum() *TopicEventResponse_TopicEventResponseStatus { - p := new(TopicEventResponse_TopicEventResponseStatus) - *p = x - return p -} - -func (x TopicEventResponse_TopicEventResponseStatus) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (TopicEventResponse_TopicEventResponseStatus) Descriptor() protoreflect.EnumDescriptor { - return file_dapr_proto_runtime_v1_appcallback_proto_enumTypes[0].Descriptor() -} - -func (TopicEventResponse_TopicEventResponseStatus) Type() protoreflect.EnumType { - return &file_dapr_proto_runtime_v1_appcallback_proto_enumTypes[0] -} - -func (x TopicEventResponse_TopicEventResponseStatus) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use TopicEventResponse_TopicEventResponseStatus.Descriptor instead. -func (TopicEventResponse_TopicEventResponseStatus) EnumDescriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{1, 0} -} - -// BindingEventConcurrency is the kind of concurrency -type BindingEventResponse_BindingEventConcurrency int32 - -const ( - // SEQUENTIAL sends data to output bindings specified in "to" sequentially. - BindingEventResponse_SEQUENTIAL BindingEventResponse_BindingEventConcurrency = 0 - // PARALLEL sends data to output bindings specified in "to" in parallel. - BindingEventResponse_PARALLEL BindingEventResponse_BindingEventConcurrency = 1 -) - -// Enum value maps for BindingEventResponse_BindingEventConcurrency. -var ( - BindingEventResponse_BindingEventConcurrency_name = map[int32]string{ - 0: "SEQUENTIAL", - 1: "PARALLEL", - } - BindingEventResponse_BindingEventConcurrency_value = map[string]int32{ - "SEQUENTIAL": 0, - "PARALLEL": 1, - } -) - -func (x BindingEventResponse_BindingEventConcurrency) Enum() *BindingEventResponse_BindingEventConcurrency { - p := new(BindingEventResponse_BindingEventConcurrency) - *p = x - return p -} - -func (x BindingEventResponse_BindingEventConcurrency) String() string { - return protoimpl.X.EnumStringOf(x.Descriptor(), protoreflect.EnumNumber(x)) -} - -func (BindingEventResponse_BindingEventConcurrency) Descriptor() protoreflect.EnumDescriptor { - return file_dapr_proto_runtime_v1_appcallback_proto_enumTypes[1].Descriptor() -} - -func (BindingEventResponse_BindingEventConcurrency) Type() protoreflect.EnumType { - return &file_dapr_proto_runtime_v1_appcallback_proto_enumTypes[1] -} - -func (x BindingEventResponse_BindingEventConcurrency) Number() protoreflect.EnumNumber { - return protoreflect.EnumNumber(x) -} - -// Deprecated: Use BindingEventResponse_BindingEventConcurrency.Descriptor instead. -func (BindingEventResponse_BindingEventConcurrency) EnumDescriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{3, 0} -} - -// TopicEventRequest message is compatible with CloudEvent spec v1.0 -// https://github.com/cloudevents/spec/blob/v1.0/spec.md -type TopicEventRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // id identifies the event. Producers MUST ensure that source + id - // is unique for each distinct event. If a duplicate event is re-sent - // (e.g. due to a network error) it MAY have the same id. - Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` - // source identifies the context in which an event happened. - // Often this will include information such as the type of the - // event source, the organization publishing the event or the process - // that produced the event. The exact syntax and semantics behind - // the data encoded in the URI is defined by the event producer. - Source string `protobuf:"bytes,2,opt,name=source,proto3" json:"source,omitempty"` - // The type of event related to the originating occurrence. - Type string `protobuf:"bytes,3,opt,name=type,proto3" json:"type,omitempty"` - // The version of the CloudEvents specification. - SpecVersion string `protobuf:"bytes,4,opt,name=spec_version,json=specVersion,proto3" json:"spec_version,omitempty"` - // The content type of data value. - DataContentType string `protobuf:"bytes,5,opt,name=data_content_type,json=dataContentType,proto3" json:"data_content_type,omitempty"` - // The content of the event. - Data []byte `protobuf:"bytes,7,opt,name=data,proto3" json:"data,omitempty"` - // The pubsub topic which publisher sent to. - Topic string `protobuf:"bytes,6,opt,name=topic,proto3" json:"topic,omitempty"` - // The name of the pubsub the publisher sent to. - PubsubName string `protobuf:"bytes,8,opt,name=pubsub_name,json=pubsubName,proto3" json:"pubsub_name,omitempty"` - // The matching path from TopicSubscription/routes (if specified) for this event. - // This value is used by OnTopicEvent to "switch" inside the handler. - Path string `protobuf:"bytes,9,opt,name=path,proto3" json:"path,omitempty"` -} - -func (x *TopicEventRequest) Reset() { - *x = TopicEventRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[0] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TopicEventRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TopicEventRequest) ProtoMessage() {} - -func (x *TopicEventRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[0] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TopicEventRequest.ProtoReflect.Descriptor instead. -func (*TopicEventRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{0} -} - -func (x *TopicEventRequest) GetId() string { - if x != nil { - return x.Id - } - return "" -} - -func (x *TopicEventRequest) GetSource() string { - if x != nil { - return x.Source - } - return "" -} - -func (x *TopicEventRequest) GetType() string { - if x != nil { - return x.Type - } - return "" -} - -func (x *TopicEventRequest) GetSpecVersion() string { - if x != nil { - return x.SpecVersion - } - return "" -} - -func (x *TopicEventRequest) GetDataContentType() string { - if x != nil { - return x.DataContentType - } - return "" -} - -func (x *TopicEventRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *TopicEventRequest) GetTopic() string { - if x != nil { - return x.Topic - } - return "" -} - -func (x *TopicEventRequest) GetPubsubName() string { - if x != nil { - return x.PubsubName - } - return "" -} - -func (x *TopicEventRequest) GetPath() string { - if x != nil { - return x.Path - } - return "" -} - -// TopicEventResponse is response from app on published message -type TopicEventResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of output bindings. - Status TopicEventResponse_TopicEventResponseStatus `protobuf:"varint,1,opt,name=status,proto3,enum=dapr.proto.runtime.v1.TopicEventResponse_TopicEventResponseStatus" json:"status,omitempty"` -} - -func (x *TopicEventResponse) Reset() { - *x = TopicEventResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[1] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TopicEventResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TopicEventResponse) ProtoMessage() {} - -func (x *TopicEventResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[1] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TopicEventResponse.ProtoReflect.Descriptor instead. -func (*TopicEventResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{1} -} - -func (x *TopicEventResponse) GetStatus() TopicEventResponse_TopicEventResponseStatus { - if x != nil { - return x.Status - } - return TopicEventResponse_SUCCESS -} - -// BindingEventRequest represents input bindings event. -type BindingEventRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The name of the input binding component. - Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` - // Required. The payload that the input bindings sent - Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` - // The metadata set by the input binging components. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *BindingEventRequest) Reset() { - *x = BindingEventRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[2] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *BindingEventRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*BindingEventRequest) ProtoMessage() {} - -func (x *BindingEventRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[2] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use BindingEventRequest.ProtoReflect.Descriptor instead. -func (*BindingEventRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{2} -} - -func (x *BindingEventRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -func (x *BindingEventRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *BindingEventRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// BindingEventResponse includes operations to save state or -// send data to output bindings optionally. -type BindingEventResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store where states are saved. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The state key values which will be stored in store_name. - States []*v1.StateItem `protobuf:"bytes,2,rep,name=states,proto3" json:"states,omitempty"` - // The list of output bindings. - To []string `protobuf:"bytes,3,rep,name=to,proto3" json:"to,omitempty"` - // The content which will be sent to "to" output bindings. - Data []byte `protobuf:"bytes,4,opt,name=data,proto3" json:"data,omitempty"` - // The concurrency of output bindings to send data to - // "to" output bindings list. The default is SEQUENTIAL. - Concurrency BindingEventResponse_BindingEventConcurrency `protobuf:"varint,5,opt,name=concurrency,proto3,enum=dapr.proto.runtime.v1.BindingEventResponse_BindingEventConcurrency" json:"concurrency,omitempty"` -} - -func (x *BindingEventResponse) Reset() { - *x = BindingEventResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[3] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *BindingEventResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*BindingEventResponse) ProtoMessage() {} - -func (x *BindingEventResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[3] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use BindingEventResponse.ProtoReflect.Descriptor instead. -func (*BindingEventResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{3} -} - -func (x *BindingEventResponse) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *BindingEventResponse) GetStates() []*v1.StateItem { - if x != nil { - return x.States - } - return nil -} - -func (x *BindingEventResponse) GetTo() []string { - if x != nil { - return x.To - } - return nil -} - -func (x *BindingEventResponse) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *BindingEventResponse) GetConcurrency() BindingEventResponse_BindingEventConcurrency { - if x != nil { - return x.Concurrency - } - return BindingEventResponse_SEQUENTIAL -} - -// ListTopicSubscriptionsResponse is the message including the list of the subscribing topics. -type ListTopicSubscriptionsResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of topics. - Subscriptions []*TopicSubscription `protobuf:"bytes,1,rep,name=subscriptions,proto3" json:"subscriptions,omitempty"` -} - -func (x *ListTopicSubscriptionsResponse) Reset() { - *x = ListTopicSubscriptionsResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[4] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ListTopicSubscriptionsResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ListTopicSubscriptionsResponse) ProtoMessage() {} - -func (x *ListTopicSubscriptionsResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[4] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ListTopicSubscriptionsResponse.ProtoReflect.Descriptor instead. -func (*ListTopicSubscriptionsResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{4} -} - -func (x *ListTopicSubscriptionsResponse) GetSubscriptions() []*TopicSubscription { - if x != nil { - return x.Subscriptions - } - return nil -} - -// TopicSubscription represents topic and metadata. -type TopicSubscription struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The name of the pubsub containing the topic below to subscribe to. - PubsubName string `protobuf:"bytes,1,opt,name=pubsub_name,json=pubsubName,proto3" json:"pubsub_name,omitempty"` - // Required. The name of topic which will be subscribed - Topic string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"` - // The optional properties used for this topic's subscription e.g. session id - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` - // The optional routing rules to match against. In the gRPC interface, OnTopicEvent - // is still invoked but the matching path is sent in the TopicEventRequest. - Routes *TopicRoutes `protobuf:"bytes,5,opt,name=routes,proto3" json:"routes,omitempty"` -} - -func (x *TopicSubscription) Reset() { - *x = TopicSubscription{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[5] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TopicSubscription) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TopicSubscription) ProtoMessage() {} - -func (x *TopicSubscription) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[5] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TopicSubscription.ProtoReflect.Descriptor instead. -func (*TopicSubscription) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{5} -} - -func (x *TopicSubscription) GetPubsubName() string { - if x != nil { - return x.PubsubName - } - return "" -} - -func (x *TopicSubscription) GetTopic() string { - if x != nil { - return x.Topic - } - return "" -} - -func (x *TopicSubscription) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -func (x *TopicSubscription) GetRoutes() *TopicRoutes { - if x != nil { - return x.Routes - } - return nil -} - -type TopicRoutes struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of rules for this topic. - Rules []*TopicRule `protobuf:"bytes,1,rep,name=rules,proto3" json:"rules,omitempty"` - // The default path for this topic. - Default string `protobuf:"bytes,2,opt,name=default,proto3" json:"default,omitempty"` -} - -func (x *TopicRoutes) Reset() { - *x = TopicRoutes{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[6] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TopicRoutes) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TopicRoutes) ProtoMessage() {} - -func (x *TopicRoutes) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[6] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TopicRoutes.ProtoReflect.Descriptor instead. -func (*TopicRoutes) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{6} -} - -func (x *TopicRoutes) GetRules() []*TopicRule { - if x != nil { - return x.Rules - } - return nil -} - -func (x *TopicRoutes) GetDefault() string { - if x != nil { - return x.Default - } - return "" -} - -type TopicRule struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The optional CEL expression used to match the event. - // If the match is not specified, then the route is considered - // the default. - Match string `protobuf:"bytes,1,opt,name=match,proto3" json:"match,omitempty"` - // The path used to identify matches for this subscription. - // This value is passed in TopicEventRequest and used by OnTopicEvent to "switch" - // inside the handler. - Path string `protobuf:"bytes,2,opt,name=path,proto3" json:"path,omitempty"` -} - -func (x *TopicRule) Reset() { - *x = TopicRule{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[7] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TopicRule) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TopicRule) ProtoMessage() {} - -func (x *TopicRule) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[7] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TopicRule.ProtoReflect.Descriptor instead. -func (*TopicRule) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{7} -} - -func (x *TopicRule) GetMatch() string { - if x != nil { - return x.Match - } - return "" -} - -func (x *TopicRule) GetPath() string { - if x != nil { - return x.Path - } - return "" -} - -// ListInputBindingsResponse is the message including the list of input bindings. -type ListInputBindingsResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of input bindings. - Bindings []string `protobuf:"bytes,1,rep,name=bindings,proto3" json:"bindings,omitempty"` -} - -func (x *ListInputBindingsResponse) Reset() { - *x = ListInputBindingsResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[8] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ListInputBindingsResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ListInputBindingsResponse) ProtoMessage() {} - -func (x *ListInputBindingsResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[8] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ListInputBindingsResponse.ProtoReflect.Descriptor instead. -func (*ListInputBindingsResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP(), []int{8} -} - -func (x *ListInputBindingsResponse) GetBindings() []string { - if x != nil { - return x.Bindings - } - return nil -} - -var File_dapr_proto_runtime_v1_appcallback_proto protoreflect.FileDescriptor - -var file_dapr_proto_runtime_v1_appcallback_proto_rawDesc = []byte{ - 0x0a, 0x27, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x72, 0x75, 0x6e, - 0x74, 0x69, 0x6d, 0x65, 0x2f, 0x76, 0x31, 0x2f, 0x61, 0x70, 0x70, 0x63, 0x61, 0x6c, 0x6c, 0x62, - 0x61, 0x63, 0x6b, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x12, 0x15, 0x64, 0x61, 0x70, 0x72, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, - 0x1a, 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x21, 0x64, - 0x61, 0x70, 0x72, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x2f, 0x76, 0x31, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x22, 0xfd, 0x01, 0x0a, 0x11, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x0e, 0x0a, 0x02, 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x02, 0x69, 0x64, 0x12, 0x16, 0x0a, 0x06, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x73, 0x6f, 0x75, 0x72, 0x63, 0x65, 0x12, 0x12, - 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x74, 0x79, - 0x70, 0x65, 0x12, 0x21, 0x0a, 0x0c, 0x73, 0x70, 0x65, 0x63, 0x5f, 0x76, 0x65, 0x72, 0x73, 0x69, - 0x6f, 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0b, 0x73, 0x70, 0x65, 0x63, 0x56, 0x65, - 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x12, 0x2a, 0x0a, 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x63, 0x6f, - 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x43, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, - 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0c, 0x52, - 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x14, 0x0a, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x18, 0x06, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x12, 0x1f, 0x0a, 0x0b, 0x70, - 0x75, 0x62, 0x73, 0x75, 0x62, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x08, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x0a, 0x70, 0x75, 0x62, 0x73, 0x75, 0x62, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, 0x04, - 0x70, 0x61, 0x74, 0x68, 0x18, 0x09, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x70, 0x61, 0x74, 0x68, - 0x22, 0xae, 0x01, 0x0a, 0x12, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x5a, 0x0a, 0x06, 0x73, 0x74, 0x61, 0x74, 0x75, - 0x73, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x42, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, - 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x2e, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x52, 0x06, 0x73, 0x74, 0x61, - 0x74, 0x75, 0x73, 0x22, 0x3c, 0x0a, 0x18, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, - 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x53, 0x74, 0x61, 0x74, 0x75, 0x73, 0x12, - 0x0b, 0x0a, 0x07, 0x53, 0x55, 0x43, 0x43, 0x45, 0x53, 0x53, 0x10, 0x00, 0x12, 0x09, 0x0a, 0x05, - 0x52, 0x45, 0x54, 0x52, 0x59, 0x10, 0x01, 0x12, 0x08, 0x0a, 0x04, 0x44, 0x52, 0x4f, 0x50, 0x10, - 0x02, 0x22, 0xd0, 0x01, 0x0a, 0x13, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x45, 0x76, 0x65, - 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, - 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, - 0x61, 0x12, 0x54, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x38, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x69, 0x6e, 0x64, - 0x69, 0x6e, 0x67, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, - 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, - 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, - 0x3a, 0x02, 0x38, 0x01, 0x22, 0xb2, 0x02, 0x0a, 0x14, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, - 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1d, 0x0a, - 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x37, 0x0a, 0x06, - 0x73, 0x74, 0x61, 0x74, 0x65, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x1f, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x06, 0x73, - 0x74, 0x61, 0x74, 0x65, 0x73, 0x12, 0x0e, 0x0a, 0x02, 0x74, 0x6f, 0x18, 0x03, 0x20, 0x03, 0x28, - 0x09, 0x52, 0x02, 0x74, 0x6f, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, - 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x65, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, - 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x43, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, - 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x45, 0x76, - 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x42, 0x69, 0x6e, 0x64, - 0x69, 0x6e, 0x67, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x43, 0x6f, 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, - 0x6e, 0x63, 0x79, 0x52, 0x0b, 0x63, 0x6f, 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, - 0x22, 0x37, 0x0a, 0x17, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x45, 0x76, 0x65, 0x6e, 0x74, - 0x43, 0x6f, 0x6e, 0x63, 0x75, 0x72, 0x72, 0x65, 0x6e, 0x63, 0x79, 0x12, 0x0e, 0x0a, 0x0a, 0x53, - 0x45, 0x51, 0x55, 0x45, 0x4e, 0x54, 0x49, 0x41, 0x4c, 0x10, 0x00, 0x12, 0x0c, 0x0a, 0x08, 0x50, - 0x41, 0x52, 0x41, 0x4c, 0x4c, 0x45, 0x4c, 0x10, 0x01, 0x22, 0x70, 0x0a, 0x1e, 0x4c, 0x69, 0x73, - 0x74, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x4e, 0x0a, 0x0d, 0x73, - 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x01, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x28, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, - 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, 0x69, 0x63, - 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0d, 0x73, 0x75, - 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x22, 0x97, 0x02, 0x0a, 0x11, - 0x54, 0x6f, 0x70, 0x69, 0x63, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, - 0x6e, 0x12, 0x1f, 0x0a, 0x0b, 0x70, 0x75, 0x62, 0x73, 0x75, 0x62, 0x5f, 0x6e, 0x61, 0x6d, 0x65, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0a, 0x70, 0x75, 0x62, 0x73, 0x75, 0x62, 0x4e, 0x61, - 0x6d, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x12, 0x52, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x36, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, - 0x74, 0x69, 0x6f, 0x6e, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, - 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x3a, 0x0a, 0x06, - 0x72, 0x6f, 0x75, 0x74, 0x65, 0x73, 0x18, 0x05, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x22, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x52, 0x6f, 0x75, 0x74, 0x65, 0x73, - 0x52, 0x06, 0x72, 0x6f, 0x75, 0x74, 0x65, 0x73, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, - 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x5f, 0x0a, 0x0b, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x52, 0x6f, - 0x75, 0x74, 0x65, 0x73, 0x12, 0x36, 0x0a, 0x05, 0x72, 0x75, 0x6c, 0x65, 0x73, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x20, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, 0x69, - 0x63, 0x52, 0x75, 0x6c, 0x65, 0x52, 0x05, 0x72, 0x75, 0x6c, 0x65, 0x73, 0x12, 0x18, 0x0a, 0x07, - 0x64, 0x65, 0x66, 0x61, 0x75, 0x6c, 0x74, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x64, - 0x65, 0x66, 0x61, 0x75, 0x6c, 0x74, 0x22, 0x35, 0x0a, 0x09, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x52, - 0x75, 0x6c, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x05, 0x6d, 0x61, 0x74, 0x63, 0x68, 0x12, 0x12, 0x0a, 0x04, 0x70, 0x61, 0x74, - 0x68, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x70, 0x61, 0x74, 0x68, 0x22, 0x37, 0x0a, - 0x19, 0x4c, 0x69, 0x73, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, - 0x67, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x1a, 0x0a, 0x08, 0x62, 0x69, - 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x09, 0x52, 0x08, 0x62, 0x69, - 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x73, 0x32, 0x86, 0x04, 0x0a, 0x0b, 0x41, 0x70, 0x70, 0x43, 0x61, - 0x6c, 0x6c, 0x62, 0x61, 0x63, 0x6b, 0x12, 0x57, 0x0a, 0x08, 0x4f, 0x6e, 0x49, 0x6e, 0x76, 0x6f, - 0x6b, 0x65, 0x12, 0x23, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, - 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x24, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x49, - 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, - 0x69, 0x0a, 0x16, 0x4c, 0x69, 0x73, 0x74, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x53, 0x75, 0x62, 0x73, - 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, - 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, - 0x79, 0x1a, 0x35, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, - 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x54, 0x6f, - 0x70, 0x69, 0x63, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x65, 0x0a, 0x0c, 0x4f, 0x6e, - 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x12, 0x28, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x1a, 0x29, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x6f, 0x70, - 0x69, 0x63, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, - 0x00, 0x12, 0x5f, 0x0a, 0x11, 0x4c, 0x69, 0x73, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, 0x42, 0x69, - 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x73, 0x12, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x1a, 0x30, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, - 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x4c, 0x69, 0x73, 0x74, 0x49, 0x6e, 0x70, 0x75, 0x74, - 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x73, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x22, 0x00, 0x12, 0x6b, 0x0a, 0x0e, 0x4f, 0x6e, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x45, - 0x76, 0x65, 0x6e, 0x74, 0x12, 0x2a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x69, 0x6e, - 0x64, 0x69, 0x6e, 0x67, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x2b, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, - 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x42, - 0x79, 0x0a, 0x0a, 0x69, 0x6f, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x76, 0x31, 0x42, 0x15, 0x44, - 0x61, 0x70, 0x72, 0x41, 0x70, 0x70, 0x43, 0x61, 0x6c, 0x6c, 0x62, 0x61, 0x63, 0x6b, 0x50, 0x72, - 0x6f, 0x74, 0x6f, 0x73, 0x5a, 0x31, 0x67, 0x69, 0x74, 0x68, 0x75, 0x62, 0x2e, 0x63, 0x6f, 0x6d, - 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x6b, 0x67, 0x2f, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2f, 0x76, 0x31, 0x3b, - 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0xaa, 0x02, 0x20, 0x44, 0x61, 0x70, 0x72, 0x2e, 0x41, - 0x70, 0x70, 0x43, 0x61, 0x6c, 0x6c, 0x62, 0x61, 0x63, 0x6b, 0x2e, 0x41, 0x75, 0x74, 0x6f, 0x67, - 0x65, 0x6e, 0x2e, 0x47, 0x72, 0x70, 0x63, 0x2e, 0x76, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x33, -} - -var ( - file_dapr_proto_runtime_v1_appcallback_proto_rawDescOnce sync.Once - file_dapr_proto_runtime_v1_appcallback_proto_rawDescData = file_dapr_proto_runtime_v1_appcallback_proto_rawDesc -) - -func file_dapr_proto_runtime_v1_appcallback_proto_rawDescGZIP() []byte { - file_dapr_proto_runtime_v1_appcallback_proto_rawDescOnce.Do(func() { - file_dapr_proto_runtime_v1_appcallback_proto_rawDescData = protoimpl.X.CompressGZIP(file_dapr_proto_runtime_v1_appcallback_proto_rawDescData) - }) - return file_dapr_proto_runtime_v1_appcallback_proto_rawDescData -} - -var file_dapr_proto_runtime_v1_appcallback_proto_enumTypes = make([]protoimpl.EnumInfo, 2) -var file_dapr_proto_runtime_v1_appcallback_proto_msgTypes = make([]protoimpl.MessageInfo, 11) -var file_dapr_proto_runtime_v1_appcallback_proto_goTypes = []interface{}{ - (TopicEventResponse_TopicEventResponseStatus)(0), // 0: dapr.proto.runtime.v1.TopicEventResponse.TopicEventResponseStatus - (BindingEventResponse_BindingEventConcurrency)(0), // 1: dapr.proto.runtime.v1.BindingEventResponse.BindingEventConcurrency - (*TopicEventRequest)(nil), // 2: dapr.proto.runtime.v1.TopicEventRequest - (*TopicEventResponse)(nil), // 3: dapr.proto.runtime.v1.TopicEventResponse - (*BindingEventRequest)(nil), // 4: dapr.proto.runtime.v1.BindingEventRequest - (*BindingEventResponse)(nil), // 5: dapr.proto.runtime.v1.BindingEventResponse - (*ListTopicSubscriptionsResponse)(nil), // 6: dapr.proto.runtime.v1.ListTopicSubscriptionsResponse - (*TopicSubscription)(nil), // 7: dapr.proto.runtime.v1.TopicSubscription - (*TopicRoutes)(nil), // 8: dapr.proto.runtime.v1.TopicRoutes - (*TopicRule)(nil), // 9: dapr.proto.runtime.v1.TopicRule - (*ListInputBindingsResponse)(nil), // 10: dapr.proto.runtime.v1.ListInputBindingsResponse - nil, // 11: dapr.proto.runtime.v1.BindingEventRequest.MetadataEntry - nil, // 12: dapr.proto.runtime.v1.TopicSubscription.MetadataEntry - (*v1.StateItem)(nil), // 13: dapr.proto.common.v1.StateItem - (*v1.InvokeRequest)(nil), // 14: dapr.proto.common.v1.InvokeRequest - (*emptypb.Empty)(nil), // 15: google.protobuf.Empty - (*v1.InvokeResponse)(nil), // 16: dapr.proto.common.v1.InvokeResponse -} -var file_dapr_proto_runtime_v1_appcallback_proto_depIdxs = []int32{ - 0, // 0: dapr.proto.runtime.v1.TopicEventResponse.status:type_name -> dapr.proto.runtime.v1.TopicEventResponse.TopicEventResponseStatus - 11, // 1: dapr.proto.runtime.v1.BindingEventRequest.metadata:type_name -> dapr.proto.runtime.v1.BindingEventRequest.MetadataEntry - 13, // 2: dapr.proto.runtime.v1.BindingEventResponse.states:type_name -> dapr.proto.common.v1.StateItem - 1, // 3: dapr.proto.runtime.v1.BindingEventResponse.concurrency:type_name -> dapr.proto.runtime.v1.BindingEventResponse.BindingEventConcurrency - 7, // 4: dapr.proto.runtime.v1.ListTopicSubscriptionsResponse.subscriptions:type_name -> dapr.proto.runtime.v1.TopicSubscription - 12, // 5: dapr.proto.runtime.v1.TopicSubscription.metadata:type_name -> dapr.proto.runtime.v1.TopicSubscription.MetadataEntry - 8, // 6: dapr.proto.runtime.v1.TopicSubscription.routes:type_name -> dapr.proto.runtime.v1.TopicRoutes - 9, // 7: dapr.proto.runtime.v1.TopicRoutes.rules:type_name -> dapr.proto.runtime.v1.TopicRule - 14, // 8: dapr.proto.runtime.v1.AppCallback.OnInvoke:input_type -> dapr.proto.common.v1.InvokeRequest - 15, // 9: dapr.proto.runtime.v1.AppCallback.ListTopicSubscriptions:input_type -> google.protobuf.Empty - 2, // 10: dapr.proto.runtime.v1.AppCallback.OnTopicEvent:input_type -> dapr.proto.runtime.v1.TopicEventRequest - 15, // 11: dapr.proto.runtime.v1.AppCallback.ListInputBindings:input_type -> google.protobuf.Empty - 4, // 12: dapr.proto.runtime.v1.AppCallback.OnBindingEvent:input_type -> dapr.proto.runtime.v1.BindingEventRequest - 16, // 13: dapr.proto.runtime.v1.AppCallback.OnInvoke:output_type -> dapr.proto.common.v1.InvokeResponse - 6, // 14: dapr.proto.runtime.v1.AppCallback.ListTopicSubscriptions:output_type -> dapr.proto.runtime.v1.ListTopicSubscriptionsResponse - 3, // 15: dapr.proto.runtime.v1.AppCallback.OnTopicEvent:output_type -> dapr.proto.runtime.v1.TopicEventResponse - 10, // 16: dapr.proto.runtime.v1.AppCallback.ListInputBindings:output_type -> dapr.proto.runtime.v1.ListInputBindingsResponse - 5, // 17: dapr.proto.runtime.v1.AppCallback.OnBindingEvent:output_type -> dapr.proto.runtime.v1.BindingEventResponse - 13, // [13:18] is the sub-list for method output_type - 8, // [8:13] is the sub-list for method input_type - 8, // [8:8] is the sub-list for extension type_name - 8, // [8:8] is the sub-list for extension extendee - 0, // [0:8] is the sub-list for field type_name -} - -func init() { file_dapr_proto_runtime_v1_appcallback_proto_init() } -func file_dapr_proto_runtime_v1_appcallback_proto_init() { - if File_dapr_proto_runtime_v1_appcallback_proto != nil { - return - } - if !protoimpl.UnsafeEnabled { - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[0].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TopicEventRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[1].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TopicEventResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[2].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*BindingEventRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[3].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*BindingEventResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[4].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ListTopicSubscriptionsResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[5].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TopicSubscription); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[6].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TopicRoutes); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[7].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TopicRule); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_appcallback_proto_msgTypes[8].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ListInputBindingsResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - } - type x struct{} - out := protoimpl.TypeBuilder{ - File: protoimpl.DescBuilder{ - GoPackagePath: reflect.TypeOf(x{}).PkgPath(), - RawDescriptor: file_dapr_proto_runtime_v1_appcallback_proto_rawDesc, - NumEnums: 2, - NumMessages: 11, - NumExtensions: 0, - NumServices: 1, - }, - GoTypes: file_dapr_proto_runtime_v1_appcallback_proto_goTypes, - DependencyIndexes: file_dapr_proto_runtime_v1_appcallback_proto_depIdxs, - EnumInfos: file_dapr_proto_runtime_v1_appcallback_proto_enumTypes, - MessageInfos: file_dapr_proto_runtime_v1_appcallback_proto_msgTypes, - }.Build() - File_dapr_proto_runtime_v1_appcallback_proto = out.File - file_dapr_proto_runtime_v1_appcallback_proto_rawDesc = nil - file_dapr_proto_runtime_v1_appcallback_proto_goTypes = nil - file_dapr_proto_runtime_v1_appcallback_proto_depIdxs = nil -} diff --git a/pkg/grpc/dapr/proto/runtime/v1/appcallback_grpc.pb.go b/pkg/grpc/dapr/proto/runtime/v1/appcallback_grpc.pb.go deleted file mode 100644 index 19b3de1098..0000000000 --- a/pkg/grpc/dapr/proto/runtime/v1/appcallback_grpc.pb.go +++ /dev/null @@ -1,263 +0,0 @@ -// Code generated by protoc-gen-go-grpc. DO NOT EDIT. - -package runtime - -import ( - context "context" - - grpc "google.golang.org/grpc" - codes "google.golang.org/grpc/codes" - status "google.golang.org/grpc/status" - emptypb "google.golang.org/protobuf/types/known/emptypb" - - v1 "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" -) - -// This is a compile-time assertion to ensure that this generated file -// is compatible with the grpc package it is being compiled against. -// Requires gRPC-Go v1.32.0 or later. -const _ = grpc.SupportPackageIsVersion7 - -// AppCallbackClient is the client API for AppCallback service. -// -// For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream. -type AppCallbackClient interface { - // Invokes service method with InvokeRequest. - OnInvoke(ctx context.Context, in *v1.InvokeRequest, opts ...grpc.CallOption) (*v1.InvokeResponse, error) - // Lists all topics subscribed by this app. - ListTopicSubscriptions(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*ListTopicSubscriptionsResponse, error) - // Subscribes events from Pubsub - OnTopicEvent(ctx context.Context, in *TopicEventRequest, opts ...grpc.CallOption) (*TopicEventResponse, error) - // Lists all input bindings subscribed by this app. - ListInputBindings(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*ListInputBindingsResponse, error) - // Listens events from the input bindings - // - // User application can save the states or send the events to the output - // bindings optionally by returning BindingEventResponse. - OnBindingEvent(ctx context.Context, in *BindingEventRequest, opts ...grpc.CallOption) (*BindingEventResponse, error) -} - -type appCallbackClient struct { - cc grpc.ClientConnInterface -} - -func NewAppCallbackClient(cc grpc.ClientConnInterface) AppCallbackClient { - return &appCallbackClient{cc} -} - -func (c *appCallbackClient) OnInvoke(ctx context.Context, in *v1.InvokeRequest, opts ...grpc.CallOption) (*v1.InvokeResponse, error) { - out := new(v1.InvokeResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.AppCallback/OnInvoke", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *appCallbackClient) ListTopicSubscriptions(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*ListTopicSubscriptionsResponse, error) { - out := new(ListTopicSubscriptionsResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.AppCallback/ListTopicSubscriptions", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *appCallbackClient) OnTopicEvent(ctx context.Context, in *TopicEventRequest, opts ...grpc.CallOption) (*TopicEventResponse, error) { - out := new(TopicEventResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.AppCallback/OnTopicEvent", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *appCallbackClient) ListInputBindings(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*ListInputBindingsResponse, error) { - out := new(ListInputBindingsResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.AppCallback/ListInputBindings", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *appCallbackClient) OnBindingEvent(ctx context.Context, in *BindingEventRequest, opts ...grpc.CallOption) (*BindingEventResponse, error) { - out := new(BindingEventResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.AppCallback/OnBindingEvent", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -// AppCallbackServer is the server API for AppCallback service. -// All implementations should embed UnimplementedAppCallbackServer -// for forward compatibility -type AppCallbackServer interface { - // Invokes service method with InvokeRequest. - OnInvoke(context.Context, *v1.InvokeRequest) (*v1.InvokeResponse, error) - // Lists all topics subscribed by this app. - ListTopicSubscriptions(context.Context, *emptypb.Empty) (*ListTopicSubscriptionsResponse, error) - // Subscribes events from Pubsub - OnTopicEvent(context.Context, *TopicEventRequest) (*TopicEventResponse, error) - // Lists all input bindings subscribed by this app. - ListInputBindings(context.Context, *emptypb.Empty) (*ListInputBindingsResponse, error) - // Listens events from the input bindings - // - // User application can save the states or send the events to the output - // bindings optionally by returning BindingEventResponse. - OnBindingEvent(context.Context, *BindingEventRequest) (*BindingEventResponse, error) -} - -// UnimplementedAppCallbackServer should be embedded to have forward compatible implementations. -type UnimplementedAppCallbackServer struct { -} - -func (UnimplementedAppCallbackServer) OnInvoke(context.Context, *v1.InvokeRequest) (*v1.InvokeResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method OnInvoke not implemented") -} -func (UnimplementedAppCallbackServer) ListTopicSubscriptions(context.Context, *emptypb.Empty) (*ListTopicSubscriptionsResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method ListTopicSubscriptions not implemented") -} -func (UnimplementedAppCallbackServer) OnTopicEvent(context.Context, *TopicEventRequest) (*TopicEventResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method OnTopicEvent not implemented") -} -func (UnimplementedAppCallbackServer) ListInputBindings(context.Context, *emptypb.Empty) (*ListInputBindingsResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method ListInputBindings not implemented") -} -func (UnimplementedAppCallbackServer) OnBindingEvent(context.Context, *BindingEventRequest) (*BindingEventResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method OnBindingEvent not implemented") -} - -// UnsafeAppCallbackServer may be embedded to opt out of forward compatibility for this service. -// Use of this interface is not recommended, as added methods to AppCallbackServer will -// result in compilation errors. -type UnsafeAppCallbackServer interface { - mustEmbedUnimplementedAppCallbackServer() -} - -func RegisterAppCallbackServer(s grpc.ServiceRegistrar, srv AppCallbackServer) { - s.RegisterService(&AppCallback_ServiceDesc, srv) -} - -func _AppCallback_OnInvoke_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(v1.InvokeRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(AppCallbackServer).OnInvoke(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.AppCallback/OnInvoke", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(AppCallbackServer).OnInvoke(ctx, req.(*v1.InvokeRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _AppCallback_ListTopicSubscriptions_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(emptypb.Empty) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(AppCallbackServer).ListTopicSubscriptions(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.AppCallback/ListTopicSubscriptions", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(AppCallbackServer).ListTopicSubscriptions(ctx, req.(*emptypb.Empty)) - } - return interceptor(ctx, in, info, handler) -} - -func _AppCallback_OnTopicEvent_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(TopicEventRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(AppCallbackServer).OnTopicEvent(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.AppCallback/OnTopicEvent", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(AppCallbackServer).OnTopicEvent(ctx, req.(*TopicEventRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _AppCallback_ListInputBindings_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(emptypb.Empty) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(AppCallbackServer).ListInputBindings(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.AppCallback/ListInputBindings", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(AppCallbackServer).ListInputBindings(ctx, req.(*emptypb.Empty)) - } - return interceptor(ctx, in, info, handler) -} - -func _AppCallback_OnBindingEvent_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(BindingEventRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(AppCallbackServer).OnBindingEvent(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.AppCallback/OnBindingEvent", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(AppCallbackServer).OnBindingEvent(ctx, req.(*BindingEventRequest)) - } - return interceptor(ctx, in, info, handler) -} - -// AppCallback_ServiceDesc is the grpc.ServiceDesc for AppCallback service. -// It's only intended for direct use with grpc.RegisterService, -// and not to be introspected or modified (even as a copy) -var AppCallback_ServiceDesc = grpc.ServiceDesc{ - ServiceName: "dapr.proto.runtime.v1.AppCallback", - HandlerType: (*AppCallbackServer)(nil), - Methods: []grpc.MethodDesc{ - { - MethodName: "OnInvoke", - Handler: _AppCallback_OnInvoke_Handler, - }, - { - MethodName: "ListTopicSubscriptions", - Handler: _AppCallback_ListTopicSubscriptions_Handler, - }, - { - MethodName: "OnTopicEvent", - Handler: _AppCallback_OnTopicEvent_Handler, - }, - { - MethodName: "ListInputBindings", - Handler: _AppCallback_ListInputBindings_Handler, - }, - { - MethodName: "OnBindingEvent", - Handler: _AppCallback_OnBindingEvent_Handler, - }, - }, - Streams: []grpc.StreamDesc{}, - Metadata: "dapr/proto/runtime/v1/appcallback.proto", -} diff --git a/pkg/grpc/dapr/proto/runtime/v1/dapr.pb.go b/pkg/grpc/dapr/proto/runtime/v1/dapr.pb.go deleted file mode 100644 index 46e34aeabb..0000000000 --- a/pkg/grpc/dapr/proto/runtime/v1/dapr.pb.go +++ /dev/null @@ -1,3948 +0,0 @@ -// ------------------------------------------------------------ -// Copyright (c) Microsoft Corporation and Dapr Contributors. -// Licensed under the MIT License. -// ------------------------------------------------------------ - -// Code generated by protoc-gen-go. DO NOT EDIT. -// versions: -// protoc-gen-go v1.25.0 -// protoc v3.14.0 -// source: dapr/proto/runtime/v1/dapr.proto - -package runtime - -import ( - reflect "reflect" - sync "sync" - - proto "github.com/golang/protobuf/proto" - protoreflect "google.golang.org/protobuf/reflect/protoreflect" - protoimpl "google.golang.org/protobuf/runtime/protoimpl" - anypb "google.golang.org/protobuf/types/known/anypb" - emptypb "google.golang.org/protobuf/types/known/emptypb" - - v1 "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" -) - -const ( - // Verify that this generated code is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(20 - protoimpl.MinVersion) - // Verify that runtime/protoimpl is sufficiently up-to-date. - _ = protoimpl.EnforceVersion(protoimpl.MaxVersion - 20) -) - -// This is a compile-time assertion that a sufficiently up-to-date version -// of the legacy proto package is being used. -const _ = proto.ProtoPackageIsVersion4 - -// InvokeServiceRequest represents the request message for Service invocation. -type InvokeServiceRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. Callee's app id. - Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` - // Required. message which will be delivered to callee. - Message *v1.InvokeRequest `protobuf:"bytes,3,opt,name=message,proto3" json:"message,omitempty"` -} - -func (x *InvokeServiceRequest) Reset() { - *x = InvokeServiceRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[0] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeServiceRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeServiceRequest) ProtoMessage() {} - -func (x *InvokeServiceRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[0] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeServiceRequest.ProtoReflect.Descriptor instead. -func (*InvokeServiceRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{0} -} - -func (x *InvokeServiceRequest) GetId() string { - if x != nil { - return x.Id - } - return "" -} - -func (x *InvokeServiceRequest) GetMessage() *v1.InvokeRequest { - if x != nil { - return x.Message - } - return nil -} - -// GetStateRequest is the message to get key-value states from specific state store. -type GetStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The key of the desired state - Key string `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"` - // The read consistency of the state store. - Consistency v1.StateOptions_StateConsistency `protobuf:"varint,3,opt,name=consistency,proto3,enum=dapr.proto.common.v1.StateOptions_StateConsistency" json:"consistency,omitempty"` - // The metadata which will be sent to state store components. - Metadata map[string]string `protobuf:"bytes,4,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetStateRequest) Reset() { - *x = GetStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[1] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetStateRequest) ProtoMessage() {} - -func (x *GetStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[1] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetStateRequest.ProtoReflect.Descriptor instead. -func (*GetStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{1} -} - -func (x *GetStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *GetStateRequest) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *GetStateRequest) GetConsistency() v1.StateOptions_StateConsistency { - if x != nil { - return x.Consistency - } - return v1.StateOptions_CONSISTENCY_UNSPECIFIED -} - -func (x *GetStateRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetBulkStateRequest is the message to get a list of key-value states from specific state store. -type GetBulkStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The keys to get. - Keys []string `protobuf:"bytes,2,rep,name=keys,proto3" json:"keys,omitempty"` - // The number of parallel operations executed on the state store for a get operation. - Parallelism int32 `protobuf:"varint,3,opt,name=parallelism,proto3" json:"parallelism,omitempty"` - // The metadata which will be sent to state store components. - Metadata map[string]string `protobuf:"bytes,4,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetBulkStateRequest) Reset() { - *x = GetBulkStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[2] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetBulkStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetBulkStateRequest) ProtoMessage() {} - -func (x *GetBulkStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[2] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetBulkStateRequest.ProtoReflect.Descriptor instead. -func (*GetBulkStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{2} -} - -func (x *GetBulkStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *GetBulkStateRequest) GetKeys() []string { - if x != nil { - return x.Keys - } - return nil -} - -func (x *GetBulkStateRequest) GetParallelism() int32 { - if x != nil { - return x.Parallelism - } - return 0 -} - -func (x *GetBulkStateRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetBulkStateResponse is the response conveying the list of state values. -type GetBulkStateResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of items containing the keys to get values for. - Items []*BulkStateItem `protobuf:"bytes,1,rep,name=items,proto3" json:"items,omitempty"` -} - -func (x *GetBulkStateResponse) Reset() { - *x = GetBulkStateResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[3] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetBulkStateResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetBulkStateResponse) ProtoMessage() {} - -func (x *GetBulkStateResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[3] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetBulkStateResponse.ProtoReflect.Descriptor instead. -func (*GetBulkStateResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{3} -} - -func (x *GetBulkStateResponse) GetItems() []*BulkStateItem { - if x != nil { - return x.Items - } - return nil -} - -// BulkStateItem is the response item for a bulk get operation. -// Return values include the item key, data and etag. -type BulkStateItem struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // state item key - Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` - // The byte array data - Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` - // The entity tag which represents the specific version of data. - // ETag format is defined by the corresponding data store. - Etag string `protobuf:"bytes,3,opt,name=etag,proto3" json:"etag,omitempty"` - // The error that was returned from the state store in case of a failed get operation. - Error string `protobuf:"bytes,4,opt,name=error,proto3" json:"error,omitempty"` - // The metadata which will be sent to app. - Metadata map[string]string `protobuf:"bytes,5,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *BulkStateItem) Reset() { - *x = BulkStateItem{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[4] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *BulkStateItem) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*BulkStateItem) ProtoMessage() {} - -func (x *BulkStateItem) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[4] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use BulkStateItem.ProtoReflect.Descriptor instead. -func (*BulkStateItem) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{4} -} - -func (x *BulkStateItem) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *BulkStateItem) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *BulkStateItem) GetEtag() string { - if x != nil { - return x.Etag - } - return "" -} - -func (x *BulkStateItem) GetError() string { - if x != nil { - return x.Error - } - return "" -} - -func (x *BulkStateItem) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetStateResponse is the response conveying the state value and etag. -type GetStateResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The byte array data - Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"` - // The entity tag which represents the specific version of data. - // ETag format is defined by the corresponding data store. - Etag string `protobuf:"bytes,2,opt,name=etag,proto3" json:"etag,omitempty"` - // The metadata which will be sent to app. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetStateResponse) Reset() { - *x = GetStateResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[5] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetStateResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetStateResponse) ProtoMessage() {} - -func (x *GetStateResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[5] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetStateResponse.ProtoReflect.Descriptor instead. -func (*GetStateResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{5} -} - -func (x *GetStateResponse) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *GetStateResponse) GetEtag() string { - if x != nil { - return x.Etag - } - return "" -} - -func (x *GetStateResponse) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// DeleteStateRequest is the message to delete key-value states in the specific state store. -type DeleteStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The key of the desired state - Key string `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"` - // The entity tag which represents the specific version of data. - // The exact ETag format is defined by the corresponding data store. - Etag *v1.Etag `protobuf:"bytes,3,opt,name=etag,proto3" json:"etag,omitempty"` - // State operation options which includes concurrency/ - // consistency/retry_policy. - Options *v1.StateOptions `protobuf:"bytes,4,opt,name=options,proto3" json:"options,omitempty"` - // The metadata which will be sent to state store components. - Metadata map[string]string `protobuf:"bytes,5,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *DeleteStateRequest) Reset() { - *x = DeleteStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[6] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *DeleteStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*DeleteStateRequest) ProtoMessage() {} - -func (x *DeleteStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[6] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use DeleteStateRequest.ProtoReflect.Descriptor instead. -func (*DeleteStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{6} -} - -func (x *DeleteStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *DeleteStateRequest) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *DeleteStateRequest) GetEtag() *v1.Etag { - if x != nil { - return x.Etag - } - return nil -} - -func (x *DeleteStateRequest) GetOptions() *v1.StateOptions { - if x != nil { - return x.Options - } - return nil -} - -func (x *DeleteStateRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// DeleteBulkStateRequest is the message to delete a list of key-value states from specific state store. -type DeleteBulkStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The array of the state key values. - States []*v1.StateItem `protobuf:"bytes,2,rep,name=states,proto3" json:"states,omitempty"` -} - -func (x *DeleteBulkStateRequest) Reset() { - *x = DeleteBulkStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[7] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *DeleteBulkStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*DeleteBulkStateRequest) ProtoMessage() {} - -func (x *DeleteBulkStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[7] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use DeleteBulkStateRequest.ProtoReflect.Descriptor instead. -func (*DeleteBulkStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{7} -} - -func (x *DeleteBulkStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *DeleteBulkStateRequest) GetStates() []*v1.StateItem { - if x != nil { - return x.States - } - return nil -} - -// SaveStateRequest is the message to save multiple states into state store. -type SaveStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The array of the state key values. - States []*v1.StateItem `protobuf:"bytes,2,rep,name=states,proto3" json:"states,omitempty"` -} - -func (x *SaveStateRequest) Reset() { - *x = SaveStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[8] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *SaveStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*SaveStateRequest) ProtoMessage() {} - -func (x *SaveStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[8] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use SaveStateRequest.ProtoReflect.Descriptor instead. -func (*SaveStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{8} -} - -func (x *SaveStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *SaveStateRequest) GetStates() []*v1.StateItem { - if x != nil { - return x.States - } - return nil -} - -// QueryStateRequest is the message to query state store. -type QueryStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of state store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The query in JSON format. - Query string `protobuf:"bytes,2,opt,name=query,proto3" json:"query,omitempty"` - // The metadata which will be sent to state store components. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *QueryStateRequest) Reset() { - *x = QueryStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[9] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *QueryStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*QueryStateRequest) ProtoMessage() {} - -func (x *QueryStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[9] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use QueryStateRequest.ProtoReflect.Descriptor instead. -func (*QueryStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{9} -} - -func (x *QueryStateRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *QueryStateRequest) GetQuery() string { - if x != nil { - return x.Query - } - return "" -} - -func (x *QueryStateRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -type QueryStateItem struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The object key. - Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` - // The object value. - Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` - // The entity tag which represents the specific version of data. - // ETag format is defined by the corresponding data store. - Etag string `protobuf:"bytes,3,opt,name=etag,proto3" json:"etag,omitempty"` - // The error message indicating an error in processing of the query result. - Error string `protobuf:"bytes,4,opt,name=error,proto3" json:"error,omitempty"` -} - -func (x *QueryStateItem) Reset() { - *x = QueryStateItem{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[10] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *QueryStateItem) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*QueryStateItem) ProtoMessage() {} - -func (x *QueryStateItem) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[10] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use QueryStateItem.ProtoReflect.Descriptor instead. -func (*QueryStateItem) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{10} -} - -func (x *QueryStateItem) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *QueryStateItem) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *QueryStateItem) GetEtag() string { - if x != nil { - return x.Etag - } - return "" -} - -func (x *QueryStateItem) GetError() string { - if x != nil { - return x.Error - } - return "" -} - -// QueryStateResponse is the response conveying the query results. -type QueryStateResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // An array of query results. - Results []*QueryStateItem `protobuf:"bytes,1,rep,name=results,proto3" json:"results,omitempty"` - // Pagination token. - Token string `protobuf:"bytes,2,opt,name=token,proto3" json:"token,omitempty"` - // The metadata which will be sent to app. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *QueryStateResponse) Reset() { - *x = QueryStateResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[11] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *QueryStateResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*QueryStateResponse) ProtoMessage() {} - -func (x *QueryStateResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[11] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use QueryStateResponse.ProtoReflect.Descriptor instead. -func (*QueryStateResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{11} -} - -func (x *QueryStateResponse) GetResults() []*QueryStateItem { - if x != nil { - return x.Results - } - return nil -} - -func (x *QueryStateResponse) GetToken() string { - if x != nil { - return x.Token - } - return "" -} - -func (x *QueryStateResponse) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// PublishEventRequest is the message to publish event data to pubsub topic -type PublishEventRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of the pubsub component - PubsubName string `protobuf:"bytes,1,opt,name=pubsub_name,json=pubsubName,proto3" json:"pubsub_name,omitempty"` - // The pubsub topic - Topic string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"` - // The data which will be published to topic. - Data []byte `protobuf:"bytes,3,opt,name=data,proto3" json:"data,omitempty"` - // The content type for the data (optional). - DataContentType string `protobuf:"bytes,4,opt,name=data_content_type,json=dataContentType,proto3" json:"data_content_type,omitempty"` - // The metadata passing to pub components - // - // metadata property: - // - key : the key of the message. - Metadata map[string]string `protobuf:"bytes,5,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *PublishEventRequest) Reset() { - *x = PublishEventRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[12] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *PublishEventRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*PublishEventRequest) ProtoMessage() {} - -func (x *PublishEventRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[12] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use PublishEventRequest.ProtoReflect.Descriptor instead. -func (*PublishEventRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{12} -} - -func (x *PublishEventRequest) GetPubsubName() string { - if x != nil { - return x.PubsubName - } - return "" -} - -func (x *PublishEventRequest) GetTopic() string { - if x != nil { - return x.Topic - } - return "" -} - -func (x *PublishEventRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *PublishEventRequest) GetDataContentType() string { - if x != nil { - return x.DataContentType - } - return "" -} - -func (x *PublishEventRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// InvokeBindingRequest is the message to send data to output bindings -type InvokeBindingRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of the output binding to invoke. - Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` - // The data which will be sent to output binding. - Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` - // The metadata passing to output binding components - // - // Common metadata property: - // - ttlInSeconds : the time to live in seconds for the message. - // If set in the binding definition will cause all messages to - // have a default time to live. The message ttl overrides any value - // in the binding definition. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` - // The name of the operation type for the binding to invoke - Operation string `protobuf:"bytes,4,opt,name=operation,proto3" json:"operation,omitempty"` -} - -func (x *InvokeBindingRequest) Reset() { - *x = InvokeBindingRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[13] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeBindingRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeBindingRequest) ProtoMessage() {} - -func (x *InvokeBindingRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[13] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeBindingRequest.ProtoReflect.Descriptor instead. -func (*InvokeBindingRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{13} -} - -func (x *InvokeBindingRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -func (x *InvokeBindingRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *InvokeBindingRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -func (x *InvokeBindingRequest) GetOperation() string { - if x != nil { - return x.Operation - } - return "" -} - -// InvokeBindingResponse is the message returned from an output binding invocation -type InvokeBindingResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The data which will be sent to output binding. - Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"` - // The metadata returned from an external system - Metadata map[string]string `protobuf:"bytes,2,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *InvokeBindingResponse) Reset() { - *x = InvokeBindingResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[14] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeBindingResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeBindingResponse) ProtoMessage() {} - -func (x *InvokeBindingResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[14] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeBindingResponse.ProtoReflect.Descriptor instead. -func (*InvokeBindingResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{14} -} - -func (x *InvokeBindingResponse) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *InvokeBindingResponse) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetSecretRequest is the message to get secret from secret store. -type GetSecretRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of secret store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The name of secret key. - Key string `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"` - // The metadata which will be sent to secret store components. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetSecretRequest) Reset() { - *x = GetSecretRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[15] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetSecretRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetSecretRequest) ProtoMessage() {} - -func (x *GetSecretRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[15] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetSecretRequest.ProtoReflect.Descriptor instead. -func (*GetSecretRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{15} -} - -func (x *GetSecretRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *GetSecretRequest) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *GetSecretRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetSecretResponse is the response message to convey the requested secret. -type GetSecretResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // data is the secret value. Some secret store, such as kubernetes secret - // store, can save multiple secrets for single secret key. - Data map[string]string `protobuf:"bytes,1,rep,name=data,proto3" json:"data,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetSecretResponse) Reset() { - *x = GetSecretResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[16] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetSecretResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetSecretResponse) ProtoMessage() {} - -func (x *GetSecretResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[16] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetSecretResponse.ProtoReflect.Descriptor instead. -func (*GetSecretResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{16} -} - -func (x *GetSecretResponse) GetData() map[string]string { - if x != nil { - return x.Data - } - return nil -} - -// GetBulkSecretRequest is the message to get the secrets from secret store. -type GetBulkSecretRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of secret store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // The metadata which will be sent to secret store components. - Metadata map[string]string `protobuf:"bytes,2,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetBulkSecretRequest) Reset() { - *x = GetBulkSecretRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[17] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetBulkSecretRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetBulkSecretRequest) ProtoMessage() {} - -func (x *GetBulkSecretRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[17] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetBulkSecretRequest.ProtoReflect.Descriptor instead. -func (*GetBulkSecretRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{17} -} - -func (x *GetBulkSecretRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *GetBulkSecretRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// SecretResponse is a map of decrypted string/string values -type SecretResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Secrets map[string]string `protobuf:"bytes,1,rep,name=secrets,proto3" json:"secrets,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *SecretResponse) Reset() { - *x = SecretResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[18] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *SecretResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*SecretResponse) ProtoMessage() {} - -func (x *SecretResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[18] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use SecretResponse.ProtoReflect.Descriptor instead. -func (*SecretResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{18} -} - -func (x *SecretResponse) GetSecrets() map[string]string { - if x != nil { - return x.Secrets - } - return nil -} - -// GetBulkSecretResponse is the response message to convey the requested secrets. -type GetBulkSecretResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // data hold the secret values. Some secret store, such as kubernetes secret - // store, can save multiple secrets for single secret key. - Data map[string]*SecretResponse `protobuf:"bytes,1,rep,name=data,proto3" json:"data,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetBulkSecretResponse) Reset() { - *x = GetBulkSecretResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[19] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetBulkSecretResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetBulkSecretResponse) ProtoMessage() {} - -func (x *GetBulkSecretResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[19] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetBulkSecretResponse.ProtoReflect.Descriptor instead. -func (*GetBulkSecretResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{19} -} - -func (x *GetBulkSecretResponse) GetData() map[string]*SecretResponse { - if x != nil { - return x.Data - } - return nil -} - -// TransactionalStateOperation is the message to execute a specified operation with a key-value pair. -type TransactionalStateOperation struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The type of operation to be executed - OperationType string `protobuf:"bytes,1,opt,name=operationType,proto3" json:"operationType,omitempty"` - // State values to be operated on - Request *v1.StateItem `protobuf:"bytes,2,opt,name=request,proto3" json:"request,omitempty"` -} - -func (x *TransactionalStateOperation) Reset() { - *x = TransactionalStateOperation{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[20] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TransactionalStateOperation) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TransactionalStateOperation) ProtoMessage() {} - -func (x *TransactionalStateOperation) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[20] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TransactionalStateOperation.ProtoReflect.Descriptor instead. -func (*TransactionalStateOperation) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{20} -} - -func (x *TransactionalStateOperation) GetOperationType() string { - if x != nil { - return x.OperationType - } - return "" -} - -func (x *TransactionalStateOperation) GetRequest() *v1.StateItem { - if x != nil { - return x.Request - } - return nil -} - -// ExecuteStateTransactionRequest is the message to execute multiple operations on a specified store. -type ExecuteStateTransactionRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. name of state store. - StoreName string `protobuf:"bytes,1,opt,name=storeName,proto3" json:"storeName,omitempty"` - // Required. transactional operation list. - Operations []*TransactionalStateOperation `protobuf:"bytes,2,rep,name=operations,proto3" json:"operations,omitempty"` - // The metadata used for transactional operations. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *ExecuteStateTransactionRequest) Reset() { - *x = ExecuteStateTransactionRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[21] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ExecuteStateTransactionRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ExecuteStateTransactionRequest) ProtoMessage() {} - -func (x *ExecuteStateTransactionRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[21] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ExecuteStateTransactionRequest.ProtoReflect.Descriptor instead. -func (*ExecuteStateTransactionRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{21} -} - -func (x *ExecuteStateTransactionRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *ExecuteStateTransactionRequest) GetOperations() []*TransactionalStateOperation { - if x != nil { - return x.Operations - } - return nil -} - -func (x *ExecuteStateTransactionRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// RegisterActorTimerRequest is the message to register a timer for an actor of a given type and id. -type RegisterActorTimerRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Name string `protobuf:"bytes,3,opt,name=name,proto3" json:"name,omitempty"` - DueTime string `protobuf:"bytes,4,opt,name=due_time,json=dueTime,proto3" json:"due_time,omitempty"` - Period string `protobuf:"bytes,5,opt,name=period,proto3" json:"period,omitempty"` - Callback string `protobuf:"bytes,6,opt,name=callback,proto3" json:"callback,omitempty"` - Data []byte `protobuf:"bytes,7,opt,name=data,proto3" json:"data,omitempty"` - Ttl string `protobuf:"bytes,8,opt,name=ttl,proto3" json:"ttl,omitempty"` -} - -func (x *RegisterActorTimerRequest) Reset() { - *x = RegisterActorTimerRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[22] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RegisterActorTimerRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RegisterActorTimerRequest) ProtoMessage() {} - -func (x *RegisterActorTimerRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[22] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RegisterActorTimerRequest.ProtoReflect.Descriptor instead. -func (*RegisterActorTimerRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{22} -} - -func (x *RegisterActorTimerRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *RegisterActorTimerRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *RegisterActorTimerRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -func (x *RegisterActorTimerRequest) GetDueTime() string { - if x != nil { - return x.DueTime - } - return "" -} - -func (x *RegisterActorTimerRequest) GetPeriod() string { - if x != nil { - return x.Period - } - return "" -} - -func (x *RegisterActorTimerRequest) GetCallback() string { - if x != nil { - return x.Callback - } - return "" -} - -func (x *RegisterActorTimerRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *RegisterActorTimerRequest) GetTtl() string { - if x != nil { - return x.Ttl - } - return "" -} - -// UnregisterActorTimerRequest is the message to unregister an actor timer -type UnregisterActorTimerRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Name string `protobuf:"bytes,3,opt,name=name,proto3" json:"name,omitempty"` -} - -func (x *UnregisterActorTimerRequest) Reset() { - *x = UnregisterActorTimerRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[23] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *UnregisterActorTimerRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*UnregisterActorTimerRequest) ProtoMessage() {} - -func (x *UnregisterActorTimerRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[23] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use UnregisterActorTimerRequest.ProtoReflect.Descriptor instead. -func (*UnregisterActorTimerRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{23} -} - -func (x *UnregisterActorTimerRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *UnregisterActorTimerRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *UnregisterActorTimerRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -// RegisterActorReminderRequest is the message to register a reminder for an actor of a given type and id. -type RegisterActorReminderRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Name string `protobuf:"bytes,3,opt,name=name,proto3" json:"name,omitempty"` - DueTime string `protobuf:"bytes,4,opt,name=due_time,json=dueTime,proto3" json:"due_time,omitempty"` - Period string `protobuf:"bytes,5,opt,name=period,proto3" json:"period,omitempty"` - Data []byte `protobuf:"bytes,6,opt,name=data,proto3" json:"data,omitempty"` - Ttl string `protobuf:"bytes,7,opt,name=ttl,proto3" json:"ttl,omitempty"` -} - -func (x *RegisterActorReminderRequest) Reset() { - *x = RegisterActorReminderRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[24] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RegisterActorReminderRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RegisterActorReminderRequest) ProtoMessage() {} - -func (x *RegisterActorReminderRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[24] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RegisterActorReminderRequest.ProtoReflect.Descriptor instead. -func (*RegisterActorReminderRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{24} -} - -func (x *RegisterActorReminderRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *RegisterActorReminderRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *RegisterActorReminderRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -func (x *RegisterActorReminderRequest) GetDueTime() string { - if x != nil { - return x.DueTime - } - return "" -} - -func (x *RegisterActorReminderRequest) GetPeriod() string { - if x != nil { - return x.Period - } - return "" -} - -func (x *RegisterActorReminderRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -func (x *RegisterActorReminderRequest) GetTtl() string { - if x != nil { - return x.Ttl - } - return "" -} - -// UnregisterActorReminderRequest is the message to unregister an actor reminder. -type UnregisterActorReminderRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Name string `protobuf:"bytes,3,opt,name=name,proto3" json:"name,omitempty"` -} - -func (x *UnregisterActorReminderRequest) Reset() { - *x = UnregisterActorReminderRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[25] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *UnregisterActorReminderRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*UnregisterActorReminderRequest) ProtoMessage() {} - -func (x *UnregisterActorReminderRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[25] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use UnregisterActorReminderRequest.ProtoReflect.Descriptor instead. -func (*UnregisterActorReminderRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{25} -} - -func (x *UnregisterActorReminderRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *UnregisterActorReminderRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *UnregisterActorReminderRequest) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -// GetActorStateRequest is the message to get key-value states from specific actor. -type GetActorStateRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Key string `protobuf:"bytes,3,opt,name=key,proto3" json:"key,omitempty"` -} - -func (x *GetActorStateRequest) Reset() { - *x = GetActorStateRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[26] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetActorStateRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetActorStateRequest) ProtoMessage() {} - -func (x *GetActorStateRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[26] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetActorStateRequest.ProtoReflect.Descriptor instead. -func (*GetActorStateRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{26} -} - -func (x *GetActorStateRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *GetActorStateRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *GetActorStateRequest) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -// GetActorStateResponse is the response conveying the actor's state value. -type GetActorStateResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"` -} - -func (x *GetActorStateResponse) Reset() { - *x = GetActorStateResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[27] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetActorStateResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetActorStateResponse) ProtoMessage() {} - -func (x *GetActorStateResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[27] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetActorStateResponse.ProtoReflect.Descriptor instead. -func (*GetActorStateResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{27} -} - -func (x *GetActorStateResponse) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -// ExecuteActorStateTransactionRequest is the message to execute multiple operations on a specified actor. -type ExecuteActorStateTransactionRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Operations []*TransactionalActorStateOperation `protobuf:"bytes,3,rep,name=operations,proto3" json:"operations,omitempty"` -} - -func (x *ExecuteActorStateTransactionRequest) Reset() { - *x = ExecuteActorStateTransactionRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[28] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ExecuteActorStateTransactionRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ExecuteActorStateTransactionRequest) ProtoMessage() {} - -func (x *ExecuteActorStateTransactionRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[28] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ExecuteActorStateTransactionRequest.ProtoReflect.Descriptor instead. -func (*ExecuteActorStateTransactionRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{28} -} - -func (x *ExecuteActorStateTransactionRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *ExecuteActorStateTransactionRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *ExecuteActorStateTransactionRequest) GetOperations() []*TransactionalActorStateOperation { - if x != nil { - return x.Operations - } - return nil -} - -// TransactionalAcorStateOperation is the message to execute a specified operation with a key-value pair. -type TransactionalActorStateOperation struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - OperationType string `protobuf:"bytes,1,opt,name=operationType,proto3" json:"operationType,omitempty"` - Key string `protobuf:"bytes,2,opt,name=key,proto3" json:"key,omitempty"` - Value *anypb.Any `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"` -} - -func (x *TransactionalActorStateOperation) Reset() { - *x = TransactionalActorStateOperation{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[29] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *TransactionalActorStateOperation) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*TransactionalActorStateOperation) ProtoMessage() {} - -func (x *TransactionalActorStateOperation) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[29] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use TransactionalActorStateOperation.ProtoReflect.Descriptor instead. -func (*TransactionalActorStateOperation) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{29} -} - -func (x *TransactionalActorStateOperation) GetOperationType() string { - if x != nil { - return x.OperationType - } - return "" -} - -func (x *TransactionalActorStateOperation) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *TransactionalActorStateOperation) GetValue() *anypb.Any { - if x != nil { - return x.Value - } - return nil -} - -// InvokeActorRequest is the message to call an actor. -type InvokeActorRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - ActorType string `protobuf:"bytes,1,opt,name=actor_type,json=actorType,proto3" json:"actor_type,omitempty"` - ActorId string `protobuf:"bytes,2,opt,name=actor_id,json=actorId,proto3" json:"actor_id,omitempty"` - Method string `protobuf:"bytes,3,opt,name=method,proto3" json:"method,omitempty"` - Data []byte `protobuf:"bytes,4,opt,name=data,proto3" json:"data,omitempty"` -} - -func (x *InvokeActorRequest) Reset() { - *x = InvokeActorRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[30] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeActorRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeActorRequest) ProtoMessage() {} - -func (x *InvokeActorRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[30] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeActorRequest.ProtoReflect.Descriptor instead. -func (*InvokeActorRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{30} -} - -func (x *InvokeActorRequest) GetActorType() string { - if x != nil { - return x.ActorType - } - return "" -} - -func (x *InvokeActorRequest) GetActorId() string { - if x != nil { - return x.ActorId - } - return "" -} - -func (x *InvokeActorRequest) GetMethod() string { - if x != nil { - return x.Method - } - return "" -} - -func (x *InvokeActorRequest) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -// InvokeActorResponse is the method that returns an actor invocation response. -type InvokeActorResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"` -} - -func (x *InvokeActorResponse) Reset() { - *x = InvokeActorResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[31] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *InvokeActorResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*InvokeActorResponse) ProtoMessage() {} - -func (x *InvokeActorResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[31] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use InvokeActorResponse.ProtoReflect.Descriptor instead. -func (*InvokeActorResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{31} -} - -func (x *InvokeActorResponse) GetData() []byte { - if x != nil { - return x.Data - } - return nil -} - -// GetMetadataResponse is a message that is returned on GetMetadata rpc call -type GetMetadataResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"` - ActiveActorsCount []*ActiveActorsCount `protobuf:"bytes,2,rep,name=active_actors_count,json=activeActorsCount,proto3" json:"active_actors_count,omitempty"` - RegisteredComponents []*RegisteredComponents `protobuf:"bytes,3,rep,name=registered_components,json=registeredComponents,proto3" json:"registered_components,omitempty"` - ExtendedMetadata map[string]string `protobuf:"bytes,4,rep,name=extended_metadata,json=extendedMetadata,proto3" json:"extended_metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetMetadataResponse) Reset() { - *x = GetMetadataResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[32] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetMetadataResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetMetadataResponse) ProtoMessage() {} - -func (x *GetMetadataResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[32] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetMetadataResponse.ProtoReflect.Descriptor instead. -func (*GetMetadataResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{32} -} - -func (x *GetMetadataResponse) GetId() string { - if x != nil { - return x.Id - } - return "" -} - -func (x *GetMetadataResponse) GetActiveActorsCount() []*ActiveActorsCount { - if x != nil { - return x.ActiveActorsCount - } - return nil -} - -func (x *GetMetadataResponse) GetRegisteredComponents() []*RegisteredComponents { - if x != nil { - return x.RegisteredComponents - } - return nil -} - -func (x *GetMetadataResponse) GetExtendedMetadata() map[string]string { - if x != nil { - return x.ExtendedMetadata - } - return nil -} - -type ActiveActorsCount struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Type string `protobuf:"bytes,1,opt,name=type,proto3" json:"type,omitempty"` - Count int32 `protobuf:"varint,2,opt,name=count,proto3" json:"count,omitempty"` -} - -func (x *ActiveActorsCount) Reset() { - *x = ActiveActorsCount{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[33] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *ActiveActorsCount) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*ActiveActorsCount) ProtoMessage() {} - -func (x *ActiveActorsCount) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[33] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use ActiveActorsCount.ProtoReflect.Descriptor instead. -func (*ActiveActorsCount) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{33} -} - -func (x *ActiveActorsCount) GetType() string { - if x != nil { - return x.Type - } - return "" -} - -func (x *ActiveActorsCount) GetCount() int32 { - if x != nil { - return x.Count - } - return 0 -} - -type RegisteredComponents struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` - Type string `protobuf:"bytes,2,opt,name=type,proto3" json:"type,omitempty"` - Version string `protobuf:"bytes,3,opt,name=version,proto3" json:"version,omitempty"` -} - -func (x *RegisteredComponents) Reset() { - *x = RegisteredComponents{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[34] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *RegisteredComponents) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*RegisteredComponents) ProtoMessage() {} - -func (x *RegisteredComponents) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[34] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use RegisteredComponents.ProtoReflect.Descriptor instead. -func (*RegisteredComponents) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{34} -} - -func (x *RegisteredComponents) GetName() string { - if x != nil { - return x.Name - } - return "" -} - -func (x *RegisteredComponents) GetType() string { - if x != nil { - return x.Type - } - return "" -} - -func (x *RegisteredComponents) GetVersion() string { - if x != nil { - return x.Version - } - return "" -} - -type SetMetadataRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` - Value string `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"` -} - -func (x *SetMetadataRequest) Reset() { - *x = SetMetadataRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[35] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *SetMetadataRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*SetMetadataRequest) ProtoMessage() {} - -func (x *SetMetadataRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[35] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use SetMetadataRequest.ProtoReflect.Descriptor instead. -func (*SetMetadataRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{35} -} - -func (x *SetMetadataRequest) GetKey() string { - if x != nil { - return x.Key - } - return "" -} - -func (x *SetMetadataRequest) GetValue() string { - if x != nil { - return x.Value - } - return "" -} - -// GetConfigurationRequest is the message to get a list of key-value configuration from specified configuration store. -type GetConfigurationRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // Required. The name of configuration store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // Optional. The key of the configuration item to fetch. - // If set, only query for the specified configuration items. - // Empty list means fetch all. - Keys []string `protobuf:"bytes,2,rep,name=keys,proto3" json:"keys,omitempty"` - // Optional. The metadata which will be sent to configuration store components. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *GetConfigurationRequest) Reset() { - *x = GetConfigurationRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[36] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetConfigurationRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetConfigurationRequest) ProtoMessage() {} - -func (x *GetConfigurationRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[36] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetConfigurationRequest.ProtoReflect.Descriptor instead. -func (*GetConfigurationRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{36} -} - -func (x *GetConfigurationRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *GetConfigurationRequest) GetKeys() []string { - if x != nil { - return x.Keys - } - return nil -} - -func (x *GetConfigurationRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -// GetConfigurationResponse is the response conveying the list of configuration values. -// It should be the FULL configuration of specified application which contains all of its configuration items. -type GetConfigurationResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - Items []*v1.ConfigurationItem `protobuf:"bytes,1,rep,name=items,proto3" json:"items,omitempty"` -} - -func (x *GetConfigurationResponse) Reset() { - *x = GetConfigurationResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[37] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *GetConfigurationResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*GetConfigurationResponse) ProtoMessage() {} - -func (x *GetConfigurationResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[37] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use GetConfigurationResponse.ProtoReflect.Descriptor instead. -func (*GetConfigurationResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{37} -} - -func (x *GetConfigurationResponse) GetItems() []*v1.ConfigurationItem { - if x != nil { - return x.Items - } - return nil -} - -// SubscribeConfigurationRequest is the message to get a list of key-value configuration from specified configuration store. -type SubscribeConfigurationRequest struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The name of configuration store. - StoreName string `protobuf:"bytes,1,opt,name=store_name,json=storeName,proto3" json:"store_name,omitempty"` - // Optional. The key of the configuration item to fetch. - // If set, only query for the specified configuration items. - // Empty list means fetch all. - Keys []string `protobuf:"bytes,2,rep,name=keys,proto3" json:"keys,omitempty"` - // The metadata which will be sent to configuration store components. - Metadata map[string]string `protobuf:"bytes,3,rep,name=metadata,proto3" json:"metadata,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` -} - -func (x *SubscribeConfigurationRequest) Reset() { - *x = SubscribeConfigurationRequest{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[38] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *SubscribeConfigurationRequest) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*SubscribeConfigurationRequest) ProtoMessage() {} - -func (x *SubscribeConfigurationRequest) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[38] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use SubscribeConfigurationRequest.ProtoReflect.Descriptor instead. -func (*SubscribeConfigurationRequest) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{38} -} - -func (x *SubscribeConfigurationRequest) GetStoreName() string { - if x != nil { - return x.StoreName - } - return "" -} - -func (x *SubscribeConfigurationRequest) GetKeys() []string { - if x != nil { - return x.Keys - } - return nil -} - -func (x *SubscribeConfigurationRequest) GetMetadata() map[string]string { - if x != nil { - return x.Metadata - } - return nil -} - -type SubscribeConfigurationResponse struct { - state protoimpl.MessageState - sizeCache protoimpl.SizeCache - unknownFields protoimpl.UnknownFields - - // The list of items containing configuration values - Items []*v1.ConfigurationItem `protobuf:"bytes,1,rep,name=items,proto3" json:"items,omitempty"` -} - -func (x *SubscribeConfigurationResponse) Reset() { - *x = SubscribeConfigurationResponse{} - if protoimpl.UnsafeEnabled { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[39] - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - ms.StoreMessageInfo(mi) - } -} - -func (x *SubscribeConfigurationResponse) String() string { - return protoimpl.X.MessageStringOf(x) -} - -func (*SubscribeConfigurationResponse) ProtoMessage() {} - -func (x *SubscribeConfigurationResponse) ProtoReflect() protoreflect.Message { - mi := &file_dapr_proto_runtime_v1_dapr_proto_msgTypes[39] - if protoimpl.UnsafeEnabled && x != nil { - ms := protoimpl.X.MessageStateOf(protoimpl.Pointer(x)) - if ms.LoadMessageInfo() == nil { - ms.StoreMessageInfo(mi) - } - return ms - } - return mi.MessageOf(x) -} - -// Deprecated: Use SubscribeConfigurationResponse.ProtoReflect.Descriptor instead. -func (*SubscribeConfigurationResponse) Descriptor() ([]byte, []int) { - return file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP(), []int{39} -} - -func (x *SubscribeConfigurationResponse) GetItems() []*v1.ConfigurationItem { - if x != nil { - return x.Items - } - return nil -} - -var File_dapr_proto_runtime_v1_dapr_proto protoreflect.FileDescriptor - -var file_dapr_proto_runtime_v1_dapr_proto_rawDesc = []byte{ - 0x0a, 0x20, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x72, 0x75, 0x6e, - 0x74, 0x69, 0x6d, 0x65, 0x2f, 0x76, 0x31, 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x12, 0x15, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, - 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x1a, 0x19, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x61, 0x6e, 0x79, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x1a, 0x1b, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2f, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2f, 0x65, 0x6d, 0x70, 0x74, 0x79, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x1a, 0x21, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2f, 0x63, 0x6f, - 0x6d, 0x6d, 0x6f, 0x6e, 0x2f, 0x76, 0x31, 0x2f, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x22, 0x65, 0x0a, 0x14, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x53, 0x65, - 0x72, 0x76, 0x69, 0x63, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x0e, 0x0a, 0x02, - 0x69, 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x02, 0x69, 0x64, 0x12, 0x3d, 0x0a, 0x07, - 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x23, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, - 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x52, 0x07, 0x6d, 0x65, 0x73, 0x73, 0x61, 0x67, 0x65, 0x22, 0xa8, 0x02, 0x0a, 0x0f, - 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, - 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x10, - 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, - 0x12, 0x55, 0x0a, 0x0b, 0x63, 0x6f, 0x6e, 0x73, 0x69, 0x73, 0x74, 0x65, 0x6e, 0x63, 0x79, 0x18, - 0x03, 0x20, 0x01, 0x28, 0x0e, 0x32, 0x33, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, - 0x74, 0x65, 0x4f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x43, - 0x6f, 0x6e, 0x73, 0x69, 0x73, 0x74, 0x65, 0x6e, 0x63, 0x79, 0x52, 0x0b, 0x63, 0x6f, 0x6e, 0x73, - 0x69, 0x73, 0x74, 0x65, 0x6e, 0x63, 0x79, 0x12, 0x50, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x34, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xfd, 0x01, 0x0a, 0x13, 0x47, 0x65, 0x74, 0x42, 0x75, - 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, - 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, - 0x04, 0x6b, 0x65, 0x79, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x09, 0x52, 0x04, 0x6b, 0x65, 0x79, - 0x73, 0x12, 0x20, 0x0a, 0x0b, 0x70, 0x61, 0x72, 0x61, 0x6c, 0x6c, 0x65, 0x6c, 0x69, 0x73, 0x6d, - 0x18, 0x03, 0x20, 0x01, 0x28, 0x05, 0x52, 0x0b, 0x70, 0x61, 0x72, 0x61, 0x6c, 0x6c, 0x65, 0x6c, - 0x69, 0x73, 0x6d, 0x12, 0x54, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, - 0x04, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x38, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, - 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x52, 0x0a, 0x14, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, - 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x3a, - 0x0a, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x24, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, - 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, - 0x74, 0x65, 0x6d, 0x52, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x22, 0xec, 0x01, 0x0a, 0x0d, 0x42, - 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x12, - 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, - 0x74, 0x61, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x14, 0x0a, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x18, - 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x12, 0x4e, 0x0a, 0x08, - 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x05, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x32, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, - 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, - 0x49, 0x74, 0x65, 0x6d, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, - 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, - 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, - 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, - 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xca, 0x01, 0x0a, 0x10, 0x47, 0x65, - 0x74, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x12, - 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, - 0x74, 0x61, 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x51, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x35, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, - 0x2e, 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xc5, 0x02, 0x0a, 0x12, 0x44, 0x65, 0x6c, 0x65, 0x74, - 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, - 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x2e, - 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1a, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, - 0x2e, 0x76, 0x31, 0x2e, 0x45, 0x74, 0x61, 0x67, 0x52, 0x04, 0x65, 0x74, 0x61, 0x67, 0x12, 0x3c, - 0x0a, 0x07, 0x6f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x04, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x22, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, - 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x52, 0x07, 0x6f, 0x70, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x12, 0x53, 0x0a, 0x08, - 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x05, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x37, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, - 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x53, 0x74, 0x61, - 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, - 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, - 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, - 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x70, - 0x0a, 0x16, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, - 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, - 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, - 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x37, 0x0a, 0x06, 0x73, 0x74, 0x61, 0x74, 0x65, - 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x1f, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, - 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x06, 0x73, 0x74, 0x61, 0x74, 0x65, 0x73, - 0x22, 0x6a, 0x0a, 0x10, 0x53, 0x61, 0x76, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, - 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, - 0x61, 0x6d, 0x65, 0x12, 0x37, 0x0a, 0x06, 0x73, 0x74, 0x61, 0x74, 0x65, 0x73, 0x18, 0x02, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x1f, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, 0x65, - 0x49, 0x74, 0x65, 0x6d, 0x52, 0x06, 0x73, 0x74, 0x61, 0x74, 0x65, 0x73, 0x22, 0xd9, 0x01, 0x0a, - 0x11, 0x51, 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, - 0x65, 0x12, 0x14, 0x0a, 0x05, 0x71, 0x75, 0x65, 0x72, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x05, 0x71, 0x75, 0x65, 0x72, 0x79, 0x12, 0x52, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x36, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x51, 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, - 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, - 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x60, 0x0a, 0x0e, 0x51, 0x75, 0x65, 0x72, - 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x12, 0x0a, 0x04, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, - 0x12, 0x12, 0x0a, 0x04, 0x65, 0x74, 0x61, 0x67, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, - 0x65, 0x74, 0x61, 0x67, 0x12, 0x14, 0x0a, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x18, 0x04, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x05, 0x65, 0x72, 0x72, 0x6f, 0x72, 0x22, 0xfd, 0x01, 0x0a, 0x12, 0x51, - 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, - 0x65, 0x12, 0x3f, 0x0a, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, - 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x51, 0x75, 0x65, 0x72, 0x79, - 0x53, 0x74, 0x61, 0x74, 0x65, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x07, 0x72, 0x65, 0x73, 0x75, 0x6c, - 0x74, 0x73, 0x12, 0x14, 0x0a, 0x05, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x05, 0x74, 0x6f, 0x6b, 0x65, 0x6e, 0x12, 0x53, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x37, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x51, 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, - 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, - 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, - 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, - 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x9f, 0x02, 0x0a, 0x13, 0x50, - 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x12, 0x1f, 0x0a, 0x0b, 0x70, 0x75, 0x62, 0x73, 0x75, 0x62, 0x5f, 0x6e, 0x61, 0x6d, - 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0a, 0x70, 0x75, 0x62, 0x73, 0x75, 0x62, 0x4e, - 0x61, 0x6d, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x05, 0x74, 0x6f, 0x70, 0x69, 0x63, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, - 0x61, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x2a, 0x0a, - 0x11, 0x64, 0x61, 0x74, 0x61, 0x5f, 0x63, 0x6f, 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x5f, 0x74, 0x79, - 0x70, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x0f, 0x64, 0x61, 0x74, 0x61, 0x43, 0x6f, - 0x6e, 0x74, 0x65, 0x6e, 0x74, 0x54, 0x79, 0x70, 0x65, 0x12, 0x54, 0x0a, 0x08, 0x6d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x05, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x38, 0x2e, 0x64, 0x61, - 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, - 0x2e, 0x76, 0x31, 0x2e, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, - 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, - 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, - 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, - 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xf0, 0x01, 0x0a, - 0x14, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, - 0x61, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x55, 0x0a, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, - 0x39, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, - 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, - 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x12, 0x1c, 0x0a, 0x09, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, - 0x6e, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, - 0xc0, 0x01, 0x0a, 0x15, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, - 0x67, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, - 0x61, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x56, 0x0a, - 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, - 0x3a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, - 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, - 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x4d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, - 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, - 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, - 0x38, 0x01, 0x22, 0xd3, 0x01, 0x0a, 0x10, 0x47, 0x65, 0x74, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, - 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, - 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, - 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x51, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x35, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, - 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, - 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x94, 0x01, 0x0a, 0x11, 0x47, 0x65, 0x74, - 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x46, - 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x44, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, - 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x37, 0x0a, 0x09, 0x44, 0x61, 0x74, 0x61, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, - 0xc9, 0x01, 0x0a, 0x14, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, 0x72, 0x65, - 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, - 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, - 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x55, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x39, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, - 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, - 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, - 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, - 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x9a, 0x01, 0x0a, 0x0e, - 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x4c, - 0x0a, 0x07, 0x73, 0x65, 0x63, 0x72, 0x65, 0x74, 0x73, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, - 0x32, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, - 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, - 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x73, 0x45, 0x6e, - 0x74, 0x72, 0x79, 0x52, 0x07, 0x73, 0x65, 0x63, 0x72, 0x65, 0x74, 0x73, 0x1a, 0x3a, 0x0a, 0x0c, - 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x73, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, - 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0xc3, 0x01, 0x0a, 0x15, 0x47, 0x65, 0x74, - 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x12, 0x4a, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, - 0x32, 0x36, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, - 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x44, - 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x5e, - 0x0a, 0x09, 0x44, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, - 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x3b, 0x0a, - 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x0b, 0x32, 0x25, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, - 0x6e, 0x73, 0x65, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x7e, - 0x0a, 0x1b, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x61, 0x6c, 0x53, - 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x24, 0x0a, - 0x0d, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x0d, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x54, - 0x79, 0x70, 0x65, 0x12, 0x39, 0x0a, 0x07, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x0b, 0x32, 0x1f, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x74, 0x61, 0x74, - 0x65, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x07, 0x72, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x22, 0xb0, - 0x02, 0x0a, 0x1e, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, - 0x72, 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x12, 0x1c, 0x0a, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, - 0x52, 0x0a, 0x0a, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x02, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x32, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x72, 0x61, 0x6e, - 0x73, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x61, 0x6c, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0a, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x12, 0x5f, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, - 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x43, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x45, 0x78, - 0x65, 0x63, 0x75, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, - 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, - 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, - 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, - 0x01, 0x22, 0xde, 0x01, 0x0a, 0x19, 0x52, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, - 0x74, 0x6f, 0x72, 0x54, 0x69, 0x6d, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, - 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, 0x12, 0x19, - 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, - 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x19, 0x0a, - 0x08, 0x64, 0x75, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x07, 0x64, 0x75, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x16, 0x0a, 0x06, 0x70, 0x65, 0x72, 0x69, - 0x6f, 0x64, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x70, 0x65, 0x72, 0x69, 0x6f, 0x64, - 0x12, 0x1a, 0x0a, 0x08, 0x63, 0x61, 0x6c, 0x6c, 0x62, 0x61, 0x63, 0x6b, 0x18, 0x06, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x08, 0x63, 0x61, 0x6c, 0x6c, 0x62, 0x61, 0x63, 0x6b, 0x12, 0x12, 0x0a, 0x04, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x07, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, - 0x12, 0x10, 0x0a, 0x03, 0x74, 0x74, 0x6c, 0x18, 0x08, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x74, - 0x74, 0x6c, 0x22, 0x6b, 0x0a, 0x1b, 0x55, 0x6e, 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, - 0x41, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x69, 0x6d, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, - 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, - 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, - 0x12, 0x19, 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x6e, - 0x61, 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, - 0xc5, 0x01, 0x0a, 0x1c, 0x52, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, - 0x72, 0x52, 0x65, 0x6d, 0x69, 0x6e, 0x64, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, 0x12, - 0x19, 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, - 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x19, - 0x0a, 0x08, 0x64, 0x75, 0x65, 0x5f, 0x74, 0x69, 0x6d, 0x65, 0x18, 0x04, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x07, 0x64, 0x75, 0x65, 0x54, 0x69, 0x6d, 0x65, 0x12, 0x16, 0x0a, 0x06, 0x70, 0x65, 0x72, - 0x69, 0x6f, 0x64, 0x18, 0x05, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x70, 0x65, 0x72, 0x69, 0x6f, - 0x64, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x06, 0x20, 0x01, 0x28, 0x0c, 0x52, - 0x04, 0x64, 0x61, 0x74, 0x61, 0x12, 0x10, 0x0a, 0x03, 0x74, 0x74, 0x6c, 0x18, 0x07, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x03, 0x74, 0x74, 0x6c, 0x22, 0x6e, 0x0a, 0x1e, 0x55, 0x6e, 0x72, 0x65, 0x67, - 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x6d, 0x69, 0x6e, 0x64, - 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, - 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, - 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, 0x12, 0x19, 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, - 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, - 0x72, 0x49, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x22, 0x62, 0x0a, 0x14, 0x47, 0x65, 0x74, 0x41, 0x63, - 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, - 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, 0x12, 0x19, - 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, - 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x22, 0x2b, 0x0a, 0x15, 0x47, - 0x65, 0x74, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x22, 0xb8, 0x01, 0x0a, 0x23, 0x45, 0x78, 0x65, - 0x63, 0x75, 0x74, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, - 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x12, 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, 0x65, 0x12, - 0x19, 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, 0x01, 0x28, - 0x09, 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x57, 0x0a, 0x0a, 0x6f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x73, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x37, - 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, - 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, 0x69, - 0x6f, 0x6e, 0x61, 0x6c, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, 0x70, - 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x0a, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, - 0x6f, 0x6e, 0x73, 0x22, 0x86, 0x01, 0x0a, 0x20, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, - 0x69, 0x6f, 0x6e, 0x61, 0x6c, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x4f, - 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x24, 0x0a, 0x0d, 0x6f, 0x70, 0x65, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, - 0x0d, 0x6f, 0x70, 0x65, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x54, 0x79, 0x70, 0x65, 0x12, 0x10, - 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, - 0x12, 0x2a, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x03, 0x20, 0x01, 0x28, 0x0b, 0x32, - 0x14, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, - 0x66, 0x2e, 0x41, 0x6e, 0x79, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x22, 0x7a, 0x0a, 0x12, - 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x74, 0x79, 0x70, 0x65, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x79, 0x70, - 0x65, 0x12, 0x19, 0x0a, 0x08, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x5f, 0x69, 0x64, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x09, 0x52, 0x07, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x49, 0x64, 0x12, 0x16, 0x0a, 0x06, - 0x6d, 0x65, 0x74, 0x68, 0x6f, 0x64, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x06, 0x6d, 0x65, - 0x74, 0x68, 0x6f, 0x64, 0x12, 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, 0x01, - 0x28, 0x0c, 0x52, 0x04, 0x64, 0x61, 0x74, 0x61, 0x22, 0x29, 0x0a, 0x13, 0x49, 0x6e, 0x76, 0x6f, - 0x6b, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, - 0x12, 0x0a, 0x04, 0x64, 0x61, 0x74, 0x61, 0x18, 0x01, 0x20, 0x01, 0x28, 0x0c, 0x52, 0x04, 0x64, - 0x61, 0x74, 0x61, 0x22, 0x95, 0x03, 0x0a, 0x13, 0x47, 0x65, 0x74, 0x4d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x0e, 0x0a, 0x02, 0x69, - 0x64, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x02, 0x69, 0x64, 0x12, 0x58, 0x0a, 0x13, 0x61, - 0x63, 0x74, 0x69, 0x76, 0x65, 0x5f, 0x61, 0x63, 0x74, 0x6f, 0x72, 0x73, 0x5f, 0x63, 0x6f, 0x75, - 0x6e, 0x74, 0x18, 0x02, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x28, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, - 0x2e, 0x41, 0x63, 0x74, 0x69, 0x76, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x73, 0x43, 0x6f, 0x75, - 0x6e, 0x74, 0x52, 0x11, 0x61, 0x63, 0x74, 0x69, 0x76, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x73, - 0x43, 0x6f, 0x75, 0x6e, 0x74, 0x12, 0x60, 0x0a, 0x15, 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, - 0x72, 0x65, 0x64, 0x5f, 0x63, 0x6f, 0x6d, 0x70, 0x6f, 0x6e, 0x65, 0x6e, 0x74, 0x73, 0x18, 0x03, - 0x20, 0x03, 0x28, 0x0b, 0x32, 0x2b, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x65, 0x67, - 0x69, 0x73, 0x74, 0x65, 0x72, 0x65, 0x64, 0x43, 0x6f, 0x6d, 0x70, 0x6f, 0x6e, 0x65, 0x6e, 0x74, - 0x73, 0x52, 0x14, 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x65, 0x64, 0x43, 0x6f, 0x6d, - 0x70, 0x6f, 0x6e, 0x65, 0x6e, 0x74, 0x73, 0x12, 0x6d, 0x0a, 0x11, 0x65, 0x78, 0x74, 0x65, 0x6e, - 0x64, 0x65, 0x64, 0x5f, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x04, 0x20, 0x03, - 0x28, 0x0b, 0x32, 0x40, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, - 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x4d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x2e, 0x45, - 0x78, 0x74, 0x65, 0x6e, 0x64, 0x65, 0x64, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, - 0x6e, 0x74, 0x72, 0x79, 0x52, 0x10, 0x65, 0x78, 0x74, 0x65, 0x6e, 0x64, 0x65, 0x64, 0x4d, 0x65, - 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x43, 0x0a, 0x15, 0x45, 0x78, 0x74, 0x65, 0x6e, 0x64, - 0x65, 0x64, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, - 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, - 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x3d, 0x0a, 0x11, 0x41, - 0x63, 0x74, 0x69, 0x76, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x73, 0x43, 0x6f, 0x75, 0x6e, 0x74, - 0x12, 0x12, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, - 0x74, 0x79, 0x70, 0x65, 0x12, 0x14, 0x0a, 0x05, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x18, 0x02, 0x20, - 0x01, 0x28, 0x05, 0x52, 0x05, 0x63, 0x6f, 0x75, 0x6e, 0x74, 0x22, 0x58, 0x0a, 0x14, 0x52, 0x65, - 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x65, 0x64, 0x43, 0x6f, 0x6d, 0x70, 0x6f, 0x6e, 0x65, 0x6e, - 0x74, 0x73, 0x12, 0x12, 0x0a, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, - 0x52, 0x04, 0x6e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x74, 0x79, 0x70, 0x65, 0x18, 0x02, - 0x20, 0x01, 0x28, 0x09, 0x52, 0x04, 0x74, 0x79, 0x70, 0x65, 0x12, 0x18, 0x0a, 0x07, 0x76, 0x65, - 0x72, 0x73, 0x69, 0x6f, 0x6e, 0x18, 0x03, 0x20, 0x01, 0x28, 0x09, 0x52, 0x07, 0x76, 0x65, 0x72, - 0x73, 0x69, 0x6f, 0x6e, 0x22, 0x3c, 0x0a, 0x12, 0x53, 0x65, 0x74, 0x4d, 0x65, 0x74, 0x61, 0x64, - 0x61, 0x74, 0x61, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, - 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, - 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, - 0x75, 0x65, 0x22, 0xe3, 0x01, 0x0a, 0x17, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, - 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, - 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, - 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, - 0x04, 0x6b, 0x65, 0x79, 0x73, 0x18, 0x02, 0x20, 0x03, 0x28, 0x09, 0x52, 0x04, 0x6b, 0x65, 0x79, - 0x73, 0x12, 0x58, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x3c, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, - 0x65, 0x73, 0x74, 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, - 0x79, 0x52, 0x08, 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, - 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, - 0x6b, 0x65, 0x79, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, - 0x0a, 0x05, 0x76, 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x59, 0x0a, 0x18, 0x47, 0x65, 0x74, 0x43, - 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x3d, 0x0a, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x18, 0x01, 0x20, - 0x03, 0x28, 0x0b, 0x32, 0x27, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x6f, 0x6e, 0x66, 0x69, - 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x49, 0x74, 0x65, 0x6d, 0x52, 0x05, 0x69, 0x74, - 0x65, 0x6d, 0x73, 0x22, 0xef, 0x01, 0x0a, 0x1d, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x62, - 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x12, 0x1d, 0x0a, 0x0a, 0x73, 0x74, 0x6f, 0x72, 0x65, 0x5f, 0x6e, - 0x61, 0x6d, 0x65, 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x09, 0x73, 0x74, 0x6f, 0x72, 0x65, - 0x4e, 0x61, 0x6d, 0x65, 0x12, 0x12, 0x0a, 0x04, 0x6b, 0x65, 0x79, 0x73, 0x18, 0x02, 0x20, 0x03, - 0x28, 0x09, 0x52, 0x04, 0x6b, 0x65, 0x79, 0x73, 0x12, 0x5e, 0x0a, 0x08, 0x6d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x18, 0x03, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x42, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x62, 0x65, 0x43, 0x6f, 0x6e, 0x66, - 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x2e, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x52, 0x08, - 0x6d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x1a, 0x3b, 0x0a, 0x0d, 0x4d, 0x65, 0x74, 0x61, - 0x64, 0x61, 0x74, 0x61, 0x45, 0x6e, 0x74, 0x72, 0x79, 0x12, 0x10, 0x0a, 0x03, 0x6b, 0x65, 0x79, - 0x18, 0x01, 0x20, 0x01, 0x28, 0x09, 0x52, 0x03, 0x6b, 0x65, 0x79, 0x12, 0x14, 0x0a, 0x05, 0x76, - 0x61, 0x6c, 0x75, 0x65, 0x18, 0x02, 0x20, 0x01, 0x28, 0x09, 0x52, 0x05, 0x76, 0x61, 0x6c, 0x75, - 0x65, 0x3a, 0x02, 0x38, 0x01, 0x22, 0x5f, 0x0a, 0x1e, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, - 0x62, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x12, 0x3d, 0x0a, 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, - 0x18, 0x01, 0x20, 0x03, 0x28, 0x0b, 0x32, 0x27, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x43, 0x6f, - 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x49, 0x74, 0x65, 0x6d, 0x52, - 0x05, 0x69, 0x74, 0x65, 0x6d, 0x73, 0x32, 0xff, 0x12, 0x0a, 0x04, 0x44, 0x61, 0x70, 0x72, 0x12, - 0x64, 0x0a, 0x0d, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x53, 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, - 0x12, 0x2b, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x53, - 0x65, 0x72, 0x76, 0x69, 0x63, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x24, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x63, 0x6f, 0x6d, 0x6d, 0x6f, - 0x6e, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, - 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x5d, 0x0a, 0x08, 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, 0x74, - 0x65, 0x12, 0x26, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, - 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, - 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x27, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x22, 0x00, 0x12, 0x69, 0x0a, 0x0c, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, - 0x74, 0x61, 0x74, 0x65, 0x12, 0x2a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, - 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x2b, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, - 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, - 0x4e, 0x0a, 0x09, 0x53, 0x61, 0x76, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x27, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x61, 0x76, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, - 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, - 0x69, 0x0a, 0x10, 0x51, 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x41, 0x6c, 0x70, - 0x68, 0x61, 0x31, 0x12, 0x28, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, - 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x51, 0x75, 0x65, 0x72, - 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x29, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, - 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x51, 0x75, 0x65, 0x72, 0x79, 0x53, 0x74, 0x61, 0x74, 0x65, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x52, 0x0a, 0x0b, 0x44, 0x65, - 0x6c, 0x65, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x29, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x5a, - 0x0a, 0x0f, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, - 0x65, 0x12, 0x2d, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, - 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x44, 0x65, 0x6c, 0x65, 0x74, 0x65, - 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x6a, 0x0a, 0x17, 0x45, 0x78, - 0x65, 0x63, 0x75, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, - 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x35, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x45, 0x78, - 0x65, 0x63, 0x75, 0x74, 0x65, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, - 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, - 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x54, 0x0a, 0x0c, 0x50, 0x75, 0x62, 0x6c, 0x69, 0x73, - 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x12, 0x2a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x50, - 0x75, 0x62, 0x6c, 0x69, 0x73, 0x68, 0x45, 0x76, 0x65, 0x6e, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x6c, 0x0a, 0x0d, - 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, 0x12, 0x2b, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, - 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, 0x6e, 0x64, - 0x69, 0x6e, 0x67, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2c, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x42, 0x69, 0x6e, 0x64, 0x69, 0x6e, 0x67, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x60, 0x0a, 0x09, 0x47, 0x65, - 0x74, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x12, 0x27, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, - 0x47, 0x65, 0x74, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x28, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x53, 0x65, 0x63, 0x72, - 0x65, 0x74, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x6c, 0x0a, 0x0d, - 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, 0x12, 0x2b, 0x2e, - 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, - 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, - 0x72, 0x65, 0x74, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2c, 0x2e, 0x64, 0x61, 0x70, - 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, - 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x42, 0x75, 0x6c, 0x6b, 0x53, 0x65, 0x63, 0x72, 0x65, 0x74, - 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x60, 0x0a, 0x12, 0x52, 0x65, - 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x69, 0x6d, 0x65, 0x72, - 0x12, 0x30, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, - 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x69, 0x6d, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, - 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x64, 0x0a, 0x14, - 0x55, 0x6e, 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x54, - 0x69, 0x6d, 0x65, 0x72, 0x12, 0x32, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x55, 0x6e, 0x72, - 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x54, 0x69, 0x6d, 0x65, - 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, - 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, - 0x22, 0x00, 0x12, 0x66, 0x0a, 0x15, 0x52, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, - 0x74, 0x6f, 0x72, 0x52, 0x65, 0x6d, 0x69, 0x6e, 0x64, 0x65, 0x72, 0x12, 0x33, 0x2e, 0x64, 0x61, - 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, - 0x2e, 0x76, 0x31, 0x2e, 0x52, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, - 0x72, 0x52, 0x65, 0x6d, 0x69, 0x6e, 0x64, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x6a, 0x0a, 0x17, 0x55, 0x6e, - 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x6d, - 0x69, 0x6e, 0x64, 0x65, 0x72, 0x12, 0x35, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x55, 0x6e, - 0x72, 0x65, 0x67, 0x69, 0x73, 0x74, 0x65, 0x72, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x6d, - 0x69, 0x6e, 0x64, 0x65, 0x72, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x16, 0x2e, 0x67, - 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, - 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x6c, 0x0a, 0x0d, 0x47, 0x65, 0x74, 0x41, 0x63, 0x74, - 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x12, 0x2b, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, - 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, - 0x47, 0x65, 0x74, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2c, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, - 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, - 0x73, 0x65, 0x22, 0x00, 0x12, 0x74, 0x0a, 0x1c, 0x45, 0x78, 0x65, 0x63, 0x75, 0x74, 0x65, 0x41, - 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, 0x61, 0x6e, 0x73, 0x61, 0x63, - 0x74, 0x69, 0x6f, 0x6e, 0x12, 0x3a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x45, 0x78, 0x65, - 0x63, 0x75, 0x74, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x53, 0x74, 0x61, 0x74, 0x65, 0x54, 0x72, - 0x61, 0x6e, 0x73, 0x61, 0x63, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x66, 0x0a, 0x0b, 0x49, 0x6e, - 0x76, 0x6f, 0x6b, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x12, 0x29, 0x2e, 0x64, 0x61, 0x70, 0x72, - 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, - 0x31, 0x2e, 0x49, 0x6e, 0x76, 0x6f, 0x6b, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x71, - 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, - 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x49, 0x6e, 0x76, - 0x6f, 0x6b, 0x65, 0x41, 0x63, 0x74, 0x6f, 0x72, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, - 0x22, 0x00, 0x12, 0x7b, 0x0a, 0x16, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, - 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x70, 0x68, 0x61, 0x31, 0x12, 0x2e, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x2f, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, - 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x47, 0x65, 0x74, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, - 0x8f, 0x01, 0x0a, 0x1c, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x62, 0x65, 0x43, 0x6f, 0x6e, - 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x41, 0x6c, 0x70, 0x68, 0x61, 0x31, - 0x12, 0x34, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, - 0x62, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, - 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, 0x1a, 0x35, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, - 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, - 0x75, 0x62, 0x73, 0x63, 0x72, 0x69, 0x62, 0x65, 0x43, 0x6f, 0x6e, 0x66, 0x69, 0x67, 0x75, 0x72, - 0x61, 0x74, 0x69, 0x6f, 0x6e, 0x52, 0x65, 0x73, 0x70, 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x30, - 0x01, 0x12, 0x53, 0x0a, 0x0b, 0x47, 0x65, 0x74, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, - 0x12, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x1a, 0x2a, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, - 0x2e, 0x47, 0x65, 0x74, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x65, 0x73, 0x70, - 0x6f, 0x6e, 0x73, 0x65, 0x22, 0x00, 0x12, 0x52, 0x0a, 0x0b, 0x53, 0x65, 0x74, 0x4d, 0x65, 0x74, - 0x61, 0x64, 0x61, 0x74, 0x61, 0x12, 0x29, 0x2e, 0x64, 0x61, 0x70, 0x72, 0x2e, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2e, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2e, 0x76, 0x31, 0x2e, 0x53, 0x65, - 0x74, 0x4d, 0x65, 0x74, 0x61, 0x64, 0x61, 0x74, 0x61, 0x52, 0x65, 0x71, 0x75, 0x65, 0x73, 0x74, - 0x1a, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, - 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x12, 0x3c, 0x0a, 0x08, 0x53, 0x68, - 0x75, 0x74, 0x64, 0x6f, 0x77, 0x6e, 0x12, 0x16, 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, - 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x1a, 0x16, - 0x2e, 0x67, 0x6f, 0x6f, 0x67, 0x6c, 0x65, 0x2e, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x62, 0x75, 0x66, - 0x2e, 0x45, 0x6d, 0x70, 0x74, 0x79, 0x22, 0x00, 0x42, 0x69, 0x0a, 0x0a, 0x69, 0x6f, 0x2e, 0x64, - 0x61, 0x70, 0x72, 0x2e, 0x76, 0x31, 0x42, 0x0a, 0x44, 0x61, 0x70, 0x72, 0x50, 0x72, 0x6f, 0x74, - 0x6f, 0x73, 0x5a, 0x31, 0x67, 0x69, 0x74, 0x68, 0x75, 0x62, 0x2e, 0x63, 0x6f, 0x6d, 0x2f, 0x64, - 0x61, 0x70, 0x72, 0x2f, 0x64, 0x61, 0x70, 0x72, 0x2f, 0x70, 0x6b, 0x67, 0x2f, 0x70, 0x72, 0x6f, - 0x74, 0x6f, 0x2f, 0x72, 0x75, 0x6e, 0x74, 0x69, 0x6d, 0x65, 0x2f, 0x76, 0x31, 0x3b, 0x72, 0x75, - 0x6e, 0x74, 0x69, 0x6d, 0x65, 0xaa, 0x02, 0x1b, 0x44, 0x61, 0x70, 0x72, 0x2e, 0x43, 0x6c, 0x69, - 0x65, 0x6e, 0x74, 0x2e, 0x41, 0x75, 0x74, 0x6f, 0x67, 0x65, 0x6e, 0x2e, 0x47, 0x72, 0x70, 0x63, - 0x2e, 0x76, 0x31, 0x62, 0x06, 0x70, 0x72, 0x6f, 0x74, 0x6f, 0x33, -} - -var ( - file_dapr_proto_runtime_v1_dapr_proto_rawDescOnce sync.Once - file_dapr_proto_runtime_v1_dapr_proto_rawDescData = file_dapr_proto_runtime_v1_dapr_proto_rawDesc -) - -func file_dapr_proto_runtime_v1_dapr_proto_rawDescGZIP() []byte { - file_dapr_proto_runtime_v1_dapr_proto_rawDescOnce.Do(func() { - file_dapr_proto_runtime_v1_dapr_proto_rawDescData = protoimpl.X.CompressGZIP(file_dapr_proto_runtime_v1_dapr_proto_rawDescData) - }) - return file_dapr_proto_runtime_v1_dapr_proto_rawDescData -} - -var file_dapr_proto_runtime_v1_dapr_proto_msgTypes = make([]protoimpl.MessageInfo, 59) -var file_dapr_proto_runtime_v1_dapr_proto_goTypes = []interface{}{ - (*InvokeServiceRequest)(nil), // 0: dapr.proto.runtime.v1.InvokeServiceRequest - (*GetStateRequest)(nil), // 1: dapr.proto.runtime.v1.GetStateRequest - (*GetBulkStateRequest)(nil), // 2: dapr.proto.runtime.v1.GetBulkStateRequest - (*GetBulkStateResponse)(nil), // 3: dapr.proto.runtime.v1.GetBulkStateResponse - (*BulkStateItem)(nil), // 4: dapr.proto.runtime.v1.BulkStateItem - (*GetStateResponse)(nil), // 5: dapr.proto.runtime.v1.GetStateResponse - (*DeleteStateRequest)(nil), // 6: dapr.proto.runtime.v1.DeleteStateRequest - (*DeleteBulkStateRequest)(nil), // 7: dapr.proto.runtime.v1.DeleteBulkStateRequest - (*SaveStateRequest)(nil), // 8: dapr.proto.runtime.v1.SaveStateRequest - (*QueryStateRequest)(nil), // 9: dapr.proto.runtime.v1.QueryStateRequest - (*QueryStateItem)(nil), // 10: dapr.proto.runtime.v1.QueryStateItem - (*QueryStateResponse)(nil), // 11: dapr.proto.runtime.v1.QueryStateResponse - (*PublishEventRequest)(nil), // 12: dapr.proto.runtime.v1.PublishEventRequest - (*InvokeBindingRequest)(nil), // 13: dapr.proto.runtime.v1.InvokeBindingRequest - (*InvokeBindingResponse)(nil), // 14: dapr.proto.runtime.v1.InvokeBindingResponse - (*GetSecretRequest)(nil), // 15: dapr.proto.runtime.v1.GetSecretRequest - (*GetSecretResponse)(nil), // 16: dapr.proto.runtime.v1.GetSecretResponse - (*GetBulkSecretRequest)(nil), // 17: dapr.proto.runtime.v1.GetBulkSecretRequest - (*SecretResponse)(nil), // 18: dapr.proto.runtime.v1.SecretResponse - (*GetBulkSecretResponse)(nil), // 19: dapr.proto.runtime.v1.GetBulkSecretResponse - (*TransactionalStateOperation)(nil), // 20: dapr.proto.runtime.v1.TransactionalStateOperation - (*ExecuteStateTransactionRequest)(nil), // 21: dapr.proto.runtime.v1.ExecuteStateTransactionRequest - (*RegisterActorTimerRequest)(nil), // 22: dapr.proto.runtime.v1.RegisterActorTimerRequest - (*UnregisterActorTimerRequest)(nil), // 23: dapr.proto.runtime.v1.UnregisterActorTimerRequest - (*RegisterActorReminderRequest)(nil), // 24: dapr.proto.runtime.v1.RegisterActorReminderRequest - (*UnregisterActorReminderRequest)(nil), // 25: dapr.proto.runtime.v1.UnregisterActorReminderRequest - (*GetActorStateRequest)(nil), // 26: dapr.proto.runtime.v1.GetActorStateRequest - (*GetActorStateResponse)(nil), // 27: dapr.proto.runtime.v1.GetActorStateResponse - (*ExecuteActorStateTransactionRequest)(nil), // 28: dapr.proto.runtime.v1.ExecuteActorStateTransactionRequest - (*TransactionalActorStateOperation)(nil), // 29: dapr.proto.runtime.v1.TransactionalActorStateOperation - (*InvokeActorRequest)(nil), // 30: dapr.proto.runtime.v1.InvokeActorRequest - (*InvokeActorResponse)(nil), // 31: dapr.proto.runtime.v1.InvokeActorResponse - (*GetMetadataResponse)(nil), // 32: dapr.proto.runtime.v1.GetMetadataResponse - (*ActiveActorsCount)(nil), // 33: dapr.proto.runtime.v1.ActiveActorsCount - (*RegisteredComponents)(nil), // 34: dapr.proto.runtime.v1.RegisteredComponents - (*SetMetadataRequest)(nil), // 35: dapr.proto.runtime.v1.SetMetadataRequest - (*GetConfigurationRequest)(nil), // 36: dapr.proto.runtime.v1.GetConfigurationRequest - (*GetConfigurationResponse)(nil), // 37: dapr.proto.runtime.v1.GetConfigurationResponse - (*SubscribeConfigurationRequest)(nil), // 38: dapr.proto.runtime.v1.SubscribeConfigurationRequest - (*SubscribeConfigurationResponse)(nil), // 39: dapr.proto.runtime.v1.SubscribeConfigurationResponse - nil, // 40: dapr.proto.runtime.v1.GetStateRequest.MetadataEntry - nil, // 41: dapr.proto.runtime.v1.GetBulkStateRequest.MetadataEntry - nil, // 42: dapr.proto.runtime.v1.BulkStateItem.MetadataEntry - nil, // 43: dapr.proto.runtime.v1.GetStateResponse.MetadataEntry - nil, // 44: dapr.proto.runtime.v1.DeleteStateRequest.MetadataEntry - nil, // 45: dapr.proto.runtime.v1.QueryStateRequest.MetadataEntry - nil, // 46: dapr.proto.runtime.v1.QueryStateResponse.MetadataEntry - nil, // 47: dapr.proto.runtime.v1.PublishEventRequest.MetadataEntry - nil, // 48: dapr.proto.runtime.v1.InvokeBindingRequest.MetadataEntry - nil, // 49: dapr.proto.runtime.v1.InvokeBindingResponse.MetadataEntry - nil, // 50: dapr.proto.runtime.v1.GetSecretRequest.MetadataEntry - nil, // 51: dapr.proto.runtime.v1.GetSecretResponse.DataEntry - nil, // 52: dapr.proto.runtime.v1.GetBulkSecretRequest.MetadataEntry - nil, // 53: dapr.proto.runtime.v1.SecretResponse.SecretsEntry - nil, // 54: dapr.proto.runtime.v1.GetBulkSecretResponse.DataEntry - nil, // 55: dapr.proto.runtime.v1.ExecuteStateTransactionRequest.MetadataEntry - nil, // 56: dapr.proto.runtime.v1.GetMetadataResponse.ExtendedMetadataEntry - nil, // 57: dapr.proto.runtime.v1.GetConfigurationRequest.MetadataEntry - nil, // 58: dapr.proto.runtime.v1.SubscribeConfigurationRequest.MetadataEntry - (*v1.InvokeRequest)(nil), // 59: dapr.proto.common.v1.InvokeRequest - (v1.StateOptions_StateConsistency)(0), // 60: dapr.proto.common.v1.StateOptions.StateConsistency - (*v1.Etag)(nil), // 61: dapr.proto.common.v1.Etag - (*v1.StateOptions)(nil), // 62: dapr.proto.common.v1.StateOptions - (*v1.StateItem)(nil), // 63: dapr.proto.common.v1.StateItem - (*anypb.Any)(nil), // 64: google.protobuf.Any - (*v1.ConfigurationItem)(nil), // 65: dapr.proto.common.v1.ConfigurationItem - (*emptypb.Empty)(nil), // 66: google.protobuf.Empty - (*v1.InvokeResponse)(nil), // 67: dapr.proto.common.v1.InvokeResponse -} -var file_dapr_proto_runtime_v1_dapr_proto_depIdxs = []int32{ - 59, // 0: dapr.proto.runtime.v1.InvokeServiceRequest.message:type_name -> dapr.proto.common.v1.InvokeRequest - 60, // 1: dapr.proto.runtime.v1.GetStateRequest.consistency:type_name -> dapr.proto.common.v1.StateOptions.StateConsistency - 40, // 2: dapr.proto.runtime.v1.GetStateRequest.metadata:type_name -> dapr.proto.runtime.v1.GetStateRequest.MetadataEntry - 41, // 3: dapr.proto.runtime.v1.GetBulkStateRequest.metadata:type_name -> dapr.proto.runtime.v1.GetBulkStateRequest.MetadataEntry - 4, // 4: dapr.proto.runtime.v1.GetBulkStateResponse.items:type_name -> dapr.proto.runtime.v1.BulkStateItem - 42, // 5: dapr.proto.runtime.v1.BulkStateItem.metadata:type_name -> dapr.proto.runtime.v1.BulkStateItem.MetadataEntry - 43, // 6: dapr.proto.runtime.v1.GetStateResponse.metadata:type_name -> dapr.proto.runtime.v1.GetStateResponse.MetadataEntry - 61, // 7: dapr.proto.runtime.v1.DeleteStateRequest.etag:type_name -> dapr.proto.common.v1.Etag - 62, // 8: dapr.proto.runtime.v1.DeleteStateRequest.options:type_name -> dapr.proto.common.v1.StateOptions - 44, // 9: dapr.proto.runtime.v1.DeleteStateRequest.metadata:type_name -> dapr.proto.runtime.v1.DeleteStateRequest.MetadataEntry - 63, // 10: dapr.proto.runtime.v1.DeleteBulkStateRequest.states:type_name -> dapr.proto.common.v1.StateItem - 63, // 11: dapr.proto.runtime.v1.SaveStateRequest.states:type_name -> dapr.proto.common.v1.StateItem - 45, // 12: dapr.proto.runtime.v1.QueryStateRequest.metadata:type_name -> dapr.proto.runtime.v1.QueryStateRequest.MetadataEntry - 10, // 13: dapr.proto.runtime.v1.QueryStateResponse.results:type_name -> dapr.proto.runtime.v1.QueryStateItem - 46, // 14: dapr.proto.runtime.v1.QueryStateResponse.metadata:type_name -> dapr.proto.runtime.v1.QueryStateResponse.MetadataEntry - 47, // 15: dapr.proto.runtime.v1.PublishEventRequest.metadata:type_name -> dapr.proto.runtime.v1.PublishEventRequest.MetadataEntry - 48, // 16: dapr.proto.runtime.v1.InvokeBindingRequest.metadata:type_name -> dapr.proto.runtime.v1.InvokeBindingRequest.MetadataEntry - 49, // 17: dapr.proto.runtime.v1.InvokeBindingResponse.metadata:type_name -> dapr.proto.runtime.v1.InvokeBindingResponse.MetadataEntry - 50, // 18: dapr.proto.runtime.v1.GetSecretRequest.metadata:type_name -> dapr.proto.runtime.v1.GetSecretRequest.MetadataEntry - 51, // 19: dapr.proto.runtime.v1.GetSecretResponse.data:type_name -> dapr.proto.runtime.v1.GetSecretResponse.DataEntry - 52, // 20: dapr.proto.runtime.v1.GetBulkSecretRequest.metadata:type_name -> dapr.proto.runtime.v1.GetBulkSecretRequest.MetadataEntry - 53, // 21: dapr.proto.runtime.v1.SecretResponse.secrets:type_name -> dapr.proto.runtime.v1.SecretResponse.SecretsEntry - 54, // 22: dapr.proto.runtime.v1.GetBulkSecretResponse.data:type_name -> dapr.proto.runtime.v1.GetBulkSecretResponse.DataEntry - 63, // 23: dapr.proto.runtime.v1.TransactionalStateOperation.request:type_name -> dapr.proto.common.v1.StateItem - 20, // 24: dapr.proto.runtime.v1.ExecuteStateTransactionRequest.operations:type_name -> dapr.proto.runtime.v1.TransactionalStateOperation - 55, // 25: dapr.proto.runtime.v1.ExecuteStateTransactionRequest.metadata:type_name -> dapr.proto.runtime.v1.ExecuteStateTransactionRequest.MetadataEntry - 29, // 26: dapr.proto.runtime.v1.ExecuteActorStateTransactionRequest.operations:type_name -> dapr.proto.runtime.v1.TransactionalActorStateOperation - 64, // 27: dapr.proto.runtime.v1.TransactionalActorStateOperation.value:type_name -> google.protobuf.Any - 33, // 28: dapr.proto.runtime.v1.GetMetadataResponse.active_actors_count:type_name -> dapr.proto.runtime.v1.ActiveActorsCount - 34, // 29: dapr.proto.runtime.v1.GetMetadataResponse.registered_components:type_name -> dapr.proto.runtime.v1.RegisteredComponents - 56, // 30: dapr.proto.runtime.v1.GetMetadataResponse.extended_metadata:type_name -> dapr.proto.runtime.v1.GetMetadataResponse.ExtendedMetadataEntry - 57, // 31: dapr.proto.runtime.v1.GetConfigurationRequest.metadata:type_name -> dapr.proto.runtime.v1.GetConfigurationRequest.MetadataEntry - 65, // 32: dapr.proto.runtime.v1.GetConfigurationResponse.items:type_name -> dapr.proto.common.v1.ConfigurationItem - 58, // 33: dapr.proto.runtime.v1.SubscribeConfigurationRequest.metadata:type_name -> dapr.proto.runtime.v1.SubscribeConfigurationRequest.MetadataEntry - 65, // 34: dapr.proto.runtime.v1.SubscribeConfigurationResponse.items:type_name -> dapr.proto.common.v1.ConfigurationItem - 18, // 35: dapr.proto.runtime.v1.GetBulkSecretResponse.DataEntry.value:type_name -> dapr.proto.runtime.v1.SecretResponse - 0, // 36: dapr.proto.runtime.v1.Dapr.InvokeService:input_type -> dapr.proto.runtime.v1.InvokeServiceRequest - 1, // 37: dapr.proto.runtime.v1.Dapr.GetState:input_type -> dapr.proto.runtime.v1.GetStateRequest - 2, // 38: dapr.proto.runtime.v1.Dapr.GetBulkState:input_type -> dapr.proto.runtime.v1.GetBulkStateRequest - 8, // 39: dapr.proto.runtime.v1.Dapr.SaveState:input_type -> dapr.proto.runtime.v1.SaveStateRequest - 9, // 40: dapr.proto.runtime.v1.Dapr.QueryStateAlpha1:input_type -> dapr.proto.runtime.v1.QueryStateRequest - 6, // 41: dapr.proto.runtime.v1.Dapr.DeleteState:input_type -> dapr.proto.runtime.v1.DeleteStateRequest - 7, // 42: dapr.proto.runtime.v1.Dapr.DeleteBulkState:input_type -> dapr.proto.runtime.v1.DeleteBulkStateRequest - 21, // 43: dapr.proto.runtime.v1.Dapr.ExecuteStateTransaction:input_type -> dapr.proto.runtime.v1.ExecuteStateTransactionRequest - 12, // 44: dapr.proto.runtime.v1.Dapr.PublishEvent:input_type -> dapr.proto.runtime.v1.PublishEventRequest - 13, // 45: dapr.proto.runtime.v1.Dapr.InvokeBinding:input_type -> dapr.proto.runtime.v1.InvokeBindingRequest - 15, // 46: dapr.proto.runtime.v1.Dapr.GetSecret:input_type -> dapr.proto.runtime.v1.GetSecretRequest - 17, // 47: dapr.proto.runtime.v1.Dapr.GetBulkSecret:input_type -> dapr.proto.runtime.v1.GetBulkSecretRequest - 22, // 48: dapr.proto.runtime.v1.Dapr.RegisterActorTimer:input_type -> dapr.proto.runtime.v1.RegisterActorTimerRequest - 23, // 49: dapr.proto.runtime.v1.Dapr.UnregisterActorTimer:input_type -> dapr.proto.runtime.v1.UnregisterActorTimerRequest - 24, // 50: dapr.proto.runtime.v1.Dapr.RegisterActorReminder:input_type -> dapr.proto.runtime.v1.RegisterActorReminderRequest - 25, // 51: dapr.proto.runtime.v1.Dapr.UnregisterActorReminder:input_type -> dapr.proto.runtime.v1.UnregisterActorReminderRequest - 26, // 52: dapr.proto.runtime.v1.Dapr.GetActorState:input_type -> dapr.proto.runtime.v1.GetActorStateRequest - 28, // 53: dapr.proto.runtime.v1.Dapr.ExecuteActorStateTransaction:input_type -> dapr.proto.runtime.v1.ExecuteActorStateTransactionRequest - 30, // 54: dapr.proto.runtime.v1.Dapr.InvokeActor:input_type -> dapr.proto.runtime.v1.InvokeActorRequest - 36, // 55: dapr.proto.runtime.v1.Dapr.GetConfigurationAlpha1:input_type -> dapr.proto.runtime.v1.GetConfigurationRequest - 38, // 56: dapr.proto.runtime.v1.Dapr.SubscribeConfigurationAlpha1:input_type -> dapr.proto.runtime.v1.SubscribeConfigurationRequest - 66, // 57: dapr.proto.runtime.v1.Dapr.GetMetadata:input_type -> google.protobuf.Empty - 35, // 58: dapr.proto.runtime.v1.Dapr.SetMetadata:input_type -> dapr.proto.runtime.v1.SetMetadataRequest - 66, // 59: dapr.proto.runtime.v1.Dapr.Shutdown:input_type -> google.protobuf.Empty - 67, // 60: dapr.proto.runtime.v1.Dapr.InvokeService:output_type -> dapr.proto.common.v1.InvokeResponse - 5, // 61: dapr.proto.runtime.v1.Dapr.GetState:output_type -> dapr.proto.runtime.v1.GetStateResponse - 3, // 62: dapr.proto.runtime.v1.Dapr.GetBulkState:output_type -> dapr.proto.runtime.v1.GetBulkStateResponse - 66, // 63: dapr.proto.runtime.v1.Dapr.SaveState:output_type -> google.protobuf.Empty - 11, // 64: dapr.proto.runtime.v1.Dapr.QueryStateAlpha1:output_type -> dapr.proto.runtime.v1.QueryStateResponse - 66, // 65: dapr.proto.runtime.v1.Dapr.DeleteState:output_type -> google.protobuf.Empty - 66, // 66: dapr.proto.runtime.v1.Dapr.DeleteBulkState:output_type -> google.protobuf.Empty - 66, // 67: dapr.proto.runtime.v1.Dapr.ExecuteStateTransaction:output_type -> google.protobuf.Empty - 66, // 68: dapr.proto.runtime.v1.Dapr.PublishEvent:output_type -> google.protobuf.Empty - 14, // 69: dapr.proto.runtime.v1.Dapr.InvokeBinding:output_type -> dapr.proto.runtime.v1.InvokeBindingResponse - 16, // 70: dapr.proto.runtime.v1.Dapr.GetSecret:output_type -> dapr.proto.runtime.v1.GetSecretResponse - 19, // 71: dapr.proto.runtime.v1.Dapr.GetBulkSecret:output_type -> dapr.proto.runtime.v1.GetBulkSecretResponse - 66, // 72: dapr.proto.runtime.v1.Dapr.RegisterActorTimer:output_type -> google.protobuf.Empty - 66, // 73: dapr.proto.runtime.v1.Dapr.UnregisterActorTimer:output_type -> google.protobuf.Empty - 66, // 74: dapr.proto.runtime.v1.Dapr.RegisterActorReminder:output_type -> google.protobuf.Empty - 66, // 75: dapr.proto.runtime.v1.Dapr.UnregisterActorReminder:output_type -> google.protobuf.Empty - 27, // 76: dapr.proto.runtime.v1.Dapr.GetActorState:output_type -> dapr.proto.runtime.v1.GetActorStateResponse - 66, // 77: dapr.proto.runtime.v1.Dapr.ExecuteActorStateTransaction:output_type -> google.protobuf.Empty - 31, // 78: dapr.proto.runtime.v1.Dapr.InvokeActor:output_type -> dapr.proto.runtime.v1.InvokeActorResponse - 37, // 79: dapr.proto.runtime.v1.Dapr.GetConfigurationAlpha1:output_type -> dapr.proto.runtime.v1.GetConfigurationResponse - 39, // 80: dapr.proto.runtime.v1.Dapr.SubscribeConfigurationAlpha1:output_type -> dapr.proto.runtime.v1.SubscribeConfigurationResponse - 32, // 81: dapr.proto.runtime.v1.Dapr.GetMetadata:output_type -> dapr.proto.runtime.v1.GetMetadataResponse - 66, // 82: dapr.proto.runtime.v1.Dapr.SetMetadata:output_type -> google.protobuf.Empty - 66, // 83: dapr.proto.runtime.v1.Dapr.Shutdown:output_type -> google.protobuf.Empty - 60, // [60:84] is the sub-list for method output_type - 36, // [36:60] is the sub-list for method input_type - 36, // [36:36] is the sub-list for extension type_name - 36, // [36:36] is the sub-list for extension extendee - 0, // [0:36] is the sub-list for field type_name -} - -func init() { file_dapr_proto_runtime_v1_dapr_proto_init() } -func file_dapr_proto_runtime_v1_dapr_proto_init() { - if File_dapr_proto_runtime_v1_dapr_proto != nil { - return - } - if !protoimpl.UnsafeEnabled { - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[0].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeServiceRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[1].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[2].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetBulkStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[3].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetBulkStateResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[4].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*BulkStateItem); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[5].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetStateResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[6].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*DeleteStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[7].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*DeleteBulkStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[8].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*SaveStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[9].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*QueryStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[10].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*QueryStateItem); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[11].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*QueryStateResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[12].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*PublishEventRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[13].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeBindingRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[14].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeBindingResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[15].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetSecretRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[16].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetSecretResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[17].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetBulkSecretRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[18].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*SecretResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[19].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetBulkSecretResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[20].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TransactionalStateOperation); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[21].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ExecuteStateTransactionRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[22].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RegisterActorTimerRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[23].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*UnregisterActorTimerRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[24].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RegisterActorReminderRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[25].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*UnregisterActorReminderRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[26].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetActorStateRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[27].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetActorStateResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[28].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ExecuteActorStateTransactionRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[29].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*TransactionalActorStateOperation); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[30].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeActorRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[31].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*InvokeActorResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[32].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetMetadataResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[33].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*ActiveActorsCount); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[34].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*RegisteredComponents); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[35].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*SetMetadataRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[36].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetConfigurationRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[37].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*GetConfigurationResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[38].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*SubscribeConfigurationRequest); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - file_dapr_proto_runtime_v1_dapr_proto_msgTypes[39].Exporter = func(v interface{}, i int) interface{} { - switch v := v.(*SubscribeConfigurationResponse); i { - case 0: - return &v.state - case 1: - return &v.sizeCache - case 2: - return &v.unknownFields - default: - return nil - } - } - } - type x struct{} - out := protoimpl.TypeBuilder{ - File: protoimpl.DescBuilder{ - GoPackagePath: reflect.TypeOf(x{}).PkgPath(), - RawDescriptor: file_dapr_proto_runtime_v1_dapr_proto_rawDesc, - NumEnums: 0, - NumMessages: 59, - NumExtensions: 0, - NumServices: 1, - }, - GoTypes: file_dapr_proto_runtime_v1_dapr_proto_goTypes, - DependencyIndexes: file_dapr_proto_runtime_v1_dapr_proto_depIdxs, - MessageInfos: file_dapr_proto_runtime_v1_dapr_proto_msgTypes, - }.Build() - File_dapr_proto_runtime_v1_dapr_proto = out.File - file_dapr_proto_runtime_v1_dapr_proto_rawDesc = nil - file_dapr_proto_runtime_v1_dapr_proto_goTypes = nil - file_dapr_proto_runtime_v1_dapr_proto_depIdxs = nil -} diff --git a/pkg/grpc/dapr/proto/runtime/v1/dapr_grpc.pb.go b/pkg/grpc/dapr/proto/runtime/v1/dapr_grpc.pb.go deleted file mode 100644 index f30afc8e3f..0000000000 --- a/pkg/grpc/dapr/proto/runtime/v1/dapr_grpc.pb.go +++ /dev/null @@ -1,1007 +0,0 @@ -// Code generated by protoc-gen-go-grpc. DO NOT EDIT. - -package runtime - -import ( - context "context" - - grpc "google.golang.org/grpc" - codes "google.golang.org/grpc/codes" - status "google.golang.org/grpc/status" - emptypb "google.golang.org/protobuf/types/known/emptypb" - - v1 "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" -) - -// This is a compile-time assertion to ensure that this generated file -// is compatible with the grpc package it is being compiled against. -// Requires gRPC-Go v1.32.0 or later. -const _ = grpc.SupportPackageIsVersion7 - -// DaprClient is the client API for Dapr service. -// -// For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream. -type DaprClient interface { - // Invokes a method on a remote Dapr app. - InvokeService(ctx context.Context, in *InvokeServiceRequest, opts ...grpc.CallOption) (*v1.InvokeResponse, error) - // Gets the state for a specific key. - GetState(ctx context.Context, in *GetStateRequest, opts ...grpc.CallOption) (*GetStateResponse, error) - // Gets a bulk of state items for a list of keys - GetBulkState(ctx context.Context, in *GetBulkStateRequest, opts ...grpc.CallOption) (*GetBulkStateResponse, error) - // Saves the state for a specific key. - SaveState(ctx context.Context, in *SaveStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Queries the state. - QueryStateAlpha1(ctx context.Context, in *QueryStateRequest, opts ...grpc.CallOption) (*QueryStateResponse, error) - // Deletes the state for a specific key. - DeleteState(ctx context.Context, in *DeleteStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Deletes a bulk of state items for a list of keys - DeleteBulkState(ctx context.Context, in *DeleteBulkStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Executes transactions for a specified store - ExecuteStateTransaction(ctx context.Context, in *ExecuteStateTransactionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Publishes events to the specific topic. - PublishEvent(ctx context.Context, in *PublishEventRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Invokes binding data to specific output bindings - InvokeBinding(ctx context.Context, in *InvokeBindingRequest, opts ...grpc.CallOption) (*InvokeBindingResponse, error) - // Gets secrets from secret stores. - GetSecret(ctx context.Context, in *GetSecretRequest, opts ...grpc.CallOption) (*GetSecretResponse, error) - // Gets a bulk of secrets - GetBulkSecret(ctx context.Context, in *GetBulkSecretRequest, opts ...grpc.CallOption) (*GetBulkSecretResponse, error) - // Register an actor timer. - RegisterActorTimer(ctx context.Context, in *RegisterActorTimerRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Unregister an actor timer. - UnregisterActorTimer(ctx context.Context, in *UnregisterActorTimerRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Register an actor reminder. - RegisterActorReminder(ctx context.Context, in *RegisterActorReminderRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Unregister an actor reminder. - UnregisterActorReminder(ctx context.Context, in *UnregisterActorReminderRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Gets the state for a specific actor. - GetActorState(ctx context.Context, in *GetActorStateRequest, opts ...grpc.CallOption) (*GetActorStateResponse, error) - // Executes state transactions for a specified actor - ExecuteActorStateTransaction(ctx context.Context, in *ExecuteActorStateTransactionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // InvokeActor calls a method on an actor. - InvokeActor(ctx context.Context, in *InvokeActorRequest, opts ...grpc.CallOption) (*InvokeActorResponse, error) - // GetConfiguration gets configuration from configuration store. - GetConfigurationAlpha1(ctx context.Context, in *GetConfigurationRequest, opts ...grpc.CallOption) (*GetConfigurationResponse, error) - // SubscribeConfiguration gets configuration from configuration store and subscribe the updates event by grpc stream - SubscribeConfigurationAlpha1(ctx context.Context, in *SubscribeConfigurationRequest, opts ...grpc.CallOption) (Dapr_SubscribeConfigurationAlpha1Client, error) - // Gets metadata of the sidecar - GetMetadata(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*GetMetadataResponse, error) - // Sets value in extended metadata of the sidecar - SetMetadata(ctx context.Context, in *SetMetadataRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) - // Shutdown the sidecar - Shutdown(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*emptypb.Empty, error) -} - -type daprClient struct { - cc grpc.ClientConnInterface -} - -func NewDaprClient(cc grpc.ClientConnInterface) DaprClient { - return &daprClient{cc} -} - -func (c *daprClient) InvokeService(ctx context.Context, in *InvokeServiceRequest, opts ...grpc.CallOption) (*v1.InvokeResponse, error) { - out := new(v1.InvokeResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/InvokeService", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetState(ctx context.Context, in *GetStateRequest, opts ...grpc.CallOption) (*GetStateResponse, error) { - out := new(GetStateResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetBulkState(ctx context.Context, in *GetBulkStateRequest, opts ...grpc.CallOption) (*GetBulkStateResponse, error) { - out := new(GetBulkStateResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetBulkState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) SaveState(ctx context.Context, in *SaveStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/SaveState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) QueryStateAlpha1(ctx context.Context, in *QueryStateRequest, opts ...grpc.CallOption) (*QueryStateResponse, error) { - out := new(QueryStateResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/QueryStateAlpha1", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) DeleteState(ctx context.Context, in *DeleteStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/DeleteState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) DeleteBulkState(ctx context.Context, in *DeleteBulkStateRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/DeleteBulkState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) ExecuteStateTransaction(ctx context.Context, in *ExecuteStateTransactionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/ExecuteStateTransaction", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) PublishEvent(ctx context.Context, in *PublishEventRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/PublishEvent", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) InvokeBinding(ctx context.Context, in *InvokeBindingRequest, opts ...grpc.CallOption) (*InvokeBindingResponse, error) { - out := new(InvokeBindingResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/InvokeBinding", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetSecret(ctx context.Context, in *GetSecretRequest, opts ...grpc.CallOption) (*GetSecretResponse, error) { - out := new(GetSecretResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetSecret", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetBulkSecret(ctx context.Context, in *GetBulkSecretRequest, opts ...grpc.CallOption) (*GetBulkSecretResponse, error) { - out := new(GetBulkSecretResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetBulkSecret", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) RegisterActorTimer(ctx context.Context, in *RegisterActorTimerRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/RegisterActorTimer", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) UnregisterActorTimer(ctx context.Context, in *UnregisterActorTimerRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/UnregisterActorTimer", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) RegisterActorReminder(ctx context.Context, in *RegisterActorReminderRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/RegisterActorReminder", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) UnregisterActorReminder(ctx context.Context, in *UnregisterActorReminderRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/UnregisterActorReminder", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetActorState(ctx context.Context, in *GetActorStateRequest, opts ...grpc.CallOption) (*GetActorStateResponse, error) { - out := new(GetActorStateResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetActorState", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) ExecuteActorStateTransaction(ctx context.Context, in *ExecuteActorStateTransactionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/ExecuteActorStateTransaction", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) InvokeActor(ctx context.Context, in *InvokeActorRequest, opts ...grpc.CallOption) (*InvokeActorResponse, error) { - out := new(InvokeActorResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/InvokeActor", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) GetConfigurationAlpha1(ctx context.Context, in *GetConfigurationRequest, opts ...grpc.CallOption) (*GetConfigurationResponse, error) { - out := new(GetConfigurationResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetConfigurationAlpha1", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) SubscribeConfigurationAlpha1(ctx context.Context, in *SubscribeConfigurationRequest, opts ...grpc.CallOption) (Dapr_SubscribeConfigurationAlpha1Client, error) { - stream, err := c.cc.NewStream(ctx, &Dapr_ServiceDesc.Streams[0], "/dapr.proto.runtime.v1.Dapr/SubscribeConfigurationAlpha1", opts...) - if err != nil { - return nil, err - } - x := &daprSubscribeConfigurationAlpha1Client{stream} - if err := x.ClientStream.SendMsg(in); err != nil { - return nil, err - } - if err := x.ClientStream.CloseSend(); err != nil { - return nil, err - } - return x, nil -} - -type Dapr_SubscribeConfigurationAlpha1Client interface { - Recv() (*SubscribeConfigurationResponse, error) - grpc.ClientStream -} - -type daprSubscribeConfigurationAlpha1Client struct { - grpc.ClientStream -} - -func (x *daprSubscribeConfigurationAlpha1Client) Recv() (*SubscribeConfigurationResponse, error) { - m := new(SubscribeConfigurationResponse) - if err := x.ClientStream.RecvMsg(m); err != nil { - return nil, err - } - return m, nil -} - -func (c *daprClient) GetMetadata(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*GetMetadataResponse, error) { - out := new(GetMetadataResponse) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/GetMetadata", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) SetMetadata(ctx context.Context, in *SetMetadataRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/SetMetadata", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -func (c *daprClient) Shutdown(ctx context.Context, in *emptypb.Empty, opts ...grpc.CallOption) (*emptypb.Empty, error) { - out := new(emptypb.Empty) - err := c.cc.Invoke(ctx, "/dapr.proto.runtime.v1.Dapr/Shutdown", in, out, opts...) - if err != nil { - return nil, err - } - return out, nil -} - -// DaprServer is the server API for Dapr service. -// All implementations should embed UnimplementedDaprServer -// for forward compatibility -type DaprServer interface { - // Invokes a method on a remote Dapr app. - InvokeService(context.Context, *InvokeServiceRequest) (*v1.InvokeResponse, error) - // Gets the state for a specific key. - GetState(context.Context, *GetStateRequest) (*GetStateResponse, error) - // Gets a bulk of state items for a list of keys - GetBulkState(context.Context, *GetBulkStateRequest) (*GetBulkStateResponse, error) - // Saves the state for a specific key. - SaveState(context.Context, *SaveStateRequest) (*emptypb.Empty, error) - // Queries the state. - QueryStateAlpha1(context.Context, *QueryStateRequest) (*QueryStateResponse, error) - // Deletes the state for a specific key. - DeleteState(context.Context, *DeleteStateRequest) (*emptypb.Empty, error) - // Deletes a bulk of state items for a list of keys - DeleteBulkState(context.Context, *DeleteBulkStateRequest) (*emptypb.Empty, error) - // Executes transactions for a specified store - ExecuteStateTransaction(context.Context, *ExecuteStateTransactionRequest) (*emptypb.Empty, error) - // Publishes events to the specific topic. - PublishEvent(context.Context, *PublishEventRequest) (*emptypb.Empty, error) - // Invokes binding data to specific output bindings - InvokeBinding(context.Context, *InvokeBindingRequest) (*InvokeBindingResponse, error) - // Gets secrets from secret stores. - GetSecret(context.Context, *GetSecretRequest) (*GetSecretResponse, error) - // Gets a bulk of secrets - GetBulkSecret(context.Context, *GetBulkSecretRequest) (*GetBulkSecretResponse, error) - // Register an actor timer. - RegisterActorTimer(context.Context, *RegisterActorTimerRequest) (*emptypb.Empty, error) - // Unregister an actor timer. - UnregisterActorTimer(context.Context, *UnregisterActorTimerRequest) (*emptypb.Empty, error) - // Register an actor reminder. - RegisterActorReminder(context.Context, *RegisterActorReminderRequest) (*emptypb.Empty, error) - // Unregister an actor reminder. - UnregisterActorReminder(context.Context, *UnregisterActorReminderRequest) (*emptypb.Empty, error) - // Gets the state for a specific actor. - GetActorState(context.Context, *GetActorStateRequest) (*GetActorStateResponse, error) - // Executes state transactions for a specified actor - ExecuteActorStateTransaction(context.Context, *ExecuteActorStateTransactionRequest) (*emptypb.Empty, error) - // InvokeActor calls a method on an actor. - InvokeActor(context.Context, *InvokeActorRequest) (*InvokeActorResponse, error) - // GetConfiguration gets configuration from configuration store. - GetConfigurationAlpha1(context.Context, *GetConfigurationRequest) (*GetConfigurationResponse, error) - // SubscribeConfiguration gets configuration from configuration store and subscribe the updates event by grpc stream - SubscribeConfigurationAlpha1(*SubscribeConfigurationRequest, Dapr_SubscribeConfigurationAlpha1Server) error - // Gets metadata of the sidecar - GetMetadata(context.Context, *emptypb.Empty) (*GetMetadataResponse, error) - // Sets value in extended metadata of the sidecar - SetMetadata(context.Context, *SetMetadataRequest) (*emptypb.Empty, error) - // Shutdown the sidecar - Shutdown(context.Context, *emptypb.Empty) (*emptypb.Empty, error) -} - -// UnimplementedDaprServer should be embedded to have forward compatible implementations. -type UnimplementedDaprServer struct { -} - -func (UnimplementedDaprServer) InvokeService(context.Context, *InvokeServiceRequest) (*v1.InvokeResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method InvokeService not implemented") -} -func (UnimplementedDaprServer) GetState(context.Context, *GetStateRequest) (*GetStateResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetState not implemented") -} -func (UnimplementedDaprServer) GetBulkState(context.Context, *GetBulkStateRequest) (*GetBulkStateResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetBulkState not implemented") -} -func (UnimplementedDaprServer) SaveState(context.Context, *SaveStateRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method SaveState not implemented") -} -func (UnimplementedDaprServer) QueryStateAlpha1(context.Context, *QueryStateRequest) (*QueryStateResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method QueryStateAlpha1 not implemented") -} -func (UnimplementedDaprServer) DeleteState(context.Context, *DeleteStateRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method DeleteState not implemented") -} -func (UnimplementedDaprServer) DeleteBulkState(context.Context, *DeleteBulkStateRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method DeleteBulkState not implemented") -} -func (UnimplementedDaprServer) ExecuteStateTransaction(context.Context, *ExecuteStateTransactionRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method ExecuteStateTransaction not implemented") -} -func (UnimplementedDaprServer) PublishEvent(context.Context, *PublishEventRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method PublishEvent not implemented") -} -func (UnimplementedDaprServer) InvokeBinding(context.Context, *InvokeBindingRequest) (*InvokeBindingResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method InvokeBinding not implemented") -} -func (UnimplementedDaprServer) GetSecret(context.Context, *GetSecretRequest) (*GetSecretResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetSecret not implemented") -} -func (UnimplementedDaprServer) GetBulkSecret(context.Context, *GetBulkSecretRequest) (*GetBulkSecretResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetBulkSecret not implemented") -} -func (UnimplementedDaprServer) RegisterActorTimer(context.Context, *RegisterActorTimerRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method RegisterActorTimer not implemented") -} -func (UnimplementedDaprServer) UnregisterActorTimer(context.Context, *UnregisterActorTimerRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method UnregisterActorTimer not implemented") -} -func (UnimplementedDaprServer) RegisterActorReminder(context.Context, *RegisterActorReminderRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method RegisterActorReminder not implemented") -} -func (UnimplementedDaprServer) UnregisterActorReminder(context.Context, *UnregisterActorReminderRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method UnregisterActorReminder not implemented") -} -func (UnimplementedDaprServer) GetActorState(context.Context, *GetActorStateRequest) (*GetActorStateResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetActorState not implemented") -} -func (UnimplementedDaprServer) ExecuteActorStateTransaction(context.Context, *ExecuteActorStateTransactionRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method ExecuteActorStateTransaction not implemented") -} -func (UnimplementedDaprServer) InvokeActor(context.Context, *InvokeActorRequest) (*InvokeActorResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method InvokeActor not implemented") -} -func (UnimplementedDaprServer) GetConfigurationAlpha1(context.Context, *GetConfigurationRequest) (*GetConfigurationResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetConfigurationAlpha1 not implemented") -} -func (UnimplementedDaprServer) SubscribeConfigurationAlpha1(*SubscribeConfigurationRequest, Dapr_SubscribeConfigurationAlpha1Server) error { - return status.Errorf(codes.Unimplemented, "method SubscribeConfigurationAlpha1 not implemented") -} -func (UnimplementedDaprServer) GetMetadata(context.Context, *emptypb.Empty) (*GetMetadataResponse, error) { - return nil, status.Errorf(codes.Unimplemented, "method GetMetadata not implemented") -} -func (UnimplementedDaprServer) SetMetadata(context.Context, *SetMetadataRequest) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method SetMetadata not implemented") -} -func (UnimplementedDaprServer) Shutdown(context.Context, *emptypb.Empty) (*emptypb.Empty, error) { - return nil, status.Errorf(codes.Unimplemented, "method Shutdown not implemented") -} - -// UnsafeDaprServer may be embedded to opt out of forward compatibility for this service. -// Use of this interface is not recommended, as added methods to DaprServer will -// result in compilation errors. -type UnsafeDaprServer interface { - mustEmbedUnimplementedDaprServer() -} - -func RegisterDaprServer(s grpc.ServiceRegistrar, srv DaprServer) { - s.RegisterService(&Dapr_ServiceDesc, srv) -} - -func _Dapr_InvokeService_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(InvokeServiceRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).InvokeService(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/InvokeService", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).InvokeService(ctx, req.(*InvokeServiceRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetState(ctx, req.(*GetStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetBulkState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetBulkStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetBulkState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetBulkState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetBulkState(ctx, req.(*GetBulkStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_SaveState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(SaveStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).SaveState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/SaveState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).SaveState(ctx, req.(*SaveStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_QueryStateAlpha1_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(QueryStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).QueryStateAlpha1(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/QueryStateAlpha1", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).QueryStateAlpha1(ctx, req.(*QueryStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_DeleteState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(DeleteStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).DeleteState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/DeleteState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).DeleteState(ctx, req.(*DeleteStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_DeleteBulkState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(DeleteBulkStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).DeleteBulkState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/DeleteBulkState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).DeleteBulkState(ctx, req.(*DeleteBulkStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_ExecuteStateTransaction_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(ExecuteStateTransactionRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).ExecuteStateTransaction(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/ExecuteStateTransaction", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).ExecuteStateTransaction(ctx, req.(*ExecuteStateTransactionRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_PublishEvent_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(PublishEventRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).PublishEvent(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/PublishEvent", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).PublishEvent(ctx, req.(*PublishEventRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_InvokeBinding_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(InvokeBindingRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).InvokeBinding(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/InvokeBinding", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).InvokeBinding(ctx, req.(*InvokeBindingRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetSecret_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetSecretRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetSecret(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetSecret", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetSecret(ctx, req.(*GetSecretRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetBulkSecret_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetBulkSecretRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetBulkSecret(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetBulkSecret", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetBulkSecret(ctx, req.(*GetBulkSecretRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_RegisterActorTimer_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(RegisterActorTimerRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).RegisterActorTimer(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/RegisterActorTimer", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).RegisterActorTimer(ctx, req.(*RegisterActorTimerRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_UnregisterActorTimer_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(UnregisterActorTimerRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).UnregisterActorTimer(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/UnregisterActorTimer", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).UnregisterActorTimer(ctx, req.(*UnregisterActorTimerRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_RegisterActorReminder_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(RegisterActorReminderRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).RegisterActorReminder(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/RegisterActorReminder", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).RegisterActorReminder(ctx, req.(*RegisterActorReminderRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_UnregisterActorReminder_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(UnregisterActorReminderRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).UnregisterActorReminder(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/UnregisterActorReminder", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).UnregisterActorReminder(ctx, req.(*UnregisterActorReminderRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetActorState_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetActorStateRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetActorState(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetActorState", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetActorState(ctx, req.(*GetActorStateRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_ExecuteActorStateTransaction_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(ExecuteActorStateTransactionRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).ExecuteActorStateTransaction(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/ExecuteActorStateTransaction", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).ExecuteActorStateTransaction(ctx, req.(*ExecuteActorStateTransactionRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_InvokeActor_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(InvokeActorRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).InvokeActor(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/InvokeActor", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).InvokeActor(ctx, req.(*InvokeActorRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_GetConfigurationAlpha1_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(GetConfigurationRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetConfigurationAlpha1(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetConfigurationAlpha1", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetConfigurationAlpha1(ctx, req.(*GetConfigurationRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_SubscribeConfigurationAlpha1_Handler(srv interface{}, stream grpc.ServerStream) error { - m := new(SubscribeConfigurationRequest) - if err := stream.RecvMsg(m); err != nil { - return err - } - return srv.(DaprServer).SubscribeConfigurationAlpha1(m, &daprSubscribeConfigurationAlpha1Server{stream}) -} - -type Dapr_SubscribeConfigurationAlpha1Server interface { - Send(*SubscribeConfigurationResponse) error - grpc.ServerStream -} - -type daprSubscribeConfigurationAlpha1Server struct { - grpc.ServerStream -} - -func (x *daprSubscribeConfigurationAlpha1Server) Send(m *SubscribeConfigurationResponse) error { - return x.ServerStream.SendMsg(m) -} - -func _Dapr_GetMetadata_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(emptypb.Empty) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).GetMetadata(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/GetMetadata", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).GetMetadata(ctx, req.(*emptypb.Empty)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_SetMetadata_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(SetMetadataRequest) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).SetMetadata(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/SetMetadata", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).SetMetadata(ctx, req.(*SetMetadataRequest)) - } - return interceptor(ctx, in, info, handler) -} - -func _Dapr_Shutdown_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) { - in := new(emptypb.Empty) - if err := dec(in); err != nil { - return nil, err - } - if interceptor == nil { - return srv.(DaprServer).Shutdown(ctx, in) - } - info := &grpc.UnaryServerInfo{ - Server: srv, - FullMethod: "/dapr.proto.runtime.v1.Dapr/Shutdown", - } - handler := func(ctx context.Context, req interface{}) (interface{}, error) { - return srv.(DaprServer).Shutdown(ctx, req.(*emptypb.Empty)) - } - return interceptor(ctx, in, info, handler) -} - -// Dapr_ServiceDesc is the grpc.ServiceDesc for Dapr service. -// It's only intended for direct use with grpc.RegisterService, -// and not to be introspected or modified (even as a copy) -var Dapr_ServiceDesc = grpc.ServiceDesc{ - ServiceName: "dapr.proto.runtime.v1.Dapr", - HandlerType: (*DaprServer)(nil), - Methods: []grpc.MethodDesc{ - { - MethodName: "InvokeService", - Handler: _Dapr_InvokeService_Handler, - }, - { - MethodName: "GetState", - Handler: _Dapr_GetState_Handler, - }, - { - MethodName: "GetBulkState", - Handler: _Dapr_GetBulkState_Handler, - }, - { - MethodName: "SaveState", - Handler: _Dapr_SaveState_Handler, - }, - { - MethodName: "QueryStateAlpha1", - Handler: _Dapr_QueryStateAlpha1_Handler, - }, - { - MethodName: "DeleteState", - Handler: _Dapr_DeleteState_Handler, - }, - { - MethodName: "DeleteBulkState", - Handler: _Dapr_DeleteBulkState_Handler, - }, - { - MethodName: "ExecuteStateTransaction", - Handler: _Dapr_ExecuteStateTransaction_Handler, - }, - { - MethodName: "PublishEvent", - Handler: _Dapr_PublishEvent_Handler, - }, - { - MethodName: "InvokeBinding", - Handler: _Dapr_InvokeBinding_Handler, - }, - { - MethodName: "GetSecret", - Handler: _Dapr_GetSecret_Handler, - }, - { - MethodName: "GetBulkSecret", - Handler: _Dapr_GetBulkSecret_Handler, - }, - { - MethodName: "RegisterActorTimer", - Handler: _Dapr_RegisterActorTimer_Handler, - }, - { - MethodName: "UnregisterActorTimer", - Handler: _Dapr_UnregisterActorTimer_Handler, - }, - { - MethodName: "RegisterActorReminder", - Handler: _Dapr_RegisterActorReminder_Handler, - }, - { - MethodName: "UnregisterActorReminder", - Handler: _Dapr_UnregisterActorReminder_Handler, - }, - { - MethodName: "GetActorState", - Handler: _Dapr_GetActorState_Handler, - }, - { - MethodName: "ExecuteActorStateTransaction", - Handler: _Dapr_ExecuteActorStateTransaction_Handler, - }, - { - MethodName: "InvokeActor", - Handler: _Dapr_InvokeActor_Handler, - }, - { - MethodName: "GetConfigurationAlpha1", - Handler: _Dapr_GetConfigurationAlpha1_Handler, - }, - { - MethodName: "GetMetadata", - Handler: _Dapr_GetMetadata_Handler, - }, - { - MethodName: "SetMetadata", - Handler: _Dapr_SetMetadata_Handler, - }, - { - MethodName: "Shutdown", - Handler: _Dapr_Shutdown_Handler, - }, - }, - Streams: []grpc.StreamDesc{ - { - StreamName: "SubscribeConfigurationAlpha1", - Handler: _Dapr_SubscribeConfigurationAlpha1_Handler, - ServerStreams: true, - }, - }, - Metadata: "dapr/proto/runtime/v1/dapr.proto", -} diff --git a/pkg/grpc/default_api/api.go b/pkg/grpc/default_api/api.go index fa4903b98f..92dd521d84 100644 --- a/pkg/grpc/default_api/api.go +++ b/pkg/grpc/default_api/api.go @@ -19,6 +19,7 @@ package default_api import ( "context" "errors" + "strings" "sync" "github.com/dapr/components-contrib/secretstores" @@ -28,18 +29,19 @@ import ( "github.com/dapr/components-contrib/state" jsoniter "github.com/json-iterator/go" "google.golang.org/grpc" + "google.golang.org/protobuf/types/known/anypb" "mosn.io/pkg/log" + "google.golang.org/grpc/metadata" "mosn.io/layotto/components/configstores" "mosn.io/layotto/components/file" "mosn.io/layotto/components/hello" "mosn.io/layotto/components/lock" + runtime_common "mosn.io/layotto/components/pkg/common" "mosn.io/layotto/components/rpc" + mosninvoker "mosn.io/layotto/components/rpc/invoker/mosn" "mosn.io/layotto/components/sequencer" grpc_api "mosn.io/layotto/pkg/grpc" - "mosn.io/layotto/pkg/grpc/dapr" - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" "mosn.io/layotto/spec/proto/runtime/v1" runtimev1pb "mosn.io/layotto/spec/proto/runtime/v1" ) @@ -70,7 +72,6 @@ type API interface { // api is a default implementation for MosnRuntimeServer. type api struct { - daprAPI dapr.DaprGrpcAPI appId string hellos map[string]hello.HelloService configStores map[string]configstores.Store @@ -128,12 +129,8 @@ func NewAPI( transactionalStateStores[key] = store.(state.TransactionalStore) } } - dAPI := dapr.NewDaprServer(appId, hellos, configStores, rpcs, pubSubs, - stateStores, transactionalStateStores, - files, lockStores, sequencers, sendToOutputBindingFn, secretStores) // construct return &api{ - daprAPI: dAPI, appId: appId, hellos: hellos, configStores: configStores, @@ -186,33 +183,71 @@ func (a *api) getHello(name string) (hello.HelloService, error) { func (a *api) InvokeService(ctx context.Context, in *runtimev1pb.InvokeServiceRequest) (*runtimev1pb.InvokeResponse, error) { // convert request - var msg *dapr_common_v1pb.InvokeRequest + var msg *runtimev1pb.CommonInvokeRequest if in != nil && in.Message != nil { - msg = &dapr_common_v1pb.InvokeRequest{ + msg = &runtimev1pb.CommonInvokeRequest{ Method: in.Message.Method, Data: in.Message.Data, ContentType: in.Message.ContentType, } if in.Message.HttpExtension != nil { - msg.HttpExtension = &dapr_common_v1pb.HTTPExtension{ - Verb: dapr_common_v1pb.HTTPExtension_Verb(in.Message.HttpExtension.Verb), + msg.HttpExtension = &runtimev1pb.HTTPExtension{ + Verb: runtimev1pb.HTTPExtension_Verb(in.Message.HttpExtension.Verb), Querystring: in.Message.HttpExtension.Querystring, } } } - // delegate to dapr api implementation - daprResp, err := a.daprAPI.InvokeService(ctx, &dapr_v1pb.InvokeServiceRequest{ - Id: in.Id, - Message: msg, - }) - // handle error + + // convert request to RPCRequest,which is the parameter for RPC components + req := &rpc.RPCRequest{ + Ctx: ctx, + Id: in.Id, + Method: msg.GetMethod(), + ContentType: msg.GetContentType(), + Data: msg.GetData().GetValue(), + } + if md, ok := metadata.FromIncomingContext(ctx); ok { + req.Header = rpc.RPCHeader(md) + } else { + req.Header = rpc.RPCHeader(map[string][]string{}) + } + if ext := msg.GetHttpExtension(); ext != nil { + req.Header["verb"] = []string{ext.Verb.String()} + req.Header["query_string"] = []string{ext.GetQuerystring()} + } + + // route to the specific rpc.Invoker component. + // Only support mosn component now. + invoker, ok := a.rpcs[mosninvoker.Name] + if !ok { + return nil, errors.New("invoker not init") + } + + // delegate to the rpc.Invoker component + resp, err := invoker.Invoke(ctx, req) + + // check result if err != nil { - return nil, err + return nil, runtime_common.ToGrpcError(err) + } + if !resp.Success && resp.Error != nil { + return nil, runtime_common.ToGrpcError(resp.Error) + } + if resp.Header != nil { + header := metadata.Pairs() + for k, values := range resp.Header { + // fix https://github.com/mosn/layotto/issues/285 + if strings.EqualFold("content-length", k) { + continue + } + header.Set(k, values...) + } + grpc.SetHeader(ctx, header) } // convert resp return &runtimev1pb.InvokeResponse{ - Data: daprResp.Data, - ContentType: daprResp.ContentType, + ContentType: resp.ContentType, + Data: &anypb.Any{Value: resp.Data}, }, nil } diff --git a/pkg/grpc/default_api/api_binding.go b/pkg/grpc/default_api/api_binding.go index e527bb236d..dc13f4c359 100644 --- a/pkg/grpc/default_api/api_binding.go +++ b/pkg/grpc/default_api/api_binding.go @@ -19,22 +19,35 @@ package default_api import ( "context" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" + "github.com/dapr/components-contrib/bindings" + "google.golang.org/grpc/codes" + "google.golang.org/grpc/status" + + "mosn.io/layotto/pkg/messages" runtimev1pb "mosn.io/layotto/spec/proto/runtime/v1" + "mosn.io/pkg/log" ) func (a *api) InvokeBinding(ctx context.Context, in *runtimev1pb.InvokeBindingRequest) (*runtimev1pb.InvokeBindingResponse, error) { - daprResp, err := a.daprAPI.InvokeBinding(ctx, &dapr_v1pb.InvokeBindingRequest{ - Name: in.Name, - Data: in.Data, + req := &bindings.InvokeRequest{ Metadata: in.Metadata, - Operation: in.Operation, - }) + Operation: bindings.OperationKind(in.Operation), + } + if in.Data != nil { + req.Data = in.Data + } + + r := &runtimev1pb.InvokeBindingResponse{} + resp, err := a.sendToOutputBindingFn(in.Name, req) if err != nil { - return &runtimev1pb.InvokeBindingResponse{}, err + err = status.Errorf(codes.Internal, messages.ErrInvokeOutputBinding, in.Name, err.Error()) + log.DefaultLogger.Errorf("call out binding fail, err:%+v", err) + return r, err + } + if resp != nil { + r.Data = resp.Data + r.Metadata = resp.Metadata } - return &runtimev1pb.InvokeBindingResponse{ - Data: daprResp.Data, - Metadata: daprResp.Metadata, - }, nil + + return r, nil } diff --git a/pkg/grpc/default_api/api_pubsub.go b/pkg/grpc/default_api/api_pubsub.go index 0b4cb82229..add04aa4eb 100644 --- a/pkg/grpc/default_api/api_pubsub.go +++ b/pkg/grpc/default_api/api_pubsub.go @@ -21,31 +21,93 @@ import ( "fmt" "github.com/dapr/components-contrib/pubsub" + "github.com/google/uuid" + jsoniter "github.com/json-iterator/go" "google.golang.org/grpc/codes" "google.golang.org/grpc/status" "google.golang.org/protobuf/types/known/emptypb" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" - "encoding/base64" "github.com/dapr/components-contrib/contenttype" "mosn.io/pkg/log" + l8_comp_pubsub "mosn.io/layotto/components/pubsub" + "mosn.io/layotto/pkg/messages" runtimev1pb "mosn.io/layotto/spec/proto/runtime/v1" ) // Publishes events to the specific topic. func (a *api) PublishEvent(ctx context.Context, in *runtimev1pb.PublishEventRequest) (*emptypb.Empty, error) { - p := &dapr_v1pb.PublishEventRequest{ - Topic: in.GetTopic(), - PubsubName: in.GetPubsubName(), - Data: in.GetData(), - DataContentType: in.GetDataContentType(), - Metadata: in.GetMetadata(), + return a.doPublishEvent(ctx, in.GetPubsubName(), in.GetTopic(), + in.GetData(), in.GetDataContentType(), in.GetMetadata()) +} + +func (a *api) doPublishEvent(ctx context.Context, pubsubName string, topic string, data []byte, contentType string, metadata map[string]string) (*emptypb.Empty, error) { + // validate + if pubsubName == "" { + err := status.Error(codes.InvalidArgument, messages.ErrPubsubEmpty) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) + return &emptypb.Empty{}, err + } + if topic == "" { + err := status.Errorf(codes.InvalidArgument, messages.ErrTopicEmpty, pubsubName) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) + return &emptypb.Empty{}, err + } + + // get component + component, ok := a.pubSubs[pubsubName] + if !ok { + err := status.Errorf(codes.InvalidArgument, messages.ErrPubsubNotFound, pubsubName) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) + return &emptypb.Empty{}, err + } + + // new cloudevent request + if data == nil { + data = []byte{} + } + var envelope map[string]interface{} + var err error + if contenttype.IsCloudEventContentType(contentType) { + envelope, err = pubsub.FromCloudEvent(data, topic, pubsubName, "") + if err != nil { + err = status.Errorf(codes.InvalidArgument, messages.ErrPubsubCloudEventCreation, err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) + return &emptypb.Empty{}, err + } + } else { + envelope = pubsub.NewCloudEventsEnvelope(uuid.New().String(), l8_comp_pubsub.DefaultCloudEventSource, l8_comp_pubsub.DefaultCloudEventType, "", topic, pubsubName, + contentType, data, "") + } + + features := component.Features() + pubsub.ApplyMetadata(envelope, features, metadata) + b, err := jsoniter.ConfigFastest.Marshal(envelope) + if err != nil { + err = status.Errorf(codes.InvalidArgument, messages.ErrPubsubCloudEventsSer, topic, pubsubName, err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", err) + return &emptypb.Empty{}, err + } + + // publish + req := pubsub.PublishRequest{ + PubsubName: pubsubName, + Topic: topic, + Data: b, + Metadata: metadata, + } + + // TODO limit topic scope + err = component.Publish(&req) + if err != nil { + nerr := status.Errorf(codes.Internal, messages.ErrPubsubPublishMessage, topic, pubsubName, err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.PublishEvent] %v", nerr) + return &emptypb.Empty{}, nerr } - return a.daprAPI.PublishEvent(ctx, p) + return &emptypb.Empty{}, nil } func (a *api) startSubscribing() error { diff --git a/pkg/grpc/default_api/api_secret.go b/pkg/grpc/default_api/api_secret.go index b179327701..054767557b 100644 --- a/pkg/grpc/default_api/api_secret.go +++ b/pkg/grpc/default_api/api_secret.go @@ -19,48 +19,105 @@ package default_api import ( "context" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" + "github.com/dapr/components-contrib/secretstores" + "google.golang.org/grpc/codes" + "google.golang.org/grpc/status" + + "mosn.io/layotto/pkg/messages" runtimev1pb "mosn.io/layotto/spec/proto/runtime/v1" + "mosn.io/pkg/log" ) func (a *api) GetSecret(ctx context.Context, in *runtimev1pb.GetSecretRequest) (*runtimev1pb.GetSecretResponse, error) { - daprResp, err := a.daprAPI.GetSecret(ctx, &dapr_v1pb.GetSecretRequest{ - StoreName: in.StoreName, - Key: in.Key, - Metadata: in.Metadata, - }) + // check parameters + if a.secretStores == nil || len(a.secretStores) == 0 { + err := status.Error(codes.FailedPrecondition, messages.ErrSecretStoreNotConfigured) + log.DefaultLogger.Errorf("GetSecret fail,not configured err:%+v", err) + return &runtimev1pb.GetSecretResponse{}, err + } + secretStoreName := in.StoreName + if a.secretStores[secretStoreName] == nil { + err := status.Errorf(codes.InvalidArgument, messages.ErrSecretStoreNotFound, secretStoreName) + log.DefaultLogger.Errorf("GetSecret fail,not find err:%+v", err) + return &runtimev1pb.GetSecretResponse{}, err + } + + // TODO permission control + if !a.isSecretAllowed(in.StoreName, in.Key) { + err := status.Errorf(codes.PermissionDenied, messages.ErrPermissionDenied, in.Key, in.StoreName) + return &runtimev1pb.GetSecretResponse{}, err + } + + // delegate to components + req := secretstores.GetSecretRequest{ + Name: in.Key, + Metadata: in.Metadata, + } + + // parse result + getResponse, err := a.secretStores[secretStoreName].GetSecret(req) if err != nil { + err = status.Errorf(codes.Internal, messages.ErrSecretGet, req.Name, secretStoreName, err.Error()) + log.DefaultLogger.Errorf("GetSecret fail,get secret err:%+v", err) return &runtimev1pb.GetSecretResponse{}, err } - return &runtimev1pb.GetSecretResponse{Data: daprResp.Data}, nil + response := &runtimev1pb.GetSecretResponse{} + if getResponse.Data != nil { + response.Data = getResponse.Data + } + + return &runtimev1pb.GetSecretResponse{Data: response.Data}, nil } func (a *api) GetBulkSecret(ctx context.Context, in *runtimev1pb.GetBulkSecretRequest) (*runtimev1pb.GetBulkSecretResponse, error) { - daprResp, err := a.daprAPI.GetBulkSecret(ctx, &dapr_v1pb.GetBulkSecretRequest{ - StoreName: in.StoreName, - Metadata: in.Metadata, - }) + // check parameters + if a.secretStores == nil || len(a.secretStores) == 0 { + err := status.Error(codes.FailedPrecondition, messages.ErrSecretStoreNotConfigured) + log.DefaultLogger.Errorf("GetBulkSecret fail,not configured err:%+v", err) + return &runtimev1pb.GetBulkSecretResponse{}, err + } + secretStoreName := in.StoreName + if a.secretStores[secretStoreName] == nil { + err := status.Errorf(codes.InvalidArgument, messages.ErrSecretStoreNotFound, secretStoreName) + log.DefaultLogger.Errorf("GetBulkSecret fail,not find err:%+v", err) + return &runtimev1pb.GetBulkSecretResponse{}, err + } + + // delegate to components + req := secretstores.BulkGetSecretRequest{ + Metadata: in.Metadata, + } + getResponse, err := a.secretStores[secretStoreName].BulkGetSecret(req) + + // parse result if err != nil { + err = status.Errorf(codes.Internal, messages.ErrBulkSecretGet, secretStoreName, err.Error()) + log.DefaultLogger.Errorf("GetBulkSecret fail,bulk secret err:%+v", err) return &runtimev1pb.GetBulkSecretResponse{}, err } - return &runtimev1pb.GetBulkSecretResponse{ - Data: convertSecretResponseMap(daprResp.Data), - }, nil -} -func convertSecretResponseMap(data map[string]*dapr_v1pb.SecretResponse) map[string]*runtimev1pb.SecretResponse { - if data == nil { - return nil + // filter result + filteredSecrets := map[string]map[string]string{} + for key, v := range getResponse.Data { + // TODO: permission control + if a.isSecretAllowed(secretStoreName, key) { + filteredSecrets[key] = v + } else { + log.DefaultLogger.Debugf(messages.ErrPermissionDenied, key, in.StoreName) + } } - result := make(map[string]*runtimev1pb.SecretResponse) - for k, v := range data { - var converted *runtimev1pb.SecretResponse - if v != nil { - converted = &runtimev1pb.SecretResponse{ - Secrets: v.Secrets, - } + response := &runtimev1pb.GetBulkSecretResponse{} + if getResponse.Data != nil { + response.Data = map[string]*runtimev1pb.SecretResponse{} + for key, v := range filteredSecrets { + response.Data[key] = &runtimev1pb.SecretResponse{Secrets: v} } - result[k] = converted } - return result + + return response, nil +} + +func (a *api) isSecretAllowed(storeName string, key string) bool { + // TODO: add permission control + return true } diff --git a/pkg/grpc/default_api/api_state.go b/pkg/grpc/default_api/api_state.go index f85d87fbb0..663677cdc5 100644 --- a/pkg/grpc/default_api/api_state.go +++ b/pkg/grpc/default_api/api_state.go @@ -19,39 +19,58 @@ package default_api import ( "context" + "github.com/dapr/components-contrib/state" "github.com/golang/protobuf/ptypes/empty" "google.golang.org/grpc/codes" "google.golang.org/grpc/status" "google.golang.org/protobuf/types/known/emptypb" - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" + "github.com/gammazero/workerpool" + "mosn.io/layotto/pkg/common" + "mosn.io/layotto/pkg/messages" + state2 "mosn.io/layotto/pkg/runtime/state" runtimev1pb "mosn.io/layotto/spec/proto/runtime/v1" + "mosn.io/pkg/log" ) // GetState obtains the state for a specific key. func (a *api) GetState(ctx context.Context, in *runtimev1pb.GetStateRequest) (*runtimev1pb.GetStateResponse, error) { - // Check if the StateRequest is exists + // check if the StateRequest is exists if in == nil { return &runtimev1pb.GetStateResponse{}, status.Error(codes.InvalidArgument, "GetStateRequest is nil") } - // convert request - daprReq := &dapr_v1pb.GetStateRequest{ - StoreName: in.GetStoreName(), - Key: in.GetKey(), - Consistency: dapr_common_v1pb.StateOptions_StateConsistency(in.GetConsistency()), - Metadata: in.GetMetadata(), + + // get store + store, err := a.getStateStore(in.GetStoreName()) + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.GetState] error: %v", err) + return nil, err } - // Generate response by request - resp, err := a.daprAPI.GetState(ctx, daprReq) + + // generate the actual key + key, err := state2.GetModifiedStateKey(in.GetKey(), in.GetStoreName(), a.appId) if err != nil { return &runtimev1pb.GetStateResponse{}, err } - return &runtimev1pb.GetStateResponse{ - Data: resp.GetData(), - Etag: resp.GetEtag(), - Metadata: resp.GetMetadata(), - }, nil + req := &state.GetRequest{ + Key: key, + Metadata: in.GetMetadata(), + Options: state.GetStateOption{ + Consistency: StateConsistencyToString(in.GetConsistency()), + }, + } + + // query + compResp, err := store.Get(req) + + // check result + if err != nil { + err = status.Errorf(codes.Internal, messages.ErrStateGet, in.GetKey(), in.GetStoreName(), err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.GetState] %v", err) + return &runtimev1pb.GetStateResponse{}, err + } + + return GetResponse2GetStateResponse(compResp), nil } func (a *api) SaveState(ctx context.Context, in *runtimev1pb.SaveStateRequest) (*emptypb.Empty, error) { @@ -59,32 +78,50 @@ func (a *api) SaveState(ctx context.Context, in *runtimev1pb.SaveStateRequest) ( if in == nil { return &emptypb.Empty{}, status.Error(codes.InvalidArgument, "SaveStateRequest is nil") } - // convert request - daprReq := &dapr_v1pb.SaveStateRequest{ - StoreName: in.StoreName, - States: convertStatesToDaprPB(in.States), + + // get store + store, err := a.getStateStore(in.StoreName) + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.SaveState] error: %v", err) + return &emptypb.Empty{}, err } - // delegate to dapr api implementation - return a.daprAPI.SaveState(ctx, daprReq) + + // convert requests + reqs := []state.SetRequest{} + for _, s := range in.States { + key, err := state2.GetModifiedStateKey(s.Key, in.StoreName, a.appId) + if err != nil { + return &emptypb.Empty{}, err + } + reqs = append(reqs, *StateItem2SetRequest(s, key)) + } + + // query + err = store.BulkSet(reqs) + + // check result + if err != nil { + err = a.wrapDaprComponentError(err, messages.ErrStateSave, in.StoreName, err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.SaveState] error: %v", err) + return &emptypb.Empty{}, err + } + + return &emptypb.Empty{}, nil } // GetBulkState gets a batch of state data func (a *api) GetBulkState(ctx context.Context, in *runtimev1pb.GetBulkStateRequest) (*runtimev1pb.GetBulkStateResponse, error) { + // Check if the request is nil if in == nil { return &runtimev1pb.GetBulkStateResponse{}, status.Error(codes.InvalidArgument, "GetBulkStateRequest is nil") } - // convert request - daprReq := &dapr_v1pb.GetBulkStateRequest{ - StoreName: in.GetStoreName(), - Keys: in.GetKeys(), - Parallelism: in.GetParallelism(), - Metadata: in.GetMetadata(), - } + // Generate response by request - resp, err := a.daprAPI.GetBulkState(ctx, daprReq) + resp, err := a.getBulkState(ctx, in) if err != nil { return &runtimev1pb.GetBulkStateResponse{}, err } + ret := &runtimev1pb.GetBulkStateResponse{Items: make([]*runtimev1pb.BulkStateItem, 0)} for _, item := range resp.Items { ret.Items = append(ret.Items, &runtimev1pb.BulkStateItem{ @@ -95,107 +132,399 @@ func (a *api) GetBulkState(ctx context.Context, in *runtimev1pb.GetBulkStateRequ Metadata: item.GetMetadata(), }) } + return ret, nil } func (a *api) DeleteState(ctx context.Context, in *runtimev1pb.DeleteStateRequest) (*emptypb.Empty, error) { + // Check if the request is nil if in == nil { return &emptypb.Empty{}, status.Error(codes.InvalidArgument, "DeleteStateRequest is nil") } - // convert request - daprReq := &dapr_v1pb.DeleteStateRequest{ - StoreName: in.GetStoreName(), - Key: in.GetKey(), - Etag: convertEtagToDaprPB(in.Etag), - Options: convertOptionsToDaprPB(in.Options), - Metadata: in.GetMetadata(), + + // get store + store, err := a.getStateStore(in.GetStoreName()) + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.DeleteState] error: %v", err) + return &emptypb.Empty{}, err } - return a.daprAPI.DeleteState(ctx, daprReq) + + // generate the actual key + key, err := state2.GetModifiedStateKey(in.GetKey(), in.GetStoreName(), a.appId) + if err != nil { + return &empty.Empty{}, err + } + + // convert and send request + err = store.Delete(DeleteStateRequest2DeleteRequest(in, key)) + + // 4. check result + if err != nil { + err = a.wrapDaprComponentError(err, messages.ErrStateDelete, in.GetKey(), err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.DeleteState] error: %v", err) + return &empty.Empty{}, err + } + + return &empty.Empty{}, nil } func (a *api) DeleteBulkState(ctx context.Context, in *runtimev1pb.DeleteBulkStateRequest) (*empty.Empty, error) { + // Check if the request is nil if in == nil { return &emptypb.Empty{}, status.Error(codes.InvalidArgument, "DeleteBulkStateRequest is nil") } + + // get store + store, err := a.getStateStore(in.GetStoreName()) + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.DeleteBulkState] error: %v", err) + return &empty.Empty{}, err + } + // convert request - daprReq := &dapr_v1pb.DeleteBulkStateRequest{ - StoreName: in.GetStoreName(), - States: convertStatesToDaprPB(in.States), + reqs := make([]state.DeleteRequest, 0, len(in.GetStates())) + for _, item := range in.States { + key, err := state2.GetModifiedStateKey(item.Key, in.GetStoreName(), a.appId) + if err != nil { + return &empty.Empty{}, err + } + reqs = append(reqs, *StateItem2DeleteRequest(item, key)) + } + + // send request + err = store.BulkDelete(reqs) + + // check result + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.DeleteBulkState] error: %v", err) + return &emptypb.Empty{}, err } - return a.daprAPI.DeleteBulkState(ctx, daprReq) + + return &emptypb.Empty{}, nil } func (a *api) ExecuteStateTransaction(ctx context.Context, in *runtimev1pb.ExecuteStateTransactionRequest) (*emptypb.Empty, error) { + // Check if the request is nil if in == nil { return &emptypb.Empty{}, status.Error(codes.InvalidArgument, "ExecuteStateTransactionRequest is nil") } + + // 1. check params + if a.stateStores == nil || len(a.stateStores) == 0 { + err := status.Error(codes.FailedPrecondition, messages.ErrStateStoresNotConfigured) + log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) + return &emptypb.Empty{}, err + } + storeName := in.GetStoreName() + if a.stateStores[storeName] == nil { + err := status.Errorf(codes.InvalidArgument, messages.ErrStateStoreNotFound, storeName) + log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) + return &emptypb.Empty{}, err + } + + // find store + store, ok := a.transactionalStateStores[storeName] + if !ok { + err := status.Errorf(codes.Unimplemented, messages.ErrStateStoreNotSupported, storeName) + log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) + return &emptypb.Empty{}, err + } + // convert request - daprReq := &dapr_v1pb.ExecuteStateTransactionRequest{ - StoreName: in.GetStoreName(), - Operations: convertTransactionalStateOperationToDaprPB(in.Operations), + operations := []state.TransactionalStateOperation{} + for _, op := range in.Operations { + // extract and validate fields + var operation state.TransactionalStateOperation + var req = op.Request + // tolerant npe + if req == nil { + log.DefaultLogger.Warnf("[runtime] [grpc.ExecuteStateTransaction] one of TransactionalStateOperation.Request is nil") + continue + } + key, err := state2.GetModifiedStateKey(req.Key, in.GetStoreName(), a.appId) + if err != nil { + return &emptypb.Empty{}, err + } + // 3.2. prepare TransactionalStateOperation struct according to the operation type + switch state.OperationType(op.OperationType) { + case state.Upsert: + operation = state.TransactionalStateOperation{ + Operation: state.Upsert, + Request: *StateItem2SetRequest(req, key), + } + case state.Delete: + operation = state.TransactionalStateOperation{ + Operation: state.Delete, + Request: *StateItem2DeleteRequest(req, key), + } + default: + err := status.Errorf(codes.Unimplemented, messages.ErrNotSupportedStateOperation, op.OperationType) + log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) + return &emptypb.Empty{}, err + } + operations = append(operations, operation) + } + + // submit transactional request + err := store.Multi(&state.TransactionalStateRequest{ + Operations: operations, Metadata: in.GetMetadata(), + }) + + // check result + if err != nil { + err = status.Errorf(codes.Internal, messages.ErrStateTransaction, err.Error()) + log.DefaultLogger.Errorf("[runtime] [grpc.ExecuteStateTransaction] error: %v", err) + return &emptypb.Empty{}, err } - return a.daprAPI.ExecuteStateTransaction(ctx, daprReq) + + return &emptypb.Empty{}, nil } -// some code for converting from runtimev1pb to dapr_common_v1pb +// the specific processing logic of GetBulkState +func (a *api) getBulkState(ctx context.Context, in *runtimev1pb.GetBulkStateRequest) (*runtimev1pb.GetBulkStateResponse, error) { + // get store + store, err := a.getStateStore(in.GetStoreName()) + if err != nil { + log.DefaultLogger.Errorf("[runtime] [grpc.GetBulkState] error: %v", err) + return &runtimev1pb.GetBulkStateResponse{}, err + } -func convertEtagToDaprPB(etag *runtimev1pb.Etag) *dapr_common_v1pb.Etag { - if etag == nil { - return &dapr_common_v1pb.Etag{} + bulkResp := &runtimev1pb.GetBulkStateResponse{} + if len(in.GetKeys()) == 0 { + return bulkResp, nil } - return &dapr_common_v1pb.Etag{Value: etag.GetValue()} + + // store.BulkGet + // convert reqs + reqs := make([]state.GetRequest, len(in.GetKeys())) + for i, k := range in.GetKeys() { + key, err := state2.GetModifiedStateKey(k, in.GetStoreName(), a.appId) + if err != nil { + return &runtimev1pb.GetBulkStateResponse{}, err + } + r := state.GetRequest{ + Key: key, + Metadata: in.GetMetadata(), + } + reqs[i] = r + } + + // query + support, responses, err := store.BulkGet(reqs) + if err != nil { + return bulkResp, err + } + // parse and return result if store supports this method + if support { + for i := 0; i < len(responses); i++ { + bulkResp.Items = append(bulkResp.Items, BulkGetResponse2BulkStateItem(&responses[i])) + } + return bulkResp, nil + } + + // Simulate the method if the store doesn't support it + n := len(reqs) + pool := workerpool.New(int(in.GetParallelism())) + resultCh := make(chan *runtimev1pb.BulkStateItem, n) + for i := 0; i < n; i++ { + pool.Submit(generateGetStateTask(store, &reqs[i], resultCh)) + } + pool.StopWait() + for { + select { + case item, ok := <-resultCh: + if !ok { + return bulkResp, nil + } + bulkResp.Items = append(bulkResp.Items, item) + default: + return bulkResp, nil + } + } +} + +func (a *api) getStateStore(name string) (state.Store, error) { + // check if the stateStores exists + if a.stateStores == nil || len(a.stateStores) == 0 { + return nil, status.Error(codes.FailedPrecondition, messages.ErrStateStoresNotConfigured) + } + // check name + if a.stateStores[name] == nil { + return nil, status.Errorf(codes.InvalidArgument, messages.ErrStateStoreNotFound, name) + } + return a.stateStores[name], nil } -func convertOptionsToDaprPB(op *runtimev1pb.StateOptions) *dapr_common_v1pb.StateOptions { - if op == nil { - return &dapr_common_v1pb.StateOptions{} + +func StateConsistencyToString(c runtimev1pb.StateOptions_StateConsistency) string { + // check + switch c { + case runtimev1pb.StateOptions_CONSISTENCY_EVENTUAL: + return "eventual" + case runtimev1pb.StateOptions_CONSISTENCY_STRONG: + return "strong" + } + return "" +} + +func StateConcurrencyToString(c runtimev1pb.StateOptions_StateConcurrency) string { + // check the StateOptions of StateOptions_StateConcurrency + switch c { + case runtimev1pb.StateOptions_CONCURRENCY_FIRST_WRITE: + return "first-write" + case runtimev1pb.StateOptions_CONCURRENCY_LAST_WRITE: + return "last-write" } - return &dapr_common_v1pb.StateOptions{ - Concurrency: dapr_common_v1pb.StateOptions_StateConcurrency(op.Concurrency), - Consistency: dapr_common_v1pb.StateOptions_StateConsistency(op.Consistency), + + return "" +} + +func GetResponse2GetStateResponse(compResp *state.GetResponse) *runtimev1pb.GetStateResponse { + // Initialize an element of type GetStateResponse + resp := &runtimev1pb.GetStateResponse{} + // check if the compResp exists + if compResp != nil { + resp.Etag = common.PointerToString(compResp.ETag) + resp.Data = compResp.Data + resp.Metadata = compResp.Metadata } + return resp } -func convertStatesToDaprPB(states []*runtimev1pb.StateItem) []*dapr_common_v1pb.StateItem { - dStates := make([]*dapr_common_v1pb.StateItem, 0, len(states)) - if states == nil { - return dStates +func StateItem2SetRequest(grpcReq *runtimev1pb.StateItem, key string) *state.SetRequest { + // Set the key for the request + req := &state.SetRequest{ + Key: key, + } + // check if the grpcReq exists + if grpcReq == nil { + return req } - for _, s := range states { - ds := &dapr_common_v1pb.StateItem{ - Key: s.Key, - Value: s.Value, - Metadata: s.Metadata, + // Assign the value of grpcReq property to req + req.Metadata = grpcReq.Metadata + req.Value = grpcReq.Value + // Check grpcReq.Etag + if grpcReq.Etag != nil { + req.ETag = &grpcReq.Etag.Value + } + // Check grpcReq.Options + if grpcReq.Options != nil { + req.Options = state.SetStateOption{ + Consistency: StateConsistencyToString(grpcReq.Options.Consistency), + Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), } - if s.Etag != nil { - ds.Etag = convertEtagToDaprPB(s.Etag) + } + return req +} + +// wrapDaprComponentError parse and wrap error from dapr component +func (a *api) wrapDaprComponentError(err error, format string, args ...interface{}) error { + e, ok := err.(*state.ETagError) + if !ok { + return status.Errorf(codes.Internal, format, args...) + } + // check the Kind of error + switch e.Kind() { + case state.ETagMismatch: + return status.Errorf(codes.Aborted, format, args...) + case state.ETagInvalid: + return status.Errorf(codes.InvalidArgument, format, args...) + } + + return status.Errorf(codes.Internal, format, args...) +} + +// converting from BulkGetResponse to BulkStateItem +func BulkGetResponse2BulkStateItem(compResp *state.BulkGetResponse) *runtimev1pb.BulkStateItem { + if compResp == nil { + return &runtimev1pb.BulkStateItem{} + } + return &runtimev1pb.BulkStateItem{ + Key: state2.GetOriginalStateKey(compResp.Key), + Data: compResp.Data, + Etag: common.PointerToString(compResp.ETag), + Metadata: compResp.Metadata, + Error: compResp.Error, + } +} + +func generateGetStateTask(store state.Store, req *state.GetRequest, resultCh chan *runtimev1pb.BulkStateItem) func() { + return func() { + // get + r, err := store.Get(req) + // convert + var item *runtimev1pb.BulkStateItem + if err != nil { + item = &runtimev1pb.BulkStateItem{ + Key: state2.GetOriginalStateKey(req.Key), + Error: err.Error(), + } + } else { + item = GetResponse2BulkStateItem(r, state2.GetOriginalStateKey(req.Key)) } - if s.Options != nil { - ds.Options = convertOptionsToDaprPB(s.Options) + // collect result + select { + case resultCh <- item: + default: + //never happen + log.DefaultLogger.Errorf("[api.generateGetStateTask] can not push result to the resultCh. item: %+v", item) } - dStates = append(dStates, ds) - } - return dStates -} - -func convertTransactionalStateOperationToDaprPB(ops []*runtimev1pb.TransactionalStateOperation) []*dapr_v1pb.TransactionalStateOperation { - ret := make([]*dapr_v1pb.TransactionalStateOperation, 0, len(ops)) - for i := 0; i < len(ops); i++ { - op := ops[i] - var req *dapr_common_v1pb.StateItem - if op.Request != nil { - req = &dapr_common_v1pb.StateItem{ - Key: op.GetRequest().GetKey(), - Value: op.GetRequest().GetValue(), - Etag: convertEtagToDaprPB(op.GetRequest().GetEtag()), - Metadata: op.GetRequest().GetMetadata(), - Options: convertOptionsToDaprPB(op.GetRequest().GetOptions()), - } + } +} + +// converting from GetResponse to BulkStateItem +func GetResponse2BulkStateItem(compResp *state.GetResponse, key string) *runtimev1pb.BulkStateItem { + // convert + resp := &runtimev1pb.BulkStateItem{} + resp.Key = key + if compResp != nil { + resp.Data = compResp.Data + resp.Etag = common.PointerToString(compResp.ETag) + resp.Metadata = compResp.Metadata + } + return resp +} + +// converting from DeleteStateRequest to DeleteRequest +func DeleteStateRequest2DeleteRequest(grpcReq *runtimev1pb.DeleteStateRequest, key string) *state.DeleteRequest { + // convert + req := &state.DeleteRequest{ + Key: key, + } + if grpcReq == nil { + return req + } + req.Metadata = grpcReq.Metadata + if grpcReq.Etag != nil { + req.ETag = &grpcReq.Etag.Value + } + if grpcReq.Options != nil { + req.Options = state.DeleteStateOption{ + Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), + Consistency: StateConsistencyToString(grpcReq.Options.Consistency), + } + } + return req +} + +// converting from StateItem to DeleteRequest +func StateItem2DeleteRequest(grpcReq *runtimev1pb.StateItem, key string) *state.DeleteRequest { + //convert + req := &state.DeleteRequest{ + Key: key, + } + if grpcReq == nil { + return req + } + req.Metadata = grpcReq.Metadata + if grpcReq.Etag != nil { + req.ETag = &grpcReq.Etag.Value + } + if grpcReq.Options != nil { + req.Options = state.DeleteStateOption{ + Concurrency: StateConcurrencyToString(grpcReq.Options.Concurrency), + Consistency: StateConsistencyToString(grpcReq.Options.Consistency), } - ret = append(ret, &dapr_v1pb.TransactionalStateOperation{ - OperationType: op.OperationType, - Request: req, - }) } - return ret + return req } diff --git a/pkg/mock/runtime/appcallback/dapr_appcallback.go b/pkg/mock/runtime/appcallback/dapr_appcallback.go deleted file mode 100644 index 66e0a5767d..0000000000 --- a/pkg/mock/runtime/appcallback/dapr_appcallback.go +++ /dev/null @@ -1,96 +0,0 @@ -package mock_appcallback - -import ( - "context" - "reflect" - - "github.com/golang/mock/gomock" - empty "google.golang.org/protobuf/types/known/emptypb" - - dapr_common_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/common/v1" - dapr_v1pb "mosn.io/layotto/pkg/grpc/dapr/proto/runtime/v1" -) - -type MockDaprAppCallbackServer struct { - ctrl *gomock.Controller - recorder *MockDaprAppCallbackServerMockRecorder -} - -type MockDaprAppCallbackServerMockRecorder struct { - mock *MockDaprAppCallbackServer -} - -func (m *MockDaprAppCallbackServer) OnInvoke(ctx context.Context, in *dapr_common_v1pb.InvokeRequest) (*dapr_common_v1pb.InvokeResponse, error) { - m.ctrl.T.Helper() - ret := m.ctrl.Call(m, "ListTopicSubscriptions", ctx, in) - ret0, _ := ret[0].(*dapr_common_v1pb.InvokeResponse) - ret1, _ := ret[1].(error) - return ret0, ret1 -} - -func (m *MockDaprAppCallbackServer) ListInputBindings(ctx context.Context, in *empty.Empty) (*dapr_v1pb.ListInputBindingsResponse, error) { - m.ctrl.T.Helper() - ret := m.ctrl.Call(m, "ListTopicSubscriptions", ctx, in) - ret0, _ := ret[0].(*dapr_v1pb.ListInputBindingsResponse) - ret1, _ := ret[1].(error) - return ret0, ret1 -} - -func (m *MockDaprAppCallbackServer) OnBindingEvent(ctx context.Context, in *dapr_v1pb.BindingEventRequest) (*dapr_v1pb.BindingEventResponse, error) { - m.ctrl.T.Helper() - ret := m.ctrl.Call(m, "ListTopicSubscriptions", ctx, in) - ret0, _ := ret[0].(*dapr_v1pb.BindingEventResponse) - ret1, _ := ret[1].(error) - return ret0, ret1 -} - -func (m *MockDaprAppCallbackServer) ListTopicSubscriptions(arg0 context.Context, arg1 *empty.Empty) (*dapr_v1pb.ListTopicSubscriptionsResponse, error) { - m.ctrl.T.Helper() - ret := m.ctrl.Call(m, "ListTopicSubscriptions", arg0, arg1) - ret0, _ := ret[0].(*dapr_v1pb.ListTopicSubscriptionsResponse) - ret1, _ := ret[1].(error) - return ret0, ret1 -} - -func (m *MockDaprAppCallbackServer) OnTopicEvent(ctx context.Context, in *dapr_v1pb.TopicEventRequest) (*dapr_v1pb.TopicEventResponse, error) { - m.ctrl.T.Helper() - ret := m.ctrl.Call(m, "OnTopicEvent", ctx, in) - ret0, _ := ret[0].(*dapr_v1pb.TopicEventResponse) - ret1, _ := ret[1].(error) - return ret0, ret1 -} - -func (mr *MockDaprAppCallbackServerMockRecorder) OnInvoke(arg0, arg1 interface{}) *gomock.Call { - mr.mock.ctrl.T.Helper() - return mr.mock.ctrl.RecordCallWithMethodType(mr.mock, "OnInvoke", reflect.TypeOf((*MockDaprAppCallbackServer)(nil).OnInvoke), arg0, arg1) -} - -func (mr *MockDaprAppCallbackServerMockRecorder) ListInputBindings(arg0, arg1 interface{}) *gomock.Call { - mr.mock.ctrl.T.Helper() - return mr.mock.ctrl.RecordCallWithMethodType(mr.mock, "ListInputBindings", reflect.TypeOf((*MockDaprAppCallbackServer)(nil).ListInputBindings), arg0, arg1) -} - -func (mr *MockDaprAppCallbackServerMockRecorder) OnBindingEvent(arg0, arg1 interface{}) *gomock.Call { - mr.mock.ctrl.T.Helper() - return mr.mock.ctrl.RecordCallWithMethodType(mr.mock, "OnBindingEvent", reflect.TypeOf((*MockDaprAppCallbackServer)(nil).OnBindingEvent), arg0, arg1) -} - -func (mr *MockDaprAppCallbackServerMockRecorder) ListTopicSubscriptions(arg0, arg1 interface{}) *gomock.Call { - mr.mock.ctrl.T.Helper() - return mr.mock.ctrl.RecordCallWithMethodType(mr.mock, "ListTopicSubscriptions", reflect.TypeOf((*MockDaprAppCallbackServer)(nil).ListTopicSubscriptions), arg0, arg1) -} - -func (mr *MockDaprAppCallbackServerMockRecorder) OnTopicEvent(arg0, arg1 interface{}) *gomock.Call { - mr.mock.ctrl.T.Helper() - return mr.mock.ctrl.RecordCallWithMethodType(mr.mock, "OnTopicEvent", reflect.TypeOf((*MockDaprAppCallbackServer)(nil).OnTopicEvent), arg0, arg1) -} - -func NewMockDaprAppCallbackServer(ctrl *gomock.Controller) *MockDaprAppCallbackServer { - mock := &MockDaprAppCallbackServer{ctrl: ctrl} - mock.recorder = &MockDaprAppCallbackServerMockRecorder{mock} - return mock -} - -func (m *MockDaprAppCallbackServer) EXPECT() *MockDaprAppCallbackServerMockRecorder { - return m.recorder -}