mirror of
				https://github.com/openimsdk/open-im-server.git
				synced 2025-10-26 21:22:16 +08:00 
			
		
		
		
	* pb * fix: Modifying other fields while setting IsPrivateChat does not take effect * fix: quote message error revoke * refactoring scheduled tasks * refactoring scheduled tasks * refactoring scheduled tasks * refactoring scheduled tasks * refactoring scheduled tasks * refactoring scheduled tasks * upgrading pkg tools * fix * fix * optimize log output * feat: support GetLastMessage * feat: support GetLastMessage * feat: s3 switch * feat: s3 switch * fix: GetUsersOnline * feat: SendBusinessNotification supported configuration parameters * feat: SendBusinessNotification supported configuration parameters * feat: SendBusinessNotification supported configuration parameters * feat: seq conversion failed without exiting * monolithic * fix: DeleteDoc crash * fix: DeleteDoc crash * fix: monolithic * fix: monolithic * fix: fill send time * fix: fill send time * fix: crash caused by withdrawing messages from users who have left the group * fix: mq * fix: mq * fix: user msg timestamp * fix: mq * 1 * 1 * 1 * 1 * 1 * 1 * 1 * seq read config * seq read config * 1 * 1 * fix: the source message of the reference is withdrawn, and the referenced message is deleted * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1 * 1
		
			
				
	
	
		
			420 lines
		
	
	
		
			9.8 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
			
		
		
	
	
			420 lines
		
	
	
		
			9.8 KiB
		
	
	
	
		
			Go
		
	
	
	
	
	
| package main
 | |
| 
 | |
| import (
 | |
| 	"bytes"
 | |
| 	"context"
 | |
| 	"encoding/json"
 | |
| 	"flag"
 | |
| 	"fmt"
 | |
| 	"net"
 | |
| 	"os"
 | |
| 	"os/signal"
 | |
| 	"path"
 | |
| 	"path/filepath"
 | |
| 	"reflect"
 | |
| 	"runtime"
 | |
| 	"strings"
 | |
| 	"sync"
 | |
| 	"syscall"
 | |
| 	"time"
 | |
| 
 | |
| 	"github.com/mitchellh/mapstructure"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/api"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/msggateway"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/msgtransfer"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/push"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/auth"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/conversation"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/group"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/msg"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/relation"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/third"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/rpc/user"
 | |
| 	"github.com/openimsdk/open-im-server/v3/internal/tools/cron"
 | |
| 	"github.com/openimsdk/open-im-server/v3/pkg/common/config"
 | |
| 	"github.com/openimsdk/open-im-server/v3/pkg/common/prommetrics"
 | |
| 	"github.com/openimsdk/open-im-server/v3/version"
 | |
| 	"github.com/openimsdk/tools/discovery"
 | |
| 	"github.com/openimsdk/tools/discovery/standalone"
 | |
| 	"github.com/openimsdk/tools/log"
 | |
| 	"github.com/openimsdk/tools/system/program"
 | |
| 	"github.com/openimsdk/tools/utils/datautil"
 | |
| 	"github.com/openimsdk/tools/utils/network"
 | |
| 	"github.com/spf13/viper"
 | |
| 	"google.golang.org/grpc"
 | |
| )
 | |
| 
 | |
| func init() {
 | |
| 	config.SetStandalone()
 | |
| 	prommetrics.RegistryAll()
 | |
| }
 | |
| 
 | |
| func main() {
 | |
| 	var configPath string
 | |
| 	flag.StringVar(&configPath, "c", "", "config path")
 | |
| 	flag.Parse()
 | |
| 	if configPath == "" {
 | |
| 		_, _ = fmt.Fprintln(os.Stderr, "config path is empty")
 | |
| 		os.Exit(1)
 | |
| 		return
 | |
| 	}
 | |
| 	cmd := newCmds(configPath)
 | |
| 	putCmd(cmd, false, auth.Start)
 | |
| 	putCmd(cmd, false, conversation.Start)
 | |
| 	putCmd(cmd, false, relation.Start)
 | |
| 	putCmd(cmd, false, group.Start)
 | |
| 	putCmd(cmd, false, msg.Start)
 | |
| 	putCmd(cmd, false, third.Start)
 | |
| 	putCmd(cmd, false, user.Start)
 | |
| 	putCmd(cmd, false, push.Start)
 | |
| 	putCmd(cmd, true, msggateway.Start)
 | |
| 	putCmd(cmd, true, msgtransfer.Start)
 | |
| 	putCmd(cmd, true, api.Start)
 | |
| 	putCmd(cmd, true, cron.Start)
 | |
| 	ctx := context.Background()
 | |
| 	if err := cmd.run(ctx); err != nil {
 | |
| 		_, _ = fmt.Fprintf(os.Stderr, "server exit %s", err)
 | |
| 		os.Exit(1)
 | |
| 		return
 | |
| 	}
 | |
| }
 | |
| 
 | |
| func newCmds(confPath string) *cmds {
 | |
| 	return &cmds{confPath: confPath}
 | |
| }
 | |
| 
 | |
| type cmdName struct {
 | |
| 	Name  string
 | |
| 	Func  func(ctx context.Context) error
 | |
| 	Block bool
 | |
| }
 | |
| type cmds struct {
 | |
| 	confPath string
 | |
| 	cmds     []cmdName
 | |
| 	config   config.AllConfig
 | |
| 	conf     map[string]reflect.Value
 | |
| }
 | |
| 
 | |
| func (x *cmds) getTypePath(typ reflect.Type) string {
 | |
| 	return path.Join(typ.PkgPath(), typ.Name())
 | |
| }
 | |
| 
 | |
| func (x *cmds) initDiscovery() {
 | |
| 	x.config.Discovery.Enable = "standalone"
 | |
| 	vof := reflect.ValueOf(&x.config.Discovery.RpcService).Elem()
 | |
| 	tof := reflect.TypeOf(&x.config.Discovery.RpcService).Elem()
 | |
| 	num := tof.NumField()
 | |
| 	for i := 0; i < num; i++ {
 | |
| 		field := tof.Field(i)
 | |
| 		if !field.IsExported() {
 | |
| 			continue
 | |
| 		}
 | |
| 		if field.Type.Kind() != reflect.String {
 | |
| 			continue
 | |
| 		}
 | |
| 		vof.Field(i).SetString(field.Name)
 | |
| 	}
 | |
| }
 | |
| 
 | |
| func (x *cmds) initAllConfig() error {
 | |
| 	x.conf = make(map[string]reflect.Value)
 | |
| 	vof := reflect.ValueOf(&x.config).Elem()
 | |
| 	num := vof.NumField()
 | |
| 	for i := 0; i < num; i++ {
 | |
| 		field := vof.Field(i)
 | |
| 		for ptr := true; ptr; {
 | |
| 			if field.Kind() == reflect.Ptr {
 | |
| 				field = field.Elem()
 | |
| 			} else {
 | |
| 				ptr = false
 | |
| 			}
 | |
| 		}
 | |
| 		x.conf[x.getTypePath(field.Type())] = field
 | |
| 		val := field.Addr().Interface()
 | |
| 		name := val.(interface{ GetConfigFileName() string }).GetConfigFileName()
 | |
| 		confData, err := os.ReadFile(filepath.Join(x.confPath, name))
 | |
| 		if err != nil {
 | |
| 			if os.IsNotExist(err) {
 | |
| 				continue
 | |
| 			}
 | |
| 			return err
 | |
| 		}
 | |
| 		v := viper.New()
 | |
| 		v.SetConfigType("yaml")
 | |
| 		if err := v.ReadConfig(bytes.NewReader(confData)); err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 		opt := func(conf *mapstructure.DecoderConfig) {
 | |
| 			conf.TagName = config.StructTagName
 | |
| 		}
 | |
| 		if err := v.Unmarshal(val, opt); err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 	}
 | |
| 	x.initDiscovery()
 | |
| 	x.config.Redis.Disable = false
 | |
| 	x.config.LocalCache = config.LocalCache{}
 | |
| 	config.InitNotification(&x.config.Notification)
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| func (x *cmds) parseConf(conf any) error {
 | |
| 	vof := reflect.ValueOf(conf)
 | |
| 	for {
 | |
| 		if vof.Kind() == reflect.Ptr {
 | |
| 			vof = vof.Elem()
 | |
| 		} else {
 | |
| 			break
 | |
| 		}
 | |
| 	}
 | |
| 	tof := vof.Type()
 | |
| 	numField := vof.NumField()
 | |
| 	for i := 0; i < numField; i++ {
 | |
| 		typeField := tof.Field(i)
 | |
| 		if !typeField.IsExported() {
 | |
| 			continue
 | |
| 		}
 | |
| 		field := vof.Field(i)
 | |
| 		pkt := x.getTypePath(field.Type())
 | |
| 		val, ok := x.conf[pkt]
 | |
| 		if !ok {
 | |
| 			switch field.Interface().(type) {
 | |
| 			case config.Index:
 | |
| 			case config.Path:
 | |
| 				field.SetString(x.confPath)
 | |
| 			case config.AllConfig:
 | |
| 				field.Set(reflect.ValueOf(x.config))
 | |
| 			case *config.AllConfig:
 | |
| 				field.Set(reflect.ValueOf(&x.config))
 | |
| 			default:
 | |
| 				return fmt.Errorf("config field %s %s not found", vof.Type().Name(), typeField.Name)
 | |
| 			}
 | |
| 			continue
 | |
| 		}
 | |
| 		field.Set(val)
 | |
| 	}
 | |
| 	return nil
 | |
| }
 | |
| 
 | |
| func (x *cmds) add(name string, block bool, fn func(ctx context.Context) error) {
 | |
| 	x.cmds = append(x.cmds, cmdName{Name: name, Block: block, Func: fn})
 | |
| }
 | |
| 
 | |
| func (x *cmds) initLog() error {
 | |
| 	conf := x.config.Log
 | |
| 	if err := log.InitLoggerFromConfig(
 | |
| 		"openim-server",
 | |
| 		program.GetProcessName(),
 | |
| 		"", "",
 | |
| 		conf.RemainLogLevel,
 | |
| 		conf.IsStdout,
 | |
| 		conf.IsJson,
 | |
| 		conf.StorageLocation,
 | |
| 		conf.RemainRotationCount,
 | |
| 		conf.RotationTime,
 | |
| 		strings.TrimSpace(version.Version),
 | |
| 		conf.IsSimplify,
 | |
| 	); err != nil {
 | |
| 		return err
 | |
| 	}
 | |
| 	return nil
 | |
| 
 | |
| }
 | |
| 
 | |
| func (x *cmds) run(ctx context.Context) error {
 | |
| 	if len(x.cmds) == 0 {
 | |
| 		return fmt.Errorf("no command to run")
 | |
| 	}
 | |
| 	if err := x.initAllConfig(); err != nil {
 | |
| 		return err
 | |
| 	}
 | |
| 	if err := x.initLog(); err != nil {
 | |
| 		return err
 | |
| 	}
 | |
| 
 | |
| 	ctx, cancel := context.WithCancelCause(ctx)
 | |
| 
 | |
| 	go func() {
 | |
| 		<-ctx.Done()
 | |
| 		log.ZError(ctx, "context server exit cause", context.Cause(ctx))
 | |
| 	}()
 | |
| 
 | |
| 	if prometheus := x.config.API.Prometheus; prometheus.Enable {
 | |
| 		var (
 | |
| 			port int
 | |
| 			err  error
 | |
| 		)
 | |
| 		if !prometheus.AutoSetPorts {
 | |
| 			port, err = datautil.GetElemByIndex(prometheus.Ports, 0)
 | |
| 			if err != nil {
 | |
| 				return err
 | |
| 			}
 | |
| 		}
 | |
| 		ip, err := network.GetLocalIP()
 | |
| 		if err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 		listener, err := net.Listen("tcp", fmt.Sprintf(":%d", port))
 | |
| 		if err != nil {
 | |
| 			return fmt.Errorf("prometheus listen %d error %w", port, err)
 | |
| 		}
 | |
| 		defer listener.Close()
 | |
| 		log.ZDebug(ctx, "prometheus start", "addr", listener.Addr())
 | |
| 		target, err := json.Marshal(prommetrics.BuildDefaultTarget(ip, listener.Addr().(*net.TCPAddr).Port))
 | |
| 		if err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 		if err := standalone.GetKeyValue().SetKey(ctx, prommetrics.BuildDiscoveryKey(prommetrics.APIKeyName), target); err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 		go func() {
 | |
| 			err := prommetrics.Start(listener)
 | |
| 			if err == nil {
 | |
| 				err = fmt.Errorf("http done")
 | |
| 			}
 | |
| 			cancel(fmt.Errorf("prometheus %w", err))
 | |
| 		}()
 | |
| 	}
 | |
| 
 | |
| 	go func() {
 | |
| 		sigs := make(chan os.Signal, 1)
 | |
| 		signal.Notify(sigs, syscall.SIGTERM, syscall.SIGINT, syscall.SIGKILL)
 | |
| 		select {
 | |
| 		case <-ctx.Done():
 | |
| 			return
 | |
| 		case val := <-sigs:
 | |
| 			log.ZDebug(ctx, "recv signal", "signal", val.String())
 | |
| 			cancel(fmt.Errorf("signal %s", val.String()))
 | |
| 		}
 | |
| 	}()
 | |
| 
 | |
| 	for i := range x.cmds {
 | |
| 		cmd := x.cmds[i]
 | |
| 		if cmd.Block {
 | |
| 			continue
 | |
| 		}
 | |
| 		if err := cmd.Func(ctx); err != nil {
 | |
| 			cancel(fmt.Errorf("server %s exit %w", cmd.Name, err))
 | |
| 			return err
 | |
| 		}
 | |
| 		go func() {
 | |
| 			if cmd.Block {
 | |
| 				cancel(fmt.Errorf("server %s exit", cmd.Name))
 | |
| 			}
 | |
| 		}()
 | |
| 	}
 | |
| 
 | |
| 	var wait cmdManger
 | |
| 	for i := range x.cmds {
 | |
| 		cmd := x.cmds[i]
 | |
| 		if !cmd.Block {
 | |
| 			continue
 | |
| 		}
 | |
| 		wait.Start(cmd.Name)
 | |
| 		go func() {
 | |
| 			defer wait.Shutdown(cmd.Name)
 | |
| 			if err := cmd.Func(ctx); err != nil {
 | |
| 				cancel(fmt.Errorf("server %s exit %w", cmd.Name, err))
 | |
| 				return
 | |
| 			}
 | |
| 			cancel(fmt.Errorf("server %s exit", cmd.Name))
 | |
| 		}()
 | |
| 	}
 | |
| 	<-ctx.Done()
 | |
| 	exitCause := context.Cause(ctx)
 | |
| 	log.ZWarn(ctx, "notification of service closure", exitCause)
 | |
| 	done := wait.Wait()
 | |
| 	timeout := time.NewTimer(time.Second * 10)
 | |
| 	defer timeout.Stop()
 | |
| 	for {
 | |
| 		select {
 | |
| 		case <-timeout.C:
 | |
| 			log.ZWarn(ctx, "server exit timeout", nil, "running", wait.Running())
 | |
| 			return exitCause
 | |
| 		case _, ok := <-done:
 | |
| 			if ok {
 | |
| 				log.ZWarn(ctx, "waiting for the service to exit", nil, "running", wait.Running())
 | |
| 			} else {
 | |
| 				log.ZInfo(ctx, "all server exit done")
 | |
| 				return exitCause
 | |
| 			}
 | |
| 		}
 | |
| 	}
 | |
| }
 | |
| 
 | |
| func putCmd[C any](cmd *cmds, block bool, fn func(ctx context.Context, config *C, client discovery.Conn, server grpc.ServiceRegistrar) error) {
 | |
| 	name := path.Base(runtime.FuncForPC(reflect.ValueOf(fn).Pointer()).Name())
 | |
| 	if index := strings.Index(name, "."); index >= 0 {
 | |
| 		name = name[:index]
 | |
| 	}
 | |
| 	cmd.add(name, block, func(ctx context.Context) error {
 | |
| 		var conf C
 | |
| 		if err := cmd.parseConf(&conf); err != nil {
 | |
| 			return err
 | |
| 		}
 | |
| 		return fn(ctx, &conf, standalone.GetDiscoveryConn(), standalone.GetServiceRegistrar())
 | |
| 	})
 | |
| }
 | |
| 
 | |
| type cmdManger struct {
 | |
| 	lock  sync.Mutex
 | |
| 	done  chan struct{}
 | |
| 	count int
 | |
| 	names map[string]struct{}
 | |
| }
 | |
| 
 | |
| func (x *cmdManger) Start(name string) {
 | |
| 	x.lock.Lock()
 | |
| 	defer x.lock.Unlock()
 | |
| 	if x.names == nil {
 | |
| 		x.names = make(map[string]struct{})
 | |
| 	}
 | |
| 	if x.done == nil {
 | |
| 		x.done = make(chan struct{}, 1)
 | |
| 	}
 | |
| 	if _, ok := x.names[name]; ok {
 | |
| 		panic(fmt.Errorf("cmd %s already exists", name))
 | |
| 	}
 | |
| 	x.count++
 | |
| 	x.names[name] = struct{}{}
 | |
| }
 | |
| 
 | |
| func (x *cmdManger) Shutdown(name string) {
 | |
| 	x.lock.Lock()
 | |
| 	defer x.lock.Unlock()
 | |
| 	if _, ok := x.names[name]; !ok {
 | |
| 		panic(fmt.Errorf("cmd %s not exists", name))
 | |
| 	}
 | |
| 	delete(x.names, name)
 | |
| 	x.count--
 | |
| 	if x.count == 0 {
 | |
| 		close(x.done)
 | |
| 	} else {
 | |
| 		select {
 | |
| 		case x.done <- struct{}{}:
 | |
| 		default:
 | |
| 		}
 | |
| 	}
 | |
| }
 | |
| 
 | |
| func (x *cmdManger) Wait() <-chan struct{} {
 | |
| 	x.lock.Lock()
 | |
| 	defer x.lock.Unlock()
 | |
| 	if x.count == 0 || x.done == nil {
 | |
| 		tmp := make(chan struct{})
 | |
| 		close(tmp)
 | |
| 		return tmp
 | |
| 	}
 | |
| 	return x.done
 | |
| }
 | |
| 
 | |
| func (x *cmdManger) Running() []string {
 | |
| 	x.lock.Lock()
 | |
| 	defer x.lock.Unlock()
 | |
| 	names := make([]string, 0, len(x.names))
 | |
| 	for name := range x.names {
 | |
| 		names = append(names, name)
 | |
| 	}
 | |
| 	return names
 | |
| }
 |