Compare commits

..

No commits in common. "main" and "v0.0.10" have entirely different histories.

11 changed files with 27 additions and 255 deletions

15
app.go
View File

@ -109,14 +109,10 @@ func (s *Service) injectVars(v any) {
continue
}
fieldType := refType.Field(i)
if !(fieldType.Type.Kind() != reflect.Ptr || fieldType.Type.Kind() != reflect.Interface) {
if fieldType.Type.Kind() != reflect.Ptr {
continue
}
for _, rv := range s.refValues {
if fieldType.Type.Kind() == reflect.Interface && rv.Type().Implements(fieldType.Type) {
refValue.Field(i).Set(rv)
break
}
if fieldType.Type == rv.Type() {
refValue.Field(i).Set(rv)
break
@ -127,10 +123,7 @@ func (s *Service) injectVars(v any) {
func (s *Service) preStart(ctx context.Context) (err error) {
s.Logger().Info(ctx, "starting")
s.refValues = append(s.refValues, s.opts.injectVars...)
s.refValues = append(s.refValues, reflect.ValueOf(s.Logger()))
for _, ptr := range s.opts.servers {
s.injectVars(ptr)
s.refValues = append(s.refValues, reflect.ValueOf(ptr))
}
if s.opts.registry != nil {
@ -192,7 +185,7 @@ func (s *Service) preStart(ctx context.Context) (err error) {
o.Context = ctx
o.TTL = s.opts.registrarTimeout
}); err != nil {
s.Logger().Warnf(ctx, "service register error: %v", err)
s.Logger().Warn(ctx, "service register error: %v", err)
}
}
}
@ -213,14 +206,14 @@ func (s *Service) preStop() (err error) {
}()
for _, srv := range s.opts.servers {
if err = srv.Stop(ctx); err != nil {
s.Logger().Warnf(ctx, "server stop error: %v", err)
s.Logger().Warn(ctx, "server stop error: %v", err)
}
}
if s.opts.registry != nil {
if err = s.opts.registry.Deregister(s.service, func(o *registry.DeregisterOptions) {
o.Context = ctx
}); err != nil {
s.Logger().Warnf(ctx, "server deregister error: %v", err)
s.Logger().Warn(ctx, "server deregister error: %v", err)
}
}
s.Logger().Info(ctx, "stopped")

View File

@ -57,16 +57,9 @@ func WithAllow(paths ...string) Option {
}
}
func WithClaims(claims any) Option {
func WithClaims(claims reflect.Type) Option {
return func(o *options) {
if tv, ok := claims.(reflect.Type); ok {
o.claims = tv
} else {
o.claims = reflect.TypeOf(claims)
if o.claims.Kind() == reflect.Ptr {
o.claims = o.claims.Elem()
}
}
o.claims = claims
}
}

View File

@ -3,7 +3,6 @@ package aeus
import (
"context"
"maps"
"reflect"
"time"
"git.nobla.cn/golang/aeus/pkg/logger"
@ -25,7 +24,6 @@ type options struct {
registry registry.Registry
serviceLoader ServiceLoader
stopTimeout time.Duration
injectVars []reflect.Value
}
func WithName(name string) Option {
@ -79,14 +77,6 @@ func WithDebug(debug bool) Option {
}
}
func WithInjectVars(vars ...any) Option {
return func(o *options) {
for _, v := range vars {
o.injectVars = append(o.injectVars, reflect.ValueOf(v))
}
}
}
func WithServiceLoader(loader ServiceLoader) Option {
return func(o *options) {
o.serviceLoader = loader

View File

@ -4,8 +4,6 @@ import (
"context"
"encoding/json"
"time"
"git.nobla.cn/golang/aeus"
)
type redisCache struct {
@ -59,12 +57,7 @@ func (c *redisCache) String() string {
}
func NewCache(opts ...Option) *redisCache {
cache := &redisCache{
return &redisCache{
opts: newOptions(opts...),
}
app := aeus.FromContext(cache.opts.context)
if app != nil {
cache.opts.prefix = app.Name() + ":" + cache.opts.prefix
}
return cache
}

View File

@ -1,14 +1,11 @@
package redis
import (
"context"
"github.com/redis/go-redis/v9"
)
type (
options struct {
context context.Context
client *redis.Client
prefix string
}
@ -22,12 +19,6 @@ func WithClient(client *redis.Client) Option {
}
}
func WithContext(ctx context.Context) Option {
return func(o *options) {
o.context = ctx
}
}
func WithPrefix(prefix string) Option {
return func(o *options) {
o.prefix = prefix

View File

@ -3,7 +3,6 @@ package logger
import (
"context"
"log/slog"
"os"
)
var (
@ -11,56 +10,32 @@ var (
)
func init() {
log = NewLogger(slog.New(
slog.NewTextHandler(os.Stdout, &slog.HandlerOptions{
Level: slog.LevelDebug,
}),
))
log = NewLogger(slog.Default())
}
type Logger interface {
Debug(ctx context.Context, format string, args ...any) //Structured context as loosely typed key-value pairs.
Debugf(ctx context.Context, format string, args ...any)
Debug(ctx context.Context, format string, args ...any)
Info(ctx context.Context, format string, args ...any)
Infof(ctx context.Context, format string, args ...any)
Warn(ctx context.Context, format string, args ...any)
Warnf(ctx context.Context, format string, args ...any)
Error(ctx context.Context, format string, args ...any)
Errorf(ctx context.Context, format string, args ...any)
}
func Debug(ctx context.Context, format string, args ...any) {
log.Debug(ctx, format, args...)
}
func Debugf(ctx context.Context, format string, args ...any) {
log.Debugf(ctx, format, args...)
}
func Info(ctx context.Context, format string, args ...any) {
log.Info(ctx, format, args...)
}
func Infof(ctx context.Context, format string, args ...any) {
log.Infof(ctx, format, args...)
log.Debug(ctx, format, args...)
}
func Warn(ctx context.Context, format string, args ...any) {
log.Warn(ctx, format, args...)
}
func Warnf(ctx context.Context, format string, args ...any) {
log.Warnf(ctx, format, args...)
log.Debug(ctx, format, args...)
}
func Error(ctx context.Context, format string, args ...any) {
log.Debug(ctx, format, args...)
}
func Errorf(ctx context.Context, format string, args ...any) {
log.Errorf(ctx, format, args...)
}
func Default() Logger {
return log
}

View File

@ -11,34 +11,18 @@ type logger struct {
}
func (l *logger) Debug(ctx context.Context, msg string, args ...any) {
l.log.DebugContext(ctx, msg, args...)
}
func (l *logger) Debugf(ctx context.Context, msg string, args ...any) {
l.log.DebugContext(ctx, fmt.Sprintf(msg, args...))
}
func (l *logger) Info(ctx context.Context, msg string, args ...any) {
l.log.InfoContext(ctx, msg, args...)
}
func (l *logger) Infof(ctx context.Context, msg string, args ...any) {
l.log.InfoContext(ctx, fmt.Sprintf(msg, args...))
}
func (l *logger) Warn(ctx context.Context, msg string, args ...any) {
l.log.WarnContext(ctx, msg, args...)
}
func (l *logger) Warnf(ctx context.Context, msg string, args ...any) {
l.log.WarnContext(ctx, fmt.Sprintf(msg, args...))
}
func (l *logger) Error(ctx context.Context, msg string, args ...any) {
l.log.ErrorContext(ctx, msg, args...)
}
func (l *logger) Errorf(ctx context.Context, msg string, args ...any) {
l.log.ErrorContext(ctx, fmt.Sprintf(msg, args...))
}

View File

@ -32,7 +32,6 @@ type Server struct {
uri *url.URL
exitFlag int32
middleware []middleware.Middleware
Logger logger.Logger
}
func (svr *Server) Use(middlewares ...middleware.Middleware) {
@ -135,7 +134,7 @@ func (s *Server) execute(ctx *Context, frame *Frame) (err error) {
func (svr *Server) nextSequence() int64 {
svr.sequenceLocker.Lock()
defer svr.sequenceLocker.Unlock()
if svr.sequence == math.MaxInt64 {
if svr.sequence >= math.MaxInt64 {
svr.sequence = 1
}
svr.sequence++
@ -209,16 +208,10 @@ func (s *Server) serve() (err error) {
func (s *Server) Start(ctx context.Context) (err error) {
s.ctx = ctx
if s.opts.logger != nil {
s.Logger = s.opts.logger
}
if s.Logger == nil {
s.Logger = logger.Default()
}
if err = s.createListener(); err != nil {
return
}
s.Logger.Infof(ctx, "cli server listen on: %s", s.uri.Host)
s.opts.logger.Info(ctx, "cli server listen on: %s", s.uri.Host)
s.Handle("/help", "Display help information", func(ctx *Context) (err error) {
return ctx.Success(s.router.String())
})
@ -231,9 +224,7 @@ func (s *Server) Stop(ctx context.Context) (err error) {
return
}
if s.listener != nil {
if err = s.listener.Close(); err != nil {
s.Logger.Warnf(ctx, "cli listener close error: %v", err)
}
err = s.listener.Close()
}
s.ctxMap.Range(func(key, value any) bool {
if ctx, ok := value.(*Context); ok {
@ -241,7 +232,6 @@ func (s *Server) Stop(ctx context.Context) (err error) {
}
return true
})
s.Logger.Info(ctx, "cli server stopped")
return
}
@ -250,6 +240,7 @@ func New(cbs ...Option) *Server {
opts: &options{
network: "tcp",
address: ":0",
logger: logger.Default(),
},
uri: &url.URL{Scheme: "cli"},
router: newRouter(""),

View File

@ -25,7 +25,6 @@ type Server struct {
serve *grpc.Server
listener net.Listener
middlewares []middleware.Middleware
Logger logger.Logger
}
func (s *Server) createListener() (err error) {
@ -108,16 +107,11 @@ func (s *Server) Use(middlewares ...middleware.Middleware) {
func (s *Server) Start(ctx context.Context) (err error) {
s.ctx = ctx
if s.opts.logger != nil {
s.Logger = s.opts.logger
}
if s.Logger == nil {
s.Logger = logger.Default()
}
if err = s.createListener(); err != nil {
return
}
s.Logger.Infof(ctx, "grpc server listen on: %s", s.uri.Host)
s.opts.logger.Info(ctx, "grpc server listen on: %s", s.uri.Host)
reflection.Register(s.serve)
s.serve.Serve(s.listener)
return
@ -136,7 +130,7 @@ func (s *Server) RegisterService(sd *grpc.ServiceDesc, ss any) {
func (s *Server) Stop(ctx context.Context) (err error) {
s.serve.GracefulStop()
s.Logger.Infof(s.ctx, "grpc server stopped")
s.opts.logger.Info(s.ctx, "grpc server stopped")
return
}
@ -144,6 +138,7 @@ func New(cbs ...Option) *Server {
svr := &Server{
opts: &options{
network: "tcp",
logger: logger.Default(),
grpcOpts: make([]grpc.ServerOption, 0, 10),
},
uri: &url.URL{

View File

@ -3,17 +3,13 @@ package http
import (
"context"
"fmt"
"io"
"net"
"net/http"
"net/http/pprof"
"net/url"
"os"
"path"
"path/filepath"
"slices"
"strconv"
"strings"
"sync"
"time"
@ -36,7 +32,6 @@ type Server struct {
listener net.Listener
fs *filesystem
middlewares []middleware.Middleware
Logger logger.Logger
}
func (s *Server) Endpoint(ctx context.Context) (string, error) {
@ -111,60 +106,14 @@ func (s *Server) Webroot(prefix string, fs http.FileSystem) {
s.fs.SetIndexFile("/index.html")
}
func (s *Server) shouldCompress(req *http.Request) bool {
if !strings.Contains(req.Header.Get(headerAcceptEncoding), "gzip") ||
strings.Contains(req.Header.Get("Connection"), "Upgrade") {
return false
}
// Check if the request path is excluded from compression
extension := filepath.Ext(req.URL.Path)
if slices.Contains(assetsExtensions, extension) {
return true
}
return false
}
func (s *Server) staticHandle(ctx *gin.Context, fp http.File) {
uri := path.Clean(ctx.Request.URL.Path)
fi, err := fp.Stat()
if err != nil {
return
}
if !fi.IsDir() {
//https://github.com/gin-contrib/gzip
if s.shouldCompress(ctx.Request) && fi.Size() > 8192 {
gzWriter := newGzipWriter()
gzWriter.Reset(ctx.Writer)
ctx.Header(headerContentEncoding, "gzip")
ctx.Writer.Header().Add(headerVary, headerAcceptEncoding)
originalEtag := ctx.GetHeader("ETag")
if originalEtag != "" && !strings.HasPrefix(originalEtag, "W/") {
ctx.Header("ETag", "W/"+originalEtag)
}
ctx.Writer = &gzipWriter{ctx.Writer, gzWriter}
defer func() {
if ctx.Writer.Size() < 0 {
gzWriter.Reset(io.Discard)
}
gzWriter.Close()
if ctx.Writer.Size() > -1 {
ctx.Header("Content-Length", strconv.Itoa(ctx.Writer.Size()))
}
putGzipWriter(gzWriter)
}()
}
}
http.ServeContent(ctx.Writer, ctx.Request, path.Base(uri), s.fs.modtime, fp)
ctx.Abort()
}
func (s *Server) notFoundHandle(ctx *gin.Context) {
if s.fs != nil && ctx.Request.Method == http.MethodGet {
uri := path.Clean(ctx.Request.URL.Path)
if fp, err := s.fs.Open(uri); err == nil {
s.staticHandle(ctx, fp)
http.ServeContent(ctx.Writer, ctx.Request, path.Base(uri), s.fs.modtime, fp)
fp.Close()
ctx.Abort()
return
}
}
ctx.JSON(http.StatusNotFound, newResponse(errors.NotFound, "Not Found", nil))
@ -255,12 +204,6 @@ func (s *Server) Start(ctx context.Context) (err error) {
Addr: s.opts.address,
Handler: s.engine,
}
if s.opts.logger != nil {
s.Logger = s.opts.logger
}
if s.Logger == nil {
s.Logger = logger.Default()
}
s.ctx = ctx
if s.opts.debug {
s.engine.Handle(http.MethodGet, "/debug/pprof/", s.wrapHandle(pprof.Index))
@ -277,7 +220,7 @@ func (s *Server) Start(ctx context.Context) (err error) {
return
}
s.engine.NoRoute(s.notFoundHandle)
s.Logger.Infof(ctx, "http server listen on: %s", s.uri.Host)
s.opts.logger.Info(ctx, "http server listen on: %s", s.uri.Host)
if s.opts.certFile != "" && s.opts.keyFile != "" {
s.uri.Scheme = "https"
err = s.serve.ServeTLS(s.listener, s.opts.certFile, s.opts.keyFile)
@ -292,7 +235,7 @@ func (s *Server) Start(ctx context.Context) (err error) {
func (s *Server) Stop(ctx context.Context) (err error) {
err = s.serve.Shutdown(ctx)
s.Logger.Infof(ctx, "http server stopped")
s.opts.logger.Info(ctx, "http server stopped")
return
}
@ -301,6 +244,7 @@ func New(cbs ...Option) *Server {
uri: &url.URL{Scheme: "http"},
opts: &options{
network: "tcp",
logger: logger.Default(),
},
}
port, _ := strconv.Atoi(os.Getenv("HTTP_PORT"))

View File

@ -1,14 +1,8 @@
package http
import (
"bufio"
"compress/gzip"
"context"
"errors"
"io"
"net"
"net/http"
"sync"
"git.nobla.cn/golang/aeus/pkg/logger"
"github.com/gin-gonic/gin"
@ -47,77 +41,6 @@ type (
}
)
const (
headerAcceptEncoding = "Accept-Encoding"
headerContentEncoding = "Content-Encoding"
headerVary = "Vary"
)
var (
gzPool sync.Pool
assetsExtensions = []string{".css", ".js", ".png", ".jpg", ".jpeg", ".gif", ".svg", ".ico", ".woff", ".woff2", ".ttf", ".eot", ".otf"}
)
type gzipWriter struct {
gin.ResponseWriter
writer *gzip.Writer
}
func (g *gzipWriter) WriteString(s string) (int, error) {
g.Header().Del("Content-Length")
return g.writer.Write([]byte(s))
}
func (g *gzipWriter) Write(data []byte) (int, error) {
g.Header().Del("Content-Length")
return g.writer.Write(data)
}
func (g *gzipWriter) Flush() {
_ = g.writer.Flush()
g.ResponseWriter.Flush()
}
// Fix: https://github.com/mholt/caddy/issues/38
func (g *gzipWriter) WriteHeader(code int) {
g.Header().Del("Content-Length")
g.ResponseWriter.WriteHeader(code)
}
var _ http.Hijacker = (*gzipWriter)(nil)
// Hijack allows the caller to take over the connection from the HTTP server.
// After a call to Hijack, the HTTP server library will not do anything else with the connection.
// It becomes the caller's responsibility to manage and close the connection.
//
// It returns the underlying net.Conn, a buffered reader/writer for the connection, and an error
// if the ResponseWriter does not support the Hijacker interface.
func (g *gzipWriter) Hijack() (net.Conn, *bufio.ReadWriter, error) {
hijacker, ok := g.ResponseWriter.(http.Hijacker)
if !ok {
return nil, nil, errors.New("the ResponseWriter doesn't support the Hijacker interface")
}
return hijacker.Hijack()
}
func newGzipWriter() (writer *gzip.Writer) {
v := gzPool.Get()
if v == nil {
writer, _ = gzip.NewWriterLevel(io.Discard, gzip.DefaultCompression)
} else {
if w, ok := v.(*gzip.Writer); ok {
return w
} else {
writer, _ = gzip.NewWriterLevel(io.Discard, gzip.DefaultCompression)
}
}
return
}
func putGzipWriter(writer *gzip.Writer) {
gzPool.Put(writer)
}
func WithNetwork(network string) Option {
return func(o *options) {
o.network = network