2020-01-03 10:13:16 +08:00
|
|
|
// Copyright 2020 Kentaro Hibino. All rights reserved.
|
|
|
|
// Use of this source code is governed by a MIT license
|
|
|
|
// that can be found in the LICENSE file.
|
|
|
|
|
2019-11-24 07:22:43 +08:00
|
|
|
package asynq
|
|
|
|
|
|
|
|
import (
|
2020-02-11 23:06:52 +08:00
|
|
|
"context"
|
2020-04-13 02:00:45 +08:00
|
|
|
"errors"
|
2019-11-27 22:33:04 +08:00
|
|
|
"fmt"
|
2019-12-30 09:43:19 +08:00
|
|
|
"math"
|
|
|
|
"math/rand"
|
2019-11-24 07:44:42 +08:00
|
|
|
"os"
|
2019-11-24 07:22:43 +08:00
|
|
|
"sync"
|
|
|
|
"time"
|
2019-12-04 13:01:26 +08:00
|
|
|
|
2020-01-06 23:15:59 +08:00
|
|
|
"github.com/hibiken/asynq/internal/base"
|
2020-03-09 22:11:16 +08:00
|
|
|
"github.com/hibiken/asynq/internal/log"
|
2019-12-04 13:01:26 +08:00
|
|
|
"github.com/hibiken/asynq/internal/rdb"
|
2019-11-24 07:22:43 +08:00
|
|
|
)
|
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
// Server is responsible for managing the background-task processing.
|
2019-12-07 14:00:09 +08:00
|
|
|
//
|
2020-04-12 23:16:42 +08:00
|
|
|
// Server pulls tasks off queues and process them.
|
|
|
|
// If the processing of a task is unsuccessful, server will
|
2020-01-17 11:50:45 +08:00
|
|
|
// schedule it for a retry until either the task gets processed successfully
|
|
|
|
// or it exhausts its max retry count.
|
2019-12-07 14:00:09 +08:00
|
|
|
//
|
|
|
|
// Once a task exhausts its retries, it will be moved to the "dead" queue and
|
|
|
|
// will be kept in the queue for some time until a certain condition is met
|
|
|
|
// (e.g., queue size reaches a certain limit, or the task has been in the
|
|
|
|
// queue for a certain amount of time).
|
2020-04-12 23:16:42 +08:00
|
|
|
type Server struct {
|
2020-04-13 02:41:50 +08:00
|
|
|
ss *base.ServerState
|
2020-02-16 15:14:30 +08:00
|
|
|
|
2020-03-12 22:31:10 +08:00
|
|
|
logger Logger
|
2020-03-09 22:11:16 +08:00
|
|
|
|
2020-04-13 02:41:50 +08:00
|
|
|
rdb *rdb.RDB
|
|
|
|
|
|
|
|
// wait group to wait for all goroutines to finish.
|
|
|
|
wg sync.WaitGroup
|
2020-01-31 22:48:58 +08:00
|
|
|
scheduler *scheduler
|
|
|
|
processor *processor
|
|
|
|
syncer *syncer
|
|
|
|
heartbeater *heartbeater
|
2020-02-13 09:12:09 +08:00
|
|
|
subscriber *subscriber
|
2019-11-24 07:22:43 +08:00
|
|
|
}
|
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
// Config specifies the server's background-task processing behavior.
|
2019-12-30 08:55:51 +08:00
|
|
|
type Config struct {
|
2020-01-17 11:50:45 +08:00
|
|
|
// Maximum number of concurrent processing of tasks.
|
2019-12-30 08:55:51 +08:00
|
|
|
//
|
2020-04-12 23:16:42 +08:00
|
|
|
// If set to a zero or negative value, NewServer will overwrite the value to one.
|
2019-12-30 08:55:51 +08:00
|
|
|
Concurrency int
|
|
|
|
|
2019-12-30 09:43:19 +08:00
|
|
|
// Function to calculate retry delay for a failed task.
|
|
|
|
//
|
|
|
|
// By default, it uses exponential backoff algorithm to calculate the delay.
|
|
|
|
//
|
|
|
|
// n is the number of times the task has been retried.
|
|
|
|
// e is the error returned by the task handler.
|
2020-01-05 05:13:46 +08:00
|
|
|
// t is the task in question.
|
2019-12-30 09:43:19 +08:00
|
|
|
RetryDelayFunc func(n int, e error, t *Task) time.Duration
|
2020-01-06 23:15:59 +08:00
|
|
|
|
2020-02-13 14:23:25 +08:00
|
|
|
// List of queues to process with given priority value. Keys are the names of the
|
|
|
|
// queues and values are associated priority value.
|
2020-01-06 23:15:59 +08:00
|
|
|
//
|
2020-04-12 23:16:42 +08:00
|
|
|
// If set to nil or not specified, the server will process only the "default" queue.
|
2020-01-06 23:15:59 +08:00
|
|
|
//
|
2020-01-08 13:53:38 +08:00
|
|
|
// Priority is treated as follows to avoid starving low priority queues.
|
|
|
|
//
|
2020-01-06 23:15:59 +08:00
|
|
|
// Example:
|
2020-02-13 14:23:25 +08:00
|
|
|
// Queues: map[string]int{
|
2020-01-06 23:15:59 +08:00
|
|
|
// "critical": 6,
|
|
|
|
// "default": 3,
|
|
|
|
// "low": 1,
|
|
|
|
// }
|
2020-01-08 13:53:38 +08:00
|
|
|
// With the above config and given that all queues are not empty, the tasks
|
2020-01-06 23:15:59 +08:00
|
|
|
// in "critical", "default", "low" should be processed 60%, 30%, 10% of
|
|
|
|
// the time respectively.
|
2020-02-13 14:23:25 +08:00
|
|
|
//
|
|
|
|
// If a queue has a zero or negative priority value, the queue will be ignored.
|
|
|
|
Queues map[string]int
|
2020-01-12 23:46:51 +08:00
|
|
|
|
|
|
|
// StrictPriority indicates whether the queue priority should be treated strictly.
|
|
|
|
//
|
|
|
|
// If set to true, tasks in the queue with the highest priority is processed first.
|
|
|
|
// The tasks in lower priority queues are processed only when those queues with
|
|
|
|
// higher priorities are empty.
|
|
|
|
StrictPriority bool
|
2020-02-28 23:26:46 +08:00
|
|
|
|
|
|
|
// ErrorHandler handles errors returned by the task handler.
|
|
|
|
//
|
|
|
|
// HandleError is invoked only if the task handler returns a non-nil error.
|
|
|
|
//
|
|
|
|
// Example:
|
|
|
|
// func reportError(task *asynq.Task, err error, retried, maxRetry int) {
|
|
|
|
// if retried >= maxRetry {
|
|
|
|
// err = fmt.Errorf("retry exhausted for task %s: %w", task.Type, err)
|
|
|
|
// }
|
|
|
|
// errorReportingService.Notify(err)
|
|
|
|
// })
|
|
|
|
//
|
|
|
|
// ErrorHandler: asynq.ErrorHandlerFunc(reportError)
|
|
|
|
ErrorHandler ErrorHandler
|
2020-03-12 22:31:10 +08:00
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
// Logger specifies the logger used by the server instance.
|
2020-03-12 22:31:10 +08:00
|
|
|
//
|
|
|
|
// If unset, default logger is used.
|
|
|
|
Logger Logger
|
2020-02-28 23:26:46 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
// An ErrorHandler handles errors returned by the task handler.
|
|
|
|
type ErrorHandler interface {
|
|
|
|
HandleError(task *Task, err error, retried, maxRetry int)
|
|
|
|
}
|
|
|
|
|
|
|
|
// The ErrorHandlerFunc type is an adapter to allow the use of ordinary functions as a ErrorHandler.
|
|
|
|
// If f is a function with the appropriate signature, ErrorHandlerFunc(f) is a ErrorHandler that calls f.
|
|
|
|
type ErrorHandlerFunc func(task *Task, err error, retried, maxRetry int)
|
|
|
|
|
|
|
|
// HandleError calls fn(task, err, retried, maxRetry)
|
|
|
|
func (fn ErrorHandlerFunc) HandleError(task *Task, err error, retried, maxRetry int) {
|
|
|
|
fn(task, err, retried, maxRetry)
|
2019-12-30 09:43:19 +08:00
|
|
|
}
|
|
|
|
|
2020-03-12 22:31:10 +08:00
|
|
|
// Logger implements logging with various log levels.
|
|
|
|
type Logger interface {
|
|
|
|
// Debug logs a message at Debug level.
|
|
|
|
Debug(format string, args ...interface{})
|
|
|
|
|
|
|
|
// Info logs a message at Info level.
|
|
|
|
Info(format string, args ...interface{})
|
|
|
|
|
|
|
|
// Warn logs a message at Warning level.
|
|
|
|
Warn(format string, args ...interface{})
|
|
|
|
|
|
|
|
// Error logs a message at Error level.
|
|
|
|
Error(format string, args ...interface{})
|
|
|
|
|
|
|
|
// Fatal logs a message at Fatal level
|
|
|
|
// and process will exit with status set to 1.
|
|
|
|
Fatal(format string, args ...interface{})
|
|
|
|
}
|
|
|
|
|
2019-12-30 09:43:19 +08:00
|
|
|
// Formula taken from https://github.com/mperham/sidekiq.
|
|
|
|
func defaultDelayFunc(n int, e error, t *Task) time.Duration {
|
|
|
|
r := rand.New(rand.NewSource(time.Now().UnixNano()))
|
|
|
|
s := int(math.Pow(float64(n), 4)) + 15 + (r.Intn(30) * (n + 1))
|
|
|
|
return time.Duration(s) * time.Second
|
2019-12-30 08:55:51 +08:00
|
|
|
}
|
|
|
|
|
2020-02-13 14:23:25 +08:00
|
|
|
var defaultQueueConfig = map[string]int{
|
2020-01-06 23:15:59 +08:00
|
|
|
base.DefaultQueueName: 1,
|
|
|
|
}
|
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
// NewServer returns a new Server given a redis connection option
|
2019-12-30 08:55:51 +08:00
|
|
|
// and background processing configuration.
|
2020-04-12 23:16:42 +08:00
|
|
|
func NewServer(r RedisConnOpt, cfg Config) *Server {
|
2019-12-30 08:55:51 +08:00
|
|
|
n := cfg.Concurrency
|
|
|
|
if n < 1 {
|
|
|
|
n = 1
|
|
|
|
}
|
2019-12-30 09:43:19 +08:00
|
|
|
delayFunc := cfg.RetryDelayFunc
|
|
|
|
if delayFunc == nil {
|
|
|
|
delayFunc = defaultDelayFunc
|
|
|
|
}
|
2020-02-13 14:23:25 +08:00
|
|
|
queues := make(map[string]int)
|
|
|
|
for qname, p := range cfg.Queues {
|
|
|
|
if p > 0 {
|
|
|
|
queues[qname] = p
|
|
|
|
}
|
|
|
|
}
|
|
|
|
if len(queues) == 0 {
|
2020-01-06 23:15:59 +08:00
|
|
|
queues = defaultQueueConfig
|
|
|
|
}
|
2020-03-12 22:31:10 +08:00
|
|
|
logger := cfg.Logger
|
|
|
|
if logger == nil {
|
|
|
|
logger = log.NewLogger(os.Stderr)
|
|
|
|
}
|
2020-01-14 23:26:41 +08:00
|
|
|
|
2020-01-31 22:48:58 +08:00
|
|
|
host, err := os.Hostname()
|
|
|
|
if err != nil {
|
|
|
|
host = "unknown-host"
|
|
|
|
}
|
|
|
|
pid := os.Getpid()
|
|
|
|
|
|
|
|
rdb := rdb.NewRDB(createRedisClient(r))
|
2020-04-13 02:41:50 +08:00
|
|
|
ss := base.NewServerState(host, pid, n, queues, cfg.StrictPriority)
|
2020-02-18 22:57:39 +08:00
|
|
|
syncCh := make(chan *syncRequest)
|
|
|
|
cancels := base.NewCancelations()
|
2020-03-09 22:11:16 +08:00
|
|
|
syncer := newSyncer(logger, syncCh, 5*time.Second)
|
2020-04-13 02:41:50 +08:00
|
|
|
heartbeater := newHeartbeater(logger, rdb, ss, 5*time.Second)
|
2020-03-09 22:11:16 +08:00
|
|
|
scheduler := newScheduler(logger, rdb, 5*time.Second, queues)
|
2020-04-13 02:41:50 +08:00
|
|
|
processor := newProcessor(logger, rdb, ss, delayFunc, syncCh, cancels, cfg.ErrorHandler)
|
2020-03-09 22:11:16 +08:00
|
|
|
subscriber := newSubscriber(logger, rdb, cancels)
|
2020-04-12 23:16:42 +08:00
|
|
|
return &Server{
|
2020-04-13 02:41:50 +08:00
|
|
|
ss: ss,
|
2020-03-09 22:11:16 +08:00
|
|
|
logger: logger,
|
2020-01-31 22:48:58 +08:00
|
|
|
rdb: rdb,
|
|
|
|
scheduler: scheduler,
|
|
|
|
processor: processor,
|
|
|
|
syncer: syncer,
|
|
|
|
heartbeater: heartbeater,
|
2020-02-13 09:12:09 +08:00
|
|
|
subscriber: subscriber,
|
2019-11-24 07:22:43 +08:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-02-28 23:26:46 +08:00
|
|
|
// A Handler processes tasks.
|
2019-12-03 12:42:21 +08:00
|
|
|
//
|
|
|
|
// ProcessTask should return nil if the processing of a task
|
|
|
|
// is successful.
|
|
|
|
//
|
|
|
|
// If ProcessTask return a non-nil error or panics, the task
|
|
|
|
// will be retried after delay.
|
|
|
|
type Handler interface {
|
2020-02-11 23:06:52 +08:00
|
|
|
ProcessTask(context.Context, *Task) error
|
2019-12-03 12:42:21 +08:00
|
|
|
}
|
|
|
|
|
|
|
|
// The HandlerFunc type is an adapter to allow the use of
|
|
|
|
// ordinary functions as a Handler. If f is a function
|
|
|
|
// with the appropriate signature, HandlerFunc(f) is a
|
|
|
|
// Handler that calls f.
|
2020-02-11 23:06:52 +08:00
|
|
|
type HandlerFunc func(context.Context, *Task) error
|
2019-12-03 12:42:21 +08:00
|
|
|
|
2020-02-11 23:06:52 +08:00
|
|
|
// ProcessTask calls fn(ctx, task)
|
|
|
|
func (fn HandlerFunc) ProcessTask(ctx context.Context, task *Task) error {
|
|
|
|
return fn(ctx, task)
|
2019-12-03 12:42:21 +08:00
|
|
|
}
|
2019-11-24 07:22:43 +08:00
|
|
|
|
2020-04-13 02:00:45 +08:00
|
|
|
// ErrServerStopped indicates that the operation is now illegal because of the server being stopped.
|
|
|
|
var ErrServerStopped = errors.New("asynq: the server has been stopped")
|
|
|
|
|
2019-11-24 07:44:42 +08:00
|
|
|
// Run starts the background-task processing and blocks until
|
|
|
|
// an os signal to exit the program is received. Once it receives
|
|
|
|
// a signal, it gracefully shuts down all pending workers and other
|
|
|
|
// goroutines to process the tasks.
|
2020-04-13 02:00:45 +08:00
|
|
|
func (srv *Server) Run(handler Handler) error {
|
|
|
|
if err := srv.Start(handler); err != nil {
|
|
|
|
return err
|
2020-03-12 22:31:10 +08:00
|
|
|
}
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.waitForSignals()
|
2020-04-13 02:00:45 +08:00
|
|
|
srv.Stop()
|
|
|
|
return nil
|
2019-11-24 07:44:42 +08:00
|
|
|
}
|
|
|
|
|
2020-04-13 02:00:45 +08:00
|
|
|
// Starts the background-task processing.
|
|
|
|
// TODO: doc
|
|
|
|
func (srv *Server) Start(handler Handler) error {
|
2020-04-13 02:41:50 +08:00
|
|
|
switch srv.ss.Status() {
|
|
|
|
case base.StatusRunning:
|
2020-04-13 02:00:45 +08:00
|
|
|
return fmt.Errorf("asynq: the server is already running")
|
2020-04-13 02:41:50 +08:00
|
|
|
case base.StatusStopped:
|
2020-04-13 02:00:45 +08:00
|
|
|
return ErrServerStopped
|
2019-11-24 07:22:43 +08:00
|
|
|
}
|
2020-04-13 02:41:50 +08:00
|
|
|
srv.ss.SetStatus(base.StatusRunning)
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.processor.handler = handler
|
2019-11-24 07:22:43 +08:00
|
|
|
|
2020-04-13 02:00:45 +08:00
|
|
|
type prefixLogger interface {
|
|
|
|
SetPrefix(prefix string)
|
|
|
|
}
|
|
|
|
// If logger supports setting prefix, then set prefix for log output.
|
|
|
|
if l, ok := srv.logger.(prefixLogger); ok {
|
|
|
|
l.SetPrefix(fmt.Sprintf("asynq: pid=%d ", os.Getpid()))
|
|
|
|
}
|
|
|
|
srv.logger.Info("Starting processing")
|
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.heartbeater.start(&srv.wg)
|
|
|
|
srv.subscriber.start(&srv.wg)
|
|
|
|
srv.syncer.start(&srv.wg)
|
|
|
|
srv.scheduler.start(&srv.wg)
|
|
|
|
srv.processor.start(&srv.wg)
|
2020-04-13 02:00:45 +08:00
|
|
|
return nil
|
2019-11-24 07:22:43 +08:00
|
|
|
}
|
|
|
|
|
2020-04-13 02:00:45 +08:00
|
|
|
// Stops the background-task processing.
|
|
|
|
// TODO: do we need to return error?
|
|
|
|
func (srv *Server) Stop() {
|
2020-04-13 02:41:50 +08:00
|
|
|
if srv.ss.Status() != base.StatusRunning {
|
2020-04-13 02:00:45 +08:00
|
|
|
// server is not running, do nothing and return.
|
2019-11-24 07:22:43 +08:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2020-04-13 02:00:45 +08:00
|
|
|
fmt.Println() // print newline for prettier log.
|
|
|
|
srv.logger.Info("Starting graceful shutdown")
|
2020-02-17 06:42:21 +08:00
|
|
|
// Note: The order of termination is important.
|
|
|
|
// Sender goroutines should be terminated before the receiver goroutines.
|
2020-02-18 22:57:39 +08:00
|
|
|
// processor -> syncer (via syncCh)
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.scheduler.terminate()
|
|
|
|
srv.processor.terminate()
|
|
|
|
srv.syncer.terminate()
|
|
|
|
srv.subscriber.terminate()
|
|
|
|
srv.heartbeater.terminate()
|
2019-11-24 09:09:57 +08:00
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.wg.Wait()
|
2020-02-16 15:14:30 +08:00
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.rdb.Close()
|
2020-04-13 02:41:50 +08:00
|
|
|
srv.ss.SetStatus(base.StatusStopped)
|
2020-01-21 23:17:41 +08:00
|
|
|
|
2020-04-12 23:16:42 +08:00
|
|
|
srv.logger.Info("Bye!")
|
2019-11-24 07:22:43 +08:00
|
|
|
}
|
2020-04-13 02:00:45 +08:00
|
|
|
|
|
|
|
// Quiet signals server to stop processing new tasks.
|
|
|
|
// TODO: doc
|
|
|
|
func (srv *Server) Quiet() {
|
|
|
|
srv.processor.stop()
|
2020-04-13 02:41:50 +08:00
|
|
|
srv.ss.SetStatus(base.StatusQuiet)
|
2020-04-13 02:00:45 +08:00
|
|
|
}
|