From d991947d4cfd7e2d2ccdaf0e2eedc639acdcb6a7 Mon Sep 17 00:00:00 2001 From: wangchuxiao Date: Thu, 2 Mar 2023 12:00:31 +0800 Subject: [PATCH] proto modify --- internal/msggateway/relay_rpc_server.go | 8 +- internal/msggateway/ws_server.go | 4 +- .../msgtransfer/online_history_msg_handler.go | 8 +- internal/push/init.go | 6 +- internal/push/push_rpc_server.go | 87 +- internal/push/push_to_client.go | 46 +- internal/rpc/auth/auth.go | 3 +- internal/rpc/friend/friend.go | 2 +- internal/rpc/msg/server.go | 8 +- internal/rpc/third/third.go | 4 +- internal/rpc/user/user.go | 16 +- internal/startrpc/start.go | 5 +- pkg/common/db/cache/redis.go | 87 +- pkg/common/db/controller/chatlog.go | 12 +- pkg/common/db/controller/push.go | 6 + pkg/common/db/table/relation/chatlog.go | 2 +- pkg/common/kafka/producer.go | 6 +- pkg/proto/msg/msg.proto | 183 +- pkg/proto/msggateway/msg_gateway.proto | 36 +- pkg/proto/rtc/rtc.pb.go | 2834 +---------------- pkg/proto/third/third.pb.go | 134 +- 21 files changed, 344 insertions(+), 3153 deletions(-) diff --git a/internal/msggateway/relay_rpc_server.go b/internal/msggateway/relay_rpc_server.go index e7b880e1b..7c3da0619 100644 --- a/internal/msggateway/relay_rpc_server.go +++ b/internal/msggateway/relay_rpc_server.go @@ -173,7 +173,7 @@ func (r *RPCServer) GetUsersOnlineStatus(_ context.Context, req *msggateway.GetU func (r *RPCServer) SuperGroupOnlineBatchPushOneMsg(_ context.Context, req *msggateway.OnlineBatchPushOneMsgReq) (*msggateway.OnlineBatchPushOneMsgResp, error) { log.NewInfo(req.OperationID, "BatchPushMsgToUser is arriving", req.String()) - var singleUserResult []*msggateway.SingelMsgToUserResultList + var singleUserResult []*msggateway.SingleMsgToUserResultList //r.GetBatchMsgForPush(req.OperationID,req.MsgData,req.PushToUserIDList,) msgBytes, _ := proto.Marshal(req.MsgData) mReply := Resp{ @@ -189,7 +189,7 @@ func (r *RPCServer) SuperGroupOnlineBatchPushOneMsg(_ context.Context, req *msgg } for _, v := range req.PushToUserIDList { var resp []*msggateway.SingleMsgToUserPlatform - tempT := &msggateway.SingelMsgToUserResultList{ + tempT := &msggateway.SingleMsgToUserResultList{ UserID: v, } userConnMap := ws.getUserAllCons(v) @@ -224,11 +224,11 @@ func (r *RPCServer) SuperGroupOnlineBatchPushOneMsg(_ context.Context, req *msgg } func (r *RPCServer) OnlineBatchPushOneMsg(_ context.Context, req *msggateway.OnlineBatchPushOneMsgReq) (*msggateway.OnlineBatchPushOneMsgResp, error) { log.NewInfo(req.OperationID, "BatchPushMsgToUser is arriving", req.String()) - var singleUserResult []*msggateway.SingelMsgToUserResultList + var singleUserResult []*msggateway.SingleMsgToUserResultList for _, v := range req.PushToUserIDList { var resp []*msggateway.SingleMsgToUserPlatform - tempT := &msggateway.SingelMsgToUserResultList{ + tempT := &msggateway.SingleMsgToUserResultList{ UserID: v, } userConnMap := ws.getUserAllCons(v) diff --git a/internal/msggateway/ws_server.go b/internal/msggateway/ws_server.go index d744dc098..401f811ec 100644 --- a/internal/msggateway/ws_server.go +++ b/internal/msggateway/ws_server.go @@ -4,9 +4,9 @@ import ( "OpenIM/pkg/common/config" "OpenIM/pkg/common/constant" "OpenIM/pkg/common/log" - prome "OpenIM/pkg/common/prome" + "OpenIM/pkg/common/prome" "OpenIM/pkg/common/tokenverify" - msggateway "OpenIM/pkg/proto/relay" + "OpenIM/pkg/proto/msggateway" "OpenIM/pkg/utils" "bytes" "compress/gzip" diff --git a/internal/msgtransfer/online_history_msg_handler.go b/internal/msgtransfer/online_history_msg_handler.go index 5146feb13..bb394cd4b 100644 --- a/internal/msgtransfer/online_history_msg_handler.go +++ b/internal/msgtransfer/online_history_msg_handler.go @@ -242,10 +242,8 @@ func (och *OnlineHistoryRedisConsumerHandler) ConsumeClaim(sess sarama.ConsumerG } func (och *OnlineHistoryRedisConsumerHandler) sendMessageToPushMQ(ctx context.Context, message *pbMsg.MsgDataToMQ, pushToUserID string) { - log.Info(message.OperationID, utils.GetSelfFuncName(), "msg ", message.String(), pushToUserID) - rpcPushMsg := pbPush.PushMsgReq{OperationID: message.OperationID, MsgData: message.MsgData, PushToUserID: pushToUserID} mqPushMsg := pbMsg.PushMsgDataToMQ{OperationID: message.OperationID, MsgData: message.MsgData, PushToUserID: pushToUserID} - pid, offset, err := och.producerToPush.SendMessage(&mqPushMsg, mqPushMsg.PushToUserID, rpcPushMsg.OperationID) + pid, offset, err := och.producerToPush.SendMessage(ctx, &mqPushMsg, mqPushMsg.PushToUserID) if err != nil { log.Error(mqPushMsg.OperationID, "kafka send failed", "send data", message.String(), "pid", pid, "offset", offset, "err", err.Error()) } @@ -254,7 +252,7 @@ func (och *OnlineHistoryRedisConsumerHandler) sendMessageToPushMQ(ctx context.Co func (och *OnlineHistoryRedisConsumerHandler) sendMessageToModifyMQ(ctx context.Context, aggregationID string, triggerID string, messages []*pbMsg.MsgDataToMQ) { if len(messages) > 0 { - pid, offset, err := och.producerToModify.SendMessage(&pbMsg.MsgDataToModifyByMQ{AggregationID: aggregationID, MessageList: messages, TriggerID: triggerID}, aggregationID, triggerID) + pid, offset, err := och.producerToModify.SendMessage(ctx, &pbMsg.MsgDataToModifyByMQ{AggregationID: aggregationID, MessageList: messages, TriggerID: triggerID}, aggregationID) if err != nil { log.Error(triggerID, "kafka send failed", "send data", len(messages), "pid", pid, "offset", offset, "err", err.Error(), "key", aggregationID) } @@ -263,7 +261,7 @@ func (och *OnlineHistoryRedisConsumerHandler) sendMessageToModifyMQ(ctx context. func (och *OnlineHistoryRedisConsumerHandler) SendMessageToMongoCH(ctx context.Context, aggregationID string, triggerID string, messages []*pbMsg.MsgDataToMQ, lastSeq int64) { if len(messages) > 0 { - pid, offset, err := och.producerToMongo.SendMessage(&pbMsg.MsgDataToMongoByMQ{LastSeq: lastSeq, AggregationID: aggregationID, MessageList: messages, TriggerID: triggerID}, aggregationID, triggerID) + pid, offset, err := och.producerToMongo.SendMessage(ctx, &pbMsg.MsgDataToMongoByMQ{LastSeq: lastSeq, AggregationID: aggregationID, MessageList: messages, TriggerID: triggerID}, aggregationID) if err != nil { log.Error(triggerID, "kafka send failed", "send data", len(messages), "pid", pid, "offset", offset, "err", err.Error(), "key", aggregationID) } diff --git a/internal/push/init.go b/internal/push/init.go index fa211c1ed..b456a22b1 100644 --- a/internal/push/init.go +++ b/internal/push/init.go @@ -19,18 +19,18 @@ import ( ) type Push struct { - rpcServer RPCServer + rpcServer PushServer pushCh ConsumerHandler offlinePusher OfflinePusher successCount uint64 } func (p *Push) Init(rpcPort int) error { - redisClient, err := cache.NewRedis() + rdb, err := cache.NewRedis() if err != nil { return err } - var cacheInterface cache.Cache = redisClient + var cacheInterface cache.Cache p.rpcServer.Init(rpcPort, cacheInterface) p.pushCh.Init() statistics.NewStatistics(&p.successCount, config.Config.ModuleName.PushName, fmt.Sprintf("%d second push to msg_gateway count", constant.StatisticsTimeInterval), constant.StatisticsTimeInterval) diff --git a/internal/push/push_rpc_server.go b/internal/push/push_rpc_server.go index 45a62dae6..5b1f6eaa3 100644 --- a/internal/push/push_rpc_server.go +++ b/internal/push/push_rpc_server.go @@ -4,90 +4,39 @@ import ( "OpenIM/pkg/common/config" "OpenIM/pkg/common/constant" "OpenIM/pkg/common/db/cache" - "OpenIM/pkg/common/db/controller" - "OpenIM/pkg/common/log" - "OpenIM/pkg/common/prome" pbPush "OpenIM/pkg/proto/push" - "OpenIM/pkg/utils" "context" - "net" - "strconv" - "strings" - - grpcPrometheus "github.com/grpc-ecosystem/go-grpc-prometheus" + "github.com/OpenIMSDK/openKeeper" "google.golang.org/grpc" ) -type RPCServer struct { - rpcPort int - rpcRegisterName string - PushDatabase controller.PushDatabase - pusher Pusher +type pushServer struct { + pusher *Pusher } -func (r *RPCServer) Init(rpcPort int, cache cache.Cache) { - r.rpcPort = rpcPort - r.rpcRegisterName = config.Config.RpcRegisterName.OpenImPushName +func Start(client *openKeeper.ZkClient, server *grpc.Server) error { + + pbPush.RegisterPushMsgServiceServer(server, &pushServer{ + pusher: NewPusher(), + }) } -func (r *RPCServer) run() { - listenIP := "" - if config.Config.ListenIP == "" { - listenIP = "0.0.0.0" - } else { - listenIP = config.Config.ListenIP - } - address := listenIP + ":" + strconv.Itoa(r.rpcPort) - - listener, err := net.Listen("tcp", address) - if err != nil { - panic("listening err:" + err.Error() + r.rpcRegisterName) - } - defer listener.Close() - var grpcOpts []grpc.ServerOption - if config.Config.Prometheus.Enable { - prome.NewGrpcRequestCounter() - prome.NewGrpcRequestFailedCounter() - prome.NewGrpcRequestSuccessCounter() - grpcOpts = append(grpcOpts, []grpc.ServerOption{ - // grpc.UnaryInterceptor(prome.UnaryServerInterceptorProme), - grpc.StreamInterceptor(grpcPrometheus.StreamServerInterceptor), - grpc.UnaryInterceptor(grpcPrometheus.UnaryServerInterceptor), - }...) - } - srv := grpc.NewServer(grpcOpts...) - defer srv.GracefulStop() - pbPush.RegisterPushMsgServiceServer(srv, r) - rpcRegisterIP := config.Config.RpcRegisterIP - if config.Config.RpcRegisterIP == "" { - rpcRegisterIP, err = utils.GetLocalIP() - if err != nil { - log.Error("", "GetLocalIP failed ", err.Error()) - } - } - - err = rpc.RegisterEtcd(r.etcdSchema, strings.Join(r.etcdAddr, ","), rpcRegisterIP, r.rpcPort, r.rpcRegisterName, 10) - if err != nil { - log.Error("", "register push module rpc to etcd err", err.Error(), r.etcdSchema, strings.Join(r.etcdAddr, ","), rpcRegisterIP, r.rpcPort, r.rpcRegisterName) - panic(utils.Wrap(err, "register push module rpc to etcd err")) - } - err = srv.Serve(listener) - if err != nil { - log.Error("", "push module rpc start err", err.Error()) - return - } -} - -func (r *RPCServer) PushMsg(ctx context.Context, pbData *pbPush.PushMsgReq) (resp *pbPush.PushMsgResp, err error) { +func (r *pushServer) PushMsg(ctx context.Context, pbData *pbPush.PushMsgReq) (resp *pbPush.PushMsgResp, err error) { switch pbData.MsgData.SessionType { case constant.SuperGroupChatType: err = r.pusher.MsgToSuperGroupUser(ctx, pbData.SourceID, pbData.MsgData) default: err = r.pusher.MsgToUser(ctx, pbData.SourceID, pbData.MsgData) } - return &pbPush.PushMsgResp{}, err + if err != nil { + return nil, err + } + return &pbPush.PushMsgResp{}, nil } -func (r *RPCServer) DelUserPushToken(ctx context.Context, req *pbPush.DelUserPushTokenReq) (resp *pbPush.DelUserPushTokenResp, err error) { - return &pbPush.DelUserPushTokenResp{}, r.PushDatabase.DelFcmToken(ctx, req.UserID, int(req.PlatformID)) +func (r *pushServer) DelUserPushToken(ctx context.Context, req *pbPush.DelUserPushTokenReq) (resp *pbPush.DelUserPushTokenResp, err error) { + if err = r.pusher.database.DelFcmToken(ctx, req.UserID, int(req.PlatformID)); err != nil { + return nil, err + } + return &pbPush.DelUserPushTokenResp{}, nil } diff --git a/internal/push/push_to_client.go b/internal/push/push_to_client.go index 321f0c839..91d243f86 100644 --- a/internal/push/push_to_client.go +++ b/internal/push/push_to_client.go @@ -9,14 +9,13 @@ package push import ( "OpenIM/pkg/common/config" "OpenIM/pkg/common/constant" - "OpenIM/pkg/common/db/cache" + "OpenIM/pkg/common/db/controller" "OpenIM/pkg/common/db/localcache" "OpenIM/pkg/common/log" "OpenIM/pkg/common/prome" "OpenIM/pkg/common/tracelog" "OpenIM/pkg/discoveryregistry" - msggateway "OpenIM/pkg/proto/msggateway" - pbRtc "OpenIM/pkg/proto/rtc" + "OpenIM/pkg/proto/msggateway" "OpenIM/pkg/proto/sdkws" "OpenIM/pkg/utils" "context" @@ -25,7 +24,7 @@ import ( ) type Pusher struct { - cache cache.Cache + database controller.PushDatabase client discoveryregistry.SvcDiscoveryRegistry offlinePusher OfflinePusher groupLocalCache localcache.GroupLocalCache @@ -33,11 +32,14 @@ type Pusher struct { successCount int } -func NewPusher(cache cache.Cache, client discoveryregistry.SvcDiscoveryRegistry, offlinePusher OfflinePusher) *Pusher { +func NewPusher(client discoveryregistry.SvcDiscoveryRegistry, offlinePusher OfflinePusher, database controller.PushDatabase, + groupLocalCache localcache.GroupLocalCache, conversationLocalCache localcache.ConversationLocalCache) *Pusher { return &Pusher{ - cache: cache, - client: client, - offlinePusher: offlinePusher, + database: database, + client: client, + offlinePusher: offlinePusher, + groupLocalCache: groupLocalCache, + conversationLocalCache: conversationLocalCache, } } @@ -46,7 +48,7 @@ func (p *Pusher) MsgToUser(ctx context.Context, userID string, msg *sdkws.MsgDat var userIDs = []string{userID} log.Debug(operationID, "Get msg from msg_transfer And push msg", msg.String(), userID) // callback - if err := callbackOnlinePush(ctx, userIDs, msg); err != nil { + if err := callbackOnlinePush(ctx, userIDs, msg); err != nil && err != constant.ErrCallbackContinue { return err } // push @@ -65,7 +67,7 @@ func (p *Pusher) MsgToUser(ctx context.Context, userID string, msg *sdkws.MsgDat } } if msg.ContentType == constant.SignalingNotification { - isSend, err := p.cache.HandleSignalInfo(ctx, msg, userID) + isSend, err := p.database.HandleSignalInvite(ctx, msg, userID) if err != nil { return err } @@ -77,7 +79,7 @@ func (p *Pusher) MsgToUser(ctx context.Context, userID string, msg *sdkws.MsgDat if err := callbackOfflinePush(ctx, userIDs, msg, &[]string{}); err != nil { return err } - err = p.OfflinePushMsg(ctx, userID, msg, userIDs) + err = p.offlinePushMsg(ctx, userID, msg, userIDs) if err != nil { return err } @@ -89,7 +91,7 @@ func (p *Pusher) MsgToSuperGroupUser(ctx context.Context, groupID string, msg *s operationID := tracelog.GetOperationID(ctx) log.Debug(operationID, "Get super group msg from msg_transfer And push msg", msg.String(), groupID) var pushToUserIDs []string - if err := callbackBeforeSuperGroupOnlinePush(ctx, groupID, msg, &pushToUserIDs); err != nil { + if err := callbackBeforeSuperGroupOnlinePush(ctx, groupID, msg, &pushToUserIDs); err != nil && err != constant.ErrCallbackContinue { return err } if len(pushToUserIDs) == 0 { @@ -145,14 +147,14 @@ func (p *Pusher) MsgToSuperGroupUser(ctx context.Context, groupID string, msg *s if len(offlinePushUserIDs) > 0 { needOfflinePushUserIDs = offlinePushUserIDs } - err = p.OfflinePushMsg(ctx, groupID, msg, offlinePushUserIDs) + err = p.offlinePushMsg(ctx, groupID, msg, offlinePushUserIDs) if err != nil { - log.NewError(operationID, "OfflinePushMsg failed", groupID) + log.NewError(operationID, "offlinePushMsg failed", groupID) return err } _, err := p.GetConnsAndOnlinePush(ctx, msg, utils.IntersectString(needOfflinePushUserIDs, WebAndPcBackgroundUserIDs)) if err != nil { - log.NewError(operationID, "OfflinePushMsg failed", groupID) + log.NewError(operationID, "offlinePushMsg failed", groupID) return err } } @@ -160,14 +162,14 @@ func (p *Pusher) MsgToSuperGroupUser(ctx context.Context, groupID string, msg *s return nil } -func (p *Pusher) GetConnsAndOnlinePush(ctx context.Context, msg *sdkws.MsgData, pushToUserIDs []string) (wsResults []*msggateway.SingelMsgToUserResultList, err error) { +func (p *Pusher) GetConnsAndOnlinePush(ctx context.Context, msg *sdkws.MsgData, pushToUserIDs []string) (wsResults []*msggateway.SingleMsgToUserResultList, err error) { conns, err := p.client.GetConns(config.Config.RpcRegisterName.OpenImMessageGatewayName) if err != nil { return nil, err } //Online push message for _, v := range conns { - msgClient := msggateway.NewRelayClient(v) + msgClient := msggateway.NewMsgGatewayClient(v) reply, err := msgClient.SuperGroupOnlineBatchPushOneMsg(ctx, &msggateway.OnlineBatchPushOneMsgReq{OperationID: tracelog.GetOperationID(ctx), MsgData: msg, PushToUserIDList: pushToUserIDs}) if err != nil { log.NewError(tracelog.GetOperationID(ctx), msg, len(pushToUserIDs), "err", err) @@ -180,8 +182,8 @@ func (p *Pusher) GetConnsAndOnlinePush(ctx context.Context, msg *sdkws.MsgData, return wsResults, nil } -func (p *Pusher) OfflinePushMsg(ctx context.Context, sourceID string, msg *sdkws.MsgData, offlinePushUserIDs []string) error { - title, content, opts, err := p.GetOfflinePushInfos(sourceID, msg) +func (p *Pusher) offlinePushMsg(ctx context.Context, sourceID string, msg *sdkws.MsgData, offlinePushUserIDs []string) error { + title, content, opts, err := p.getOfflinePushInfos(sourceID, msg) if err != nil { return err } @@ -197,12 +199,12 @@ func (p *Pusher) OfflinePushMsg(ctx context.Context, sourceID string, msg *sdkws func (p *Pusher) GetOfflinePushOpts(msg *sdkws.MsgData) (opts *Opts, err error) { opts = &Opts{} if msg.ContentType > constant.SignalingNotificationBegin && msg.ContentType < constant.SignalingNotificationEnd { - req := &pbRtc.SignalReq{} + req := &sdkws.SignalReq{} if err := proto.Unmarshal(msg.Content, req); err != nil { return nil, utils.Wrap(err, "") } switch req.Payload.(type) { - case *pbRtc.SignalReq_Invite, *pbRtc.SignalReq_InviteInGroup: + case *sdkws.SignalReq_Invite, *sdkws.SignalReq_InviteInGroup: opts.Signal = &Signal{ClientMsgID: msg.ClientMsgID} } } @@ -214,7 +216,7 @@ func (p *Pusher) GetOfflinePushOpts(msg *sdkws.MsgData) (opts *Opts, err error) return opts, nil } -func (p *Pusher) GetOfflinePushInfos(sourceID string, msg *sdkws.MsgData) (title, content string, opts *Opts, err error) { +func (p *Pusher) getOfflinePushInfos(sourceID string, msg *sdkws.MsgData) (title, content string, opts *Opts, err error) { if p.offlinePusher == nil { err = errors.New("no offlinePusher is configured") return diff --git a/internal/rpc/auth/auth.go b/internal/rpc/auth/auth.go index 0c3cabcfe..31a7085d6 100644 --- a/internal/rpc/auth/auth.go +++ b/internal/rpc/auth/auth.go @@ -16,7 +16,6 @@ import ( "OpenIM/pkg/proto/msggateway" "OpenIM/pkg/utils" "context" - "github.com/OpenIMSDK/openKeeper" "google.golang.org/grpc" ) @@ -26,7 +25,7 @@ type authServer struct { RegisterCenter discoveryRegistry.SvcDiscoveryRegistry } -func Start(client *openKeeper.ZkClient, server *grpc.Server) error { +func Start(client discoveryRegistry.SvcDiscoveryRegistry, server *grpc.Server) error { mysql, err := relation.NewGormDB() if err != nil { return err diff --git a/internal/rpc/friend/friend.go b/internal/rpc/friend/friend.go index 5f472c27e..bb6137ebe 100644 --- a/internal/rpc/friend/friend.go +++ b/internal/rpc/friend/friend.go @@ -27,7 +27,7 @@ type friendServer struct { RegisterCenter registry.SvcDiscoveryRegistry } -func Start(client *openKeeper.ZkClient, server *grpc.Server) error { +func Start(client registry.SvcDiscoveryRegistry, server *grpc.Server) error { db, err := relation.NewGormDB() if err != nil { return err diff --git a/internal/rpc/msg/server.go b/internal/rpc/msg/server.go index 4d6f23226..35dca7f97 100644 --- a/internal/rpc/msg/server.go +++ b/internal/rpc/msg/server.go @@ -6,16 +6,14 @@ import ( "OpenIM/pkg/common/db/localcache" "OpenIM/pkg/common/db/relation" relationTb "OpenIM/pkg/common/db/table/relation" - discoveryRegistry "OpenIM/pkg/discoveryregistry" - "github.com/OpenIMSDK/openKeeper" - "OpenIM/pkg/common/prome" + "OpenIM/pkg/discoveryregistry" "OpenIM/pkg/proto/msg" "google.golang.org/grpc" ) type msgServer struct { - RegisterCenter discoveryRegistry.SvcDiscoveryRegistry + RegisterCenter discoveryregistry.SvcDiscoveryRegistry MsgDatabase controller.MsgDatabase Group *check.GroupChecker User *check.UserCheck @@ -26,7 +24,7 @@ type msgServer struct { MessageLocker MessageLocker } -func Start(client *openKeeper.ZkClient, server *grpc.Server) error { +func Start(client discoveryregistry.SvcDiscoveryRegistry, server *grpc.Server) error { mysql, err := relation.NewGormDB() if err != nil { return err diff --git a/internal/rpc/third/third.go b/internal/rpc/third/third.go index 680b38552..cd15eac15 100644 --- a/internal/rpc/third/third.go +++ b/internal/rpc/third/third.go @@ -57,7 +57,7 @@ func (t *thirdServer) GetSignalInvitationInfoStartApp(ctx context.Context, req * } func (t *thirdServer) FcmUpdateToken(ctx context.Context, req *third.FcmUpdateTokenReq) (resp *third.FcmUpdateTokenResp, err error) { - err = t.thirdDatabase.FcmUpdateToken(ctx) + err = t.thirdDatabase.FcmUpdateToken(ctx, req.Account, int(req.PlatformID), req.FcmToken, req.ExpireTime) if err != nil { return nil, err } @@ -65,7 +65,7 @@ func (t *thirdServer) FcmUpdateToken(ctx context.Context, req *third.FcmUpdateTo } func (t *thirdServer) SetAppBadge(ctx context.Context, req *third.SetAppBadgeReq) (resp *third.SetAppBadgeResp, err error) { - err = t.thirdDatabase.SetAppBadge(ctx, req.UserID, req.AppUnreadCount) + err = t.thirdDatabase.SetAppBadge(ctx, req.UserID, int(req.AppUnreadCount)) if err != nil { return nil, err } diff --git a/internal/rpc/user/user.go b/internal/rpc/user/user.go index 79108c51f..e6466c515 100644 --- a/internal/rpc/user/user.go +++ b/internal/rpc/user/user.go @@ -29,7 +29,7 @@ type userServer struct { friendCheck *check.FriendChecker } -func Start(client *openKeeper.ZkClient, server *grpc.Server) error { +func Start(client registry.SvcDiscoveryRegistry, server *grpc.Server) error { gormDB, err := relation.NewGormDB() if err != nil { return err @@ -37,6 +37,13 @@ func Start(client *openKeeper.ZkClient, server *grpc.Server) error { if err := gormDB.AutoMigrate(&tablerelation.UserModel{}); err != nil { return err } + users := make([]*tablerelation.UserModel, 0) + if len(config.Config.Manager.AppManagerUid) != len(config.Config.Manager.Nickname) { + return constant.ErrConfig.Wrap("len(config.Config.Manager.AppManagerUid) != len(config.Config.Manager.Nickname)") + } + for k, v := range config.Config.Manager.AppManagerUid { + users = append(users, &tablerelation.UserModel{UserID: v, Nickname: config.Config.Manager.Nickname[k]}) + } u := &userServer{ UserDatabase: controller.NewUserDatabase(relation.NewUserGorm(gormDB)), notification: notification.NewCheck(client), @@ -44,13 +51,6 @@ func Start(client *openKeeper.ZkClient, server *grpc.Server) error { RegisterCenter: client, } pbuser.RegisterUserServer(server, u) - users := make([]*tablerelation.UserModel, 0) - if len(config.Config.Manager.AppManagerUid) != len(config.Config.Manager.Nickname) { - return constant.ErrConfig.Wrap("len(config.Config.Manager.AppManagerUid) != len(config.Config.Manager.Nickname)") - } - for k, v := range config.Config.Manager.AppManagerUid { - users = append(users, &tablerelation.UserModel{UserID: v, Nickname: config.Config.Manager.Nickname[k]}) - } u.UserDatabase.InitOnce(context.Background(), users) return nil } diff --git a/internal/startrpc/start.go b/internal/startrpc/start.go index e7c396341..cb1660a49 100644 --- a/internal/startrpc/start.go +++ b/internal/startrpc/start.go @@ -7,6 +7,7 @@ import ( "OpenIM/pkg/common/log" "OpenIM/pkg/common/middleware" "OpenIM/pkg/common/prome" + "OpenIM/pkg/discoveryregistry" "flag" "fmt" "github.com/OpenIMSDK/openKeeper" @@ -15,7 +16,7 @@ import ( "net" ) -func start(rpcPort int, rpcRegisterName string, prometheusPorts int, rpcFn func(client *openKeeper.ZkClient, server *grpc.Server) error, options []grpc.ServerOption) error { +func start(rpcPort int, rpcRegisterName string, prometheusPorts int, rpcFn func(client discoveryregistry.SvcDiscoveryRegistry, server *grpc.Server) error, options []grpc.ServerOption) error { flagRpcPort := flag.Int("port", rpcPort, "get RpcGroupPort from cmd,default 16000 as port") flagPrometheusPort := flag.Int("prometheus_port", prometheusPorts, "groupPrometheusPort default listen port") flag.Parse() @@ -61,6 +62,6 @@ func start(rpcPort int, rpcRegisterName string, prometheusPorts int, rpcFn func( return rpcFn(zkClient, srv) } -func Start(rpcPort int, rpcRegisterName string, prometheusPort int, rpcFn func(client *openKeeper.ZkClient, server *grpc.Server) error, options ...grpc.ServerOption) error { +func Start(rpcPort int, rpcRegisterName string, prometheusPort int, rpcFn func(client discoveryregistry.SvcDiscoveryRegistry, server *grpc.Server) error, options ...grpc.ServerOption) error { return start(rpcPort, rpcRegisterName, prometheusPort, rpcFn, options) } diff --git a/pkg/common/db/cache/redis.go b/pkg/common/db/cache/redis.go index 885af9293..ab715340f 100644 --- a/pkg/common/db/cache/redis.go +++ b/pkg/common/db/cache/redis.go @@ -4,8 +4,7 @@ import ( "OpenIM/pkg/common/config" "OpenIM/pkg/common/constant" "OpenIM/pkg/common/tracelog" - pbChat "OpenIM/pkg/proto/msg" - pbRtc "OpenIM/pkg/proto/rtc" + pbMsg "OpenIM/pkg/proto/msg" "OpenIM/pkg/proto/sdkws" "OpenIM/pkg/utils" "context" @@ -20,10 +19,9 @@ import ( ) const ( - userIncrSeq = "REDIS_USER_INCR_SEQ:" // user incr seq - appleDeviceToken = "DEVICE_TOKEN" - userMinSeq = "REDIS_USER_MIN_SEQ:" - + userIncrSeq = "REDIS_USER_INCR_SEQ:" // user incr seq + appleDeviceToken = "DEVICE_TOKEN" + userMinSeq = "REDIS_USER_MIN_SEQ:" getuiToken = "GETUI_TOKEN" getuiTaskID = "GETUI_TASK_ID" messageCache = "MESSAGE_CACHE:" @@ -36,12 +34,7 @@ const ( sendMsgFailedFlag = "SEND_MSG_FAILED_FLAG:" userBadgeUnreadCountSum = "USER_BADGE_UNREAD_COUNT_SUM:" exTypeKeyLocker = "EX_LOCK:" - - uidPidToken = "UID_PID_TOKEN_STATUS:" - - SignalListCache = "SIGNAL_LIST_CACHE:" - - SignalCache = "SIGNAL_CACHE:" + uidPidToken = "UID_PID_TOKEN_STATUS:" ) type Cache interface { @@ -62,10 +55,10 @@ type Cache interface { SetTokenMapByUidPid(ctx context.Context, userID string, platform string, m map[string]int) error DeleteTokenByUidPid(ctx context.Context, userID string, platform string, fields []string) error GetMessagesBySeq(ctx context.Context, userID string, seqList []int64) (seqMsg []*sdkws.MsgData, failedSeqList []int64, err error) - SetMessageToCache(ctx context.Context, userID string, msgList []*pbChat.MsgDataToMQ) (int, error) - DeleteMessageFromCache(ctx context.Context, userID string, msgList []*pbChat.MsgDataToMQ) error + SetMessageToCache(ctx context.Context, userID string, msgList []*pbMsg.MsgDataToMQ) (int, error) + DeleteMessageFromCache(ctx context.Context, userID string, msgList []*pbMsg.MsgDataToMQ) error CleanUpOneUserAllMsg(ctx context.Context, userID string) error - HandleSignalInfo(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) + HandleSignalInvite(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) GetSignalInvitationInfoByClientMsgID(ctx context.Context, clientMsgID string) (invitationInfo *sdkws.SignalInviteReq, err error) GetAvailableSignalInvitationInfo(ctx context.Context, userID string) (invitationInfo *sdkws.SignalInviteReq, err error) DelUserSignalList(ctx context.Context, userID string) error @@ -210,9 +203,9 @@ func (c *cache) GetMessagesBySeq(ctx context.Context, userID string, seqList []i return seqMsg, failedSeqList, errResult } -func (c *cache) SetMessageToCache(ctx context.Context, userID string, msgList []*pbChat.MsgDataToMQ) (int, error) { +func (c *cache) SetMessageToCache(ctx context.Context, userID string, msgList []*pbMsg.MsgDataToMQ) (int, error) { pipe := c.rdb.Pipeline() - var failedList []pbChat.MsgDataToMQ + var failedList []pbMsg.MsgDataToMQ for _, msg := range msgList { key := messageCache + userID + "_" + strconv.Itoa(int(msg.MsgData.Seq)) s, err := utils.Pb2String(msg.MsgData) @@ -231,9 +224,9 @@ func (c *cache) SetMessageToCache(ctx context.Context, userID string, msgList [] return 0, err } -func (c *cache) DeleteMessageFromCache(ctx context.Context, userID string, msgList []*pbChat.MsgDataToMQ) error { - for _, msg := range msgList { - if err := c.rdb.Del(ctx, messageCache+userID+"_"+strconv.Itoa(int(msg.MsgData.Seq))).Err(); err != nil { +func (c *cache) DeleteMessageFromCache(ctx context.Context, userID string, msgList []*pbMsg.MsgDataToMQ) error { + for _, v := range msgList { + if err := c.rdb.Del(ctx, messageCache+userID+"_"+strconv.Itoa(int(v.MsgData.Seq))).Err(); err != nil { return utils.Wrap1(err) } } @@ -257,35 +250,35 @@ func (c *cache) CleanUpOneUserAllMsg(ctx context.Context, userID string) error { return nil } -func (c *cache) HandleSignalInfo(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) { - req := &pbRtc.SignalReq{} +func (c *cache) HandleSignalInvite(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) { + req := &sdkws.SignalReq{} if err := proto.Unmarshal(msg.Content, req); err != nil { return false, utils.Wrap1(err) } - var inviteeUserIDList []string + var inviteeUserIDs []string var isInviteSignal bool switch signalInfo := req.Payload.(type) { - case *pbRtc.SignalReq_Invite: - inviteeUserIDList = signalInfo.Invite.Invitation.InviteeUserIDList + case *sdkws.SignalReq_Invite: + inviteeUserIDs = signalInfo.Invite.Invitation.InviteeUserIDList isInviteSignal = true - case *pbRtc.SignalReq_InviteInGroup: - inviteeUserIDList = signalInfo.InviteInGroup.Invitation.InviteeUserIDList + case *sdkws.SignalReq_InviteInGroup: + inviteeUserIDs = signalInfo.InviteInGroup.Invitation.InviteeUserIDList isInviteSignal = true - if !utils.Contain(pushToUserID, inviteeUserIDList...) { + if !utils.Contain(pushToUserID, inviteeUserIDs...) { return false, nil } - case *pbRtc.SignalReq_HungUp, *pbRtc.SignalReq_Cancel, *pbRtc.SignalReq_Reject, *pbRtc.SignalReq_Accept: + case *sdkws.SignalReq_HungUp, *sdkws.SignalReq_Cancel, *sdkws.SignalReq_Reject, *sdkws.SignalReq_Accept: return false, utils.Wrap1(errors.New("signalInfo do not need offlinePush")) default: return false, nil } if isInviteSignal { - for _, userID := range inviteeUserIDList { + for _, userID := range inviteeUserIDs { timeout, err := strconv.Atoi(config.Config.Rtc.SignalTimeout) if err != nil { return false, utils.Wrap1(err) } - keyList := SignalListCache + userID + keyList := signalListCache + userID err = c.rdb.LPush(ctx, keyList, msg.ClientMsgID).Err() if err != nil { return false, utils.Wrap1(err) @@ -294,7 +287,7 @@ func (c *cache) HandleSignalInfo(ctx context.Context, msg *sdkws.MsgData, pushTo if err != nil { return false, utils.Wrap1(err) } - key := SignalCache + msg.ClientMsgID + key := signalCache + msg.ClientMsgID err = c.rdb.Set(ctx, key, msg.Content, time.Duration(timeout)*time.Second).Err() if err != nil { return false, utils.Wrap1(err) @@ -304,29 +297,29 @@ func (c *cache) HandleSignalInfo(ctx context.Context, msg *sdkws.MsgData, pushTo return true, nil } -func (c *cache) GetSignalInvitationInfoByClientMsgID(ctx context.Context, clientMsgID string) (invitationInfo *sdkws.SignalInviteReq, err error) { - bytes, err := c.rdb.Get(ctx, SignalCache+clientMsgID).Bytes() +func (c *cache) GetSignalInvitationInfoByClientMsgID(ctx context.Context, clientMsgID string) (signalInviteReq *sdkws.SignalInviteReq, err error) { + bytes, err := c.rdb.Get(ctx, signalCache+clientMsgID).Bytes() if err != nil { return nil, utils.Wrap1(err) } - req := &sdkws.SignalReq{} - if err = proto.Unmarshal(bytes, req); err != nil { + signalReq := &sdkws.SignalReq{} + if err = proto.Unmarshal(bytes, signalReq); err != nil { return nil, utils.Wrap1(err) } - invitationInfo = &sdkws.SignalInviteReq{} - switch req2 := req.Payload.(type) { - case *pbRtc.SignalReq_Invite: - invitationInfo.Invitation = req2.Invite.Invitation - invitationInfo.OpUserID = req2.Invite.OpUserID - case *pbRtc.SignalReq_InviteInGroup: - invitationInfo.Invitation = req2.InviteInGroup.Invitation - invitationInfo.OpUserID = req2.InviteInGroup.OpUserID + signalInviteReq = &sdkws.SignalInviteReq{} + switch req := signalReq.Payload.(type) { + case *sdkws.SignalReq_Invite: + signalInviteReq.Invitation = req.Invite.Invitation + signalInviteReq.OpUserID = req.Invite.OpUserID + case *sdkws.SignalReq_InviteInGroup: + signalInviteReq.Invitation = req.InviteInGroup.Invitation + signalInviteReq.OpUserID = req.InviteInGroup.OpUserID } - return invitationInfo, nil + return signalInviteReq, nil } func (c *cache) GetAvailableSignalInvitationInfo(ctx context.Context, userID string) (invitationInfo *sdkws.SignalInviteReq, err error) { - key, err := c.rdb.LPop(ctx, SignalListCache+userID).Result() + key, err := c.rdb.LPop(ctx, signalListCache+userID).Result() if err != nil { return nil, utils.Wrap1(err) } @@ -338,7 +331,7 @@ func (c *cache) GetAvailableSignalInvitationInfo(ctx context.Context, userID str } func (c *cache) DelUserSignalList(ctx context.Context, userID string) error { - return utils.Wrap1(c.rdb.Del(ctx, SignalListCache+userID).Err()) + return utils.Wrap1(c.rdb.Del(ctx, signalListCache+userID).Err()) } func (c *cache) DelMsgFromCache(ctx context.Context, userID string, seqList []int64) error { diff --git a/pkg/common/db/controller/chatlog.go b/pkg/common/db/controller/chatlog.go index 3771e78b0..e46f14530 100644 --- a/pkg/common/db/controller/chatlog.go +++ b/pkg/common/db/controller/chatlog.go @@ -7,21 +7,21 @@ import ( type ChatLogDatabase interface { CreateChatLog(msg pbMsg.MsgDataToMQ) error - GetChatLog(chatLog *relationTb.ChatLogModel, pageNumber, showNumber int32, contentTypeList []int32) (int64, []relationTb.ChatLogModel, error) + GetChatLog(chatLog *relationTb.ChatLogModel, pageNumber, showNumber int32, contentTypes []int32) (int64, []relationTb.ChatLogModel, error) } func NewChatLogDatabase(chatLogModelInterface relationTb.ChatLogModelInterface) ChatLogDatabase { - return &ChatLogDataBase{chatLogModel: chatLogModelInterface} + return &chatLogDatabase{chatLogModel: chatLogModelInterface} } -type ChatLogDataBase struct { +type chatLogDatabase struct { chatLogModel relationTb.ChatLogModelInterface } -func (c *ChatLogDataBase) CreateChatLog(msg pbMsg.MsgDataToMQ) error { +func (c *chatLogDatabase) CreateChatLog(msg pbMsg.MsgDataToMQ) error { return c.chatLogModel.Create(msg) } -func (c *ChatLogDataBase) GetChatLog(chatLog *relationTb.ChatLogModel, pageNumber, showNumber int32, contentTypeList []int32) (int64, []relationTb.ChatLogModel, error) { - return c.chatLogModel.GetChatLog(chatLog, pageNumber, showNumber, contentTypeList) +func (c *chatLogDatabase) GetChatLog(chatLog *relationTb.ChatLogModel, pageNumber, showNumber int32, contentTypes []int32) (int64, []relationTb.ChatLogModel, error) { + return c.chatLogModel.GetChatLog(chatLog, pageNumber, showNumber, contentTypes) } diff --git a/pkg/common/db/controller/push.go b/pkg/common/db/controller/push.go index ebbf2edd0..9f0819f08 100644 --- a/pkg/common/db/controller/push.go +++ b/pkg/common/db/controller/push.go @@ -2,11 +2,13 @@ package controller import ( "OpenIM/pkg/common/db/cache" + "OpenIM/pkg/proto/sdkws" "context" ) type PushDatabase interface { DelFcmToken(ctx context.Context, userID string, platformID int) error + HandleSignalInvite(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) } type pushDataBase struct { @@ -20,3 +22,7 @@ func NewPushDatabase(cache cache.Cache) PushDatabase { func (p *pushDataBase) DelFcmToken(ctx context.Context, userID string, platformID int) error { return p.cache.DelFcmToken(ctx, userID, platformID) } + +func (p *pushDataBase) HandleSignalInvite(ctx context.Context, msg *sdkws.MsgData, pushToUserID string) (isSend bool, err error) { + return p.cache.HandleSignalInvite(ctx, msg, pushToUserID) +} diff --git a/pkg/common/db/table/relation/chatlog.go b/pkg/common/db/table/relation/chatlog.go index e85e52891..dcf39aca5 100644 --- a/pkg/common/db/table/relation/chatlog.go +++ b/pkg/common/db/table/relation/chatlog.go @@ -36,5 +36,5 @@ func (ChatLogModel) TableName() string { type ChatLogModelInterface interface { Create(msg pbMsg.MsgDataToMQ) error - GetChatLog(chatLog *ChatLogModel, pageNumber, showNumber int32, contentTypeList []int32) (int64, []ChatLogModel, error) + GetChatLog(chatLog *ChatLogModel, pageNumber, showNumber int32, contentTypes []int32) (int64, []ChatLogModel, error) } diff --git a/pkg/common/kafka/producer.go b/pkg/common/kafka/producer.go index b7ecba3e4..6c9b913ca 100644 --- a/pkg/common/kafka/producer.go +++ b/pkg/common/kafka/producer.go @@ -3,7 +3,9 @@ package kafka import ( "OpenIM/pkg/common/config" log "OpenIM/pkg/common/log" + "OpenIM/pkg/common/tracelog" "OpenIM/pkg/utils" + "context" "errors" "github.com/Shopify/sarama" @@ -43,7 +45,8 @@ func NewKafkaProducer(addr []string, topic string) *Producer { return &p } -func (p *Producer) SendMessage(m proto.Message, key string, operationID string) (int32, int64, error) { +func (p *Producer) SendMessage(ctx context.Context, m proto.Message, key string) (int32, int64, error) { + operationID := tracelog.GetOperationID(ctx) log.Info(operationID, "SendMessage", "key ", key, m.String(), p.producer) kMsg := &sarama.ProducerMessage{} kMsg.Topic = p.topic @@ -63,6 +66,7 @@ func (p *Producer) SendMessage(m proto.Message, key string, operationID string) log.Error(operationID, "kMsg.Key.Length() == 0 || kMsg.Value.Length() == 0 ", kMsg) return -1, -1, errors.New("key or value == 0") } + kMsg.Metadata = ctx partition, offset, err := p.producer.SendMessage(kMsg) log.Info(operationID, "ByteEncoder SendMessage end", "key ", kMsg.Key.Length(), kMsg.Value.Length(), p.producer) if err == nil { diff --git a/pkg/proto/msg/msg.proto b/pkg/proto/msg/msg.proto index 3f716c2a5..73823c7de 100644 --- a/pkg/proto/msg/msg.proto +++ b/pkg/proto/msg/msg.proto @@ -5,40 +5,33 @@ option go_package = "OpenIM/pkg/proto/msg;msg"; package msg; message MsgDataToMQ{ - string token =1; - string operationID = 2; - sdkws.MsgData msgData = 3; + string token = 1; + sdkws.MsgData msgData = 2; } message MsgDataToDB { sdkws.MsgData msgData = 1; - string operationID = 2; - } + message PushMsgDataToMQ{ - string OperationID = 1; - sdkws.MsgData msgData = 2; - string pushToUserID = 3; + sdkws.MsgData msgData = 1; + string sourceID = 2; } + message MsgDataToMongoByMQ{ - uint64 lastSeq =1; + int64 lastSeq = 1; string aggregationID = 2; - repeated MsgDataToMQ messageList = 3; + repeated MsgDataToMQ messages = 3; string triggerID = 4; - - } message GetMaxAndMinSeqReq { string UserID = 1; - string OperationID = 2; } message GetMaxAndMinSeqResp { - int32 ErrCode = 1; - string ErrMsg = 2; - uint32 MaxSeq = 3; - uint32 MinSeq = 4; + int64 MaxSeq = 1; + int64 MinSeq = 2; } message SendMsgReq { @@ -46,9 +39,9 @@ message SendMsgReq { } message SendMsgResp { - string serverMsgID = 4; - string clientMsgID = 5; - int64 sendTime = 6; + string serverMsgID = 1; + string clientMsgID = 2; + int64 sendTime = 3; } @@ -69,119 +62,98 @@ message SetMsgMinSeqResp{ } message SetSendMsgStatusReq{ - int32 status = 2; + int32 status = 1; } message SetSendMsgStatusResp{ } message GetSendMsgStatusReq{ - string operationID = 1; } message GetSendMsgStatusResp{ - int32 errCode = 1; - string errMsg = 2; - int32 status = 3; + int32 status = 1; } + message DelSuperGroupMsgReq{ - string userID = 2; - string groupID = 3; + string userID = 1; + string groupID = 2; } + message DelSuperGroupMsgResp{ } -message GetSuperGroupMsgReq{ - string operationID = 1; - uint32 Seq = 2; - string groupID = 3; +message GetSuperGroupMsgReq{ + int64 Seq = 1; + string groupID = 2; } message GetSuperGroupMsgResp{ - int32 errCode = 1; - string errMsg = 2; - sdkws.MsgData msgData = 3; + sdkws.MsgData msgData = 1; } -message GetWriteDiffMsgReq{ - string operationID = 1; - uint32 Seq = 2; - } +message GetWriteDiffMsgReq{ + int64 Seq = 1; +} message GetWriteDiffMsgResp{ - int32 errCode = 1; - string errMsg = 2; - sdkws.MsgData msgData = 3; + sdkws.MsgData msgData = 2; } message ModifyMessageReactionExtensionsReq { - string operationID = 1; - string sourceID = 2; - string opUserID = 3; - int32 sessionType = 4; - map reactionExtensionList = 5; - string clientMsgID = 6; - google.protobuf.StringValue ex = 7; - google.protobuf.StringValue attachedInfo = 8; - bool isReact = 9; - bool isExternalExtensions = 10; - int64 msgFirstModifyTime = 11; + string sourceID = 1; + int32 sessionType = 2; + map reactionExtensions = 3; + string clientMsgID = 4; + google.protobuf.StringValue ex = 5; + google.protobuf.StringValue attachedInfo = 6; + bool isReact = 7; + bool isExternalExtensions = 8; + int64 msgFirstModifyTime = 9; } message SetMessageReactionExtensionsReq { - string operationID = 1; - string sourceID = 2; - string opUserID = 3; - int32 sessionType = 4; - map reactionExtensionList = 5; - string clientMsgID = 6; - google.protobuf.StringValue ex = 7; - google.protobuf.StringValue attachedInfo = 8; - bool isReact = 9; - bool isExternalExtensions = 10; - int64 msgFirstModifyTime = 11; + string sourceID = 1; + int32 sessionType = 2; + map reactionExtensions = 3; + string clientMsgID = 4; + google.protobuf.StringValue ex = 5; + google.protobuf.StringValue attachedInfo = 6; + bool isReact = 7; + bool isExternalExtensions = 8; + int64 msgFirstModifyTime = 9; } message SetMessageReactionExtensionsResp { - int32 errCode = 1; - string errMsg = 2; - string clientMsgID = 3; - int64 msgFirstModifyTime = 4; - bool isReact = 5; - repeated KeyValueResp result = 6; + string clientMsgID = 1; + int64 msgFirstModifyTime = 2; + bool isReact = 3; + repeated KeyValueResp result = 4; } -message GetMessageListReactionExtensionsReq { - string operationID = 1; - string opUserID = 2; - string sourceID = 3; - int32 sessionType = 4; +message GetMessagesReactionExtensionsReq { + string sourceID = 1; + int32 sessionType = 2; message MessageReactionKey { string clientMsgID = 1; int64 msgFirstModifyTime = 2; } - repeated MessageReactionKey messageReactionKeyList = 5; - repeated string TypeKeyList = 6; + repeated MessageReactionKey messageReactionKeys = 3; + repeated string TypeKeys = 4; } -message GetMessageListReactionExtensionsResp{ - int32 errCode = 1; - string errMsg = 2; - repeated SingleMessageExtensionResult singleMessageResult =3; +message GetMessagesReactionExtensionsResp{ + repeated SingleMessageExtensionResult singleMessageResult = 1; } message SingleMessageExtensionResult { - int32 errCode = 1; - string errMsg = 2; - map reactionExtensionList = 3; - string clientMsgID = 4; + map reactionExtensions = 1; + string clientMsgID = 2; } message ModifyMessageReactionExtensionsResp { - int32 errCode = 1; - string errMsg = 2; - repeated ExtendMsgResp successList = 3; - repeated ExtendMsgResp failedList = 4; + repeated ExtendMsgResp successList = 1; + repeated ExtendMsgResp failedList = 2; } -message DeleteMessageListReactionExtensionsReq { +message DeleteMessagesReactionExtensionsReq { string operationID = 1; string opUserID = 2; string sourceID = 3; @@ -189,23 +161,19 @@ message DeleteMessageListReactionExtensionsReq { string clientMsgID = 5; bool isExternalExtensions = 6; int64 msgFirstModifyTime = 7; - repeated sdkws.KeyValue reactionExtensionList = 8; + repeated sdkws.KeyValue reactionExtensions = 8; } -message DeleteMessageListReactionExtensionsResp { - int32 errCode = 1; - string errMsg = 2; - repeated KeyValueResp result = 6; +message DeleteMessagesReactionExtensionsResp { + repeated KeyValueResp result = 1; } message ExtendMsgResp { ExtendMsg extendMsg = 1; - int32 errCode = 2; - string errMsg = 3; } message ExtendMsg { - map reactionExtensionList = 1; + map reactionExtensions = 1; string clientMsgID = 2; int64 msgFirstModifyTime = 3; string attachedInfo = 4; @@ -214,33 +182,30 @@ message ExtendMsg { message KeyValueResp { sdkws.KeyValue keyValue = 1; - int32 errCode = 2; - string errMsg = 3; } message MsgDataToModifyByMQ{ - string aggregationID = 1; - repeated MsgDataToMQ messageList = 2; - string triggerID = 3; + repeated MsgDataToMQ messages = 1; + string triggerID = 2; } -message DelMsgListReq{ +message DelMsgsReq{ string userID = 2; - repeated uint32 seqList = 3; + repeated int64 seqs = 3; } -message DelMsgListResp{ +message DelMsgsResp{ } service msg { //获取最小最大seq(包括用户的,以及指定群组的) rpc GetMaxAndMinSeq(sdkws.GetMaxAndMinSeqReq) returns(sdkws.GetMaxAndMinSeqResp); //拉取历史消息(包括用户的,以及指定群组的) - rpc PullMessageBySeqList(sdkws.PullMessageBySeqListReq) returns(sdkws.PullMessageBySeqListResp); + rpc PullMessageBySeqs(sdkws.PullMessageBySeqsReq) returns(sdkws.PullMessageBySeqsResp); //发送消息 rpc SendMsg(SendMsgReq) returns(SendMsgResp); //删除某人消息 - rpc DelMsgList(DelMsgListReq) returns(DelMsgListResp); + rpc DelMsgs(DelMsgsReq) returns(DelMsgsResp); //删除某个用户某个大群消息 rpc DelSuperGroupMsg(DelSuperGroupMsgReq) returns(DelSuperGroupMsgResp); //清空某人所有消息 @@ -255,7 +220,7 @@ service msg { // 修改消息 rpc SetMessageReactionExtensions(SetMessageReactionExtensionsReq) returns(SetMessageReactionExtensionsResp); - rpc GetMessageListReactionExtensions(GetMessageListReactionExtensionsReq) returns(GetMessageListReactionExtensionsResp); + rpc GetMessagesReactionExtensions(GetMessagesReactionExtensionsReq) returns(GetMessagesReactionExtensionsResp); rpc AddMessageReactionExtensions(ModifyMessageReactionExtensionsReq) returns(ModifyMessageReactionExtensionsResp); - rpc DeleteMessageReactionExtensions(DeleteMessageListReactionExtensionsReq) returns(DeleteMessageListReactionExtensionsResp); + rpc DeleteMessageReactionExtensions(DeleteMessagesReactionExtensionsReq) returns(DeleteMessagesReactionExtensionsResp); } diff --git a/pkg/proto/msggateway/msg_gateway.proto b/pkg/proto/msggateway/msg_gateway.proto index 71231e433..a9f350556 100644 --- a/pkg/proto/msggateway/msg_gateway.proto +++ b/pkg/proto/msggateway/msg_gateway.proto @@ -4,29 +4,27 @@ option go_package = "OpenIM/pkg/proto/msggateway;msggateway"; package msggateway; message OnlinePushMsgReq { - string OperationID = 1; - sdkws.MsgData msgData = 2; - string pushToUserID = 3; + sdkws.MsgData msgData = 1; + string pushToUserID = 2; } message OnlinePushMsgResp{ repeated SingleMsgToUserPlatform resp = 1; } -message SingleMsgToUserResultList{ +message SingleMsgToUserResults { string userID =1; repeated SingleMsgToUserPlatform resp = 2; bool onlinePush = 3; } message OnlineBatchPushOneMsgReq{ - string OperationID = 1; - sdkws.MsgData msgData = 2; - repeated string pushToUserIDList = 3; + sdkws.MsgData msgData = 1; + repeated string pushToUserIDs = 2; } message OnlineBatchPushOneMsgResp{ - repeated SingleMsgToUserResultList singlePushResult= 1; + repeated SingleMsgToUserResults singlePushResult= 1; } //message SendMsgByWSReq{ // string SendID = 1; @@ -45,17 +43,14 @@ message SingleMsgToUserPlatform{ string RecvID = 2; int32 RecvPlatFormID = 3; } + message GetUsersOnlineStatusReq{ - repeated string userIDList = 1; - string operationID = 2; - string opUserID = 3; + repeated string userIDs = 1; } message GetUsersOnlineStatusResp{ - int32 errCode = 1; - string errMsg = 2; - repeated SuccessResult successResult = 3; - repeated FailedDetail failedResult = 4; + repeated SuccessResult successResult = 1; + repeated FailedDetail failedResult = 2; message SuccessDetail{ string platform = 1; string status = 2; @@ -63,9 +58,7 @@ message GetUsersOnlineStatusResp{ bool isBackground = 4; } message FailedDetail{ - string userID = 3; - int32 errCode = 1; - string errMsg = 2; + string userID = 1; } message SuccessResult{ string userID = 1; @@ -75,9 +68,8 @@ message GetUsersOnlineStatusResp{ } message KickUserOfflineReq{ - string operationID = 1; - int32 platformID = 2; - repeated string kickUserIDList = 3; + int32 platformID = 1; + repeated string kickUserIDList = 2; } message KickUserOfflineResp{ @@ -91,8 +83,6 @@ message MultiTerminalLoginCheckReq{ string operationID = 4; } message MultiTerminalLoginCheckResp{ - int32 errCode = 1; - string errMsg = 2; } service msgGateway { diff --git a/pkg/proto/rtc/rtc.pb.go b/pkg/proto/rtc/rtc.pb.go index e7b1aaeb7..b3cda45f5 100644 --- a/pkg/proto/rtc/rtc.pb.go +++ b/pkg/proto/rtc/rtc.pb.go @@ -6,6 +6,7 @@ package rtc // import "OpenIM/pkg/proto/rtc" import proto "github.com/golang/protobuf/proto" import fmt "fmt" import math "math" +import sdkws "OpenIM/pkg/proto/sdkws" import ( context "golang.org/x/net/context" @@ -23,2597 +24,19 @@ var _ = math.Inf // proto package needs to be updated. const _ = proto.ProtoPackageIsVersion2 // please upgrade the proto package -type CommonResp struct { - ErrCode int32 `protobuf:"varint,1,opt,name=errCode" json:"errCode,omitempty"` - ErrMsg string `protobuf:"bytes,2,opt,name=errMsg" json:"errMsg,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *CommonResp) Reset() { *m = CommonResp{} } -func (m *CommonResp) String() string { return proto.CompactTextString(m) } -func (*CommonResp) ProtoMessage() {} -func (*CommonResp) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{0} -} -func (m *CommonResp) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_CommonResp.Unmarshal(m, b) -} -func (m *CommonResp) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_CommonResp.Marshal(b, m, deterministic) -} -func (dst *CommonResp) XXX_Merge(src proto.Message) { - xxx_messageInfo_CommonResp.Merge(dst, src) -} -func (m *CommonResp) XXX_Size() int { - return xxx_messageInfo_CommonResp.Size(m) -} -func (m *CommonResp) XXX_DiscardUnknown() { - xxx_messageInfo_CommonResp.DiscardUnknown(m) -} - -var xxx_messageInfo_CommonResp proto.InternalMessageInfo - -func (m *CommonResp) GetErrCode() int32 { - if m != nil { - return m.ErrCode - } - return 0 -} - -func (m *CommonResp) GetErrMsg() string { - if m != nil { - return m.ErrMsg - } - return "" -} - -type MsgData struct { - SendID string `protobuf:"bytes,1,opt,name=sendID" json:"sendID,omitempty"` - RecvID string `protobuf:"bytes,2,opt,name=recvID" json:"recvID,omitempty"` - GroupID string `protobuf:"bytes,3,opt,name=groupID" json:"groupID,omitempty"` - ClientMsgID string `protobuf:"bytes,4,opt,name=clientMsgID" json:"clientMsgID,omitempty"` - ServerMsgID string `protobuf:"bytes,5,opt,name=serverMsgID" json:"serverMsgID,omitempty"` - SenderPlatformID int32 `protobuf:"varint,6,opt,name=senderPlatformID" json:"senderPlatformID,omitempty"` - SenderNickname string `protobuf:"bytes,7,opt,name=senderNickname" json:"senderNickname,omitempty"` - SenderFaceURL string `protobuf:"bytes,8,opt,name=senderFaceURL" json:"senderFaceURL,omitempty"` - SessionType int32 `protobuf:"varint,9,opt,name=sessionType" json:"sessionType,omitempty"` - MsgFrom int32 `protobuf:"varint,10,opt,name=msgFrom" json:"msgFrom,omitempty"` - ContentType int32 `protobuf:"varint,11,opt,name=contentType" json:"contentType,omitempty"` - Content []byte `protobuf:"bytes,12,opt,name=content,proto3" json:"content,omitempty"` - Seq uint32 `protobuf:"varint,14,opt,name=seq" json:"seq,omitempty"` - SendTime int64 `protobuf:"varint,15,opt,name=sendTime" json:"sendTime,omitempty"` - CreateTime int64 `protobuf:"varint,16,opt,name=createTime" json:"createTime,omitempty"` - Status int32 `protobuf:"varint,17,opt,name=status" json:"status,omitempty"` - Options map[string]bool `protobuf:"bytes,18,rep,name=options" json:"options,omitempty" protobuf_key:"bytes,1,opt,name=key" protobuf_val:"varint,2,opt,name=value"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,19,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *MsgData) Reset() { *m = MsgData{} } -func (m *MsgData) String() string { return proto.CompactTextString(m) } -func (*MsgData) ProtoMessage() {} -func (*MsgData) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{1} -} -func (m *MsgData) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_MsgData.Unmarshal(m, b) -} -func (m *MsgData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_MsgData.Marshal(b, m, deterministic) -} -func (dst *MsgData) XXX_Merge(src proto.Message) { - xxx_messageInfo_MsgData.Merge(dst, src) -} -func (m *MsgData) XXX_Size() int { - return xxx_messageInfo_MsgData.Size(m) -} -func (m *MsgData) XXX_DiscardUnknown() { - xxx_messageInfo_MsgData.DiscardUnknown(m) -} - -var xxx_messageInfo_MsgData proto.InternalMessageInfo - -func (m *MsgData) GetSendID() string { - if m != nil { - return m.SendID - } - return "" -} - -func (m *MsgData) GetRecvID() string { - if m != nil { - return m.RecvID - } - return "" -} - -func (m *MsgData) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -func (m *MsgData) GetClientMsgID() string { - if m != nil { - return m.ClientMsgID - } - return "" -} - -func (m *MsgData) GetServerMsgID() string { - if m != nil { - return m.ServerMsgID - } - return "" -} - -func (m *MsgData) GetSenderPlatformID() int32 { - if m != nil { - return m.SenderPlatformID - } - return 0 -} - -func (m *MsgData) GetSenderNickname() string { - if m != nil { - return m.SenderNickname - } - return "" -} - -func (m *MsgData) GetSenderFaceURL() string { - if m != nil { - return m.SenderFaceURL - } - return "" -} - -func (m *MsgData) GetSessionType() int32 { - if m != nil { - return m.SessionType - } - return 0 -} - -func (m *MsgData) GetMsgFrom() int32 { - if m != nil { - return m.MsgFrom - } - return 0 -} - -func (m *MsgData) GetContentType() int32 { - if m != nil { - return m.ContentType - } - return 0 -} - -func (m *MsgData) GetContent() []byte { - if m != nil { - return m.Content - } - return nil -} - -func (m *MsgData) GetSeq() uint32 { - if m != nil { - return m.Seq - } - return 0 -} - -func (m *MsgData) GetSendTime() int64 { - if m != nil { - return m.SendTime - } - return 0 -} - -func (m *MsgData) GetCreateTime() int64 { - if m != nil { - return m.CreateTime - } - return 0 -} - -func (m *MsgData) GetStatus() int32 { - if m != nil { - return m.Status - } - return 0 -} - -func (m *MsgData) GetOptions() map[string]bool { - if m != nil { - return m.Options - } - return nil -} - -func (m *MsgData) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -type GroupInfo struct { - GroupID string `protobuf:"bytes,1,opt,name=groupID" json:"groupID,omitempty"` - GroupName string `protobuf:"bytes,2,opt,name=groupName" json:"groupName,omitempty"` - Notification string `protobuf:"bytes,3,opt,name=notification" json:"notification,omitempty"` - Introduction string `protobuf:"bytes,4,opt,name=introduction" json:"introduction,omitempty"` - FaceURL string `protobuf:"bytes,5,opt,name=faceURL" json:"faceURL,omitempty"` - OwnerUserID string `protobuf:"bytes,6,opt,name=ownerUserID" json:"ownerUserID,omitempty"` - CreateTime uint32 `protobuf:"varint,7,opt,name=createTime" json:"createTime,omitempty"` - MemberCount uint32 `protobuf:"varint,8,opt,name=memberCount" json:"memberCount,omitempty"` - Ex string `protobuf:"bytes,9,opt,name=ex" json:"ex,omitempty"` - Status int32 `protobuf:"varint,10,opt,name=status" json:"status,omitempty"` - CreatorUserID string `protobuf:"bytes,11,opt,name=creatorUserID" json:"creatorUserID,omitempty"` - GroupType int32 `protobuf:"varint,12,opt,name=groupType" json:"groupType,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *GroupInfo) Reset() { *m = GroupInfo{} } -func (m *GroupInfo) String() string { return proto.CompactTextString(m) } -func (*GroupInfo) ProtoMessage() {} -func (*GroupInfo) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{2} -} -func (m *GroupInfo) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_GroupInfo.Unmarshal(m, b) -} -func (m *GroupInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_GroupInfo.Marshal(b, m, deterministic) -} -func (dst *GroupInfo) XXX_Merge(src proto.Message) { - xxx_messageInfo_GroupInfo.Merge(dst, src) -} -func (m *GroupInfo) XXX_Size() int { - return xxx_messageInfo_GroupInfo.Size(m) -} -func (m *GroupInfo) XXX_DiscardUnknown() { - xxx_messageInfo_GroupInfo.DiscardUnknown(m) -} - -var xxx_messageInfo_GroupInfo proto.InternalMessageInfo - -func (m *GroupInfo) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -func (m *GroupInfo) GetGroupName() string { - if m != nil { - return m.GroupName - } - return "" -} - -func (m *GroupInfo) GetNotification() string { - if m != nil { - return m.Notification - } - return "" -} - -func (m *GroupInfo) GetIntroduction() string { - if m != nil { - return m.Introduction - } - return "" -} - -func (m *GroupInfo) GetFaceURL() string { - if m != nil { - return m.FaceURL - } - return "" -} - -func (m *GroupInfo) GetOwnerUserID() string { - if m != nil { - return m.OwnerUserID - } - return "" -} - -func (m *GroupInfo) GetCreateTime() uint32 { - if m != nil { - return m.CreateTime - } - return 0 -} - -func (m *GroupInfo) GetMemberCount() uint32 { - if m != nil { - return m.MemberCount - } - return 0 -} - -func (m *GroupInfo) GetEx() string { - if m != nil { - return m.Ex - } - return "" -} - -func (m *GroupInfo) GetStatus() int32 { - if m != nil { - return m.Status - } - return 0 -} - -func (m *GroupInfo) GetCreatorUserID() string { - if m != nil { - return m.CreatorUserID - } - return "" -} - -func (m *GroupInfo) GetGroupType() int32 { - if m != nil { - return m.GroupType - } - return 0 -} - -type GroupMemberFullInfo struct { - GroupID string `protobuf:"bytes,1,opt,name=groupID" json:"groupID,omitempty"` - UserID string `protobuf:"bytes,2,opt,name=userID" json:"userID,omitempty"` - RoleLevel int32 `protobuf:"varint,3,opt,name=roleLevel" json:"roleLevel,omitempty"` - JoinTime int32 `protobuf:"varint,4,opt,name=joinTime" json:"joinTime,omitempty"` - Nickname string `protobuf:"bytes,5,opt,name=nickname" json:"nickname,omitempty"` - FaceURL string `protobuf:"bytes,6,opt,name=faceURL" json:"faceURL,omitempty"` - AppMangerLevel int32 `protobuf:"varint,7,opt,name=appMangerLevel" json:"appMangerLevel,omitempty"` - JoinSource int32 `protobuf:"varint,8,opt,name=joinSource" json:"joinSource,omitempty"` - OperatorUserID string `protobuf:"bytes,9,opt,name=operatorUserID" json:"operatorUserID,omitempty"` - Ex string `protobuf:"bytes,10,opt,name=ex" json:"ex,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *GroupMemberFullInfo) Reset() { *m = GroupMemberFullInfo{} } -func (m *GroupMemberFullInfo) String() string { return proto.CompactTextString(m) } -func (*GroupMemberFullInfo) ProtoMessage() {} -func (*GroupMemberFullInfo) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{3} -} -func (m *GroupMemberFullInfo) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_GroupMemberFullInfo.Unmarshal(m, b) -} -func (m *GroupMemberFullInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_GroupMemberFullInfo.Marshal(b, m, deterministic) -} -func (dst *GroupMemberFullInfo) XXX_Merge(src proto.Message) { - xxx_messageInfo_GroupMemberFullInfo.Merge(dst, src) -} -func (m *GroupMemberFullInfo) XXX_Size() int { - return xxx_messageInfo_GroupMemberFullInfo.Size(m) -} -func (m *GroupMemberFullInfo) XXX_DiscardUnknown() { - xxx_messageInfo_GroupMemberFullInfo.DiscardUnknown(m) -} - -var xxx_messageInfo_GroupMemberFullInfo proto.InternalMessageInfo - -func (m *GroupMemberFullInfo) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -func (m *GroupMemberFullInfo) GetUserID() string { - if m != nil { - return m.UserID - } - return "" -} - -func (m *GroupMemberFullInfo) GetRoleLevel() int32 { - if m != nil { - return m.RoleLevel - } - return 0 -} - -func (m *GroupMemberFullInfo) GetJoinTime() int32 { - if m != nil { - return m.JoinTime - } - return 0 -} - -func (m *GroupMemberFullInfo) GetNickname() string { - if m != nil { - return m.Nickname - } - return "" -} - -func (m *GroupMemberFullInfo) GetFaceURL() string { - if m != nil { - return m.FaceURL - } - return "" -} - -func (m *GroupMemberFullInfo) GetAppMangerLevel() int32 { - if m != nil { - return m.AppMangerLevel - } - return 0 -} - -func (m *GroupMemberFullInfo) GetJoinSource() int32 { - if m != nil { - return m.JoinSource - } - return 0 -} - -func (m *GroupMemberFullInfo) GetOperatorUserID() string { - if m != nil { - return m.OperatorUserID - } - return "" -} - -func (m *GroupMemberFullInfo) GetEx() string { - if m != nil { - return m.Ex - } - return "" -} - -type ParticipantMetaData struct { - GroupInfo *GroupInfo `protobuf:"bytes,1,opt,name=groupInfo" json:"groupInfo,omitempty"` - GroupMemberInfo *GroupMemberFullInfo `protobuf:"bytes,2,opt,name=groupMemberInfo" json:"groupMemberInfo,omitempty"` - UserInfo *PublicUserInfo `protobuf:"bytes,3,opt,name=userInfo" json:"userInfo,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *ParticipantMetaData) Reset() { *m = ParticipantMetaData{} } -func (m *ParticipantMetaData) String() string { return proto.CompactTextString(m) } -func (*ParticipantMetaData) ProtoMessage() {} -func (*ParticipantMetaData) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{4} -} -func (m *ParticipantMetaData) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_ParticipantMetaData.Unmarshal(m, b) -} -func (m *ParticipantMetaData) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_ParticipantMetaData.Marshal(b, m, deterministic) -} -func (dst *ParticipantMetaData) XXX_Merge(src proto.Message) { - xxx_messageInfo_ParticipantMetaData.Merge(dst, src) -} -func (m *ParticipantMetaData) XXX_Size() int { - return xxx_messageInfo_ParticipantMetaData.Size(m) -} -func (m *ParticipantMetaData) XXX_DiscardUnknown() { - xxx_messageInfo_ParticipantMetaData.DiscardUnknown(m) -} - -var xxx_messageInfo_ParticipantMetaData proto.InternalMessageInfo - -func (m *ParticipantMetaData) GetGroupInfo() *GroupInfo { - if m != nil { - return m.GroupInfo - } - return nil -} - -func (m *ParticipantMetaData) GetGroupMemberInfo() *GroupMemberFullInfo { - if m != nil { - return m.GroupMemberInfo - } - return nil -} - -func (m *ParticipantMetaData) GetUserInfo() *PublicUserInfo { - if m != nil { - return m.UserInfo - } - return nil -} - -type PublicUserInfo struct { - UserID string `protobuf:"bytes,1,opt,name=userID" json:"userID,omitempty"` - Nickname string `protobuf:"bytes,2,opt,name=nickname" json:"nickname,omitempty"` - FaceURL string `protobuf:"bytes,3,opt,name=faceURL" json:"faceURL,omitempty"` - Gender int32 `protobuf:"varint,4,opt,name=gender" json:"gender,omitempty"` - Ex string `protobuf:"bytes,5,opt,name=ex" json:"ex,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *PublicUserInfo) Reset() { *m = PublicUserInfo{} } -func (m *PublicUserInfo) String() string { return proto.CompactTextString(m) } -func (*PublicUserInfo) ProtoMessage() {} -func (*PublicUserInfo) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{5} -} -func (m *PublicUserInfo) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_PublicUserInfo.Unmarshal(m, b) -} -func (m *PublicUserInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_PublicUserInfo.Marshal(b, m, deterministic) -} -func (dst *PublicUserInfo) XXX_Merge(src proto.Message) { - xxx_messageInfo_PublicUserInfo.Merge(dst, src) -} -func (m *PublicUserInfo) XXX_Size() int { - return xxx_messageInfo_PublicUserInfo.Size(m) -} -func (m *PublicUserInfo) XXX_DiscardUnknown() { - xxx_messageInfo_PublicUserInfo.DiscardUnknown(m) -} - -var xxx_messageInfo_PublicUserInfo proto.InternalMessageInfo - -func (m *PublicUserInfo) GetUserID() string { - if m != nil { - return m.UserID - } - return "" -} - -func (m *PublicUserInfo) GetNickname() string { - if m != nil { - return m.Nickname - } - return "" -} - -func (m *PublicUserInfo) GetFaceURL() string { - if m != nil { - return m.FaceURL - } - return "" -} - -func (m *PublicUserInfo) GetGender() int32 { - if m != nil { - return m.Gender - } - return 0 -} - -func (m *PublicUserInfo) GetEx() string { - if m != nil { - return m.Ex - } - return "" -} - -type GetJoinTokenReq struct { - Room string `protobuf:"bytes,1,opt,name=room" json:"room,omitempty"` - Identity string `protobuf:"bytes,2,opt,name=identity" json:"identity,omitempty"` - MetaData *ParticipantMetaData `protobuf:"bytes,3,opt,name=metaData" json:"metaData,omitempty"` - OperationID string `protobuf:"bytes,4,opt,name=operationID" json:"operationID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *GetJoinTokenReq) Reset() { *m = GetJoinTokenReq{} } -func (m *GetJoinTokenReq) String() string { return proto.CompactTextString(m) } -func (*GetJoinTokenReq) ProtoMessage() {} -func (*GetJoinTokenReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{6} -} -func (m *GetJoinTokenReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_GetJoinTokenReq.Unmarshal(m, b) -} -func (m *GetJoinTokenReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_GetJoinTokenReq.Marshal(b, m, deterministic) -} -func (dst *GetJoinTokenReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_GetJoinTokenReq.Merge(dst, src) -} -func (m *GetJoinTokenReq) XXX_Size() int { - return xxx_messageInfo_GetJoinTokenReq.Size(m) -} -func (m *GetJoinTokenReq) XXX_DiscardUnknown() { - xxx_messageInfo_GetJoinTokenReq.DiscardUnknown(m) -} - -var xxx_messageInfo_GetJoinTokenReq proto.InternalMessageInfo - -func (m *GetJoinTokenReq) GetRoom() string { - if m != nil { - return m.Room - } - return "" -} - -func (m *GetJoinTokenReq) GetIdentity() string { - if m != nil { - return m.Identity - } - return "" -} - -func (m *GetJoinTokenReq) GetMetaData() *ParticipantMetaData { - if m != nil { - return m.MetaData - } - return nil -} - -func (m *GetJoinTokenReq) GetOperationID() string { - if m != nil { - return m.OperationID - } - return "" -} - -type GetJoinTokenResp struct { - CommonResp *CommonResp `protobuf:"bytes,1,opt,name=CommonResp" json:"CommonResp,omitempty"` - Jwt string `protobuf:"bytes,2,opt,name=jwt" json:"jwt,omitempty"` - LiveURL string `protobuf:"bytes,3,opt,name=liveURL" json:"liveURL,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *GetJoinTokenResp) Reset() { *m = GetJoinTokenResp{} } -func (m *GetJoinTokenResp) String() string { return proto.CompactTextString(m) } -func (*GetJoinTokenResp) ProtoMessage() {} -func (*GetJoinTokenResp) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{7} -} -func (m *GetJoinTokenResp) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_GetJoinTokenResp.Unmarshal(m, b) -} -func (m *GetJoinTokenResp) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_GetJoinTokenResp.Marshal(b, m, deterministic) -} -func (dst *GetJoinTokenResp) XXX_Merge(src proto.Message) { - xxx_messageInfo_GetJoinTokenResp.Merge(dst, src) -} -func (m *GetJoinTokenResp) XXX_Size() int { - return xxx_messageInfo_GetJoinTokenResp.Size(m) -} -func (m *GetJoinTokenResp) XXX_DiscardUnknown() { - xxx_messageInfo_GetJoinTokenResp.DiscardUnknown(m) -} - -var xxx_messageInfo_GetJoinTokenResp proto.InternalMessageInfo - -func (m *GetJoinTokenResp) GetCommonResp() *CommonResp { - if m != nil { - return m.CommonResp - } - return nil -} - -func (m *GetJoinTokenResp) GetJwt() string { - if m != nil { - return m.Jwt - } - return "" -} - -func (m *GetJoinTokenResp) GetLiveURL() string { - if m != nil { - return m.LiveURL - } - return "" -} - -type OfflinePushInfo struct { - Title string `protobuf:"bytes,1,opt,name=title" json:"title,omitempty"` - Desc string `protobuf:"bytes,2,opt,name=desc" json:"desc,omitempty"` - Ex string `protobuf:"bytes,3,opt,name=ex" json:"ex,omitempty"` - IOSPushSound string `protobuf:"bytes,4,opt,name=iOSPushSound" json:"iOSPushSound,omitempty"` - IOSBadgeCount bool `protobuf:"varint,5,opt,name=iOSBadgeCount" json:"iOSBadgeCount,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *OfflinePushInfo) Reset() { *m = OfflinePushInfo{} } -func (m *OfflinePushInfo) String() string { return proto.CompactTextString(m) } -func (*OfflinePushInfo) ProtoMessage() {} -func (*OfflinePushInfo) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{8} -} -func (m *OfflinePushInfo) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_OfflinePushInfo.Unmarshal(m, b) -} -func (m *OfflinePushInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_OfflinePushInfo.Marshal(b, m, deterministic) -} -func (dst *OfflinePushInfo) XXX_Merge(src proto.Message) { - xxx_messageInfo_OfflinePushInfo.Merge(dst, src) -} -func (m *OfflinePushInfo) XXX_Size() int { - return xxx_messageInfo_OfflinePushInfo.Size(m) -} -func (m *OfflinePushInfo) XXX_DiscardUnknown() { - xxx_messageInfo_OfflinePushInfo.DiscardUnknown(m) -} - -var xxx_messageInfo_OfflinePushInfo proto.InternalMessageInfo - -func (m *OfflinePushInfo) GetTitle() string { - if m != nil { - return m.Title - } - return "" -} - -func (m *OfflinePushInfo) GetDesc() string { - if m != nil { - return m.Desc - } - return "" -} - -func (m *OfflinePushInfo) GetEx() string { - if m != nil { - return m.Ex - } - return "" -} - -func (m *OfflinePushInfo) GetIOSPushSound() string { - if m != nil { - return m.IOSPushSound - } - return "" -} - -func (m *OfflinePushInfo) GetIOSBadgeCount() bool { - if m != nil { - return m.IOSBadgeCount - } - return false -} - -type SignalReq struct { - // Types that are valid to be assigned to Payload: - // *SignalReq_Invite - // *SignalReq_InviteInGroup - // *SignalReq_Cancel - // *SignalReq_Accept - // *SignalReq_HungUp - // *SignalReq_Reject - // *SignalReq_GetRoomByGroupID - // *SignalReq_OnRoomParticipantConnectedReq - // *SignalReq_OnRoomParticipantDisconnectedReq - // *SignalReq_GetTokenByRoomID - Payload isSignalReq_Payload `protobuf_oneof:"payload"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalReq) Reset() { *m = SignalReq{} } -func (m *SignalReq) String() string { return proto.CompactTextString(m) } -func (*SignalReq) ProtoMessage() {} -func (*SignalReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{9} -} -func (m *SignalReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalReq.Unmarshal(m, b) -} -func (m *SignalReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalReq.Marshal(b, m, deterministic) -} -func (dst *SignalReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalReq.Merge(dst, src) -} -func (m *SignalReq) XXX_Size() int { - return xxx_messageInfo_SignalReq.Size(m) -} -func (m *SignalReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalReq proto.InternalMessageInfo - -type isSignalReq_Payload interface { - isSignalReq_Payload() -} - -type SignalReq_Invite struct { - Invite *SignalInviteReq `protobuf:"bytes,1,opt,name=invite,oneof"` -} -type SignalReq_InviteInGroup struct { - InviteInGroup *SignalInviteInGroupReq `protobuf:"bytes,2,opt,name=inviteInGroup,oneof"` -} -type SignalReq_Cancel struct { - Cancel *SignalCancelReq `protobuf:"bytes,3,opt,name=cancel,oneof"` -} -type SignalReq_Accept struct { - Accept *SignalAcceptReq `protobuf:"bytes,4,opt,name=accept,oneof"` -} -type SignalReq_HungUp struct { - HungUp *SignalHungUpReq `protobuf:"bytes,5,opt,name=hungUp,oneof"` -} -type SignalReq_Reject struct { - Reject *SignalRejectReq `protobuf:"bytes,6,opt,name=reject,oneof"` -} -type SignalReq_GetRoomByGroupID struct { - GetRoomByGroupID *SignalGetRoomByGroupIDReq `protobuf:"bytes,7,opt,name=getRoomByGroupID,oneof"` -} -type SignalReq_OnRoomParticipantConnectedReq struct { - OnRoomParticipantConnectedReq *SignalOnRoomParticipantConnectedReq `protobuf:"bytes,8,opt,name=onRoomParticipantConnectedReq,oneof"` -} -type SignalReq_OnRoomParticipantDisconnectedReq struct { - OnRoomParticipantDisconnectedReq *SignalOnRoomParticipantDisconnectedReq `protobuf:"bytes,9,opt,name=onRoomParticipantDisconnectedReq,oneof"` -} -type SignalReq_GetTokenByRoomID struct { - GetTokenByRoomID *SignalGetTokenByRoomIDReq `protobuf:"bytes,10,opt,name=getTokenByRoomID,oneof"` -} - -func (*SignalReq_Invite) isSignalReq_Payload() {} -func (*SignalReq_InviteInGroup) isSignalReq_Payload() {} -func (*SignalReq_Cancel) isSignalReq_Payload() {} -func (*SignalReq_Accept) isSignalReq_Payload() {} -func (*SignalReq_HungUp) isSignalReq_Payload() {} -func (*SignalReq_Reject) isSignalReq_Payload() {} -func (*SignalReq_GetRoomByGroupID) isSignalReq_Payload() {} -func (*SignalReq_OnRoomParticipantConnectedReq) isSignalReq_Payload() {} -func (*SignalReq_OnRoomParticipantDisconnectedReq) isSignalReq_Payload() {} -func (*SignalReq_GetTokenByRoomID) isSignalReq_Payload() {} - -func (m *SignalReq) GetPayload() isSignalReq_Payload { - if m != nil { - return m.Payload - } - return nil -} - -func (m *SignalReq) GetInvite() *SignalInviteReq { - if x, ok := m.GetPayload().(*SignalReq_Invite); ok { - return x.Invite - } - return nil -} - -func (m *SignalReq) GetInviteInGroup() *SignalInviteInGroupReq { - if x, ok := m.GetPayload().(*SignalReq_InviteInGroup); ok { - return x.InviteInGroup - } - return nil -} - -func (m *SignalReq) GetCancel() *SignalCancelReq { - if x, ok := m.GetPayload().(*SignalReq_Cancel); ok { - return x.Cancel - } - return nil -} - -func (m *SignalReq) GetAccept() *SignalAcceptReq { - if x, ok := m.GetPayload().(*SignalReq_Accept); ok { - return x.Accept - } - return nil -} - -func (m *SignalReq) GetHungUp() *SignalHungUpReq { - if x, ok := m.GetPayload().(*SignalReq_HungUp); ok { - return x.HungUp - } - return nil -} - -func (m *SignalReq) GetReject() *SignalRejectReq { - if x, ok := m.GetPayload().(*SignalReq_Reject); ok { - return x.Reject - } - return nil -} - -func (m *SignalReq) GetGetRoomByGroupID() *SignalGetRoomByGroupIDReq { - if x, ok := m.GetPayload().(*SignalReq_GetRoomByGroupID); ok { - return x.GetRoomByGroupID - } - return nil -} - -func (m *SignalReq) GetOnRoomParticipantConnectedReq() *SignalOnRoomParticipantConnectedReq { - if x, ok := m.GetPayload().(*SignalReq_OnRoomParticipantConnectedReq); ok { - return x.OnRoomParticipantConnectedReq - } - return nil -} - -func (m *SignalReq) GetOnRoomParticipantDisconnectedReq() *SignalOnRoomParticipantDisconnectedReq { - if x, ok := m.GetPayload().(*SignalReq_OnRoomParticipantDisconnectedReq); ok { - return x.OnRoomParticipantDisconnectedReq - } - return nil -} - -func (m *SignalReq) GetGetTokenByRoomID() *SignalGetTokenByRoomIDReq { - if x, ok := m.GetPayload().(*SignalReq_GetTokenByRoomID); ok { - return x.GetTokenByRoomID - } - return nil -} - -// XXX_OneofFuncs is for the internal use of the proto package. -func (*SignalReq) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{}) { - return _SignalReq_OneofMarshaler, _SignalReq_OneofUnmarshaler, _SignalReq_OneofSizer, []interface{}{ - (*SignalReq_Invite)(nil), - (*SignalReq_InviteInGroup)(nil), - (*SignalReq_Cancel)(nil), - (*SignalReq_Accept)(nil), - (*SignalReq_HungUp)(nil), - (*SignalReq_Reject)(nil), - (*SignalReq_GetRoomByGroupID)(nil), - (*SignalReq_OnRoomParticipantConnectedReq)(nil), - (*SignalReq_OnRoomParticipantDisconnectedReq)(nil), - (*SignalReq_GetTokenByRoomID)(nil), - } -} - -func _SignalReq_OneofMarshaler(msg proto.Message, b *proto.Buffer) error { - m := msg.(*SignalReq) - // payload - switch x := m.Payload.(type) { - case *SignalReq_Invite: - b.EncodeVarint(1<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Invite); err != nil { - return err - } - case *SignalReq_InviteInGroup: - b.EncodeVarint(2<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.InviteInGroup); err != nil { - return err - } - case *SignalReq_Cancel: - b.EncodeVarint(3<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Cancel); err != nil { - return err - } - case *SignalReq_Accept: - b.EncodeVarint(4<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Accept); err != nil { - return err - } - case *SignalReq_HungUp: - b.EncodeVarint(5<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.HungUp); err != nil { - return err - } - case *SignalReq_Reject: - b.EncodeVarint(6<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Reject); err != nil { - return err - } - case *SignalReq_GetRoomByGroupID: - b.EncodeVarint(7<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.GetRoomByGroupID); err != nil { - return err - } - case *SignalReq_OnRoomParticipantConnectedReq: - b.EncodeVarint(8<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.OnRoomParticipantConnectedReq); err != nil { - return err - } - case *SignalReq_OnRoomParticipantDisconnectedReq: - b.EncodeVarint(9<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.OnRoomParticipantDisconnectedReq); err != nil { - return err - } - case *SignalReq_GetTokenByRoomID: - b.EncodeVarint(10<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.GetTokenByRoomID); err != nil { - return err - } - case nil: - default: - return fmt.Errorf("SignalReq.Payload has unexpected type %T", x) - } - return nil -} - -func _SignalReq_OneofUnmarshaler(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error) { - m := msg.(*SignalReq) - switch tag { - case 1: // payload.invite - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalInviteReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_Invite{msg} - return true, err - case 2: // payload.inviteInGroup - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalInviteInGroupReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_InviteInGroup{msg} - return true, err - case 3: // payload.cancel - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalCancelReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_Cancel{msg} - return true, err - case 4: // payload.accept - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalAcceptReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_Accept{msg} - return true, err - case 5: // payload.hungUp - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalHungUpReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_HungUp{msg} - return true, err - case 6: // payload.reject - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalRejectReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_Reject{msg} - return true, err - case 7: // payload.getRoomByGroupID - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalGetRoomByGroupIDReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_GetRoomByGroupID{msg} - return true, err - case 8: // payload.onRoomParticipantConnectedReq - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalOnRoomParticipantConnectedReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_OnRoomParticipantConnectedReq{msg} - return true, err - case 9: // payload.onRoomParticipantDisconnectedReq - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalOnRoomParticipantDisconnectedReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_OnRoomParticipantDisconnectedReq{msg} - return true, err - case 10: // payload.getTokenByRoomID - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalGetTokenByRoomIDReq) - err := b.DecodeMessage(msg) - m.Payload = &SignalReq_GetTokenByRoomID{msg} - return true, err - default: - return false, nil - } -} - -func _SignalReq_OneofSizer(msg proto.Message) (n int) { - m := msg.(*SignalReq) - // payload - switch x := m.Payload.(type) { - case *SignalReq_Invite: - s := proto.Size(x.Invite) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_InviteInGroup: - s := proto.Size(x.InviteInGroup) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_Cancel: - s := proto.Size(x.Cancel) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_Accept: - s := proto.Size(x.Accept) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_HungUp: - s := proto.Size(x.HungUp) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_Reject: - s := proto.Size(x.Reject) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_GetRoomByGroupID: - s := proto.Size(x.GetRoomByGroupID) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_OnRoomParticipantConnectedReq: - s := proto.Size(x.OnRoomParticipantConnectedReq) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_OnRoomParticipantDisconnectedReq: - s := proto.Size(x.OnRoomParticipantDisconnectedReq) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalReq_GetTokenByRoomID: - s := proto.Size(x.GetTokenByRoomID) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case nil: - default: - panic(fmt.Sprintf("proto: unexpected type %T in oneof", x)) - } - return n -} - -type SignalResp struct { - // Types that are valid to be assigned to Payload: - // *SignalResp_Invite - // *SignalResp_InviteInGroup - // *SignalResp_Cancel - // *SignalResp_Accept - // *SignalResp_HungUp - // *SignalResp_Reject - // *SignalResp_GetRoomByGroupID - // *SignalResp_GetTokenByRoomID - Payload isSignalResp_Payload `protobuf_oneof:"payload"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalResp) Reset() { *m = SignalResp{} } -func (m *SignalResp) String() string { return proto.CompactTextString(m) } -func (*SignalResp) ProtoMessage() {} -func (*SignalResp) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{10} -} -func (m *SignalResp) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalResp.Unmarshal(m, b) -} -func (m *SignalResp) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalResp.Marshal(b, m, deterministic) -} -func (dst *SignalResp) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalResp.Merge(dst, src) -} -func (m *SignalResp) XXX_Size() int { - return xxx_messageInfo_SignalResp.Size(m) -} -func (m *SignalResp) XXX_DiscardUnknown() { - xxx_messageInfo_SignalResp.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalResp proto.InternalMessageInfo - -type isSignalResp_Payload interface { - isSignalResp_Payload() -} - -type SignalResp_Invite struct { - Invite *SignalInviteReply `protobuf:"bytes,1,opt,name=invite,oneof"` -} -type SignalResp_InviteInGroup struct { - InviteInGroup *SignalInviteInGroupReply `protobuf:"bytes,2,opt,name=inviteInGroup,oneof"` -} -type SignalResp_Cancel struct { - Cancel *SignalCancelReply `protobuf:"bytes,3,opt,name=cancel,oneof"` -} -type SignalResp_Accept struct { - Accept *SignalAcceptReply `protobuf:"bytes,4,opt,name=accept,oneof"` -} -type SignalResp_HungUp struct { - HungUp *SignalHungUpReply `protobuf:"bytes,5,opt,name=hungUp,oneof"` -} -type SignalResp_Reject struct { - Reject *SignalRejectReply `protobuf:"bytes,6,opt,name=reject,oneof"` -} -type SignalResp_GetRoomByGroupID struct { - GetRoomByGroupID *SignalGetRoomByGroupIDReply `protobuf:"bytes,7,opt,name=getRoomByGroupID,oneof"` -} -type SignalResp_GetTokenByRoomID struct { - GetTokenByRoomID *SignalGetTokenByRoomIDReply `protobuf:"bytes,8,opt,name=getTokenByRoomID,oneof"` -} - -func (*SignalResp_Invite) isSignalResp_Payload() {} -func (*SignalResp_InviteInGroup) isSignalResp_Payload() {} -func (*SignalResp_Cancel) isSignalResp_Payload() {} -func (*SignalResp_Accept) isSignalResp_Payload() {} -func (*SignalResp_HungUp) isSignalResp_Payload() {} -func (*SignalResp_Reject) isSignalResp_Payload() {} -func (*SignalResp_GetRoomByGroupID) isSignalResp_Payload() {} -func (*SignalResp_GetTokenByRoomID) isSignalResp_Payload() {} - -func (m *SignalResp) GetPayload() isSignalResp_Payload { - if m != nil { - return m.Payload - } - return nil -} - -func (m *SignalResp) GetInvite() *SignalInviteReply { - if x, ok := m.GetPayload().(*SignalResp_Invite); ok { - return x.Invite - } - return nil -} - -func (m *SignalResp) GetInviteInGroup() *SignalInviteInGroupReply { - if x, ok := m.GetPayload().(*SignalResp_InviteInGroup); ok { - return x.InviteInGroup - } - return nil -} - -func (m *SignalResp) GetCancel() *SignalCancelReply { - if x, ok := m.GetPayload().(*SignalResp_Cancel); ok { - return x.Cancel - } - return nil -} - -func (m *SignalResp) GetAccept() *SignalAcceptReply { - if x, ok := m.GetPayload().(*SignalResp_Accept); ok { - return x.Accept - } - return nil -} - -func (m *SignalResp) GetHungUp() *SignalHungUpReply { - if x, ok := m.GetPayload().(*SignalResp_HungUp); ok { - return x.HungUp - } - return nil -} - -func (m *SignalResp) GetReject() *SignalRejectReply { - if x, ok := m.GetPayload().(*SignalResp_Reject); ok { - return x.Reject - } - return nil -} - -func (m *SignalResp) GetGetRoomByGroupID() *SignalGetRoomByGroupIDReply { - if x, ok := m.GetPayload().(*SignalResp_GetRoomByGroupID); ok { - return x.GetRoomByGroupID - } - return nil -} - -func (m *SignalResp) GetGetTokenByRoomID() *SignalGetTokenByRoomIDReply { - if x, ok := m.GetPayload().(*SignalResp_GetTokenByRoomID); ok { - return x.GetTokenByRoomID - } - return nil -} - -// XXX_OneofFuncs is for the internal use of the proto package. -func (*SignalResp) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{}) { - return _SignalResp_OneofMarshaler, _SignalResp_OneofUnmarshaler, _SignalResp_OneofSizer, []interface{}{ - (*SignalResp_Invite)(nil), - (*SignalResp_InviteInGroup)(nil), - (*SignalResp_Cancel)(nil), - (*SignalResp_Accept)(nil), - (*SignalResp_HungUp)(nil), - (*SignalResp_Reject)(nil), - (*SignalResp_GetRoomByGroupID)(nil), - (*SignalResp_GetTokenByRoomID)(nil), - } -} - -func _SignalResp_OneofMarshaler(msg proto.Message, b *proto.Buffer) error { - m := msg.(*SignalResp) - // payload - switch x := m.Payload.(type) { - case *SignalResp_Invite: - b.EncodeVarint(1<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Invite); err != nil { - return err - } - case *SignalResp_InviteInGroup: - b.EncodeVarint(2<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.InviteInGroup); err != nil { - return err - } - case *SignalResp_Cancel: - b.EncodeVarint(3<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Cancel); err != nil { - return err - } - case *SignalResp_Accept: - b.EncodeVarint(4<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Accept); err != nil { - return err - } - case *SignalResp_HungUp: - b.EncodeVarint(5<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.HungUp); err != nil { - return err - } - case *SignalResp_Reject: - b.EncodeVarint(6<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.Reject); err != nil { - return err - } - case *SignalResp_GetRoomByGroupID: - b.EncodeVarint(7<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.GetRoomByGroupID); err != nil { - return err - } - case *SignalResp_GetTokenByRoomID: - b.EncodeVarint(8<<3 | proto.WireBytes) - if err := b.EncodeMessage(x.GetTokenByRoomID); err != nil { - return err - } - case nil: - default: - return fmt.Errorf("SignalResp.Payload has unexpected type %T", x) - } - return nil -} - -func _SignalResp_OneofUnmarshaler(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error) { - m := msg.(*SignalResp) - switch tag { - case 1: // payload.invite - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalInviteReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_Invite{msg} - return true, err - case 2: // payload.inviteInGroup - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalInviteInGroupReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_InviteInGroup{msg} - return true, err - case 3: // payload.cancel - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalCancelReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_Cancel{msg} - return true, err - case 4: // payload.accept - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalAcceptReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_Accept{msg} - return true, err - case 5: // payload.hungUp - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalHungUpReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_HungUp{msg} - return true, err - case 6: // payload.reject - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalRejectReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_Reject{msg} - return true, err - case 7: // payload.getRoomByGroupID - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalGetRoomByGroupIDReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_GetRoomByGroupID{msg} - return true, err - case 8: // payload.getTokenByRoomID - if wire != proto.WireBytes { - return true, proto.ErrInternalBadWireType - } - msg := new(SignalGetTokenByRoomIDReply) - err := b.DecodeMessage(msg) - m.Payload = &SignalResp_GetTokenByRoomID{msg} - return true, err - default: - return false, nil - } -} - -func _SignalResp_OneofSizer(msg proto.Message) (n int) { - m := msg.(*SignalResp) - // payload - switch x := m.Payload.(type) { - case *SignalResp_Invite: - s := proto.Size(x.Invite) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_InviteInGroup: - s := proto.Size(x.InviteInGroup) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_Cancel: - s := proto.Size(x.Cancel) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_Accept: - s := proto.Size(x.Accept) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_HungUp: - s := proto.Size(x.HungUp) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_Reject: - s := proto.Size(x.Reject) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_GetRoomByGroupID: - s := proto.Size(x.GetRoomByGroupID) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case *SignalResp_GetTokenByRoomID: - s := proto.Size(x.GetTokenByRoomID) - n += 1 // tag and wire - n += proto.SizeVarint(uint64(s)) - n += s - case nil: - default: - panic(fmt.Sprintf("proto: unexpected type %T in oneof", x)) - } - return n -} - -type InvitationInfo struct { - InviterUserID string `protobuf:"bytes,1,opt,name=inviterUserID" json:"inviterUserID,omitempty"` - InviteeUserIDList []string `protobuf:"bytes,2,rep,name=inviteeUserIDList" json:"inviteeUserIDList,omitempty"` - CustomData string `protobuf:"bytes,3,opt,name=customData" json:"customData,omitempty"` - GroupID string `protobuf:"bytes,4,opt,name=groupID" json:"groupID,omitempty"` - RoomID string `protobuf:"bytes,5,opt,name=roomID" json:"roomID,omitempty"` - Timeout int32 `protobuf:"varint,6,opt,name=timeout" json:"timeout,omitempty"` - MediaType string `protobuf:"bytes,7,opt,name=mediaType" json:"mediaType,omitempty"` - PlatformID int32 `protobuf:"varint,8,opt,name=platformID" json:"platformID,omitempty"` - SessionType int32 `protobuf:"varint,9,opt,name=sessionType" json:"sessionType,omitempty"` - InitiateTime int32 `protobuf:"varint,10,opt,name=initiateTime" json:"initiateTime,omitempty"` - BusyLineUserIDList []string `protobuf:"bytes,11,rep,name=busyLineUserIDList" json:"busyLineUserIDList,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *InvitationInfo) Reset() { *m = InvitationInfo{} } -func (m *InvitationInfo) String() string { return proto.CompactTextString(m) } -func (*InvitationInfo) ProtoMessage() {} -func (*InvitationInfo) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{11} -} -func (m *InvitationInfo) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_InvitationInfo.Unmarshal(m, b) -} -func (m *InvitationInfo) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_InvitationInfo.Marshal(b, m, deterministic) -} -func (dst *InvitationInfo) XXX_Merge(src proto.Message) { - xxx_messageInfo_InvitationInfo.Merge(dst, src) -} -func (m *InvitationInfo) XXX_Size() int { - return xxx_messageInfo_InvitationInfo.Size(m) -} -func (m *InvitationInfo) XXX_DiscardUnknown() { - xxx_messageInfo_InvitationInfo.DiscardUnknown(m) -} - -var xxx_messageInfo_InvitationInfo proto.InternalMessageInfo - -func (m *InvitationInfo) GetInviterUserID() string { - if m != nil { - return m.InviterUserID - } - return "" -} - -func (m *InvitationInfo) GetInviteeUserIDList() []string { - if m != nil { - return m.InviteeUserIDList - } - return nil -} - -func (m *InvitationInfo) GetCustomData() string { - if m != nil { - return m.CustomData - } - return "" -} - -func (m *InvitationInfo) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -func (m *InvitationInfo) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -func (m *InvitationInfo) GetTimeout() int32 { - if m != nil { - return m.Timeout - } - return 0 -} - -func (m *InvitationInfo) GetMediaType() string { - if m != nil { - return m.MediaType - } - return "" -} - -func (m *InvitationInfo) GetPlatformID() int32 { - if m != nil { - return m.PlatformID - } - return 0 -} - -func (m *InvitationInfo) GetSessionType() int32 { - if m != nil { - return m.SessionType - } - return 0 -} - -func (m *InvitationInfo) GetInitiateTime() int32 { - if m != nil { - return m.InitiateTime - } - return 0 -} - -func (m *InvitationInfo) GetBusyLineUserIDList() []string { - if m != nil { - return m.BusyLineUserIDList - } - return nil -} - -type SignalInviteReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,4,opt,name=participant" json:"participant,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalInviteReq) Reset() { *m = SignalInviteReq{} } -func (m *SignalInviteReq) String() string { return proto.CompactTextString(m) } -func (*SignalInviteReq) ProtoMessage() {} -func (*SignalInviteReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{12} -} -func (m *SignalInviteReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalInviteReq.Unmarshal(m, b) -} -func (m *SignalInviteReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalInviteReq.Marshal(b, m, deterministic) -} -func (dst *SignalInviteReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalInviteReq.Merge(dst, src) -} -func (m *SignalInviteReq) XXX_Size() int { - return xxx_messageInfo_SignalInviteReq.Size(m) -} -func (m *SignalInviteReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalInviteReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalInviteReq proto.InternalMessageInfo - -func (m *SignalInviteReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalInviteReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalInviteReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -func (m *SignalInviteReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -type SignalInviteReply struct { - Token string `protobuf:"bytes,1,opt,name=token" json:"token,omitempty"` - RoomID string `protobuf:"bytes,2,opt,name=roomID" json:"roomID,omitempty"` - LiveURL string `protobuf:"bytes,3,opt,name=liveURL" json:"liveURL,omitempty"` - BusyLineUserIDList []string `protobuf:"bytes,4,rep,name=busyLineUserIDList" json:"busyLineUserIDList,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalInviteReply) Reset() { *m = SignalInviteReply{} } -func (m *SignalInviteReply) String() string { return proto.CompactTextString(m) } -func (*SignalInviteReply) ProtoMessage() {} -func (*SignalInviteReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{13} -} -func (m *SignalInviteReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalInviteReply.Unmarshal(m, b) -} -func (m *SignalInviteReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalInviteReply.Marshal(b, m, deterministic) -} -func (dst *SignalInviteReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalInviteReply.Merge(dst, src) -} -func (m *SignalInviteReply) XXX_Size() int { - return xxx_messageInfo_SignalInviteReply.Size(m) -} -func (m *SignalInviteReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalInviteReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalInviteReply proto.InternalMessageInfo - -func (m *SignalInviteReply) GetToken() string { - if m != nil { - return m.Token - } - return "" -} - -func (m *SignalInviteReply) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -func (m *SignalInviteReply) GetLiveURL() string { - if m != nil { - return m.LiveURL - } - return "" -} - -func (m *SignalInviteReply) GetBusyLineUserIDList() []string { - if m != nil { - return m.BusyLineUserIDList - } - return nil -} - -type SignalInviteInGroupReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,4,opt,name=participant" json:"participant,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalInviteInGroupReq) Reset() { *m = SignalInviteInGroupReq{} } -func (m *SignalInviteInGroupReq) String() string { return proto.CompactTextString(m) } -func (*SignalInviteInGroupReq) ProtoMessage() {} -func (*SignalInviteInGroupReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{14} -} -func (m *SignalInviteInGroupReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalInviteInGroupReq.Unmarshal(m, b) -} -func (m *SignalInviteInGroupReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalInviteInGroupReq.Marshal(b, m, deterministic) -} -func (dst *SignalInviteInGroupReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalInviteInGroupReq.Merge(dst, src) -} -func (m *SignalInviteInGroupReq) XXX_Size() int { - return xxx_messageInfo_SignalInviteInGroupReq.Size(m) -} -func (m *SignalInviteInGroupReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalInviteInGroupReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalInviteInGroupReq proto.InternalMessageInfo - -func (m *SignalInviteInGroupReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalInviteInGroupReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalInviteInGroupReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -func (m *SignalInviteInGroupReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -type SignalInviteInGroupReply struct { - Token string `protobuf:"bytes,1,opt,name=token" json:"token,omitempty"` - RoomID string `protobuf:"bytes,2,opt,name=roomID" json:"roomID,omitempty"` - LiveURL string `protobuf:"bytes,3,opt,name=liveURL" json:"liveURL,omitempty"` - BusyLineUserIDList []string `protobuf:"bytes,4,rep,name=busyLineUserIDList" json:"busyLineUserIDList,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalInviteInGroupReply) Reset() { *m = SignalInviteInGroupReply{} } -func (m *SignalInviteInGroupReply) String() string { return proto.CompactTextString(m) } -func (*SignalInviteInGroupReply) ProtoMessage() {} -func (*SignalInviteInGroupReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{15} -} -func (m *SignalInviteInGroupReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalInviteInGroupReply.Unmarshal(m, b) -} -func (m *SignalInviteInGroupReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalInviteInGroupReply.Marshal(b, m, deterministic) -} -func (dst *SignalInviteInGroupReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalInviteInGroupReply.Merge(dst, src) -} -func (m *SignalInviteInGroupReply) XXX_Size() int { - return xxx_messageInfo_SignalInviteInGroupReply.Size(m) -} -func (m *SignalInviteInGroupReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalInviteInGroupReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalInviteInGroupReply proto.InternalMessageInfo - -func (m *SignalInviteInGroupReply) GetToken() string { - if m != nil { - return m.Token - } - return "" -} - -func (m *SignalInviteInGroupReply) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -func (m *SignalInviteInGroupReply) GetLiveURL() string { - if m != nil { - return m.LiveURL - } - return "" -} - -func (m *SignalInviteInGroupReply) GetBusyLineUserIDList() []string { - if m != nil { - return m.BusyLineUserIDList - } - return nil -} - -type SignalCancelReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,4,opt,name=participant" json:"participant,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalCancelReq) Reset() { *m = SignalCancelReq{} } -func (m *SignalCancelReq) String() string { return proto.CompactTextString(m) } -func (*SignalCancelReq) ProtoMessage() {} -func (*SignalCancelReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{16} -} -func (m *SignalCancelReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalCancelReq.Unmarshal(m, b) -} -func (m *SignalCancelReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalCancelReq.Marshal(b, m, deterministic) -} -func (dst *SignalCancelReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalCancelReq.Merge(dst, src) -} -func (m *SignalCancelReq) XXX_Size() int { - return xxx_messageInfo_SignalCancelReq.Size(m) -} -func (m *SignalCancelReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalCancelReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalCancelReq proto.InternalMessageInfo - -func (m *SignalCancelReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalCancelReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalCancelReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -func (m *SignalCancelReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -type SignalCancelReply struct { - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalCancelReply) Reset() { *m = SignalCancelReply{} } -func (m *SignalCancelReply) String() string { return proto.CompactTextString(m) } -func (*SignalCancelReply) ProtoMessage() {} -func (*SignalCancelReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{17} -} -func (m *SignalCancelReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalCancelReply.Unmarshal(m, b) -} -func (m *SignalCancelReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalCancelReply.Marshal(b, m, deterministic) -} -func (dst *SignalCancelReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalCancelReply.Merge(dst, src) -} -func (m *SignalCancelReply) XXX_Size() int { - return xxx_messageInfo_SignalCancelReply.Size(m) -} -func (m *SignalCancelReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalCancelReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalCancelReply proto.InternalMessageInfo - -type SignalAcceptReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,4,opt,name=participant" json:"participant,omitempty"` - OpUserPlatformID int32 `protobuf:"varint,5,opt,name=opUserPlatformID" json:"opUserPlatformID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalAcceptReq) Reset() { *m = SignalAcceptReq{} } -func (m *SignalAcceptReq) String() string { return proto.CompactTextString(m) } -func (*SignalAcceptReq) ProtoMessage() {} -func (*SignalAcceptReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{18} -} -func (m *SignalAcceptReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalAcceptReq.Unmarshal(m, b) -} -func (m *SignalAcceptReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalAcceptReq.Marshal(b, m, deterministic) -} -func (dst *SignalAcceptReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalAcceptReq.Merge(dst, src) -} -func (m *SignalAcceptReq) XXX_Size() int { - return xxx_messageInfo_SignalAcceptReq.Size(m) -} -func (m *SignalAcceptReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalAcceptReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalAcceptReq proto.InternalMessageInfo - -func (m *SignalAcceptReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalAcceptReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalAcceptReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -func (m *SignalAcceptReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalAcceptReq) GetOpUserPlatformID() int32 { - if m != nil { - return m.OpUserPlatformID - } - return 0 -} - -type SignalAcceptReply struct { - Token string `protobuf:"bytes,1,opt,name=token" json:"token,omitempty"` - RoomID string `protobuf:"bytes,2,opt,name=roomID" json:"roomID,omitempty"` - LiveURL string `protobuf:"bytes,3,opt,name=liveURL" json:"liveURL,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalAcceptReply) Reset() { *m = SignalAcceptReply{} } -func (m *SignalAcceptReply) String() string { return proto.CompactTextString(m) } -func (*SignalAcceptReply) ProtoMessage() {} -func (*SignalAcceptReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{19} -} -func (m *SignalAcceptReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalAcceptReply.Unmarshal(m, b) -} -func (m *SignalAcceptReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalAcceptReply.Marshal(b, m, deterministic) -} -func (dst *SignalAcceptReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalAcceptReply.Merge(dst, src) -} -func (m *SignalAcceptReply) XXX_Size() int { - return xxx_messageInfo_SignalAcceptReply.Size(m) -} -func (m *SignalAcceptReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalAcceptReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalAcceptReply proto.InternalMessageInfo - -func (m *SignalAcceptReply) GetToken() string { - if m != nil { - return m.Token - } - return "" -} - -func (m *SignalAcceptReply) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -func (m *SignalAcceptReply) GetLiveURL() string { - if m != nil { - return m.LiveURL - } - return "" -} - -type SignalHungUpReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalHungUpReq) Reset() { *m = SignalHungUpReq{} } -func (m *SignalHungUpReq) String() string { return proto.CompactTextString(m) } -func (*SignalHungUpReq) ProtoMessage() {} -func (*SignalHungUpReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{20} -} -func (m *SignalHungUpReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalHungUpReq.Unmarshal(m, b) -} -func (m *SignalHungUpReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalHungUpReq.Marshal(b, m, deterministic) -} -func (dst *SignalHungUpReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalHungUpReq.Merge(dst, src) -} -func (m *SignalHungUpReq) XXX_Size() int { - return xxx_messageInfo_SignalHungUpReq.Size(m) -} -func (m *SignalHungUpReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalHungUpReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalHungUpReq proto.InternalMessageInfo - -func (m *SignalHungUpReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalHungUpReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalHungUpReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -type SignalHungUpReply struct { - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalHungUpReply) Reset() { *m = SignalHungUpReply{} } -func (m *SignalHungUpReply) String() string { return proto.CompactTextString(m) } -func (*SignalHungUpReply) ProtoMessage() {} -func (*SignalHungUpReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{21} -} -func (m *SignalHungUpReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalHungUpReply.Unmarshal(m, b) -} -func (m *SignalHungUpReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalHungUpReply.Marshal(b, m, deterministic) -} -func (dst *SignalHungUpReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalHungUpReply.Merge(dst, src) -} -func (m *SignalHungUpReply) XXX_Size() int { - return xxx_messageInfo_SignalHungUpReply.Size(m) -} -func (m *SignalHungUpReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalHungUpReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalHungUpReply proto.InternalMessageInfo - -type SignalRejectReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - Invitation *InvitationInfo `protobuf:"bytes,2,opt,name=invitation" json:"invitation,omitempty"` - OfflinePushInfo *OfflinePushInfo `protobuf:"bytes,3,opt,name=offlinePushInfo" json:"offlinePushInfo,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,4,opt,name=participant" json:"participant,omitempty"` - OpUserPlatformID int32 `protobuf:"varint,5,opt,name=opUserPlatformID" json:"opUserPlatformID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalRejectReq) Reset() { *m = SignalRejectReq{} } -func (m *SignalRejectReq) String() string { return proto.CompactTextString(m) } -func (*SignalRejectReq) ProtoMessage() {} -func (*SignalRejectReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{22} -} -func (m *SignalRejectReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalRejectReq.Unmarshal(m, b) -} -func (m *SignalRejectReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalRejectReq.Marshal(b, m, deterministic) -} -func (dst *SignalRejectReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalRejectReq.Merge(dst, src) -} -func (m *SignalRejectReq) XXX_Size() int { - return xxx_messageInfo_SignalRejectReq.Size(m) -} -func (m *SignalRejectReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalRejectReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalRejectReq proto.InternalMessageInfo - -func (m *SignalRejectReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalRejectReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalRejectReq) GetOfflinePushInfo() *OfflinePushInfo { - if m != nil { - return m.OfflinePushInfo - } - return nil -} - -func (m *SignalRejectReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalRejectReq) GetOpUserPlatformID() int32 { - if m != nil { - return m.OpUserPlatformID - } - return 0 -} - -type SignalRejectReply struct { - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalRejectReply) Reset() { *m = SignalRejectReply{} } -func (m *SignalRejectReply) String() string { return proto.CompactTextString(m) } -func (*SignalRejectReply) ProtoMessage() {} -func (*SignalRejectReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{23} -} -func (m *SignalRejectReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalRejectReply.Unmarshal(m, b) -} -func (m *SignalRejectReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalRejectReply.Marshal(b, m, deterministic) -} -func (dst *SignalRejectReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalRejectReply.Merge(dst, src) -} -func (m *SignalRejectReply) XXX_Size() int { - return xxx_messageInfo_SignalRejectReply.Size(m) -} -func (m *SignalRejectReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalRejectReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalRejectReply proto.InternalMessageInfo - -type SignalGetRoomByGroupIDReq struct { - OpUserID string `protobuf:"bytes,1,opt,name=opUserID" json:"opUserID,omitempty"` - GroupID string `protobuf:"bytes,2,opt,name=groupID" json:"groupID,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,3,opt,name=participant" json:"participant,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalGetRoomByGroupIDReq) Reset() { *m = SignalGetRoomByGroupIDReq{} } -func (m *SignalGetRoomByGroupIDReq) String() string { return proto.CompactTextString(m) } -func (*SignalGetRoomByGroupIDReq) ProtoMessage() {} -func (*SignalGetRoomByGroupIDReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{24} -} -func (m *SignalGetRoomByGroupIDReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalGetRoomByGroupIDReq.Unmarshal(m, b) -} -func (m *SignalGetRoomByGroupIDReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalGetRoomByGroupIDReq.Marshal(b, m, deterministic) -} -func (dst *SignalGetRoomByGroupIDReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalGetRoomByGroupIDReq.Merge(dst, src) -} -func (m *SignalGetRoomByGroupIDReq) XXX_Size() int { - return xxx_messageInfo_SignalGetRoomByGroupIDReq.Size(m) -} -func (m *SignalGetRoomByGroupIDReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalGetRoomByGroupIDReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalGetRoomByGroupIDReq proto.InternalMessageInfo - -func (m *SignalGetRoomByGroupIDReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalGetRoomByGroupIDReq) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -func (m *SignalGetRoomByGroupIDReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -type SignalGetRoomByGroupIDReply struct { - Invitation *InvitationInfo `protobuf:"bytes,1,opt,name=invitation" json:"invitation,omitempty"` - Participant []*ParticipantMetaData `protobuf:"bytes,2,rep,name=participant" json:"participant,omitempty"` - RoomID string `protobuf:"bytes,3,opt,name=roomID" json:"roomID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalGetRoomByGroupIDReply) Reset() { *m = SignalGetRoomByGroupIDReply{} } -func (m *SignalGetRoomByGroupIDReply) String() string { return proto.CompactTextString(m) } -func (*SignalGetRoomByGroupIDReply) ProtoMessage() {} -func (*SignalGetRoomByGroupIDReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{25} -} -func (m *SignalGetRoomByGroupIDReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalGetRoomByGroupIDReply.Unmarshal(m, b) -} -func (m *SignalGetRoomByGroupIDReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalGetRoomByGroupIDReply.Marshal(b, m, deterministic) -} -func (dst *SignalGetRoomByGroupIDReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalGetRoomByGroupIDReply.Merge(dst, src) -} -func (m *SignalGetRoomByGroupIDReply) XXX_Size() int { - return xxx_messageInfo_SignalGetRoomByGroupIDReply.Size(m) -} -func (m *SignalGetRoomByGroupIDReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalGetRoomByGroupIDReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalGetRoomByGroupIDReply proto.InternalMessageInfo - -func (m *SignalGetRoomByGroupIDReply) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalGetRoomByGroupIDReply) GetParticipant() []*ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalGetRoomByGroupIDReply) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -type SignalOnRoomParticipantConnectedReq struct { - Invitation *InvitationInfo `protobuf:"bytes,1,opt,name=invitation" json:"invitation,omitempty"` - Participant []*ParticipantMetaData `protobuf:"bytes,2,rep,name=participant" json:"participant,omitempty"` - GroupID string `protobuf:"bytes,3,opt,name=groupID" json:"groupID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalOnRoomParticipantConnectedReq) Reset() { *m = SignalOnRoomParticipantConnectedReq{} } -func (m *SignalOnRoomParticipantConnectedReq) String() string { return proto.CompactTextString(m) } -func (*SignalOnRoomParticipantConnectedReq) ProtoMessage() {} -func (*SignalOnRoomParticipantConnectedReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{26} -} -func (m *SignalOnRoomParticipantConnectedReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalOnRoomParticipantConnectedReq.Unmarshal(m, b) -} -func (m *SignalOnRoomParticipantConnectedReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalOnRoomParticipantConnectedReq.Marshal(b, m, deterministic) -} -func (dst *SignalOnRoomParticipantConnectedReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalOnRoomParticipantConnectedReq.Merge(dst, src) -} -func (m *SignalOnRoomParticipantConnectedReq) XXX_Size() int { - return xxx_messageInfo_SignalOnRoomParticipantConnectedReq.Size(m) -} -func (m *SignalOnRoomParticipantConnectedReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalOnRoomParticipantConnectedReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalOnRoomParticipantConnectedReq proto.InternalMessageInfo - -func (m *SignalOnRoomParticipantConnectedReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalOnRoomParticipantConnectedReq) GetParticipant() []*ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalOnRoomParticipantConnectedReq) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -type SignalOnRoomParticipantDisconnectedReq struct { - Invitation *InvitationInfo `protobuf:"bytes,1,opt,name=invitation" json:"invitation,omitempty"` - Participant []*ParticipantMetaData `protobuf:"bytes,2,rep,name=participant" json:"participant,omitempty"` - GroupID string `protobuf:"bytes,3,opt,name=groupID" json:"groupID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalOnRoomParticipantDisconnectedReq) Reset() { - *m = SignalOnRoomParticipantDisconnectedReq{} -} -func (m *SignalOnRoomParticipantDisconnectedReq) String() string { return proto.CompactTextString(m) } -func (*SignalOnRoomParticipantDisconnectedReq) ProtoMessage() {} -func (*SignalOnRoomParticipantDisconnectedReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{27} -} -func (m *SignalOnRoomParticipantDisconnectedReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq.Unmarshal(m, b) -} -func (m *SignalOnRoomParticipantDisconnectedReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq.Marshal(b, m, deterministic) -} -func (dst *SignalOnRoomParticipantDisconnectedReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq.Merge(dst, src) -} -func (m *SignalOnRoomParticipantDisconnectedReq) XXX_Size() int { - return xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq.Size(m) -} -func (m *SignalOnRoomParticipantDisconnectedReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalOnRoomParticipantDisconnectedReq proto.InternalMessageInfo - -func (m *SignalOnRoomParticipantDisconnectedReq) GetInvitation() *InvitationInfo { - if m != nil { - return m.Invitation - } - return nil -} - -func (m *SignalOnRoomParticipantDisconnectedReq) GetParticipant() []*ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalOnRoomParticipantDisconnectedReq) GetGroupID() string { - if m != nil { - return m.GroupID - } - return "" -} - -type SignalGetTokenByRoomIDReq struct { - RoomID string `protobuf:"bytes,1,opt,name=roomID" json:"roomID,omitempty"` - OpUserID string `protobuf:"bytes,2,opt,name=opUserID" json:"opUserID,omitempty"` - Participant *ParticipantMetaData `protobuf:"bytes,3,opt,name=participant" json:"participant,omitempty"` - OperationID string `protobuf:"bytes,4,opt,name=operationID" json:"operationID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalGetTokenByRoomIDReq) Reset() { *m = SignalGetTokenByRoomIDReq{} } -func (m *SignalGetTokenByRoomIDReq) String() string { return proto.CompactTextString(m) } -func (*SignalGetTokenByRoomIDReq) ProtoMessage() {} -func (*SignalGetTokenByRoomIDReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{28} -} -func (m *SignalGetTokenByRoomIDReq) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalGetTokenByRoomIDReq.Unmarshal(m, b) -} -func (m *SignalGetTokenByRoomIDReq) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalGetTokenByRoomIDReq.Marshal(b, m, deterministic) -} -func (dst *SignalGetTokenByRoomIDReq) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalGetTokenByRoomIDReq.Merge(dst, src) -} -func (m *SignalGetTokenByRoomIDReq) XXX_Size() int { - return xxx_messageInfo_SignalGetTokenByRoomIDReq.Size(m) -} -func (m *SignalGetTokenByRoomIDReq) XXX_DiscardUnknown() { - xxx_messageInfo_SignalGetTokenByRoomIDReq.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalGetTokenByRoomIDReq proto.InternalMessageInfo - -func (m *SignalGetTokenByRoomIDReq) GetRoomID() string { - if m != nil { - return m.RoomID - } - return "" -} - -func (m *SignalGetTokenByRoomIDReq) GetOpUserID() string { - if m != nil { - return m.OpUserID - } - return "" -} - -func (m *SignalGetTokenByRoomIDReq) GetParticipant() *ParticipantMetaData { - if m != nil { - return m.Participant - } - return nil -} - -func (m *SignalGetTokenByRoomIDReq) GetOperationID() string { - if m != nil { - return m.OperationID - } - return "" -} - -type SignalGetTokenByRoomIDReply struct { - Token string `protobuf:"bytes,1,opt,name=token" json:"token,omitempty"` - LiveURL string `protobuf:"bytes,2,opt,name=liveURL" json:"liveURL,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` -} - -func (m *SignalGetTokenByRoomIDReply) Reset() { *m = SignalGetTokenByRoomIDReply{} } -func (m *SignalGetTokenByRoomIDReply) String() string { return proto.CompactTextString(m) } -func (*SignalGetTokenByRoomIDReply) ProtoMessage() {} -func (*SignalGetTokenByRoomIDReply) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{29} -} -func (m *SignalGetTokenByRoomIDReply) XXX_Unmarshal(b []byte) error { - return xxx_messageInfo_SignalGetTokenByRoomIDReply.Unmarshal(m, b) -} -func (m *SignalGetTokenByRoomIDReply) XXX_Marshal(b []byte, deterministic bool) ([]byte, error) { - return xxx_messageInfo_SignalGetTokenByRoomIDReply.Marshal(b, m, deterministic) -} -func (dst *SignalGetTokenByRoomIDReply) XXX_Merge(src proto.Message) { - xxx_messageInfo_SignalGetTokenByRoomIDReply.Merge(dst, src) -} -func (m *SignalGetTokenByRoomIDReply) XXX_Size() int { - return xxx_messageInfo_SignalGetTokenByRoomIDReply.Size(m) -} -func (m *SignalGetTokenByRoomIDReply) XXX_DiscardUnknown() { - xxx_messageInfo_SignalGetTokenByRoomIDReply.DiscardUnknown(m) -} - -var xxx_messageInfo_SignalGetTokenByRoomIDReply proto.InternalMessageInfo - -func (m *SignalGetTokenByRoomIDReply) GetToken() string { - if m != nil { - return m.Token - } - return "" -} - -func (m *SignalGetTokenByRoomIDReply) GetLiveURL() string { - if m != nil { - return m.LiveURL - } - return "" -} - type SignalMessageAssembleReq struct { - SignalReq *SignalReq `protobuf:"bytes,1,opt,name=signalReq" json:"signalReq,omitempty"` - OperationID string `protobuf:"bytes,2,opt,name=operationID" json:"operationID,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` + SignalReq *sdkws.SignalReq `protobuf:"bytes,1,opt,name=signalReq" json:"signalReq,omitempty"` + OperationID string `protobuf:"bytes,2,opt,name=operationID" json:"operationID,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` } func (m *SignalMessageAssembleReq) Reset() { *m = SignalMessageAssembleReq{} } func (m *SignalMessageAssembleReq) String() string { return proto.CompactTextString(m) } func (*SignalMessageAssembleReq) ProtoMessage() {} func (*SignalMessageAssembleReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{30} + return fileDescriptor_rtc_ffe277e59422062f, []int{0} } func (m *SignalMessageAssembleReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SignalMessageAssembleReq.Unmarshal(m, b) @@ -2633,7 +56,7 @@ func (m *SignalMessageAssembleReq) XXX_DiscardUnknown() { var xxx_messageInfo_SignalMessageAssembleReq proto.InternalMessageInfo -func (m *SignalMessageAssembleReq) GetSignalReq() *SignalReq { +func (m *SignalMessageAssembleReq) GetSignalReq() *sdkws.SignalReq { if m != nil { return m.SignalReq } @@ -2648,20 +71,19 @@ func (m *SignalMessageAssembleReq) GetOperationID() string { } type SignalMessageAssembleResp struct { - CommonResp *CommonResp `protobuf:"bytes,1,opt,name=commonResp" json:"commonResp,omitempty"` - IsPass bool `protobuf:"varint,2,opt,name=isPass" json:"isPass,omitempty"` - SignalResp *SignalResp `protobuf:"bytes,3,opt,name=signalResp" json:"signalResp,omitempty"` - MsgData *MsgData `protobuf:"bytes,4,opt,name=msgData" json:"msgData,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` + IsPass bool `protobuf:"varint,1,opt,name=isPass" json:"isPass,omitempty"` + SignalResp *sdkws.SignalResp `protobuf:"bytes,2,opt,name=signalResp" json:"signalResp,omitempty"` + MsgData *sdkws.MsgData `protobuf:"bytes,3,opt,name=msgData" json:"msgData,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` } func (m *SignalMessageAssembleResp) Reset() { *m = SignalMessageAssembleResp{} } func (m *SignalMessageAssembleResp) String() string { return proto.CompactTextString(m) } func (*SignalMessageAssembleResp) ProtoMessage() {} func (*SignalMessageAssembleResp) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{31} + return fileDescriptor_rtc_ffe277e59422062f, []int{1} } func (m *SignalMessageAssembleResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SignalMessageAssembleResp.Unmarshal(m, b) @@ -2681,13 +103,6 @@ func (m *SignalMessageAssembleResp) XXX_DiscardUnknown() { var xxx_messageInfo_SignalMessageAssembleResp proto.InternalMessageInfo -func (m *SignalMessageAssembleResp) GetCommonResp() *CommonResp { - if m != nil { - return m.CommonResp - } - return nil -} - func (m *SignalMessageAssembleResp) GetIsPass() bool { if m != nil { return m.IsPass @@ -2695,14 +110,14 @@ func (m *SignalMessageAssembleResp) GetIsPass() bool { return false } -func (m *SignalMessageAssembleResp) GetSignalResp() *SignalResp { +func (m *SignalMessageAssembleResp) GetSignalResp() *sdkws.SignalResp { if m != nil { return m.SignalResp } return nil } -func (m *SignalMessageAssembleResp) GetMsgData() *MsgData { +func (m *SignalMessageAssembleResp) GetMsgData() *sdkws.MsgData { if m != nil { return m.MsgData } @@ -2710,8 +125,7 @@ func (m *SignalMessageAssembleResp) GetMsgData() *MsgData { } type SignalGetRoomsReq struct { - OperationID string `protobuf:"bytes,1,opt,name=operationID" json:"operationID,omitempty"` - RoomID string `protobuf:"bytes,2,opt,name=roomID" json:"roomID,omitempty"` + RoomID string `protobuf:"bytes,1,opt,name=roomID" json:"roomID,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` @@ -2721,7 +135,7 @@ func (m *SignalGetRoomsReq) Reset() { *m = SignalGetRoomsReq{} } func (m *SignalGetRoomsReq) String() string { return proto.CompactTextString(m) } func (*SignalGetRoomsReq) ProtoMessage() {} func (*SignalGetRoomsReq) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{32} + return fileDescriptor_rtc_ffe277e59422062f, []int{2} } func (m *SignalGetRoomsReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SignalGetRoomsReq.Unmarshal(m, b) @@ -2741,13 +155,6 @@ func (m *SignalGetRoomsReq) XXX_DiscardUnknown() { var xxx_messageInfo_SignalGetRoomsReq proto.InternalMessageInfo -func (m *SignalGetRoomsReq) GetOperationID() string { - if m != nil { - return m.OperationID - } - return "" -} - func (m *SignalGetRoomsReq) GetRoomID() string { if m != nil { return m.RoomID @@ -2756,18 +163,17 @@ func (m *SignalGetRoomsReq) GetRoomID() string { } type SignalGetRoomsResp struct { - CommonResp *CommonResp `protobuf:"bytes,1,opt,name=commonResp" json:"commonResp,omitempty"` - RoomList []*SignalGetRoomByGroupIDReply `protobuf:"bytes,2,rep,name=roomList" json:"roomList,omitempty"` - XXX_NoUnkeyedLiteral struct{} `json:"-"` - XXX_unrecognized []byte `json:"-"` - XXX_sizecache int32 `json:"-"` + Rooms []*sdkws.SignalGetRoomByGroupIDReply `protobuf:"bytes,1,rep,name=rooms" json:"rooms,omitempty"` + XXX_NoUnkeyedLiteral struct{} `json:"-"` + XXX_unrecognized []byte `json:"-"` + XXX_sizecache int32 `json:"-"` } func (m *SignalGetRoomsResp) Reset() { *m = SignalGetRoomsResp{} } func (m *SignalGetRoomsResp) String() string { return proto.CompactTextString(m) } func (*SignalGetRoomsResp) ProtoMessage() {} func (*SignalGetRoomsResp) Descriptor() ([]byte, []int) { - return fileDescriptor_rtc_6654c7cf2ade752c, []int{33} + return fileDescriptor_rtc_ffe277e59422062f, []int{3} } func (m *SignalGetRoomsResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SignalGetRoomsResp.Unmarshal(m, b) @@ -2787,52 +193,14 @@ func (m *SignalGetRoomsResp) XXX_DiscardUnknown() { var xxx_messageInfo_SignalGetRoomsResp proto.InternalMessageInfo -func (m *SignalGetRoomsResp) GetCommonResp() *CommonResp { +func (m *SignalGetRoomsResp) GetRooms() []*sdkws.SignalGetRoomByGroupIDReply { if m != nil { - return m.CommonResp - } - return nil -} - -func (m *SignalGetRoomsResp) GetRoomList() []*SignalGetRoomByGroupIDReply { - if m != nil { - return m.RoomList + return m.Rooms } return nil } func init() { - proto.RegisterType((*CommonResp)(nil), "proto.CommonResp") - proto.RegisterType((*MsgData)(nil), "proto.MsgData") - proto.RegisterMapType((map[string]bool)(nil), "proto.MsgData.OptionsEntry") - proto.RegisterType((*GroupInfo)(nil), "proto.GroupInfo") - proto.RegisterType((*GroupMemberFullInfo)(nil), "proto.GroupMemberFullInfo") - proto.RegisterType((*ParticipantMetaData)(nil), "proto.ParticipantMetaData") - proto.RegisterType((*PublicUserInfo)(nil), "proto.PublicUserInfo") - proto.RegisterType((*GetJoinTokenReq)(nil), "proto.GetJoinTokenReq") - proto.RegisterType((*GetJoinTokenResp)(nil), "proto.GetJoinTokenResp") - proto.RegisterType((*OfflinePushInfo)(nil), "proto.OfflinePushInfo") - proto.RegisterType((*SignalReq)(nil), "proto.SignalReq") - proto.RegisterType((*SignalResp)(nil), "proto.SignalResp") - proto.RegisterType((*InvitationInfo)(nil), "proto.InvitationInfo") - proto.RegisterType((*SignalInviteReq)(nil), "proto.SignalInviteReq") - proto.RegisterType((*SignalInviteReply)(nil), "proto.SignalInviteReply") - proto.RegisterType((*SignalInviteInGroupReq)(nil), "proto.SignalInviteInGroupReq") - proto.RegisterType((*SignalInviteInGroupReply)(nil), "proto.SignalInviteInGroupReply") - proto.RegisterType((*SignalCancelReq)(nil), "proto.SignalCancelReq") - proto.RegisterType((*SignalCancelReply)(nil), "proto.SignalCancelReply") - proto.RegisterType((*SignalAcceptReq)(nil), "proto.SignalAcceptReq") - proto.RegisterType((*SignalAcceptReply)(nil), "proto.SignalAcceptReply") - proto.RegisterType((*SignalHungUpReq)(nil), "proto.SignalHungUpReq") - proto.RegisterType((*SignalHungUpReply)(nil), "proto.SignalHungUpReply") - proto.RegisterType((*SignalRejectReq)(nil), "proto.SignalRejectReq") - proto.RegisterType((*SignalRejectReply)(nil), "proto.SignalRejectReply") - proto.RegisterType((*SignalGetRoomByGroupIDReq)(nil), "proto.SignalGetRoomByGroupIDReq") - proto.RegisterType((*SignalGetRoomByGroupIDReply)(nil), "proto.SignalGetRoomByGroupIDReply") - proto.RegisterType((*SignalOnRoomParticipantConnectedReq)(nil), "proto.SignalOnRoomParticipantConnectedReq") - proto.RegisterType((*SignalOnRoomParticipantDisconnectedReq)(nil), "proto.SignalOnRoomParticipantDisconnectedReq") - proto.RegisterType((*SignalGetTokenByRoomIDReq)(nil), "proto.SignalGetTokenByRoomIDReq") - proto.RegisterType((*SignalGetTokenByRoomIDReply)(nil), "proto.SignalGetTokenByRoomIDReply") proto.RegisterType((*SignalMessageAssembleReq)(nil), "proto.SignalMessageAssembleReq") proto.RegisterType((*SignalMessageAssembleResp)(nil), "proto.SignalMessageAssembleResp") proto.RegisterType((*SignalGetRoomsReq)(nil), "proto.SignalGetRoomsReq") @@ -2944,129 +312,31 @@ var _RtcService_serviceDesc = grpc.ServiceDesc{ Metadata: "rtc/rtc.proto", } -func init() { proto.RegisterFile("rtc/rtc.proto", fileDescriptor_rtc_6654c7cf2ade752c) } +func init() { proto.RegisterFile("rtc/rtc.proto", fileDescriptor_rtc_ffe277e59422062f) } -var fileDescriptor_rtc_6654c7cf2ade752c = []byte{ - // 1925 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xe4, 0x59, 0xcd, 0x6f, 0x23, 0x49, - 0x15, 0x9f, 0xb6, 0xe3, 0x24, 0x7e, 0xf9, 0xae, 0x61, 0xa3, 0xde, 0x2c, 0x0b, 0x56, 0x33, 0x1a, - 0x59, 0x23, 0xc8, 0xb0, 0x46, 0x8b, 0xd0, 0x82, 0x56, 0x6c, 0xe2, 0x99, 0x8c, 0xd1, 0x78, 0x12, - 0x55, 0x76, 0x2e, 0xcb, 0xa9, 0xd3, 0xae, 0x78, 0x7b, 0xc6, 0xae, 0xea, 0x74, 0x95, 0xb3, 0x6b, - 0x71, 0x45, 0x80, 0xc4, 0x01, 0x84, 0xc4, 0x89, 0x2b, 0xe2, 0xc0, 0x65, 0x2f, 0x48, 0x7b, 0xe3, - 0xc2, 0xbf, 0xc2, 0x01, 0x89, 0x33, 0x77, 0x54, 0xaf, 0xaa, 0xbb, 0xab, 0xdb, 0xed, 0x4c, 0x16, - 0x90, 0x76, 0x35, 0x9c, 0xdc, 0xef, 0xd5, 0x7b, 0xf5, 0xf1, 0x7e, 0xbf, 0x7a, 0xf5, 0xaa, 0x0c, - 0x5b, 0xa9, 0x8a, 0x1e, 0xa6, 0x2a, 0x3a, 0x4c, 0x52, 0xa1, 0x04, 0x69, 0xe1, 0x4f, 0xf0, 0x3e, - 0xc0, 0xb1, 0x98, 0x4e, 0x05, 0xa7, 0x4c, 0x26, 0xc4, 0x87, 0x35, 0x96, 0xa6, 0xc7, 0x62, 0xc4, - 0x7c, 0xaf, 0xe3, 0x75, 0x5b, 0x34, 0x13, 0xc9, 0x3e, 0xac, 0xb2, 0x34, 0x1d, 0xca, 0xb1, 0xdf, - 0xe8, 0x78, 0xdd, 0x36, 0xb5, 0x52, 0xf0, 0xc7, 0x16, 0xac, 0x0d, 0xe5, 0xb8, 0x1f, 0xaa, 0x50, - 0xdb, 0x48, 0xc6, 0x47, 0x83, 0x3e, 0x3a, 0xb7, 0xa9, 0x95, 0xb4, 0x3e, 0x65, 0xd1, 0xf5, 0xa0, - 0x9f, 0xf9, 0x1a, 0x49, 0x8f, 0x36, 0x4e, 0xc5, 0x2c, 0x19, 0xf4, 0xfd, 0x26, 0x36, 0x64, 0x22, - 0xe9, 0xc0, 0x46, 0x34, 0x89, 0x19, 0x57, 0x43, 0x39, 0x1e, 0xf4, 0xfd, 0x15, 0x6c, 0x75, 0x55, - 0xda, 0x42, 0xb2, 0xf4, 0x9a, 0xa5, 0xc6, 0xa2, 0x65, 0x2c, 0x1c, 0x15, 0x79, 0x00, 0xbb, 0x7a, - 0x7c, 0x96, 0x9e, 0x4d, 0x42, 0x75, 0x29, 0xd2, 0xe9, 0xa0, 0xef, 0xaf, 0xe2, 0xa2, 0x16, 0xf4, - 0xe4, 0x3e, 0x6c, 0x1b, 0xdd, 0xb3, 0x38, 0x7a, 0xc9, 0xc3, 0x29, 0xf3, 0xd7, 0xb0, 0xc3, 0x8a, - 0x96, 0xdc, 0x83, 0x2d, 0xa3, 0x79, 0x1c, 0x46, 0xec, 0x39, 0x7d, 0xea, 0xaf, 0xa3, 0x59, 0x59, - 0x69, 0xe6, 0x26, 0x65, 0x2c, 0xf8, 0x87, 0xf3, 0x84, 0xf9, 0x6d, 0x1c, 0xd4, 0x55, 0xe9, 0x95, - 0x4f, 0xe5, 0xf8, 0x71, 0x2a, 0xa6, 0x3e, 0x98, 0x38, 0x5b, 0x11, 0x57, 0x2e, 0xb8, 0x62, 0x5c, - 0xa1, 0xef, 0x86, 0xf1, 0x75, 0x54, 0xda, 0xd7, 0x8a, 0xfe, 0x66, 0xc7, 0xeb, 0x6e, 0xd2, 0x4c, - 0x24, 0xbb, 0xd0, 0x94, 0xec, 0xca, 0xdf, 0xee, 0x78, 0xdd, 0x2d, 0xaa, 0x3f, 0xc9, 0x01, 0xac, - 0xeb, 0xa9, 0x7d, 0x18, 0x4f, 0x99, 0xbf, 0xd3, 0xf1, 0xba, 0x4d, 0x9a, 0xcb, 0xe4, 0x1b, 0x00, - 0x51, 0xca, 0x42, 0xc5, 0xb0, 0x75, 0x17, 0x5b, 0x1d, 0x0d, 0xa2, 0xa9, 0x42, 0x35, 0x93, 0xfe, - 0x1e, 0x4e, 0xc2, 0x4a, 0xe4, 0x5d, 0x58, 0x13, 0x89, 0x8a, 0x05, 0x97, 0x3e, 0xe9, 0x34, 0xbb, - 0x1b, 0xbd, 0xb7, 0x0c, 0xa3, 0x0e, 0x2d, 0x0d, 0x0e, 0x4f, 0x4d, 0xeb, 0x23, 0xae, 0xd2, 0x39, - 0xcd, 0x6c, 0xc9, 0x8f, 0x61, 0x47, 0x5c, 0x5e, 0x4e, 0x62, 0xce, 0xce, 0x66, 0xf2, 0xe3, 0x01, - 0xbf, 0x14, 0xfe, 0xdd, 0x8e, 0xd7, 0xdd, 0xe8, 0xed, 0x5b, 0xf7, 0xd3, 0x72, 0x2b, 0xad, 0x9a, - 0x1f, 0xbc, 0x07, 0x9b, 0x6e, 0xd7, 0x7a, 0xb9, 0x2f, 0xd9, 0xdc, 0x72, 0x4d, 0x7f, 0x92, 0xaf, - 0x41, 0xeb, 0x3a, 0x9c, 0xcc, 0x18, 0xf2, 0x6c, 0x9d, 0x1a, 0xe1, 0xbd, 0xc6, 0x0f, 0xbc, 0xe0, - 0x5f, 0x0d, 0x68, 0x9f, 0x20, 0xb9, 0xf8, 0xa5, 0x70, 0x89, 0xe7, 0x95, 0x89, 0xf7, 0x75, 0x68, - 0xe3, 0xe7, 0x33, 0xcd, 0x01, 0xc3, 0xd6, 0x42, 0x41, 0x02, 0xd8, 0xe4, 0x42, 0xc5, 0x97, 0x71, - 0x14, 0xea, 0x79, 0x58, 0xd6, 0x96, 0x74, 0xda, 0x26, 0xe6, 0x2a, 0x15, 0xa3, 0x59, 0x84, 0x36, - 0x86, 0xbb, 0x25, 0x9d, 0x1e, 0xff, 0xd2, 0x12, 0xc8, 0x10, 0x37, 0x13, 0x35, 0xfc, 0xe2, 0x13, - 0xce, 0xd2, 0xe7, 0x92, 0xa5, 0x96, 0xaf, 0x6d, 0xea, 0xaa, 0x2a, 0xb0, 0xad, 0x21, 0xd6, 0x2e, - 0x6c, 0x1d, 0xd8, 0x98, 0xb2, 0xe9, 0x05, 0x4b, 0x8f, 0xc5, 0x8c, 0x2b, 0x24, 0xe8, 0x16, 0x75, - 0x55, 0x64, 0x1b, 0x1a, 0xec, 0x53, 0x64, 0x65, 0x9b, 0x36, 0xd8, 0xa7, 0x0e, 0xd0, 0x50, 0x02, - 0xfa, 0x1e, 0x6c, 0x61, 0xbf, 0x22, 0x9b, 0xcd, 0x86, 0x21, 0x7b, 0x49, 0x99, 0x47, 0x0c, 0xe9, - 0xba, 0x89, 0x1d, 0x14, 0x8a, 0xe0, 0xf3, 0x06, 0xdc, 0xc5, 0xb8, 0x0f, 0x71, 0x02, 0x8f, 0x67, - 0x93, 0xc9, 0x2b, 0x10, 0xd8, 0x87, 0xd5, 0x99, 0x19, 0xce, 0x26, 0x8b, 0x59, 0x3e, 0x4e, 0x2a, - 0x26, 0xec, 0x29, 0xbb, 0x66, 0x13, 0x0c, 0x7c, 0x8b, 0x16, 0x0a, 0x4d, 0xf4, 0x17, 0x22, 0xe6, - 0x18, 0x93, 0x15, 0x6c, 0xcc, 0x65, 0xdd, 0xc6, 0xb3, 0x6d, 0x6d, 0xc2, 0x9d, 0xcb, 0x2e, 0x12, - 0xab, 0x65, 0x24, 0xee, 0xc3, 0x76, 0x98, 0x24, 0xc3, 0x90, 0x8f, 0x59, 0x6a, 0x06, 0x5d, 0xc3, - 0x7e, 0x2b, 0x5a, 0x8d, 0x87, 0x1e, 0xe9, 0x5c, 0xcc, 0xd2, 0x88, 0x61, 0xb8, 0x5b, 0xd4, 0xd1, - 0xe8, 0x7e, 0x44, 0xc2, 0x52, 0x27, 0x8c, 0x26, 0xf2, 0x15, 0xad, 0x45, 0x05, 0x32, 0x54, 0x82, - 0xbf, 0x7a, 0x70, 0xf7, 0x2c, 0x4c, 0x55, 0x1c, 0xc5, 0x49, 0xc8, 0xd5, 0x90, 0xa9, 0x10, 0x93, - 0xec, 0xa1, 0x8d, 0x37, 0xee, 0x20, 0x0f, 0x77, 0xd0, 0xae, 0xdd, 0x41, 0x39, 0xc1, 0x69, 0x61, - 0x42, 0xfa, 0xb0, 0x33, 0x2e, 0x00, 0x40, 0xaf, 0x06, 0x7a, 0x1d, 0xb8, 0x5e, 0x65, 0x78, 0x68, - 0xd5, 0x85, 0xbc, 0x03, 0xeb, 0x88, 0x83, 0x76, 0x6f, 0xa2, 0xfb, 0x1b, 0xd6, 0xfd, 0x6c, 0x76, - 0x31, 0x89, 0xa3, 0xe7, 0xb6, 0x91, 0xe6, 0x66, 0xc1, 0x2f, 0x3c, 0xd8, 0x2e, 0x37, 0x3a, 0xd8, - 0x7a, 0x25, 0x6c, 0x5d, 0x84, 0x1a, 0xcb, 0x11, 0x6a, 0x96, 0x11, 0xda, 0x87, 0xd5, 0x31, 0xe6, - 0x5d, 0x8b, 0xb8, 0x95, 0x6c, 0x24, 0x5b, 0x79, 0x24, 0xff, 0xe0, 0xc1, 0xce, 0x09, 0x53, 0x3f, - 0xd1, 0x7c, 0x10, 0x2f, 0x19, 0xa7, 0xec, 0x8a, 0x10, 0x58, 0x49, 0x85, 0x98, 0xda, 0x79, 0xe0, - 0xb7, 0x9e, 0x45, 0x3c, 0x62, 0x5c, 0xc5, 0x6a, 0x9e, 0xcd, 0x22, 0x93, 0xc9, 0xf7, 0x61, 0x7d, - 0x6a, 0x11, 0xb0, 0xeb, 0xcf, 0xc2, 0x57, 0x83, 0x11, 0xcd, 0x6d, 0x71, 0x3f, 0x23, 0xce, 0xb1, - 0xe0, 0xc5, 0x41, 0xe6, 0xa8, 0x82, 0x2b, 0xd8, 0x2d, 0x4f, 0x4e, 0x26, 0xe4, 0x1d, 0xf7, 0x50, - 0xb6, 0x20, 0xef, 0xd9, 0xf1, 0x8a, 0x06, 0xea, 0x9e, 0xdc, 0xbb, 0xd0, 0x7c, 0xf1, 0x89, 0xb2, - 0xf3, 0xd6, 0x9f, 0x3a, 0x70, 0x93, 0xf8, 0xda, 0x0d, 0x9c, 0x15, 0x83, 0xdf, 0x7b, 0xb0, 0x53, - 0xc9, 0xb6, 0x3a, 0x75, 0xaa, 0x58, 0x4d, 0x98, 0x8d, 0x88, 0x11, 0x74, 0x98, 0x46, 0x4c, 0x46, - 0xb6, 0x5b, 0xfc, 0xb6, 0xe1, 0x6d, 0xe6, 0xe9, 0x43, 0x27, 0xbc, 0xd3, 0x73, 0xdd, 0xd1, 0xb9, - 0x98, 0xf1, 0x51, 0x9e, 0xf0, 0x1c, 0x9d, 0x4e, 0x25, 0xf1, 0xe9, 0xf9, 0x51, 0x38, 0x1a, 0x33, - 0x93, 0x96, 0x5a, 0x98, 0xa0, 0xcb, 0xca, 0xe0, 0x1f, 0x2d, 0x68, 0x9f, 0xc7, 0x63, 0x1e, 0x4e, - 0x34, 0x44, 0xdf, 0x85, 0xd5, 0x98, 0x5f, 0xc7, 0x8a, 0xd9, 0x00, 0x64, 0xe7, 0x84, 0xb1, 0x18, - 0x60, 0x13, 0x65, 0x57, 0x4f, 0xee, 0x50, 0x6b, 0x47, 0x1e, 0xc1, 0x96, 0xf9, 0x1a, 0x70, 0x24, - 0xb5, 0x25, 0xfa, 0xdb, 0x35, 0x8e, 0xd6, 0xc2, 0xf8, 0x97, 0xbd, 0xf4, 0xc0, 0x51, 0xc8, 0x23, - 0x9b, 0x66, 0xaa, 0x03, 0x1f, 0x63, 0x93, 0x1d, 0xd8, 0xd8, 0x69, 0x8f, 0x30, 0x8a, 0x58, 0xa2, - 0x70, 0xf1, 0x55, 0x8f, 0x0f, 0xb0, 0xc9, 0x7a, 0x18, 0x3b, 0xed, 0xf1, 0xf1, 0x8c, 0x8f, 0x9f, - 0x27, 0x18, 0x89, 0xaa, 0xc7, 0x13, 0x6c, 0xb2, 0x1e, 0xc6, 0x4e, 0x7b, 0xa4, 0xec, 0x05, 0x8b, - 0x14, 0x26, 0xaa, 0xaa, 0x07, 0xc5, 0x26, 0xeb, 0x61, 0xec, 0xc8, 0x33, 0xd8, 0x1d, 0x33, 0x45, - 0x85, 0x98, 0x1e, 0xcd, 0x4f, 0x6c, 0xb2, 0x5d, 0x43, 0xdf, 0x4e, 0xc9, 0xf7, 0xa4, 0x62, 0x64, - 0x7a, 0x59, 0xf0, 0x25, 0x29, 0xbc, 0x2d, 0xb8, 0x56, 0x39, 0x94, 0x3f, 0x16, 0x9c, 0xb3, 0x48, - 0xb1, 0x11, 0x65, 0x57, 0x98, 0xfc, 0x36, 0x7a, 0x0f, 0x4a, 0x9d, 0x9f, 0xde, 0xe4, 0xf1, 0xe4, - 0x0e, 0xbd, 0xb9, 0x4b, 0xf2, 0x33, 0xe8, 0x2c, 0x18, 0xf4, 0x63, 0x19, 0xb9, 0xc3, 0xb6, 0x71, - 0xd8, 0xef, 0xdc, 0x3c, 0x6c, 0xc5, 0xe9, 0xc9, 0x1d, 0xfa, 0xca, 0x8e, 0x6d, 0x00, 0x71, 0x5b, - 0x1e, 0xcd, 0xb5, 0xed, 0xa0, 0x8f, 0x09, 0xba, 0x26, 0x80, 0x25, 0xa3, 0x22, 0x80, 0x25, 0xf5, - 0x51, 0x1b, 0xd6, 0x92, 0x70, 0x3e, 0x11, 0xe1, 0x28, 0xf8, 0xd5, 0x0a, 0x40, 0x86, 0x9c, 0x4c, - 0x48, 0xaf, 0xc2, 0x75, 0xbf, 0x96, 0xeb, 0xc9, 0x64, 0xee, 0xb0, 0xfd, 0xa4, 0x9e, 0xed, 0xdf, - 0xbc, 0x89, 0xed, 0xa6, 0x87, 0x0a, 0xdf, 0x7b, 0x15, 0xbe, 0xfb, 0xb5, 0x7c, 0xb7, 0x83, 0x5b, - 0xc6, 0xf7, 0x2a, 0x8c, 0xf7, 0x6b, 0x19, 0x6f, 0x7d, 0x2c, 0xe7, 0x7b, 0x15, 0xce, 0xfb, 0xb5, - 0x9c, 0xb7, 0x3e, 0x96, 0xf5, 0xbd, 0x0a, 0xeb, 0xfd, 0x5a, 0xd6, 0x5b, 0x1f, 0xcb, 0xfb, 0xb3, - 0xa5, 0xbc, 0x0f, 0x5e, 0xc1, 0x7b, 0xd3, 0xcf, 0x22, 0xf3, 0xcf, 0x6a, 0x88, 0xb0, 0x5e, 0xdf, - 0x63, 0x85, 0x08, 0x45, 0x8f, 0x4b, 0xa9, 0xf0, 0xf3, 0x26, 0x6c, 0x23, 0x4c, 0xe6, 0x44, 0xd0, - 0xc9, 0xf8, 0x5e, 0x06, 0x6d, 0x56, 0x32, 0x98, 0xa4, 0x5c, 0x56, 0x92, 0x6f, 0xc3, 0x9e, 0x51, - 0x30, 0xa3, 0x78, 0x1a, 0x4b, 0x7d, 0x00, 0x34, 0xbb, 0x6d, 0xba, 0xd8, 0x80, 0x75, 0xe3, 0x4c, - 0x2a, 0x31, 0xcd, 0xcf, 0xb0, 0x36, 0x75, 0x34, 0x6e, 0x45, 0xb6, 0xb2, 0x50, 0x91, 0xa5, 0x66, - 0xcd, 0x2d, 0x7b, 0x7d, 0x43, 0x49, 0x7b, 0xa8, 0x78, 0xca, 0xc4, 0x4c, 0xd9, 0x7b, 0x55, 0x26, - 0xea, 0x5a, 0x6d, 0xca, 0x46, 0x71, 0x88, 0x35, 0xa1, 0xb9, 0x49, 0x15, 0x0a, 0x3d, 0x93, 0xa4, - 0xb8, 0x92, 0xd9, 0x8a, 0xa9, 0xd0, 0xdc, 0xe2, 0xfa, 0x84, 0x35, 0x76, 0xac, 0xe2, 0xac, 0x0a, - 0x36, 0x75, 0x6b, 0x49, 0x47, 0x0e, 0x81, 0x5c, 0xcc, 0xe4, 0xfc, 0x69, 0xcc, 0xdd, 0xf0, 0x6c, - 0x60, 0x78, 0x6a, 0x5a, 0x82, 0xbf, 0x7b, 0xb0, 0x53, 0x39, 0x5a, 0x74, 0x45, 0x20, 0x92, 0x12, - 0x04, 0xb9, 0x4c, 0xde, 0x05, 0x88, 0x73, 0xd4, 0xec, 0xde, 0xcb, 0x6a, 0xa2, 0x32, 0x9c, 0xd4, - 0x31, 0xac, 0xbb, 0x06, 0x35, 0xbf, 0xd0, 0x35, 0x88, 0xfc, 0x08, 0x36, 0x92, 0x22, 0x67, 0xd9, - 0xfd, 0x77, 0x53, 0x35, 0xe2, 0x9a, 0x07, 0xbf, 0xf6, 0x60, 0x6f, 0x21, 0xab, 0xe0, 0xe9, 0xaf, - 0xf9, 0x99, 0x9f, 0xfe, 0x5a, 0x70, 0x80, 0x6f, 0x54, 0x81, 0xaf, 0xaf, 0x2c, 0x96, 0x04, 0x7d, - 0x65, 0x69, 0xd0, 0xff, 0xe9, 0xc1, 0x7e, 0xfd, 0xb1, 0xfc, 0x3a, 0xc6, 0xfe, 0x77, 0x1e, 0xf8, - 0xcb, 0xd2, 0xf2, 0x97, 0x06, 0x41, 0xc1, 0xfb, 0xbc, 0xb2, 0x79, 0x1d, 0x63, 0x7f, 0x37, 0xa3, - 0xbd, 0x73, 0x9e, 0x05, 0xbf, 0x6d, 0x64, 0x6b, 0xcf, 0x6b, 0xb4, 0xd7, 0x70, 0xed, 0xe4, 0x01, - 0xec, 0x9a, 0x25, 0x38, 0x2f, 0x61, 0x2d, 0xf3, 0x12, 0x56, 0xd5, 0x07, 0x3f, 0xcd, 0xe2, 0xe4, - 0x9c, 0xe1, 0xff, 0x2b, 0x6e, 0x06, 0x7f, 0xca, 0xb9, 0x96, 0x57, 0xb8, 0x5f, 0xc9, 0x78, 0x17, - 0x6c, 0x71, 0xaa, 0x12, 0x87, 0x2d, 0x79, 0xb5, 0xfd, 0xff, 0xce, 0x96, 0x3c, 0x4e, 0x4e, 0x25, - 0x16, 0xfc, 0xc6, 0x83, 0x37, 0x97, 0xde, 0x2c, 0x6e, 0x8c, 0x98, 0x53, 0x83, 0x34, 0xca, 0x35, - 0x48, 0x65, 0x49, 0xcd, 0x2f, 0xb6, 0xf9, 0xff, 0xec, 0xc1, 0x5b, 0x37, 0xd4, 0x7c, 0x15, 0xa4, - 0xbc, 0xdb, 0x22, 0x55, 0x99, 0x54, 0x03, 0x5f, 0x43, 0x6f, 0x1d, 0xe7, 0x62, 0xfb, 0x34, 0xdd, - 0xed, 0x13, 0xfc, 0xc5, 0x83, 0x6f, 0xdd, 0xe2, 0xee, 0xf4, 0xe5, 0x4c, 0x7a, 0xe9, 0x93, 0x7d, - 0xf0, 0xb9, 0x07, 0xf7, 0x6f, 0x77, 0xf7, 0xfa, 0xaa, 0xcd, 0xfc, 0x33, 0x97, 0xaf, 0xd5, 0x8b, - 0x9c, 0x03, 0x93, 0x57, 0xca, 0x72, 0x2e, 0x8f, 0x1b, 0x15, 0x1e, 0xff, 0x57, 0x6c, 0xbd, 0xc5, - 0x9b, 0xd1, 0xd0, 0xa1, 0xf3, 0xe2, 0x85, 0x63, 0x49, 0xba, 0x76, 0xd2, 0x72, 0xa3, 0x9c, 0x96, - 0x27, 0x59, 0x59, 0x32, 0x64, 0x52, 0x86, 0x63, 0xf6, 0x81, 0x94, 0x6c, 0x7a, 0x31, 0xc1, 0x12, - 0xf8, 0x10, 0xda, 0x32, 0x7b, 0x92, 0xa9, 0x3c, 0x37, 0xe6, 0x4f, 0x35, 0xb4, 0x30, 0xa9, 0x4e, - 0xbe, 0xb1, 0x38, 0xf9, 0xbf, 0xe5, 0xe1, 0x5e, 0x18, 0xce, 0x3c, 0x7d, 0x45, 0xb7, 0x79, 0xfa, - 0x2a, 0x8c, 0x34, 0x42, 0xb1, 0x3c, 0x0b, 0xa5, 0xb4, 0xcf, 0xfe, 0x56, 0xd2, 0x5d, 0xc9, 0xfc, - 0x8a, 0x6d, 0x41, 0xd8, 0xab, 0xcc, 0x5d, 0x77, 0x55, 0x18, 0x91, 0x2e, 0xfe, 0x2f, 0x83, 0x37, - 0x24, 0x93, 0x35, 0xb7, 0xcb, 0xff, 0x6d, 0xd0, 0xac, 0x39, 0x18, 0x66, 0x99, 0xcf, 0x66, 0x14, - 0x59, 0xb3, 0x78, 0x6f, 0x61, 0xf1, 0xcb, 0xce, 0xcc, 0xe0, 0x97, 0x1e, 0x90, 0x6a, 0x7f, 0xff, - 0x59, 0x34, 0xde, 0x87, 0x75, 0xdd, 0x67, 0x7e, 0x19, 0xbc, 0xd5, 0xad, 0x97, 0xe6, 0x3e, 0xbd, - 0xcf, 0x3c, 0x00, 0xaa, 0xa2, 0x73, 0x96, 0x5e, 0xc7, 0x11, 0x23, 0x1f, 0xc1, 0x1b, 0xb5, 0x60, - 0x91, 0xf2, 0x3b, 0xc3, 0x22, 0x73, 0x0e, 0x3a, 0x37, 0x1b, 0xc8, 0x84, 0x3c, 0x82, 0xed, 0xf2, - 0x9a, 0x89, 0x5f, 0x37, 0x55, 0x1d, 0xda, 0x83, 0x37, 0x97, 0xb4, 0xc8, 0xe4, 0xe8, 0xe0, 0x23, - 0xff, 0x34, 0x61, 0x7c, 0x30, 0x7c, 0x98, 0xbc, 0x1c, 0x3f, 0x44, 0xb3, 0x87, 0xa9, 0x8a, 0x7e, - 0x98, 0xaa, 0xe8, 0x62, 0x15, 0xc5, 0xef, 0xfd, 0x3b, 0x00, 0x00, 0xff, 0xff, 0x0c, 0x32, 0x6b, - 0x89, 0xfd, 0x1c, 0x00, 0x00, +var fileDescriptor_rtc_ffe277e59422062f = []byte{ + // 357 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x7c, 0x92, 0x51, 0x6b, 0xa3, 0x40, + 0x10, 0xc7, 0xf1, 0x42, 0x72, 0x97, 0x91, 0x0b, 0x97, 0x85, 0x0b, 0xc6, 0x97, 0x13, 0x5f, 0x4e, + 0x38, 0xa2, 0x9c, 0x7d, 0x29, 0xf4, 0xa9, 0xc1, 0x12, 0x7c, 0xb0, 0x2d, 0x9b, 0xb7, 0xbc, 0x19, + 0xbb, 0x88, 0x44, 0xb3, 0x9b, 0x9d, 0x6d, 0x43, 0xbe, 0x45, 0xbf, 0x49, 0xbf, 0x62, 0x71, 0x35, + 0xd4, 0x84, 0xa6, 0x4f, 0x32, 0xf3, 0xff, 0xcd, 0xce, 0x7f, 0x9c, 0x81, 0x9f, 0x52, 0x65, 0x81, + 0x54, 0x99, 0x2f, 0x24, 0x57, 0x9c, 0xf4, 0xf5, 0xc7, 0xfe, 0xfb, 0x20, 0xd8, 0x76, 0x16, 0x27, + 0xb3, 0x25, 0x93, 0x2f, 0x4c, 0x06, 0x62, 0x93, 0x07, 0x5a, 0x09, 0xf0, 0x69, 0xb3, 0xc7, 0x60, + 0x8f, 0x0d, 0xef, 0x96, 0x60, 0x2d, 0x8b, 0x7c, 0x9b, 0x96, 0x09, 0x43, 0x4c, 0x73, 0x76, 0x8b, + 0xc8, 0xaa, 0x75, 0xc9, 0x28, 0xdb, 0x11, 0x1f, 0x86, 0xa8, 0x35, 0xca, 0x76, 0x96, 0xe1, 0x18, + 0x9e, 0x19, 0xfe, 0xf2, 0x75, 0xbd, 0xbf, 0x3c, 0xe6, 0xe9, 0x07, 0x42, 0x1c, 0x30, 0xb9, 0x60, + 0x32, 0x55, 0x05, 0xdf, 0xc6, 0x91, 0xf5, 0xcd, 0x31, 0xbc, 0x21, 0xed, 0xa6, 0xdc, 0x57, 0x03, + 0xa6, 0x17, 0xda, 0xa1, 0x20, 0x13, 0x18, 0x14, 0xf8, 0x98, 0x22, 0xea, 0x66, 0x3f, 0x68, 0x1b, + 0x91, 0xff, 0x00, 0xc7, 0x26, 0x28, 0xf4, 0xb3, 0x66, 0x38, 0x3e, 0x33, 0x82, 0x82, 0x76, 0x20, + 0xe2, 0xc1, 0xf7, 0x0a, 0xf3, 0x28, 0x55, 0xa9, 0xd5, 0xd3, 0xfc, 0xa8, 0xe5, 0x93, 0x26, 0x4b, + 0x8f, 0xb2, 0xfb, 0x0f, 0xc6, 0xcd, 0x1b, 0x0b, 0xa6, 0x28, 0xe7, 0x15, 0xd6, 0x93, 0x4c, 0x60, + 0x20, 0x39, 0xaf, 0xe2, 0x48, 0x3b, 0x19, 0xd2, 0x36, 0x72, 0xef, 0x81, 0x9c, 0xc3, 0x28, 0xc8, + 0x35, 0xf4, 0x6b, 0xbd, 0xb6, 0xdd, 0xf3, 0xcc, 0xd0, 0x3d, 0xb1, 0xd6, 0x92, 0xf3, 0xc3, 0x42, + 0xf2, 0x67, 0x11, 0x47, 0x94, 0x89, 0xf2, 0x40, 0x9b, 0x82, 0xf0, 0xcd, 0x00, 0xa0, 0x2a, 0xab, + 0x97, 0x54, 0x64, 0x8c, 0xac, 0xe0, 0xf7, 0xa7, 0x7f, 0x87, 0xfc, 0x69, 0xb6, 0xe5, 0x5f, 0x5a, + 0x95, 0xed, 0x7c, 0x0d, 0xa0, 0x20, 0x77, 0x30, 0x3a, 0xb5, 0x4e, 0xac, 0x93, 0x9a, 0xce, 0xf8, + 0xf6, 0xf4, 0x82, 0x82, 0x62, 0x6e, 0xaf, 0xac, 0xfa, 0xb4, 0xe2, 0xa4, 0x73, 0x52, 0x52, 0x65, + 0x37, 0x52, 0x65, 0xeb, 0x81, 0x0e, 0xaf, 0xde, 0x03, 0x00, 0x00, 0xff, 0xff, 0x5c, 0x49, 0x1f, + 0xbc, 0x93, 0x02, 0x00, 0x00, } diff --git a/pkg/proto/third/third.pb.go b/pkg/proto/third/third.pb.go index 59243f046..d6625468b 100644 --- a/pkg/proto/third/third.pb.go +++ b/pkg/proto/third/third.pb.go @@ -39,7 +39,7 @@ func (m *ApplySpaceReq) Reset() { *m = ApplySpaceReq{} } func (m *ApplySpaceReq) String() string { return proto.CompactTextString(m) } func (*ApplySpaceReq) ProtoMessage() {} func (*ApplySpaceReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{0} + return fileDescriptor_third_de04cb9a0062d654, []int{0} } func (m *ApplySpaceReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_ApplySpaceReq.Unmarshal(m, b) @@ -108,7 +108,7 @@ func (m *ApplySpaceResp) Reset() { *m = ApplySpaceResp{} } func (m *ApplySpaceResp) String() string { return proto.CompactTextString(m) } func (*ApplySpaceResp) ProtoMessage() {} func (*ApplySpaceResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{1} + return fileDescriptor_third_de04cb9a0062d654, []int{1} } func (m *ApplySpaceResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_ApplySpaceResp.Unmarshal(m, b) @@ -167,7 +167,7 @@ func (m *ConfirmSpaceReq) Reset() { *m = ConfirmSpaceReq{} } func (m *ConfirmSpaceReq) String() string { return proto.CompactTextString(m) } func (*ConfirmSpaceReq) ProtoMessage() {} func (*ConfirmSpaceReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{2} + return fileDescriptor_third_de04cb9a0062d654, []int{2} } func (m *ConfirmSpaceReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_ConfirmSpaceReq.Unmarshal(m, b) @@ -205,7 +205,7 @@ func (m *ConfirmSpaceResp) Reset() { *m = ConfirmSpaceResp{} } func (m *ConfirmSpaceResp) String() string { return proto.CompactTextString(m) } func (*ConfirmSpaceResp) ProtoMessage() {} func (*ConfirmSpaceResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{3} + return fileDescriptor_third_de04cb9a0062d654, []int{3} } func (m *ConfirmSpaceResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_ConfirmSpaceResp.Unmarshal(m, b) @@ -243,7 +243,7 @@ func (m *GetSignalInvitationInfoReq) Reset() { *m = GetSignalInvitationI func (m *GetSignalInvitationInfoReq) String() string { return proto.CompactTextString(m) } func (*GetSignalInvitationInfoReq) ProtoMessage() {} func (*GetSignalInvitationInfoReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{4} + return fileDescriptor_third_de04cb9a0062d654, []int{4} } func (m *GetSignalInvitationInfoReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_GetSignalInvitationInfoReq.Unmarshal(m, b) @@ -282,7 +282,7 @@ func (m *GetSignalInvitationInfoResp) Reset() { *m = GetSignalInvitation func (m *GetSignalInvitationInfoResp) String() string { return proto.CompactTextString(m) } func (*GetSignalInvitationInfoResp) ProtoMessage() {} func (*GetSignalInvitationInfoResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{5} + return fileDescriptor_third_de04cb9a0062d654, []int{5} } func (m *GetSignalInvitationInfoResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_GetSignalInvitationInfoResp.Unmarshal(m, b) @@ -327,7 +327,7 @@ func (m *GetSignalInvitationInfoStartAppReq) Reset() { *m = GetSignalInv func (m *GetSignalInvitationInfoStartAppReq) String() string { return proto.CompactTextString(m) } func (*GetSignalInvitationInfoStartAppReq) ProtoMessage() {} func (*GetSignalInvitationInfoStartAppReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{6} + return fileDescriptor_third_de04cb9a0062d654, []int{6} } func (m *GetSignalInvitationInfoStartAppReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_GetSignalInvitationInfoStartAppReq.Unmarshal(m, b) @@ -366,7 +366,7 @@ func (m *GetSignalInvitationInfoStartAppResp) Reset() { *m = GetSignalIn func (m *GetSignalInvitationInfoStartAppResp) String() string { return proto.CompactTextString(m) } func (*GetSignalInvitationInfoStartAppResp) ProtoMessage() {} func (*GetSignalInvitationInfoStartAppResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{7} + return fileDescriptor_third_de04cb9a0062d654, []int{7} } func (m *GetSignalInvitationInfoStartAppResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_GetSignalInvitationInfoStartAppResp.Unmarshal(m, b) @@ -401,8 +401,10 @@ func (m *GetSignalInvitationInfoStartAppResp) GetOfflinePushInfo() *sdkws.Offlin } type FcmUpdateTokenReq struct { - Platform int32 `protobuf:"varint,1,opt,name=Platform" json:"Platform,omitempty"` + PlatformID int32 `protobuf:"varint,1,opt,name=PlatformID" json:"PlatformID,omitempty"` FcmToken string `protobuf:"bytes,2,opt,name=FcmToken" json:"FcmToken,omitempty"` + Account string `protobuf:"bytes,3,opt,name=account" json:"account,omitempty"` + ExpireTime int64 `protobuf:"varint,4,opt,name=expireTime" json:"expireTime,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` XXX_sizecache int32 `json:"-"` @@ -412,7 +414,7 @@ func (m *FcmUpdateTokenReq) Reset() { *m = FcmUpdateTokenReq{} } func (m *FcmUpdateTokenReq) String() string { return proto.CompactTextString(m) } func (*FcmUpdateTokenReq) ProtoMessage() {} func (*FcmUpdateTokenReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{8} + return fileDescriptor_third_de04cb9a0062d654, []int{8} } func (m *FcmUpdateTokenReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_FcmUpdateTokenReq.Unmarshal(m, b) @@ -432,9 +434,9 @@ func (m *FcmUpdateTokenReq) XXX_DiscardUnknown() { var xxx_messageInfo_FcmUpdateTokenReq proto.InternalMessageInfo -func (m *FcmUpdateTokenReq) GetPlatform() int32 { +func (m *FcmUpdateTokenReq) GetPlatformID() int32 { if m != nil { - return m.Platform + return m.PlatformID } return 0 } @@ -446,6 +448,20 @@ func (m *FcmUpdateTokenReq) GetFcmToken() string { return "" } +func (m *FcmUpdateTokenReq) GetAccount() string { + if m != nil { + return m.Account + } + return "" +} + +func (m *FcmUpdateTokenReq) GetExpireTime() int64 { + if m != nil { + return m.ExpireTime + } + return 0 +} + type FcmUpdateTokenResp struct { XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -456,7 +472,7 @@ func (m *FcmUpdateTokenResp) Reset() { *m = FcmUpdateTokenResp{} } func (m *FcmUpdateTokenResp) String() string { return proto.CompactTextString(m) } func (*FcmUpdateTokenResp) ProtoMessage() {} func (*FcmUpdateTokenResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{9} + return fileDescriptor_third_de04cb9a0062d654, []int{9} } func (m *FcmUpdateTokenResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_FcmUpdateTokenResp.Unmarshal(m, b) @@ -477,7 +493,7 @@ func (m *FcmUpdateTokenResp) XXX_DiscardUnknown() { var xxx_messageInfo_FcmUpdateTokenResp proto.InternalMessageInfo type SetAppBadgeReq struct { - FromUserID string `protobuf:"bytes,1,opt,name=FromUserID" json:"FromUserID,omitempty"` + UserID string `protobuf:"bytes,1,opt,name=userID" json:"userID,omitempty"` AppUnreadCount int32 `protobuf:"varint,2,opt,name=AppUnreadCount" json:"AppUnreadCount,omitempty"` XXX_NoUnkeyedLiteral struct{} `json:"-"` XXX_unrecognized []byte `json:"-"` @@ -488,7 +504,7 @@ func (m *SetAppBadgeReq) Reset() { *m = SetAppBadgeReq{} } func (m *SetAppBadgeReq) String() string { return proto.CompactTextString(m) } func (*SetAppBadgeReq) ProtoMessage() {} func (*SetAppBadgeReq) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{10} + return fileDescriptor_third_de04cb9a0062d654, []int{10} } func (m *SetAppBadgeReq) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SetAppBadgeReq.Unmarshal(m, b) @@ -508,9 +524,9 @@ func (m *SetAppBadgeReq) XXX_DiscardUnknown() { var xxx_messageInfo_SetAppBadgeReq proto.InternalMessageInfo -func (m *SetAppBadgeReq) GetFromUserID() string { +func (m *SetAppBadgeReq) GetUserID() string { if m != nil { - return m.FromUserID + return m.UserID } return "" } @@ -532,7 +548,7 @@ func (m *SetAppBadgeResp) Reset() { *m = SetAppBadgeResp{} } func (m *SetAppBadgeResp) String() string { return proto.CompactTextString(m) } func (*SetAppBadgeResp) ProtoMessage() {} func (*SetAppBadgeResp) Descriptor() ([]byte, []int) { - return fileDescriptor_third_3f9746cdadff77e4, []int{11} + return fileDescriptor_third_de04cb9a0062d654, []int{11} } func (m *SetAppBadgeResp) XXX_Unmarshal(b []byte) error { return xxx_messageInfo_SetAppBadgeResp.Unmarshal(m, b) @@ -771,46 +787,46 @@ var _Third_serviceDesc = grpc.ServiceDesc{ Metadata: "third/third.proto", } -func init() { proto.RegisterFile("third/third.proto", fileDescriptor_third_3f9746cdadff77e4) } +func init() { proto.RegisterFile("third/third.proto", fileDescriptor_third_de04cb9a0062d654) } -var fileDescriptor_third_3f9746cdadff77e4 = []byte{ - // 594 bytes of a gzipped FileDescriptorProto - 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xcc, 0x54, 0xc1, 0x6e, 0xd3, 0x4c, - 0x10, 0x96, 0xeb, 0xa6, 0xff, 0x9f, 0x89, 0x9a, 0xb6, 0xab, 0xb6, 0x18, 0x53, 0x15, 0x63, 0x24, - 0x28, 0x48, 0x8d, 0x51, 0x39, 0x21, 0x0a, 0xa2, 0x2d, 0x04, 0x45, 0x28, 0x6a, 0xe5, 0x34, 0x12, - 0xe2, 0x84, 0x49, 0xd6, 0x89, 0x15, 0x7b, 0x77, 0xd8, 0x5d, 0xb7, 0x94, 0x17, 0xe0, 0x2d, 0xb8, - 0x20, 0xf1, 0x9c, 0xc8, 0x9b, 0x34, 0xb5, 0x4d, 0x42, 0x38, 0x72, 0xb1, 0x66, 0xbe, 0xfd, 0xbe, - 0xd9, 0x99, 0x9d, 0xf1, 0xc0, 0x86, 0x1a, 0x46, 0xa2, 0xef, 0xe9, 0x6f, 0x03, 0x05, 0x57, 0x9c, - 0x54, 0xb4, 0x63, 0x3f, 0x3c, 0x45, 0xca, 0xf6, 0x5b, 0xed, 0xfd, 0x0e, 0x15, 0x17, 0x54, 0x78, - 0x38, 0x1a, 0x78, 0x9a, 0xe0, 0xc9, 0xfe, 0xe8, 0x52, 0x7a, 0x97, 0x72, 0xcc, 0x77, 0xbf, 0x19, - 0xb0, 0x7a, 0x84, 0x18, 0x5f, 0x75, 0x30, 0xe8, 0x51, 0x9f, 0x7e, 0x26, 0x04, 0x96, 0x59, 0x90, - 0x50, 0xcb, 0x70, 0x8c, 0xbd, 0xaa, 0xaf, 0xed, 0x0c, 0x93, 0xd1, 0x57, 0x6a, 0x2d, 0x39, 0xc6, - 0x9e, 0xe9, 0x6b, 0x3b, 0xc3, 0x86, 0x81, 0x1c, 0x5a, 0xe6, 0x98, 0x97, 0xd9, 0xc4, 0x82, 0xff, - 0x30, 0x15, 0xc8, 0x25, 0xb5, 0x96, 0x1d, 0x63, 0x6f, 0xd5, 0xbf, 0x76, 0x89, 0x03, 0xb5, 0x1e, - 0x67, 0x8a, 0x32, 0x75, 0x7e, 0x85, 0xd4, 0xaa, 0x68, 0x51, 0x1e, 0x72, 0x43, 0xa8, 0xe7, 0x13, - 0x91, 0x48, 0xd6, 0xc1, 0x4c, 0x45, 0x3c, 0x49, 0x24, 0x33, 0x67, 0xe6, 0xb1, 0x0e, 0x26, 0xa6, - 0xca, 0x32, 0x1d, 0x33, 0x63, 0x61, 0xaa, 0xc8, 0x0e, 0x54, 0x7b, 0x9c, 0x85, 0x91, 0x48, 0x5a, - 0xaf, 0x75, 0x1e, 0x55, 0xff, 0x06, 0x70, 0x3d, 0x58, 0x3b, 0x19, 0x3b, 0xd3, 0x92, 0x0b, 0x02, - 0xa3, 0x2c, 0x78, 0x02, 0xeb, 0x45, 0x81, 0xc4, 0x05, 0x8a, 0x97, 0x60, 0xbf, 0xa5, 0xaa, 0x13, - 0x0d, 0x58, 0x10, 0xb7, 0xd8, 0x45, 0xa4, 0x02, 0x15, 0x71, 0xd6, 0x62, 0x21, 0xcf, 0x6e, 0x73, - 0xa0, 0x76, 0x12, 0x47, 0x94, 0xa9, 0xb6, 0x1c, 0x4c, 0xd5, 0x79, 0xc8, 0xfd, 0x6e, 0xc0, 0x9d, - 0xb9, 0x01, 0x24, 0x92, 0x17, 0x50, 0x8f, 0x0a, 0xa8, 0x0e, 0x52, 0x3b, 0xd8, 0x6a, 0xe8, 0xee, - 0x36, 0x4a, 0x92, 0x12, 0x99, 0xbc, 0x82, 0x35, 0x1e, 0x86, 0x71, 0xc4, 0xe8, 0x59, 0x2a, 0x87, - 0x5a, 0xbf, 0xa4, 0xf5, 0xdb, 0x13, 0xfd, 0x69, 0xf1, 0xd4, 0x2f, 0xd3, 0xdd, 0x43, 0x70, 0xe7, - 0xe4, 0xd7, 0x51, 0x81, 0x50, 0x47, 0x88, 0x59, 0xa1, 0xdb, 0xb0, 0x92, 0x4a, 0x2a, 0xa6, 0x35, - 0x4e, 0x3c, 0xf7, 0xa7, 0x01, 0xf7, 0x17, 0xca, 0xff, 0x85, 0x32, 0xdf, 0xc1, 0x46, 0xb3, 0x97, - 0x74, 0xb1, 0x1f, 0x28, 0x7a, 0xce, 0x47, 0x94, 0x65, 0x55, 0xd9, 0xf0, 0xff, 0x59, 0x1c, 0xa8, - 0x90, 0x8b, 0x44, 0xe7, 0x53, 0xf1, 0xa7, 0x7e, 0x76, 0xd6, 0xec, 0x25, 0x9a, 0xaa, 0xef, 0xaa, - 0xfa, 0x53, 0xdf, 0xdd, 0x04, 0x52, 0x0e, 0x26, 0xd1, 0x7d, 0x0f, 0xf5, 0x0e, 0xcd, 0x2a, 0x3e, - 0x0e, 0xfa, 0x03, 0x3d, 0x8c, 0xbb, 0x00, 0x4d, 0xc1, 0x93, 0x6e, 0xfe, 0xe5, 0x72, 0x08, 0x79, - 0xa0, 0xff, 0x93, 0x2e, 0x13, 0x34, 0xe8, 0x9f, 0xf0, 0x94, 0x29, 0x7d, 0x53, 0xc5, 0x2f, 0xa1, - 0xee, 0x06, 0xac, 0x15, 0x22, 0x4b, 0x3c, 0xf8, 0x61, 0xc2, 0x78, 0x3f, 0x90, 0x67, 0x00, 0x37, - 0x3f, 0x1b, 0xd9, 0x6c, 0x8c, 0x57, 0x48, 0x61, 0x11, 0xd8, 0x5b, 0x33, 0x50, 0x89, 0xe4, 0x23, - 0xdc, 0x9a, 0xd3, 0x3c, 0x72, 0x6f, 0xa2, 0x98, 0x3f, 0xfc, 0xb6, 0xbb, 0x88, 0x22, 0x91, 0x7c, - 0x81, 0xbb, 0x0b, 0xc6, 0x83, 0x3c, 0xfa, 0x73, 0x98, 0xdc, 0x14, 0xda, 0x8f, 0xff, 0x96, 0x2a, - 0x91, 0xbc, 0x81, 0x7a, 0xb1, 0x47, 0xc4, 0x9a, 0xa8, 0x7f, 0x9b, 0x03, 0xfb, 0xf6, 0x9c, 0x13, - 0x89, 0xe4, 0x10, 0x6a, 0xb9, 0xa7, 0x27, 0xd7, 0x0f, 0x59, 0x6c, 0xb4, 0xbd, 0x3d, 0x0b, 0x96, - 0x78, 0xbc, 0xfb, 0x61, 0x27, 0xdb, 0xde, 0xad, 0x76, 0x6e, 0x6b, 0x6b, 0xe6, 0x73, 0xfd, 0xfd, - 0xb4, 0xa2, 0xa1, 0xa7, 0xbf, 0x02, 0x00, 0x00, 0xff, 0xff, 0xbd, 0xf0, 0xfa, 0xf7, 0xfe, 0x05, - 0x00, 0x00, +var fileDescriptor_third_de04cb9a0062d654 = []byte{ + // 608 bytes of a gzipped FileDescriptorProto + 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xcc, 0x54, 0xcd, 0x6e, 0xd3, 0x40, + 0x10, 0x96, 0xeb, 0xb6, 0x90, 0x89, 0x9a, 0xb6, 0xab, 0xb6, 0x18, 0x53, 0x15, 0x63, 0x24, 0x28, + 0x48, 0x8d, 0x51, 0x39, 0x21, 0x0a, 0xa2, 0x2d, 0x14, 0xe5, 0x50, 0x35, 0x72, 0xd2, 0x0b, 0x27, + 0x8c, 0xb3, 0x4e, 0xac, 0x38, 0xeb, 0xc1, 0xbb, 0xee, 0x0f, 0x2f, 0x80, 0x78, 0x09, 0x2e, 0x48, + 0x3c, 0x27, 0xda, 0xb5, 0x93, 0xda, 0x26, 0x69, 0x38, 0x72, 0xb1, 0x76, 0x3e, 0x7f, 0xdf, 0xec, + 0xfc, 0xec, 0x0c, 0xac, 0x8b, 0x41, 0x98, 0xf4, 0x1c, 0xf5, 0x6d, 0x62, 0x12, 0x8b, 0x98, 0x2c, + 0x29, 0xc3, 0x7c, 0x7a, 0x86, 0x94, 0xed, 0xb5, 0x4e, 0xf7, 0x3a, 0x34, 0xb9, 0xa0, 0x89, 0x83, + 0xc3, 0xbe, 0xa3, 0x08, 0x0e, 0xef, 0x0d, 0x2f, 0xb9, 0x73, 0xc9, 0x33, 0xbe, 0xfd, 0x5d, 0x83, + 0x95, 0x43, 0xc4, 0xe8, 0xba, 0x83, 0x9e, 0x4f, 0x5d, 0xfa, 0x95, 0x10, 0x58, 0x64, 0xde, 0x88, + 0x1a, 0x9a, 0xa5, 0xed, 0xd6, 0x5c, 0x75, 0x96, 0x18, 0x0f, 0xbf, 0x51, 0x63, 0xc1, 0xd2, 0x76, + 0x75, 0x57, 0x9d, 0x25, 0x36, 0xf0, 0xf8, 0xc0, 0xd0, 0x33, 0x9e, 0x3c, 0x13, 0x03, 0xee, 0x60, + 0x9a, 0x60, 0xcc, 0xa9, 0xb1, 0x68, 0x69, 0xbb, 0x2b, 0xee, 0xd8, 0x24, 0x16, 0xd4, 0xfd, 0x98, + 0x09, 0xca, 0x44, 0xf7, 0x1a, 0xa9, 0xb1, 0xa4, 0x44, 0x45, 0xc8, 0x0e, 0xa0, 0x51, 0x0c, 0x84, + 0x23, 0x59, 0x03, 0x3d, 0x4d, 0xa2, 0x3c, 0x10, 0x79, 0x9c, 0x1a, 0xc7, 0x1a, 0xe8, 0x98, 0x0a, + 0x43, 0xb7, 0x74, 0xc9, 0xc2, 0x54, 0x90, 0x6d, 0xa8, 0xf9, 0x31, 0x0b, 0xc2, 0x64, 0xd4, 0x7a, + 0xaf, 0xe2, 0xa8, 0xb9, 0x37, 0x80, 0xed, 0xc0, 0xea, 0x71, 0x66, 0x4c, 0x52, 0x2e, 0x09, 0xb4, + 0xaa, 0xe0, 0x05, 0xac, 0x95, 0x05, 0x1c, 0xe7, 0x28, 0xde, 0x82, 0xf9, 0x91, 0x8a, 0x4e, 0xd8, + 0x67, 0x5e, 0xd4, 0x62, 0x17, 0xa1, 0xf0, 0x44, 0x18, 0xb3, 0x16, 0x0b, 0x62, 0x79, 0x9b, 0x05, + 0xf5, 0xe3, 0x28, 0xa4, 0x4c, 0x9c, 0xf2, 0xfe, 0x44, 0x5d, 0x84, 0xec, 0x9f, 0x1a, 0x3c, 0x98, + 0xe9, 0x80, 0x23, 0x79, 0x03, 0x8d, 0xb0, 0x84, 0x2a, 0x27, 0xf5, 0xfd, 0xcd, 0xa6, 0xea, 0x6e, + 0xb3, 0x22, 0xa9, 0x90, 0xc9, 0x3b, 0x58, 0x8d, 0x83, 0x20, 0x0a, 0x19, 0x6d, 0xa7, 0x7c, 0xa0, + 0xf4, 0x0b, 0x4a, 0xbf, 0x95, 0xeb, 0xcf, 0xca, 0x7f, 0xdd, 0x2a, 0xdd, 0x3e, 0x00, 0x7b, 0x46, + 0x7c, 0x1d, 0xe1, 0x25, 0xe2, 0x10, 0x51, 0x26, 0xba, 0x05, 0xcb, 0x29, 0xa7, 0xc9, 0x24, 0xc7, + 0xdc, 0xb2, 0x7f, 0x6b, 0xf0, 0x78, 0xae, 0xfc, 0x7f, 0x48, 0xf3, 0x87, 0x06, 0xeb, 0x27, 0xfe, + 0xe8, 0x1c, 0x7b, 0x9e, 0xa0, 0xdd, 0x78, 0x48, 0x99, 0x4c, 0x6b, 0x07, 0xa0, 0x1d, 0x79, 0x22, + 0x88, 0x27, 0xcd, 0x5f, 0x72, 0x0b, 0x08, 0x31, 0xe1, 0xee, 0x89, 0x3f, 0x52, 0x74, 0x75, 0x61, + 0xcd, 0x9d, 0xd8, 0x72, 0x40, 0x3c, 0xdf, 0x8f, 0x53, 0x26, 0xf2, 0xb9, 0x19, 0x9b, 0xd2, 0x2b, + 0xbd, 0xc2, 0x30, 0xa1, 0xdd, 0x70, 0x94, 0x4d, 0x8f, 0xee, 0x16, 0x10, 0x7b, 0x03, 0x48, 0x35, + 0x14, 0x8e, 0x76, 0x1b, 0x1a, 0x1d, 0x2a, 0x0b, 0x76, 0xe4, 0xf5, 0xfa, 0xf4, 0x96, 0xa2, 0x93, + 0x27, 0x6a, 0xbc, 0xce, 0x59, 0x42, 0xbd, 0xde, 0xb1, 0x0a, 0x60, 0x41, 0x45, 0x5e, 0x41, 0xed, + 0x75, 0x58, 0x2d, 0x79, 0xe4, 0xb8, 0xff, 0x4b, 0x87, 0x6c, 0xad, 0x90, 0x57, 0x00, 0x37, 0x33, + 0x4a, 0x36, 0x9a, 0xd9, 0xe6, 0x29, 0xed, 0x0f, 0x73, 0x73, 0x0a, 0xca, 0x91, 0x7c, 0x86, 0x7b, + 0x33, 0x7a, 0x4e, 0x1e, 0xe5, 0x8a, 0xd9, 0x33, 0x63, 0xda, 0xf3, 0x28, 0x1c, 0xc9, 0x15, 0x3c, + 0x9c, 0xf3, 0xaa, 0xc8, 0xb3, 0xdb, 0xdd, 0x14, 0x1e, 0xaf, 0xf9, 0xfc, 0x5f, 0xa9, 0x1c, 0xc9, + 0x07, 0x68, 0x94, 0x7b, 0x43, 0x8c, 0x5c, 0xfd, 0xd7, 0xeb, 0x31, 0xef, 0xcf, 0xf8, 0xc3, 0x91, + 0x1c, 0x40, 0xbd, 0x50, 0x7a, 0x32, 0x2e, 0x64, 0xb9, 0xc1, 0xe6, 0xd6, 0x34, 0x98, 0xe3, 0xd1, + 0xce, 0xa7, 0x6d, 0xb9, 0xf4, 0x5b, 0xa7, 0x85, 0x65, 0xaf, 0x98, 0xaf, 0xd5, 0xf7, 0xcb, 0xb2, + 0x82, 0x5e, 0xfe, 0x09, 0x00, 0x00, 0xff, 0xff, 0x74, 0xd3, 0xa9, 0xeb, 0x35, 0x06, 0x00, 0x00, }