Improve queue and logger context (#24924)
Before there was a "graceful function": RunWithShutdownFns, it's mainly for some modules which doesn't support context. The old queue system doesn't work well with context, so the old queues need it. After the queue refactoring, the new queue works with context well, so, use Golang context as much as possible, the `RunWithShutdownFns` could be removed (replaced by RunWithCancel for context cancel mechanism), the related code could be simplified. This PR also fixes some legacy queue-init problems, eg: * typo : archiver: "unable to create codes indexer queue" => "unable to create repo-archive queue" * no nil check for failed queues, which causes unfriendly panic After this PR, many goroutines could have better display name: ![image](https://github.com/go-gitea/gitea/assets/2114189/701b2a9b-8065-4137-aeaa-0bda2b34604a) ![image](https://github.com/go-gitea/gitea/assets/2114189/f1d5f50f-0534-40f0-b0be-f2c9daa5fe92)
This commit is contained in:
parent
e4922d484b
commit
18f26cfbf7
|
@ -5,51 +5,8 @@ package graceful
|
||||||
|
|
||||||
import (
|
import (
|
||||||
"context"
|
"context"
|
||||||
"time"
|
|
||||||
)
|
)
|
||||||
|
|
||||||
// ChannelContext is a context that wraps a channel and error as a context
|
|
||||||
type ChannelContext struct {
|
|
||||||
done <-chan struct{}
|
|
||||||
err error
|
|
||||||
}
|
|
||||||
|
|
||||||
// NewChannelContext creates a ChannelContext from a channel and error
|
|
||||||
func NewChannelContext(done <-chan struct{}, err error) *ChannelContext {
|
|
||||||
return &ChannelContext{
|
|
||||||
done: done,
|
|
||||||
err: err,
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
// Deadline returns the time when work done on behalf of this context
|
|
||||||
// should be canceled. There is no Deadline for a ChannelContext
|
|
||||||
func (ctx *ChannelContext) Deadline() (deadline time.Time, ok bool) {
|
|
||||||
return deadline, ok
|
|
||||||
}
|
|
||||||
|
|
||||||
// Done returns the channel provided at the creation of this context.
|
|
||||||
// When closed, work done on behalf of this context should be canceled.
|
|
||||||
func (ctx *ChannelContext) Done() <-chan struct{} {
|
|
||||||
return ctx.done
|
|
||||||
}
|
|
||||||
|
|
||||||
// Err returns nil, if Done is not closed. If Done is closed,
|
|
||||||
// Err returns the error provided at the creation of this context
|
|
||||||
func (ctx *ChannelContext) Err() error {
|
|
||||||
select {
|
|
||||||
case <-ctx.done:
|
|
||||||
return ctx.err
|
|
||||||
default:
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
// Value returns nil for all calls as no values are or can be associated with this context
|
|
||||||
func (ctx *ChannelContext) Value(key interface{}) interface{} {
|
|
||||||
return nil
|
|
||||||
}
|
|
||||||
|
|
||||||
// ShutdownContext returns a context.Context that is Done at shutdown
|
// ShutdownContext returns a context.Context that is Done at shutdown
|
||||||
// Callers using this context should ensure that they are registered as a running server
|
// Callers using this context should ensure that they are registered as a running server
|
||||||
// in order that they are waited for.
|
// in order that they are waited for.
|
||||||
|
|
|
@ -23,6 +23,11 @@ const (
|
||||||
stateTerminate
|
stateTerminate
|
||||||
)
|
)
|
||||||
|
|
||||||
|
type RunCanceler interface {
|
||||||
|
Run()
|
||||||
|
Cancel()
|
||||||
|
}
|
||||||
|
|
||||||
// There are some places that could inherit sockets:
|
// There are some places that could inherit sockets:
|
||||||
//
|
//
|
||||||
// * HTTP or HTTPS main listener
|
// * HTTP or HTTPS main listener
|
||||||
|
@ -55,46 +60,19 @@ func InitManager(ctx context.Context) {
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
||||||
// WithCallback is a runnable to call when the caller has finished
|
// RunWithCancel helps to run a function with a custom context, the Cancel function will be called at shutdown
|
||||||
type WithCallback func(callback func())
|
// The Cancel function should stop the Run function in predictable time.
|
||||||
|
func (g *Manager) RunWithCancel(rc RunCanceler) {
|
||||||
// RunnableWithShutdownFns is a runnable with functions to run at shutdown and terminate
|
g.RunAtShutdown(context.Background(), rc.Cancel)
|
||||||
// After the callback to atShutdown is called and is complete, the main function must return.
|
|
||||||
// Similarly the callback function provided to atTerminate must return once termination is complete.
|
|
||||||
// Please note that use of the atShutdown and atTerminate callbacks will create go-routines that will wait till their respective signals
|
|
||||||
// - users must therefore be careful to only call these as necessary.
|
|
||||||
type RunnableWithShutdownFns func(atShutdown, atTerminate func(func()))
|
|
||||||
|
|
||||||
// RunWithShutdownFns takes a function that has both atShutdown and atTerminate callbacks
|
|
||||||
// After the callback to atShutdown is called and is complete, the main function must return.
|
|
||||||
// Similarly the callback function provided to atTerminate must return once termination is complete.
|
|
||||||
// Please note that use of the atShutdown and atTerminate callbacks will create go-routines that will wait till their respective signals
|
|
||||||
// - users must therefore be careful to only call these as necessary.
|
|
||||||
func (g *Manager) RunWithShutdownFns(run RunnableWithShutdownFns) {
|
|
||||||
g.runningServerWaitGroup.Add(1)
|
g.runningServerWaitGroup.Add(1)
|
||||||
defer g.runningServerWaitGroup.Done()
|
defer g.runningServerWaitGroup.Done()
|
||||||
defer func() {
|
defer func() {
|
||||||
if err := recover(); err != nil {
|
if err := recover(); err != nil {
|
||||||
log.Critical("PANIC during RunWithShutdownFns: %v\nStacktrace: %s", err, log.Stack(2))
|
log.Critical("PANIC during RunWithCancel: %v\nStacktrace: %s", err, log.Stack(2))
|
||||||
g.doShutdown()
|
g.doShutdown()
|
||||||
}
|
}
|
||||||
}()
|
}()
|
||||||
run(func(atShutdown func()) {
|
rc.Run()
|
||||||
g.lock.Lock()
|
|
||||||
defer g.lock.Unlock()
|
|
||||||
g.toRunAtShutdown = append(g.toRunAtShutdown,
|
|
||||||
func() {
|
|
||||||
defer func() {
|
|
||||||
if err := recover(); err != nil {
|
|
||||||
log.Critical("PANIC during RunWithShutdownFns: %v\nStacktrace: %s", err, log.Stack(2))
|
|
||||||
g.doShutdown()
|
|
||||||
}
|
|
||||||
}()
|
|
||||||
atShutdown()
|
|
||||||
})
|
|
||||||
}, func(atTerminate func()) {
|
|
||||||
g.RunAtTerminate(atTerminate)
|
|
||||||
})
|
|
||||||
}
|
}
|
||||||
|
|
||||||
// RunWithShutdownContext takes a function that has a context to watch for shutdown.
|
// RunWithShutdownContext takes a function that has a context to watch for shutdown.
|
||||||
|
@ -151,21 +129,6 @@ func (g *Manager) RunAtShutdown(ctx context.Context, shutdown func()) {
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
||||||
// RunAtHammer creates a go-routine to run the provided function at shutdown
|
|
||||||
func (g *Manager) RunAtHammer(hammer func()) {
|
|
||||||
g.lock.Lock()
|
|
||||||
defer g.lock.Unlock()
|
|
||||||
g.toRunAtHammer = append(g.toRunAtHammer,
|
|
||||||
func() {
|
|
||||||
defer func() {
|
|
||||||
if err := recover(); err != nil {
|
|
||||||
log.Critical("PANIC during RunAtHammer: %v\nStacktrace: %s", err, log.Stack(2))
|
|
||||||
}
|
|
||||||
}()
|
|
||||||
hammer()
|
|
||||||
})
|
|
||||||
}
|
|
||||||
|
|
||||||
func (g *Manager) doShutdown() {
|
func (g *Manager) doShutdown() {
|
||||||
if !g.setStateTransition(stateRunning, stateShuttingDown) {
|
if !g.setStateTransition(stateRunning, stateShuttingDown) {
|
||||||
g.DoImmediateHammer()
|
g.DoImmediateHammer()
|
||||||
|
@ -206,9 +169,6 @@ func (g *Manager) doHammerTime(d time.Duration) {
|
||||||
g.hammerCtxCancel()
|
g.hammerCtxCancel()
|
||||||
atHammerCtx := pprof.WithLabels(g.terminateCtx, pprof.Labels("graceful-lifecycle", "post-hammer"))
|
atHammerCtx := pprof.WithLabels(g.terminateCtx, pprof.Labels("graceful-lifecycle", "post-hammer"))
|
||||||
pprof.SetGoroutineLabels(atHammerCtx)
|
pprof.SetGoroutineLabels(atHammerCtx)
|
||||||
for _, fn := range g.toRunAtHammer {
|
|
||||||
go fn()
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
g.lock.Unlock()
|
g.lock.Unlock()
|
||||||
}
|
}
|
||||||
|
|
|
@ -41,7 +41,6 @@ type Manager struct {
|
||||||
terminateWaitGroup sync.WaitGroup
|
terminateWaitGroup sync.WaitGroup
|
||||||
|
|
||||||
toRunAtShutdown []func()
|
toRunAtShutdown []func()
|
||||||
toRunAtHammer []func()
|
|
||||||
toRunAtTerminate []func()
|
toRunAtTerminate []func()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -50,7 +50,6 @@ type Manager struct {
|
||||||
shutdownRequested chan struct{}
|
shutdownRequested chan struct{}
|
||||||
|
|
||||||
toRunAtShutdown []func()
|
toRunAtShutdown []func()
|
||||||
toRunAtHammer []func()
|
|
||||||
toRunAtTerminate []func()
|
toRunAtTerminate []func()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -166,7 +166,7 @@ func Init() {
|
||||||
handler := func(items ...*IndexerData) (unhandled []*IndexerData) {
|
handler := func(items ...*IndexerData) (unhandled []*IndexerData) {
|
||||||
idx, err := indexer.get()
|
idx, err := indexer.get()
|
||||||
if idx == nil || err != nil {
|
if idx == nil || err != nil {
|
||||||
log.Error("Codes indexer handler: unable to get indexer!")
|
log.Warn("Codes indexer handler: indexer is not ready, retry later.")
|
||||||
return items
|
return items
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -201,7 +201,7 @@ func Init() {
|
||||||
return unhandled
|
return unhandled
|
||||||
}
|
}
|
||||||
|
|
||||||
indexerQueue = queue.CreateUniqueQueue("code_indexer", handler)
|
indexerQueue = queue.CreateUniqueQueue(ctx, "code_indexer", handler)
|
||||||
if indexerQueue == nil {
|
if indexerQueue == nil {
|
||||||
log.Fatal("Unable to create codes indexer queue")
|
log.Fatal("Unable to create codes indexer queue")
|
||||||
}
|
}
|
||||||
|
@ -259,7 +259,7 @@ func Init() {
|
||||||
indexer.set(rIndexer)
|
indexer.set(rIndexer)
|
||||||
|
|
||||||
// Start processing the queue
|
// Start processing the queue
|
||||||
go graceful.GetManager().RunWithShutdownFns(indexerQueue.Run)
|
go graceful.GetManager().RunWithCancel(indexerQueue)
|
||||||
|
|
||||||
if populate {
|
if populate {
|
||||||
go graceful.GetManager().RunWithShutdownContext(populateRepoIndexer)
|
go graceful.GetManager().RunWithShutdownContext(populateRepoIndexer)
|
||||||
|
|
|
@ -102,7 +102,7 @@ var (
|
||||||
func InitIssueIndexer(syncReindex bool) {
|
func InitIssueIndexer(syncReindex bool) {
|
||||||
ctx, _, finished := process.GetManager().AddTypedContext(context.Background(), "Service: IssueIndexer", process.SystemProcessType, false)
|
ctx, _, finished := process.GetManager().AddTypedContext(context.Background(), "Service: IssueIndexer", process.SystemProcessType, false)
|
||||||
|
|
||||||
waitChannel := make(chan time.Duration, 1)
|
indexerInitWaitChannel := make(chan time.Duration, 1)
|
||||||
|
|
||||||
// Create the Queue
|
// Create the Queue
|
||||||
switch setting.Indexer.IssueType {
|
switch setting.Indexer.IssueType {
|
||||||
|
@ -110,7 +110,7 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
handler := func(items ...*IndexerData) (unhandled []*IndexerData) {
|
handler := func(items ...*IndexerData) (unhandled []*IndexerData) {
|
||||||
indexer := holder.get()
|
indexer := holder.get()
|
||||||
if indexer == nil {
|
if indexer == nil {
|
||||||
log.Error("Issue indexer handler: unable to get indexer.")
|
log.Warn("Issue indexer handler: indexer is not ready, retry later.")
|
||||||
return items
|
return items
|
||||||
}
|
}
|
||||||
toIndex := make([]*IndexerData, 0, len(items))
|
toIndex := make([]*IndexerData, 0, len(items))
|
||||||
|
@ -138,15 +138,17 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
return unhandled
|
return unhandled
|
||||||
}
|
}
|
||||||
|
|
||||||
issueIndexerQueue = queue.CreateSimpleQueue("issue_indexer", handler)
|
issueIndexerQueue = queue.CreateSimpleQueue(ctx, "issue_indexer", handler)
|
||||||
|
|
||||||
if issueIndexerQueue == nil {
|
if issueIndexerQueue == nil {
|
||||||
log.Fatal("Unable to create issue indexer queue")
|
log.Fatal("Unable to create issue indexer queue")
|
||||||
}
|
}
|
||||||
default:
|
default:
|
||||||
issueIndexerQueue = queue.CreateSimpleQueue[*IndexerData]("issue_indexer", nil)
|
issueIndexerQueue = queue.CreateSimpleQueue[*IndexerData](ctx, "issue_indexer", nil)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
graceful.GetManager().RunAtTerminate(finished)
|
||||||
|
|
||||||
// Create the Indexer
|
// Create the Indexer
|
||||||
go func() {
|
go func() {
|
||||||
pprof.SetGoroutineLabels(ctx)
|
pprof.SetGoroutineLabels(ctx)
|
||||||
|
@ -178,13 +180,10 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
if issueIndexer != nil {
|
if issueIndexer != nil {
|
||||||
issueIndexer.Close()
|
issueIndexer.Close()
|
||||||
}
|
}
|
||||||
finished()
|
|
||||||
log.Info("PID: %d Issue Indexer closed", os.Getpid())
|
log.Info("PID: %d Issue Indexer closed", os.Getpid())
|
||||||
})
|
})
|
||||||
log.Debug("Created Bleve Indexer")
|
log.Debug("Created Bleve Indexer")
|
||||||
case "elasticsearch":
|
case "elasticsearch":
|
||||||
graceful.GetManager().RunWithShutdownFns(func(_, atTerminate func(func())) {
|
|
||||||
pprof.SetGoroutineLabels(ctx)
|
|
||||||
issueIndexer, err := NewElasticSearchIndexer(setting.Indexer.IssueConnStr, setting.Indexer.IssueIndexerName)
|
issueIndexer, err := NewElasticSearchIndexer(setting.Indexer.IssueConnStr, setting.Indexer.IssueIndexerName)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Fatal("Unable to initialize Elastic Search Issue Indexer at connection: %s Error: %v", setting.Indexer.IssueConnStr, err)
|
log.Fatal("Unable to initialize Elastic Search Issue Indexer at connection: %s Error: %v", setting.Indexer.IssueConnStr, err)
|
||||||
|
@ -195,15 +194,10 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
}
|
}
|
||||||
populate = !exist
|
populate = !exist
|
||||||
holder.set(issueIndexer)
|
holder.set(issueIndexer)
|
||||||
atTerminate(finished)
|
|
||||||
})
|
|
||||||
case "db":
|
case "db":
|
||||||
issueIndexer := &DBIndexer{}
|
issueIndexer := &DBIndexer{}
|
||||||
holder.set(issueIndexer)
|
holder.set(issueIndexer)
|
||||||
graceful.GetManager().RunAtTerminate(finished)
|
|
||||||
case "meilisearch":
|
case "meilisearch":
|
||||||
graceful.GetManager().RunWithShutdownFns(func(_, atTerminate func(func())) {
|
|
||||||
pprof.SetGoroutineLabels(ctx)
|
|
||||||
issueIndexer, err := NewMeilisearchIndexer(setting.Indexer.IssueConnStr, setting.Indexer.IssueConnAuth, setting.Indexer.IssueIndexerName)
|
issueIndexer, err := NewMeilisearchIndexer(setting.Indexer.IssueConnStr, setting.Indexer.IssueConnAuth, setting.Indexer.IssueIndexerName)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Fatal("Unable to initialize Meilisearch Issue Indexer at connection: %s Error: %v", setting.Indexer.IssueConnStr, err)
|
log.Fatal("Unable to initialize Meilisearch Issue Indexer at connection: %s Error: %v", setting.Indexer.IssueConnStr, err)
|
||||||
|
@ -214,15 +208,13 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
}
|
}
|
||||||
populate = !exist
|
populate = !exist
|
||||||
holder.set(issueIndexer)
|
holder.set(issueIndexer)
|
||||||
atTerminate(finished)
|
|
||||||
})
|
|
||||||
default:
|
default:
|
||||||
holder.cancel()
|
holder.cancel()
|
||||||
log.Fatal("Unknown issue indexer type: %s", setting.Indexer.IssueType)
|
log.Fatal("Unknown issue indexer type: %s", setting.Indexer.IssueType)
|
||||||
}
|
}
|
||||||
|
|
||||||
// Start processing the queue
|
// Start processing the queue
|
||||||
go graceful.GetManager().RunWithShutdownFns(issueIndexerQueue.Run)
|
go graceful.GetManager().RunWithCancel(issueIndexerQueue)
|
||||||
|
|
||||||
// Populate the index
|
// Populate the index
|
||||||
if populate {
|
if populate {
|
||||||
|
@ -232,13 +224,14 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
go graceful.GetManager().RunWithShutdownContext(populateIssueIndexer)
|
go graceful.GetManager().RunWithShutdownContext(populateIssueIndexer)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
waitChannel <- time.Since(start)
|
|
||||||
close(waitChannel)
|
indexerInitWaitChannel <- time.Since(start)
|
||||||
|
close(indexerInitWaitChannel)
|
||||||
}()
|
}()
|
||||||
|
|
||||||
if syncReindex {
|
if syncReindex {
|
||||||
select {
|
select {
|
||||||
case <-waitChannel:
|
case <-indexerInitWaitChannel:
|
||||||
case <-graceful.GetManager().IsShutdown():
|
case <-graceful.GetManager().IsShutdown():
|
||||||
}
|
}
|
||||||
} else if setting.Indexer.StartupTimeout > 0 {
|
} else if setting.Indexer.StartupTimeout > 0 {
|
||||||
|
@ -249,7 +242,7 @@ func InitIssueIndexer(syncReindex bool) {
|
||||||
timeout += setting.GracefulHammerTime
|
timeout += setting.GracefulHammerTime
|
||||||
}
|
}
|
||||||
select {
|
select {
|
||||||
case duration := <-waitChannel:
|
case duration := <-indexerInitWaitChannel:
|
||||||
log.Info("Issue Indexer Initialization took %v", duration)
|
log.Info("Issue Indexer Initialization took %v", duration)
|
||||||
case <-graceful.GetManager().IsShutdown():
|
case <-graceful.GetManager().IsShutdown():
|
||||||
log.Warn("Shutdown occurred before issue index initialisation was complete")
|
log.Warn("Shutdown occurred before issue index initialisation was complete")
|
||||||
|
|
|
@ -29,13 +29,11 @@ func handler(items ...int64) []int64 {
|
||||||
}
|
}
|
||||||
|
|
||||||
func initStatsQueue() error {
|
func initStatsQueue() error {
|
||||||
statsQueue = queue.CreateUniqueQueue("repo_stats_update", handler)
|
statsQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "repo_stats_update", handler)
|
||||||
if statsQueue == nil {
|
if statsQueue == nil {
|
||||||
return fmt.Errorf("Unable to create repo_stats_update Queue")
|
return fmt.Errorf("unable to create repo_stats_update queue")
|
||||||
}
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(statsQueue)
|
||||||
go graceful.GetManager().RunWithShutdownFns(statsQueue.Run)
|
|
||||||
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -8,6 +8,7 @@ import (
|
||||||
"fmt"
|
"fmt"
|
||||||
"io"
|
"io"
|
||||||
"regexp"
|
"regexp"
|
||||||
|
"runtime/pprof"
|
||||||
"time"
|
"time"
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -143,9 +144,17 @@ func eventWriterStartGo(ctx context.Context, w EventWriter, shared bool) {
|
||||||
}
|
}
|
||||||
w.Base().shared = shared
|
w.Base().shared = shared
|
||||||
w.Base().stopped = make(chan struct{})
|
w.Base().stopped = make(chan struct{})
|
||||||
|
|
||||||
|
ctxDesc := "Logger: EventWriter: " + w.GetWriterName()
|
||||||
|
if shared {
|
||||||
|
ctxDesc = "Logger: EventWriter (shared): " + w.GetWriterName()
|
||||||
|
}
|
||||||
|
writerCtx, writerCancel := newContext(ctx, ctxDesc)
|
||||||
go func() {
|
go func() {
|
||||||
|
defer writerCancel()
|
||||||
defer close(w.Base().stopped)
|
defer close(w.Base().stopped)
|
||||||
w.Run(ctx)
|
pprof.SetGoroutineLabels(writerCtx)
|
||||||
|
w.Run(writerCtx)
|
||||||
}()
|
}()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -40,7 +40,7 @@ func TestConnLogger(t *testing.T) {
|
||||||
level := INFO
|
level := INFO
|
||||||
flags := LstdFlags | LUTC | Lfuncname
|
flags := LstdFlags | LUTC | Lfuncname
|
||||||
|
|
||||||
logger := NewLoggerWithWriters(context.Background(), NewEventWriterConn("test-conn", WriterMode{
|
logger := NewLoggerWithWriters(context.Background(), "test", NewEventWriterConn("test-conn", WriterMode{
|
||||||
Level: level,
|
Level: level,
|
||||||
Prefix: prefix,
|
Prefix: prefix,
|
||||||
Flags: FlagsFromBits(flags),
|
Flags: FlagsFromBits(flags),
|
||||||
|
|
|
@ -4,14 +4,19 @@
|
||||||
package log
|
package log
|
||||||
|
|
||||||
import (
|
import (
|
||||||
|
"context"
|
||||||
"runtime"
|
"runtime"
|
||||||
"strings"
|
"strings"
|
||||||
|
"sync/atomic"
|
||||||
|
|
||||||
"code.gitea.io/gitea/modules/process"
|
"code.gitea.io/gitea/modules/process"
|
||||||
"code.gitea.io/gitea/modules/util/rotatingfilewriter"
|
"code.gitea.io/gitea/modules/util/rotatingfilewriter"
|
||||||
)
|
)
|
||||||
|
|
||||||
var projectPackagePrefix string
|
var (
|
||||||
|
projectPackagePrefix string
|
||||||
|
processTraceDisabled atomic.Int64
|
||||||
|
)
|
||||||
|
|
||||||
func init() {
|
func init() {
|
||||||
_, filename, _, _ := runtime.Caller(0)
|
_, filename, _, _ := runtime.Caller(0)
|
||||||
|
@ -24,6 +29,10 @@ func init() {
|
||||||
rotatingfilewriter.ErrorPrintf = FallbackErrorf
|
rotatingfilewriter.ErrorPrintf = FallbackErrorf
|
||||||
|
|
||||||
process.Trace = func(start bool, pid process.IDType, description string, parentPID process.IDType, typ string) {
|
process.Trace = func(start bool, pid process.IDType, description string, parentPID process.IDType, typ string) {
|
||||||
|
// the logger manager has its own mutex lock, so it's safe to use "Load" here
|
||||||
|
if processTraceDisabled.Load() != 0 {
|
||||||
|
return
|
||||||
|
}
|
||||||
if start && parentPID != "" {
|
if start && parentPID != "" {
|
||||||
Log(1, TRACE, "Start %s: %s (from %s) (%s)", NewColoredValue(pid, FgHiYellow), description, NewColoredValue(parentPID, FgYellow), NewColoredValue(typ, Reset))
|
Log(1, TRACE, "Start %s: %s (from %s) (%s)", NewColoredValue(pid, FgHiYellow), description, NewColoredValue(parentPID, FgYellow), NewColoredValue(typ, Reset))
|
||||||
} else if start {
|
} else if start {
|
||||||
|
@ -33,3 +42,11 @@ func init() {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
func newContext(parent context.Context, desc string) (ctx context.Context, cancel context.CancelFunc) {
|
||||||
|
// the "process manager" also calls "log.Trace()" to output logs, so if we want to create new contexts by the manager, we need to disable the trace temporarily
|
||||||
|
processTraceDisabled.Add(1)
|
||||||
|
defer processTraceDisabled.Add(-1)
|
||||||
|
ctx, _, cancel = process.GetManager().AddTypedContext(parent, desc, process.SystemProcessType, false)
|
||||||
|
return ctx, cancel
|
||||||
|
}
|
||||||
|
|
|
@ -228,9 +228,9 @@ func (l *LoggerImpl) GetLevel() Level {
|
||||||
return Level(l.level.Load())
|
return Level(l.level.Load())
|
||||||
}
|
}
|
||||||
|
|
||||||
func NewLoggerWithWriters(ctx context.Context, writer ...EventWriter) *LoggerImpl {
|
func NewLoggerWithWriters(ctx context.Context, name string, writer ...EventWriter) *LoggerImpl {
|
||||||
l := &LoggerImpl{}
|
l := &LoggerImpl{}
|
||||||
l.ctx, l.ctxCancel = context.WithCancel(ctx)
|
l.ctx, l.ctxCancel = newContext(ctx, "Logger: "+name)
|
||||||
l.LevelLogger = BaseLoggerToGeneralLogger(l)
|
l.LevelLogger = BaseLoggerToGeneralLogger(l)
|
||||||
l.eventWriters = map[string]EventWriter{}
|
l.eventWriters = map[string]EventWriter{}
|
||||||
l.syncLevelInternal()
|
l.syncLevelInternal()
|
||||||
|
|
|
@ -53,7 +53,7 @@ func newDummyWriter(name string, level Level, delay time.Duration) *dummyWriter
|
||||||
}
|
}
|
||||||
|
|
||||||
func TestLogger(t *testing.T) {
|
func TestLogger(t *testing.T) {
|
||||||
logger := NewLoggerWithWriters(context.Background())
|
logger := NewLoggerWithWriters(context.Background(), "test")
|
||||||
|
|
||||||
dump := logger.DumpWriters()
|
dump := logger.DumpWriters()
|
||||||
assert.EqualValues(t, 0, len(dump))
|
assert.EqualValues(t, 0, len(dump))
|
||||||
|
@ -88,7 +88,7 @@ func TestLogger(t *testing.T) {
|
||||||
}
|
}
|
||||||
|
|
||||||
func TestLoggerPause(t *testing.T) {
|
func TestLoggerPause(t *testing.T) {
|
||||||
logger := NewLoggerWithWriters(context.Background())
|
logger := NewLoggerWithWriters(context.Background(), "test")
|
||||||
|
|
||||||
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
||||||
logger.AddWriters(w1)
|
logger.AddWriters(w1)
|
||||||
|
@ -117,7 +117,7 @@ func (t testLogString) LogString() string {
|
||||||
}
|
}
|
||||||
|
|
||||||
func TestLoggerLogString(t *testing.T) {
|
func TestLoggerLogString(t *testing.T) {
|
||||||
logger := NewLoggerWithWriters(context.Background())
|
logger := NewLoggerWithWriters(context.Background(), "test")
|
||||||
|
|
||||||
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
||||||
w1.Mode.Colorize = true
|
w1.Mode.Colorize = true
|
||||||
|
@ -130,7 +130,7 @@ func TestLoggerLogString(t *testing.T) {
|
||||||
}
|
}
|
||||||
|
|
||||||
func TestLoggerExpressionFilter(t *testing.T) {
|
func TestLoggerExpressionFilter(t *testing.T) {
|
||||||
logger := NewLoggerWithWriters(context.Background())
|
logger := NewLoggerWithWriters(context.Background(), "test")
|
||||||
|
|
||||||
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
w1 := newDummyWriter("dummy-1", DEBUG, 0)
|
||||||
w1.Mode.Expression = "foo.*"
|
w1.Mode.Expression = "foo.*"
|
||||||
|
|
|
@ -39,7 +39,7 @@ func (m *LoggerManager) GetLogger(name string) *LoggerImpl {
|
||||||
|
|
||||||
logger := m.loggers[name]
|
logger := m.loggers[name]
|
||||||
if logger == nil {
|
if logger == nil {
|
||||||
logger = NewLoggerWithWriters(m.ctx)
|
logger = NewLoggerWithWriters(m.ctx, name)
|
||||||
m.loggers[name] = logger
|
m.loggers[name] = logger
|
||||||
if name == DEFAULT {
|
if name == DEFAULT {
|
||||||
m.defaultLogger.Store(logger)
|
m.defaultLogger.Store(logger)
|
||||||
|
@ -137,6 +137,6 @@ func GetManager() *LoggerManager {
|
||||||
|
|
||||||
func NewManager() *LoggerManager {
|
func NewManager() *LoggerManager {
|
||||||
m := &LoggerManager{writers: map[string]EventWriter{}, loggers: map[string]*LoggerImpl{}}
|
m := &LoggerManager{writers: map[string]EventWriter{}, loggers: map[string]*LoggerImpl{}}
|
||||||
m.ctx, m.ctxCancel = context.WithCancel(context.Background())
|
m.ctx, m.ctxCancel = newContext(context.Background(), "LoggerManager")
|
||||||
return m
|
return m
|
||||||
}
|
}
|
||||||
|
|
|
@ -33,9 +33,11 @@ func StartSyncMirrors(queueHandle func(data ...*SyncRequest) []*SyncRequest) {
|
||||||
if !setting.Mirror.Enabled {
|
if !setting.Mirror.Enabled {
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
mirrorQueue = queue.CreateUniqueQueue("mirror", queueHandle)
|
mirrorQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "mirror", queueHandle)
|
||||||
|
if mirrorQueue == nil {
|
||||||
go graceful.GetManager().RunWithShutdownFns(mirrorQueue.Run)
|
log.Fatal("Unable to create mirror queue")
|
||||||
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(mirrorQueue)
|
||||||
}
|
}
|
||||||
|
|
||||||
// AddPullMirrorToQueue adds repoID to mirror queue
|
// AddPullMirrorToQueue adds repoID to mirror queue
|
||||||
|
|
|
@ -37,7 +37,10 @@ var _ base.Notifier = ¬ificationService{}
|
||||||
// NewNotifier create a new notificationService notifier
|
// NewNotifier create a new notificationService notifier
|
||||||
func NewNotifier() base.Notifier {
|
func NewNotifier() base.Notifier {
|
||||||
ns := ¬ificationService{}
|
ns := ¬ificationService{}
|
||||||
ns.issueQueue = queue.CreateSimpleQueue("notification-service", handler)
|
ns.issueQueue = queue.CreateSimpleQueue(graceful.GetManager().ShutdownContext(), "notification-service", handler)
|
||||||
|
if ns.issueQueue == nil {
|
||||||
|
log.Fatal("Unable to create notification-service queue")
|
||||||
|
}
|
||||||
return ns
|
return ns
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -51,7 +54,7 @@ func handler(items ...issueNotificationOpts) []issueNotificationOpts {
|
||||||
}
|
}
|
||||||
|
|
||||||
func (ns *notificationService) Run() {
|
func (ns *notificationService) Run() {
|
||||||
go graceful.GetManager().RunWithShutdownFns(ns.issueQueue.Run)
|
go graceful.GetManager().RunWithCancel(ns.issueQueue) // TODO: using "go" here doesn't seem right, just leave it as old code
|
||||||
}
|
}
|
||||||
|
|
||||||
func (ns *notificationService) NotifyCreateIssueComment(ctx context.Context, doer *user_model.User, repo *repo_model.Repository,
|
func (ns *notificationService) NotifyCreateIssueComment(ctx context.Context, doer *user_model.User, repo *repo_model.Repository,
|
||||||
|
|
|
@ -167,6 +167,7 @@ func (pm *Manager) Add(ctx context.Context, description string, cancel context.C
|
||||||
|
|
||||||
pm.processMap[pid] = process
|
pm.processMap[pid] = process
|
||||||
pm.mutex.Unlock()
|
pm.mutex.Unlock()
|
||||||
|
|
||||||
Trace(true, pid, description, parentPID, processType)
|
Trace(true, pid, description, parentPID, processType)
|
||||||
|
|
||||||
pprofCtx := pprof.WithLabels(ctx, pprof.Labels(DescriptionPProfLabel, description, PPIDPProfLabel, string(parentPID), PIDPProfLabel, string(pid), ProcessTypePProfLabel, processType))
|
pprofCtx := pprof.WithLabels(ctx, pprof.Labels(DescriptionPProfLabel, description, PPIDPProfLabel, string(parentPID), PIDPProfLabel, string(pid), ProcessTypePProfLabel, processType))
|
||||||
|
@ -200,10 +201,16 @@ func (pm *Manager) nextPID() (start time.Time, pid IDType) {
|
||||||
}
|
}
|
||||||
|
|
||||||
func (pm *Manager) remove(process *process) {
|
func (pm *Manager) remove(process *process) {
|
||||||
|
deleted := false
|
||||||
|
|
||||||
pm.mutex.Lock()
|
pm.mutex.Lock()
|
||||||
defer pm.mutex.Unlock()
|
if pm.processMap[process.PID] == process {
|
||||||
if p := pm.processMap[process.PID]; p == process {
|
|
||||||
delete(pm.processMap, process.PID)
|
delete(pm.processMap, process.PID)
|
||||||
|
deleted = true
|
||||||
|
}
|
||||||
|
pm.mutex.Unlock()
|
||||||
|
|
||||||
|
if deleted {
|
||||||
Trace(false, process.PID, process.Description, process.ParentPID, process.Type)
|
Trace(false, process.PID, process.Description, process.ParentPID, process.Type)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -88,22 +88,22 @@ func (m *Manager) FlushAll(ctx context.Context, timeout time.Duration) error {
|
||||||
}
|
}
|
||||||
|
|
||||||
// CreateSimpleQueue creates a simple queue from global setting config provider by name
|
// CreateSimpleQueue creates a simple queue from global setting config provider by name
|
||||||
func CreateSimpleQueue[T any](name string, handler HandlerFuncT[T]) *WorkerPoolQueue[T] {
|
func CreateSimpleQueue[T any](ctx context.Context, name string, handler HandlerFuncT[T]) *WorkerPoolQueue[T] {
|
||||||
return createWorkerPoolQueue(name, setting.CfgProvider, handler, false)
|
return createWorkerPoolQueue(ctx, name, setting.CfgProvider, handler, false)
|
||||||
}
|
}
|
||||||
|
|
||||||
// CreateUniqueQueue creates a unique queue from global setting config provider by name
|
// CreateUniqueQueue creates a unique queue from global setting config provider by name
|
||||||
func CreateUniqueQueue[T any](name string, handler HandlerFuncT[T]) *WorkerPoolQueue[T] {
|
func CreateUniqueQueue[T any](ctx context.Context, name string, handler HandlerFuncT[T]) *WorkerPoolQueue[T] {
|
||||||
return createWorkerPoolQueue(name, setting.CfgProvider, handler, true)
|
return createWorkerPoolQueue(ctx, name, setting.CfgProvider, handler, true)
|
||||||
}
|
}
|
||||||
|
|
||||||
func createWorkerPoolQueue[T any](name string, cfgProvider setting.ConfigProvider, handler HandlerFuncT[T], unique bool) *WorkerPoolQueue[T] {
|
func createWorkerPoolQueue[T any](ctx context.Context, name string, cfgProvider setting.ConfigProvider, handler HandlerFuncT[T], unique bool) *WorkerPoolQueue[T] {
|
||||||
queueSetting, err := setting.GetQueueSettings(cfgProvider, name)
|
queueSetting, err := setting.GetQueueSettings(cfgProvider, name)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Error("Failed to get queue settings for %q: %v", name, err)
|
log.Error("Failed to get queue settings for %q: %v", name, err)
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
w, err := NewWorkerPoolQueueBySetting(name, queueSetting, handler, unique)
|
w, err := NewWorkerPoolQueueWithContext(ctx, name, queueSetting, handler, unique)
|
||||||
if err != nil {
|
if err != nil {
|
||||||
log.Error("Failed to create queue %q: %v", name, err)
|
log.Error("Failed to create queue %q: %v", name, err)
|
||||||
return nil
|
return nil
|
||||||
|
|
|
@ -29,7 +29,7 @@ func TestManager(t *testing.T) {
|
||||||
if err != nil {
|
if err != nil {
|
||||||
return nil, err
|
return nil, err
|
||||||
}
|
}
|
||||||
return NewWorkerPoolQueueBySetting(name, qs, func(s ...int) (unhandled []int) { return nil }, false)
|
return newWorkerPoolQueueForTest(name, qs, func(s ...int) (unhandled []int) { return nil }, false)
|
||||||
}
|
}
|
||||||
|
|
||||||
// test invalid CONN_STR
|
// test invalid CONN_STR
|
||||||
|
@ -80,7 +80,7 @@ MAX_WORKERS = 2
|
||||||
|
|
||||||
assert.NoError(t, err)
|
assert.NoError(t, err)
|
||||||
|
|
||||||
q1 := createWorkerPoolQueue[string]("no-such", cfgProvider, nil, false)
|
q1 := createWorkerPoolQueue[string](context.Background(), "no-such", cfgProvider, nil, false)
|
||||||
assert.Equal(t, "no-such", q1.GetName())
|
assert.Equal(t, "no-such", q1.GetName())
|
||||||
assert.Equal(t, "dummy", q1.GetType()) // no handler, so it becomes dummy
|
assert.Equal(t, "dummy", q1.GetType()) // no handler, so it becomes dummy
|
||||||
assert.Equal(t, filepath.Join(setting.AppDataPath, "queues/dir1"), q1.baseConfig.DataFullDir)
|
assert.Equal(t, filepath.Join(setting.AppDataPath, "queues/dir1"), q1.baseConfig.DataFullDir)
|
||||||
|
@ -96,7 +96,7 @@ MAX_WORKERS = 2
|
||||||
assert.Equal(t, "string", q1.GetItemTypeName())
|
assert.Equal(t, "string", q1.GetItemTypeName())
|
||||||
qid1 := GetManager().qidCounter
|
qid1 := GetManager().qidCounter
|
||||||
|
|
||||||
q2 := createWorkerPoolQueue("sub", cfgProvider, func(s ...int) (unhandled []int) { return nil }, false)
|
q2 := createWorkerPoolQueue(context.Background(), "sub", cfgProvider, func(s ...int) (unhandled []int) { return nil }, false)
|
||||||
assert.Equal(t, "sub", q2.GetName())
|
assert.Equal(t, "sub", q2.GetName())
|
||||||
assert.Equal(t, "level", q2.GetType())
|
assert.Equal(t, "level", q2.GetType())
|
||||||
assert.Equal(t, filepath.Join(setting.AppDataPath, "queues/dir2"), q2.baseConfig.DataFullDir)
|
assert.Equal(t, filepath.Join(setting.AppDataPath, "queues/dir2"), q2.baseConfig.DataFullDir)
|
||||||
|
|
|
@ -5,6 +5,7 @@ package queue
|
||||||
|
|
||||||
import (
|
import (
|
||||||
"context"
|
"context"
|
||||||
|
"runtime/pprof"
|
||||||
"sync"
|
"sync"
|
||||||
"sync/atomic"
|
"sync/atomic"
|
||||||
"time"
|
"time"
|
||||||
|
@ -16,6 +17,7 @@ var (
|
||||||
infiniteTimerC = make(chan time.Time)
|
infiniteTimerC = make(chan time.Time)
|
||||||
batchDebounceDuration = 100 * time.Millisecond
|
batchDebounceDuration = 100 * time.Millisecond
|
||||||
workerIdleDuration = 1 * time.Second
|
workerIdleDuration = 1 * time.Second
|
||||||
|
shutdownDefaultTimeout = 2 * time.Second
|
||||||
|
|
||||||
unhandledItemRequeueDuration atomic.Int64 // to avoid data race during test
|
unhandledItemRequeueDuration atomic.Int64 // to avoid data race during test
|
||||||
)
|
)
|
||||||
|
@ -116,13 +118,15 @@ func (q *WorkerPoolQueue[T]) doWorkerHandle(batch []T) {
|
||||||
// If the queue is shutting down, it returns true and try to push the items
|
// If the queue is shutting down, it returns true and try to push the items
|
||||||
// Otherwise it does nothing and returns false
|
// Otherwise it does nothing and returns false
|
||||||
func (q *WorkerPoolQueue[T]) basePushForShutdown(items ...T) bool {
|
func (q *WorkerPoolQueue[T]) basePushForShutdown(items ...T) bool {
|
||||||
ctxShutdown := q.ctxShutdown.Load()
|
shutdownTimeout := time.Duration(q.shutdownTimeout.Load())
|
||||||
if ctxShutdown == nil {
|
if shutdownTimeout == 0 {
|
||||||
return false
|
return false
|
||||||
}
|
}
|
||||||
|
ctxShutdown, ctxShutdownCancel := context.WithTimeout(context.Background(), shutdownTimeout)
|
||||||
|
defer ctxShutdownCancel()
|
||||||
for _, item := range items {
|
for _, item := range items {
|
||||||
// if there is still any error, the queue can do nothing instead of losing the items
|
// if there is still any error, the queue can do nothing instead of losing the items
|
||||||
if err := q.baseQueue.PushItem(*ctxShutdown, q.marshal(item)); err != nil {
|
if err := q.baseQueue.PushItem(ctxShutdown, q.marshal(item)); err != nil {
|
||||||
log.Error("Failed to requeue item for queue %q when shutting down: %v", q.GetName(), err)
|
log.Error("Failed to requeue item for queue %q when shutting down: %v", q.GetName(), err)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -246,6 +250,8 @@ var skipFlushChan = make(chan flushType) // an empty flush chan, used to skip re
|
||||||
|
|
||||||
// doRun is the main loop of the queue. All related "doXxx" functions are executed in its context.
|
// doRun is the main loop of the queue. All related "doXxx" functions are executed in its context.
|
||||||
func (q *WorkerPoolQueue[T]) doRun() {
|
func (q *WorkerPoolQueue[T]) doRun() {
|
||||||
|
pprof.SetGoroutineLabels(q.ctxRun)
|
||||||
|
|
||||||
log.Debug("Queue %q starts running", q.GetName())
|
log.Debug("Queue %q starts running", q.GetName())
|
||||||
defer log.Debug("Queue %q stops running", q.GetName())
|
defer log.Debug("Queue %q stops running", q.GetName())
|
||||||
|
|
||||||
|
@ -271,8 +277,8 @@ func (q *WorkerPoolQueue[T]) doRun() {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
ctxShutdownPtr := q.ctxShutdown.Load()
|
shutdownTimeout := time.Duration(q.shutdownTimeout.Load())
|
||||||
if ctxShutdownPtr != nil {
|
if shutdownTimeout != 0 {
|
||||||
// if there is a shutdown context, try to push the items back to the base queue
|
// if there is a shutdown context, try to push the items back to the base queue
|
||||||
q.basePushForShutdown(unhandled...)
|
q.basePushForShutdown(unhandled...)
|
||||||
workerDone := make(chan struct{})
|
workerDone := make(chan struct{})
|
||||||
|
@ -280,7 +286,7 @@ func (q *WorkerPoolQueue[T]) doRun() {
|
||||||
go func() { wg.wg.Wait(); close(workerDone) }()
|
go func() { wg.wg.Wait(); close(workerDone) }()
|
||||||
select {
|
select {
|
||||||
case <-workerDone:
|
case <-workerDone:
|
||||||
case <-(*ctxShutdownPtr).Done():
|
case <-time.After(shutdownTimeout):
|
||||||
log.Error("Queue %q is shutting down, but workers are still running after timeout", q.GetName())
|
log.Error("Queue %q is shutting down, but workers are still running after timeout", q.GetName())
|
||||||
}
|
}
|
||||||
} else {
|
} else {
|
||||||
|
|
|
@ -10,9 +10,9 @@ import (
|
||||||
"sync/atomic"
|
"sync/atomic"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
"code.gitea.io/gitea/modules/graceful"
|
|
||||||
"code.gitea.io/gitea/modules/json"
|
"code.gitea.io/gitea/modules/json"
|
||||||
"code.gitea.io/gitea/modules/log"
|
"code.gitea.io/gitea/modules/log"
|
||||||
|
"code.gitea.io/gitea/modules/process"
|
||||||
"code.gitea.io/gitea/modules/setting"
|
"code.gitea.io/gitea/modules/setting"
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -21,8 +21,9 @@ import (
|
||||||
type WorkerPoolQueue[T any] struct {
|
type WorkerPoolQueue[T any] struct {
|
||||||
ctxRun context.Context
|
ctxRun context.Context
|
||||||
ctxRunCancel context.CancelFunc
|
ctxRunCancel context.CancelFunc
|
||||||
ctxShutdown atomic.Pointer[context.Context]
|
|
||||||
shutdownDone chan struct{}
|
shutdownDone chan struct{}
|
||||||
|
shutdownTimeout atomic.Int64 // in case some buggy handlers (workers) would hang forever, "shutdown" should finish in predictable time
|
||||||
|
|
||||||
origHandler HandlerFuncT[T]
|
origHandler HandlerFuncT[T]
|
||||||
safeHandler HandlerFuncT[T]
|
safeHandler HandlerFuncT[T]
|
||||||
|
@ -175,22 +176,19 @@ func (q *WorkerPoolQueue[T]) Has(data T) (bool, error) {
|
||||||
return q.baseQueue.HasItem(q.ctxRun, q.marshal(data))
|
return q.baseQueue.HasItem(q.ctxRun, q.marshal(data))
|
||||||
}
|
}
|
||||||
|
|
||||||
func (q *WorkerPoolQueue[T]) Run(atShutdown, atTerminate func(func())) {
|
func (q *WorkerPoolQueue[T]) Run() {
|
||||||
atShutdown(func() {
|
|
||||||
// in case some queue handlers are slow or have hanging bugs, at most wait for a short time
|
|
||||||
q.ShutdownWait(1 * time.Second)
|
|
||||||
})
|
|
||||||
q.doRun()
|
q.doRun()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
func (q *WorkerPoolQueue[T]) Cancel() {
|
||||||
|
q.ctxRunCancel()
|
||||||
|
}
|
||||||
|
|
||||||
// ShutdownWait shuts down the queue, waits for all workers to finish their jobs, and pushes the unhandled items back to the base queue
|
// ShutdownWait shuts down the queue, waits for all workers to finish their jobs, and pushes the unhandled items back to the base queue
|
||||||
// It waits for all workers (handlers) to finish their jobs, in case some buggy handlers would hang forever, a reasonable timeout is needed
|
// It waits for all workers (handlers) to finish their jobs, in case some buggy handlers would hang forever, a reasonable timeout is needed
|
||||||
func (q *WorkerPoolQueue[T]) ShutdownWait(timeout time.Duration) {
|
func (q *WorkerPoolQueue[T]) ShutdownWait(timeout time.Duration) {
|
||||||
shutdownCtx, shutdownCtxCancel := context.WithTimeout(context.Background(), timeout)
|
q.shutdownTimeout.Store(int64(timeout))
|
||||||
defer shutdownCtxCancel()
|
|
||||||
if q.ctxShutdown.CompareAndSwap(nil, &shutdownCtx) {
|
|
||||||
q.ctxRunCancel()
|
q.ctxRunCancel()
|
||||||
}
|
|
||||||
<-q.shutdownDone
|
<-q.shutdownDone
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -207,7 +205,11 @@ func getNewQueueFn(t string) (string, func(cfg *BaseConfig, unique bool) (baseQu
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
func NewWorkerPoolQueueBySetting[T any](name string, queueSetting setting.QueueSettings, handler HandlerFuncT[T], unique bool) (*WorkerPoolQueue[T], error) {
|
func newWorkerPoolQueueForTest[T any](name string, queueSetting setting.QueueSettings, handler HandlerFuncT[T], unique bool) (*WorkerPoolQueue[T], error) {
|
||||||
|
return NewWorkerPoolQueueWithContext(context.Background(), name, queueSetting, handler, unique)
|
||||||
|
}
|
||||||
|
|
||||||
|
func NewWorkerPoolQueueWithContext[T any](ctx context.Context, name string, queueSetting setting.QueueSettings, handler HandlerFuncT[T], unique bool) (*WorkerPoolQueue[T], error) {
|
||||||
if handler == nil {
|
if handler == nil {
|
||||||
log.Debug("Use dummy queue for %q because handler is nil and caller doesn't want to process the queue items", name)
|
log.Debug("Use dummy queue for %q because handler is nil and caller doesn't want to process the queue items", name)
|
||||||
queueSetting.Type = "dummy"
|
queueSetting.Type = "dummy"
|
||||||
|
@ -224,10 +226,11 @@ func NewWorkerPoolQueueBySetting[T any](name string, queueSetting setting.QueueS
|
||||||
}
|
}
|
||||||
log.Trace("Created queue %q of type %q", name, queueType)
|
log.Trace("Created queue %q of type %q", name, queueType)
|
||||||
|
|
||||||
w.ctxRun, w.ctxRunCancel = context.WithCancel(graceful.GetManager().ShutdownContext())
|
w.ctxRun, _, w.ctxRunCancel = process.GetManager().AddTypedContext(ctx, "Queue: "+w.GetName(), process.SystemProcessType, false)
|
||||||
w.batchChan = make(chan []T)
|
w.batchChan = make(chan []T)
|
||||||
w.flushChan = make(chan flushType)
|
w.flushChan = make(chan flushType)
|
||||||
w.shutdownDone = make(chan struct{})
|
w.shutdownDone = make(chan struct{})
|
||||||
|
w.shutdownTimeout.Store(int64(shutdownDefaultTimeout))
|
||||||
w.workerMaxNum = queueSetting.MaxWorkers
|
w.workerMaxNum = queueSetting.MaxWorkers
|
||||||
w.batchLength = queueSetting.BatchLength
|
w.batchLength = queueSetting.BatchLength
|
||||||
|
|
||||||
|
|
|
@ -16,17 +16,9 @@ import (
|
||||||
)
|
)
|
||||||
|
|
||||||
func runWorkerPoolQueue[T any](q *WorkerPoolQueue[T]) func() {
|
func runWorkerPoolQueue[T any](q *WorkerPoolQueue[T]) func() {
|
||||||
var stop func()
|
go q.Run()
|
||||||
started := make(chan struct{})
|
|
||||||
stopped := make(chan struct{})
|
|
||||||
go func() {
|
|
||||||
q.Run(func(f func()) { stop = f; close(started) }, nil)
|
|
||||||
close(stopped)
|
|
||||||
}()
|
|
||||||
<-started
|
|
||||||
return func() {
|
return func() {
|
||||||
stop()
|
q.ShutdownWait(1 * time.Second)
|
||||||
<-stopped
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -57,7 +49,7 @@ func TestWorkerPoolQueueUnhandled(t *testing.T) {
|
||||||
return unhandled
|
return unhandled
|
||||||
}
|
}
|
||||||
|
|
||||||
q, _ := NewWorkerPoolQueueBySetting("test-workpoolqueue", queueSetting, handler, false)
|
q, _ := newWorkerPoolQueueForTest("test-workpoolqueue", queueSetting, handler, false)
|
||||||
stop := runWorkerPoolQueue(q)
|
stop := runWorkerPoolQueue(q)
|
||||||
for i := 0; i < queueSetting.Length; i++ {
|
for i := 0; i < queueSetting.Length; i++ {
|
||||||
testRecorder.Record("push:%v", i)
|
testRecorder.Record("push:%v", i)
|
||||||
|
@ -145,7 +137,7 @@ func testWorkerPoolQueuePersistence(t *testing.T, queueSetting setting.QueueSett
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
q, _ := NewWorkerPoolQueueBySetting("pr_patch_checker_test", queueSetting, testHandler, true)
|
q, _ := newWorkerPoolQueueForTest("pr_patch_checker_test", queueSetting, testHandler, true)
|
||||||
stop := runWorkerPoolQueue(q)
|
stop := runWorkerPoolQueue(q)
|
||||||
for i := 0; i < testCount; i++ {
|
for i := 0; i < testCount; i++ {
|
||||||
_ = q.Push("task-" + strconv.Itoa(i))
|
_ = q.Push("task-" + strconv.Itoa(i))
|
||||||
|
@ -169,7 +161,7 @@ func testWorkerPoolQueuePersistence(t *testing.T, queueSetting setting.QueueSett
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
q, _ := NewWorkerPoolQueueBySetting("pr_patch_checker_test", queueSetting, testHandler, true)
|
q, _ := newWorkerPoolQueueForTest("pr_patch_checker_test", queueSetting, testHandler, true)
|
||||||
stop := runWorkerPoolQueue(q)
|
stop := runWorkerPoolQueue(q)
|
||||||
assert.NoError(t, q.FlushWithContext(context.Background(), 0))
|
assert.NoError(t, q.FlushWithContext(context.Background(), 0))
|
||||||
stop()
|
stop()
|
||||||
|
@ -194,7 +186,7 @@ func TestWorkerPoolQueueActiveWorkers(t *testing.T) {
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
q, _ := NewWorkerPoolQueueBySetting("test-workpoolqueue", setting.QueueSettings{Type: "channel", BatchLength: 1, MaxWorkers: 1, Length: 100}, handler, false)
|
q, _ := newWorkerPoolQueueForTest("test-workpoolqueue", setting.QueueSettings{Type: "channel", BatchLength: 1, MaxWorkers: 1, Length: 100}, handler, false)
|
||||||
stop := runWorkerPoolQueue(q)
|
stop := runWorkerPoolQueue(q)
|
||||||
for i := 0; i < 5; i++ {
|
for i := 0; i < 5; i++ {
|
||||||
assert.NoError(t, q.Push(i))
|
assert.NoError(t, q.Push(i))
|
||||||
|
@ -210,7 +202,7 @@ func TestWorkerPoolQueueActiveWorkers(t *testing.T) {
|
||||||
assert.EqualValues(t, 1, q.GetWorkerNumber()) // there is at least one worker after the queue begins working
|
assert.EqualValues(t, 1, q.GetWorkerNumber()) // there is at least one worker after the queue begins working
|
||||||
stop()
|
stop()
|
||||||
|
|
||||||
q, _ = NewWorkerPoolQueueBySetting("test-workpoolqueue", setting.QueueSettings{Type: "channel", BatchLength: 1, MaxWorkers: 3, Length: 100}, handler, false)
|
q, _ = newWorkerPoolQueueForTest("test-workpoolqueue", setting.QueueSettings{Type: "channel", BatchLength: 1, MaxWorkers: 3, Length: 100}, handler, false)
|
||||||
stop = runWorkerPoolQueue(q)
|
stop = runWorkerPoolQueue(q)
|
||||||
for i := 0; i < 15; i++ {
|
for i := 0; i < 15; i++ {
|
||||||
assert.NoError(t, q.Push(i))
|
assert.NoError(t, q.Push(i))
|
||||||
|
@ -238,23 +230,23 @@ func TestWorkerPoolQueueShutdown(t *testing.T) {
|
||||||
if items[0] == 0 {
|
if items[0] == 0 {
|
||||||
close(handlerCalled)
|
close(handlerCalled)
|
||||||
}
|
}
|
||||||
time.Sleep(100 * time.Millisecond)
|
time.Sleep(400 * time.Millisecond)
|
||||||
return items
|
return items
|
||||||
}
|
}
|
||||||
|
|
||||||
qs := setting.QueueSettings{Type: "level", Datadir: t.TempDir() + "/queue", BatchLength: 3, MaxWorkers: 4, Length: 20}
|
qs := setting.QueueSettings{Type: "level", Datadir: t.TempDir() + "/queue", BatchLength: 3, MaxWorkers: 4, Length: 20}
|
||||||
q, _ := NewWorkerPoolQueueBySetting("test-workpoolqueue", qs, handler, false)
|
q, _ := newWorkerPoolQueueForTest("test-workpoolqueue", qs, handler, false)
|
||||||
stop := runWorkerPoolQueue(q)
|
stop := runWorkerPoolQueue(q)
|
||||||
for i := 0; i < qs.Length; i++ {
|
for i := 0; i < qs.Length; i++ {
|
||||||
assert.NoError(t, q.Push(i))
|
assert.NoError(t, q.Push(i))
|
||||||
}
|
}
|
||||||
<-handlerCalled
|
<-handlerCalled
|
||||||
time.Sleep(50 * time.Millisecond) // wait for a while to make sure all workers are active
|
time.Sleep(200 * time.Millisecond) // wait for a while to make sure all workers are active
|
||||||
assert.EqualValues(t, 4, q.GetWorkerActiveNumber())
|
assert.EqualValues(t, 4, q.GetWorkerActiveNumber())
|
||||||
stop() // stop triggers shutdown
|
stop() // stop triggers shutdown
|
||||||
assert.EqualValues(t, 0, q.GetWorkerActiveNumber())
|
assert.EqualValues(t, 0, q.GetWorkerActiveNumber())
|
||||||
|
|
||||||
// no item was ever handled, so we still get all of them again
|
// no item was ever handled, so we still get all of them again
|
||||||
q, _ = NewWorkerPoolQueueBySetting("test-workpoolqueue", qs, handler, false)
|
q, _ = newWorkerPoolQueueForTest("test-workpoolqueue", qs, handler, false)
|
||||||
assert.EqualValues(t, 20, q.GetQueueItemNumber())
|
assert.EqualValues(t, 20, q.GetQueueItemNumber())
|
||||||
}
|
}
|
||||||
|
|
|
@ -4,12 +4,13 @@
|
||||||
package admin
|
package admin
|
||||||
|
|
||||||
import (
|
import (
|
||||||
gocontext "context"
|
"runtime/pprof"
|
||||||
"sync"
|
"sync"
|
||||||
"time"
|
"time"
|
||||||
|
|
||||||
"code.gitea.io/gitea/modules/graceful"
|
"code.gitea.io/gitea/modules/graceful"
|
||||||
"code.gitea.io/gitea/modules/log"
|
"code.gitea.io/gitea/modules/log"
|
||||||
|
"code.gitea.io/gitea/modules/process"
|
||||||
"code.gitea.io/gitea/modules/queue"
|
"code.gitea.io/gitea/modules/queue"
|
||||||
"code.gitea.io/gitea/modules/setting"
|
"code.gitea.io/gitea/modules/setting"
|
||||||
)
|
)
|
||||||
|
@ -21,6 +22,7 @@ var testQueueOnce sync.Once
|
||||||
// developers could see the queue length / worker number / items number on the admin page and try to remove the items
|
// developers could see the queue length / worker number / items number on the admin page and try to remove the items
|
||||||
func initTestQueueOnce() {
|
func initTestQueueOnce() {
|
||||||
testQueueOnce.Do(func() {
|
testQueueOnce.Do(func() {
|
||||||
|
ctx, _, finished := process.GetManager().AddTypedContext(graceful.GetManager().ShutdownContext(), "TestQueue", process.SystemProcessType, false)
|
||||||
qs := setting.QueueSettings{
|
qs := setting.QueueSettings{
|
||||||
Name: "test-queue",
|
Name: "test-queue",
|
||||||
Type: "channel",
|
Type: "channel",
|
||||||
|
@ -28,7 +30,7 @@ func initTestQueueOnce() {
|
||||||
BatchLength: 2,
|
BatchLength: 2,
|
||||||
MaxWorkers: 3,
|
MaxWorkers: 3,
|
||||||
}
|
}
|
||||||
testQueue, err := queue.NewWorkerPoolQueueBySetting("test-queue", qs, func(t ...int64) (unhandled []int64) {
|
testQueue, err := queue.NewWorkerPoolQueueWithContext(ctx, "test-queue", qs, func(t ...int64) (unhandled []int64) {
|
||||||
for range t {
|
for range t {
|
||||||
select {
|
select {
|
||||||
case <-graceful.GetManager().ShutdownContext().Done():
|
case <-graceful.GetManager().ShutdownContext().Done():
|
||||||
|
@ -44,8 +46,11 @@ func initTestQueueOnce() {
|
||||||
|
|
||||||
queue.GetManager().AddManagedQueue(testQueue)
|
queue.GetManager().AddManagedQueue(testQueue)
|
||||||
testQueue.SetWorkerMaxNumber(5)
|
testQueue.SetWorkerMaxNumber(5)
|
||||||
go graceful.GetManager().RunWithShutdownFns(testQueue.Run)
|
go graceful.GetManager().RunWithCancel(testQueue)
|
||||||
go graceful.GetManager().RunWithShutdownContext(func(ctx gocontext.Context) {
|
go func() {
|
||||||
|
pprof.SetGoroutineLabels(ctx)
|
||||||
|
defer finished()
|
||||||
|
|
||||||
cnt := int64(0)
|
cnt := int64(0)
|
||||||
adding := true
|
adding := true
|
||||||
for {
|
for {
|
||||||
|
@ -67,6 +72,6 @@ func initTestQueueOnce() {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
})
|
}()
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
|
@ -5,6 +5,7 @@ package actions
|
||||||
|
|
||||||
import (
|
import (
|
||||||
"code.gitea.io/gitea/modules/graceful"
|
"code.gitea.io/gitea/modules/graceful"
|
||||||
|
"code.gitea.io/gitea/modules/log"
|
||||||
"code.gitea.io/gitea/modules/notification"
|
"code.gitea.io/gitea/modules/notification"
|
||||||
"code.gitea.io/gitea/modules/queue"
|
"code.gitea.io/gitea/modules/queue"
|
||||||
"code.gitea.io/gitea/modules/setting"
|
"code.gitea.io/gitea/modules/setting"
|
||||||
|
@ -15,8 +16,11 @@ func Init() {
|
||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
|
||||||
jobEmitterQueue = queue.CreateUniqueQueue("actions_ready_job", jobEmitterQueueHandler)
|
jobEmitterQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "actions_ready_job", jobEmitterQueueHandler)
|
||||||
go graceful.GetManager().RunWithShutdownFns(jobEmitterQueue.Run)
|
if jobEmitterQueue == nil {
|
||||||
|
log.Fatal("Unable to create actions_ready_job queue")
|
||||||
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(jobEmitterQueue)
|
||||||
|
|
||||||
notification.RegisterNotifier(NewNotifier())
|
notification.RegisterNotifier(NewNotifier())
|
||||||
}
|
}
|
||||||
|
|
|
@ -29,11 +29,11 @@ var prAutoMergeQueue *queue.WorkerPoolQueue[string]
|
||||||
|
|
||||||
// Init runs the task queue to that handles auto merges
|
// Init runs the task queue to that handles auto merges
|
||||||
func Init() error {
|
func Init() error {
|
||||||
prAutoMergeQueue = queue.CreateUniqueQueue("pr_auto_merge", handler)
|
prAutoMergeQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "pr_auto_merge", handler)
|
||||||
if prAutoMergeQueue == nil {
|
if prAutoMergeQueue == nil {
|
||||||
return fmt.Errorf("Unable to create pr_auto_merge Queue")
|
return fmt.Errorf("unable to create pr_auto_merge queue")
|
||||||
}
|
}
|
||||||
go graceful.GetManager().RunWithShutdownFns(prAutoMergeQueue.Run)
|
go graceful.GetManager().RunWithCancel(prAutoMergeQueue)
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -401,7 +401,9 @@ func NewContext(ctx context.Context) {
|
||||||
Sender = &smtpSender{}
|
Sender = &smtpSender{}
|
||||||
}
|
}
|
||||||
|
|
||||||
mailQueue = queue.CreateSimpleQueue("mail", func(items ...*Message) []*Message {
|
subjectTemplates, bodyTemplates = templates.Mailer(ctx)
|
||||||
|
|
||||||
|
mailQueue = queue.CreateSimpleQueue(graceful.GetManager().ShutdownContext(), "mail", func(items ...*Message) []*Message {
|
||||||
for _, msg := range items {
|
for _, msg := range items {
|
||||||
gomailMsg := msg.ToMessage()
|
gomailMsg := msg.ToMessage()
|
||||||
log.Trace("New e-mail sending request %s: %s", gomailMsg.GetHeader("To"), msg.Info)
|
log.Trace("New e-mail sending request %s: %s", gomailMsg.GetHeader("To"), msg.Info)
|
||||||
|
@ -413,10 +415,10 @@ func NewContext(ctx context.Context) {
|
||||||
}
|
}
|
||||||
return nil
|
return nil
|
||||||
})
|
})
|
||||||
|
if mailQueue == nil {
|
||||||
go graceful.GetManager().RunWithShutdownFns(mailQueue.Run)
|
log.Fatal("Unable to create mail queue")
|
||||||
|
}
|
||||||
subjectTemplates, bodyTemplates = templates.Mailer(ctx)
|
go graceful.GetManager().RunWithCancel(mailQueue)
|
||||||
}
|
}
|
||||||
|
|
||||||
// SendAsync send mail asynchronously
|
// SendAsync send mail asynchronously
|
||||||
|
|
|
@ -384,13 +384,13 @@ func CheckPRsForBaseBranch(baseRepo *repo_model.Repository, baseBranchName strin
|
||||||
|
|
||||||
// Init runs the task queue to test all the checking status pull requests
|
// Init runs the task queue to test all the checking status pull requests
|
||||||
func Init() error {
|
func Init() error {
|
||||||
prPatchCheckerQueue = queue.CreateUniqueQueue("pr_patch_checker", handler)
|
prPatchCheckerQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "pr_patch_checker", handler)
|
||||||
|
|
||||||
if prPatchCheckerQueue == nil {
|
if prPatchCheckerQueue == nil {
|
||||||
return fmt.Errorf("Unable to create pr_patch_checker Queue")
|
return fmt.Errorf("unable to create pr_patch_checker queue")
|
||||||
}
|
}
|
||||||
|
|
||||||
go graceful.GetManager().RunWithShutdownFns(prPatchCheckerQueue.Run)
|
go graceful.GetManager().RunWithCancel(prPatchCheckerQueue)
|
||||||
go graceful.GetManager().RunWithShutdownContext(InitializePullRequests)
|
go graceful.GetManager().RunWithShutdownContext(InitializePullRequests)
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
|
@ -5,6 +5,7 @@
|
||||||
package pull
|
package pull
|
||||||
|
|
||||||
import (
|
import (
|
||||||
|
"context"
|
||||||
"strconv"
|
"strconv"
|
||||||
"testing"
|
"testing"
|
||||||
"time"
|
"time"
|
||||||
|
@ -31,7 +32,7 @@ func TestPullRequest_AddToTaskQueue(t *testing.T) {
|
||||||
|
|
||||||
cfg, err := setting.GetQueueSettings(setting.CfgProvider, "pr_patch_checker")
|
cfg, err := setting.GetQueueSettings(setting.CfgProvider, "pr_patch_checker")
|
||||||
assert.NoError(t, err)
|
assert.NoError(t, err)
|
||||||
prPatchCheckerQueue, err = queue.NewWorkerPoolQueueBySetting("pr_patch_checker", cfg, testHandler, true)
|
prPatchCheckerQueue, err = queue.NewWorkerPoolQueueWithContext(context.Background(), "pr_patch_checker", cfg, testHandler, true)
|
||||||
assert.NoError(t, err)
|
assert.NoError(t, err)
|
||||||
|
|
||||||
pr := unittest.AssertExistsAndLoadBean(t, &issues_model.PullRequest{ID: 2})
|
pr := unittest.AssertExistsAndLoadBean(t, &issues_model.PullRequest{ID: 2})
|
||||||
|
@ -46,12 +47,7 @@ func TestPullRequest_AddToTaskQueue(t *testing.T) {
|
||||||
assert.True(t, has)
|
assert.True(t, has)
|
||||||
assert.NoError(t, err)
|
assert.NoError(t, err)
|
||||||
|
|
||||||
var queueShutdown, queueTerminate []func()
|
go prPatchCheckerQueue.Run()
|
||||||
go prPatchCheckerQueue.Run(func(shutdown func()) {
|
|
||||||
queueShutdown = append(queueShutdown, shutdown)
|
|
||||||
}, func(terminate func()) {
|
|
||||||
queueTerminate = append(queueTerminate, terminate)
|
|
||||||
})
|
|
||||||
|
|
||||||
select {
|
select {
|
||||||
case id := <-idChan:
|
case id := <-idChan:
|
||||||
|
@ -67,12 +63,6 @@ func TestPullRequest_AddToTaskQueue(t *testing.T) {
|
||||||
pr = unittest.AssertExistsAndLoadBean(t, &issues_model.PullRequest{ID: 2})
|
pr = unittest.AssertExistsAndLoadBean(t, &issues_model.PullRequest{ID: 2})
|
||||||
assert.Equal(t, issues_model.PullRequestStatusChecking, pr.Status)
|
assert.Equal(t, issues_model.PullRequestStatusChecking, pr.Status)
|
||||||
|
|
||||||
for _, callback := range queueShutdown {
|
prPatchCheckerQueue.ShutdownWait(5 * time.Second)
|
||||||
callback()
|
|
||||||
}
|
|
||||||
for _, callback := range queueTerminate {
|
|
||||||
callback()
|
|
||||||
}
|
|
||||||
|
|
||||||
prPatchCheckerQueue = nil
|
prPatchCheckerQueue = nil
|
||||||
}
|
}
|
||||||
|
|
|
@ -297,7 +297,7 @@ func ArchiveRepository(request *ArchiveRequest) (*repo_model.RepoArchiver, error
|
||||||
|
|
||||||
var archiverQueue *queue.WorkerPoolQueue[*ArchiveRequest]
|
var archiverQueue *queue.WorkerPoolQueue[*ArchiveRequest]
|
||||||
|
|
||||||
// Init initlize archive
|
// Init initializes archiver
|
||||||
func Init() error {
|
func Init() error {
|
||||||
handler := func(items ...*ArchiveRequest) []*ArchiveRequest {
|
handler := func(items ...*ArchiveRequest) []*ArchiveRequest {
|
||||||
for _, archiveReq := range items {
|
for _, archiveReq := range items {
|
||||||
|
@ -309,12 +309,11 @@ func Init() error {
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
archiverQueue = queue.CreateUniqueQueue("repo-archive", handler)
|
archiverQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "repo-archive", handler)
|
||||||
if archiverQueue == nil {
|
if archiverQueue == nil {
|
||||||
return errors.New("unable to create codes indexer queue")
|
return errors.New("unable to create repo-archive queue")
|
||||||
}
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(archiverQueue)
|
||||||
go graceful.GetManager().RunWithShutdownFns(archiverQueue.Run)
|
|
||||||
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
|
@ -42,12 +42,11 @@ func handler(items ...[]*repo_module.PushUpdateOptions) [][]*repo_module.PushUpd
|
||||||
}
|
}
|
||||||
|
|
||||||
func initPushQueue() error {
|
func initPushQueue() error {
|
||||||
pushQueue = queue.CreateSimpleQueue("push_update", handler)
|
pushQueue = queue.CreateSimpleQueue(graceful.GetManager().ShutdownContext(), "push_update", handler)
|
||||||
if pushQueue == nil {
|
if pushQueue == nil {
|
||||||
return errors.New("unable to create push_update Queue")
|
return errors.New("unable to create push_update queue")
|
||||||
}
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(pushQueue)
|
||||||
go graceful.GetManager().RunWithShutdownFns(pushQueue.Run)
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -37,14 +37,11 @@ func Run(t *admin_model.Task) error {
|
||||||
|
|
||||||
// Init will start the service to get all unfinished tasks and run them
|
// Init will start the service to get all unfinished tasks and run them
|
||||||
func Init() error {
|
func Init() error {
|
||||||
taskQueue = queue.CreateSimpleQueue("task", handler)
|
taskQueue = queue.CreateSimpleQueue(graceful.GetManager().ShutdownContext(), "task", handler)
|
||||||
|
|
||||||
if taskQueue == nil {
|
if taskQueue == nil {
|
||||||
return fmt.Errorf("Unable to create Task Queue")
|
return fmt.Errorf("unable to create task queue")
|
||||||
}
|
}
|
||||||
|
go graceful.GetManager().RunWithCancel(taskQueue)
|
||||||
go graceful.GetManager().RunWithShutdownFns(taskQueue.Run)
|
|
||||||
|
|
||||||
return nil
|
return nil
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -283,11 +283,11 @@ func Init() error {
|
||||||
},
|
},
|
||||||
}
|
}
|
||||||
|
|
||||||
hookQueue = queue.CreateUniqueQueue("webhook_sender", handler)
|
hookQueue = queue.CreateUniqueQueue(graceful.GetManager().ShutdownContext(), "webhook_sender", handler)
|
||||||
if hookQueue == nil {
|
if hookQueue == nil {
|
||||||
return fmt.Errorf("Unable to create webhook_sender Queue")
|
return fmt.Errorf("unable to create webhook_sender queue")
|
||||||
}
|
}
|
||||||
go graceful.GetManager().RunWithShutdownFns(hookQueue.Run)
|
go graceful.GetManager().RunWithCancel(hookQueue)
|
||||||
|
|
||||||
go graceful.GetManager().RunWithShutdownContext(populateWebhookSendingQueue)
|
go graceful.GetManager().RunWithShutdownContext(populateWebhookSendingQueue)
|
||||||
|
|
||||||
|
|
Loading…
Reference in New Issue