Scheduler

In distributed applications, it is often necessary to schedule messages for deferred execution—whether for implementing delayed workflows, retry mechanisms, or time-based business processes. Brighter provides built-in scheduling capabilities to handle these scenarios.

Overview

Brighter's scheduling support allows you to:

  • Defer message delivery to a specific time or after a delay

  • Schedule commands and events for future execution

  • Implement retry with delay for transient failures

  • Build time-based workflows and business processes

Scheduling integrates seamlessly with Brighter's messaging infrastructure, supporting both in-process handlers and external message brokers.

Use Cases

Common scenarios for message scheduling include:

  • Delayed Notifications: Send reminder emails after a delay (e.g., "Complete your registration")

  • Retry with Backoff: Retry failed operations with exponential backoff

  • Time-Based Workflows: Execute business processes at specific times (e.g., "End of day reports")

  • Rate Limiting: Spread message processing over time to avoid overwhelming downstream systems

  • Grace Periods: Defer actions to allow for cancellation (e.g., "Cancel order within 30 minutes")

  • Scheduled Jobs: Trigger recurring or one-time tasks at predetermined times

Scheduling Methods

The IAmACommandProcessor interface provides methods for scheduling delayed messages:

public interface IAmACommandProcessor
{
    Task<string> SendAsync<T>(T command, DateTimeOffset at, CancellationToken cancellationToken = default) where T : class, IRequest;
    Task<string> SendAsync<T>(T command, TimeSpan delay, CancellationToken cancellationToken = default) where T : class, IRequest;
    Task<string> PublishAsync<T>(T @event, DateTimeOffset at, CancellationToken cancellationToken = default) where T : class, IRequest;
    Task<string> PublishAsync<T>(T @event, TimeSpan delay, CancellationToken cancellationToken = default) where T : class, IRequest;
    Task<string> PostAsync<T>(T request, DateTimeOffset at, CancellationToken cancellationToken = default) where T : class, IRequest;
    Task<string> PostAsync<T>(T request, TimeSpan delay, CancellationToken cancellationToken = default) where T : class, IRequest;
}

Method Parameters

DateTimeOffset at

Specifies the absolute time when the message should be delivered:

// Schedule for specific date and time
var schedulerId = await commandProcessor.SendAsync(
    new ProcessOrderCommand { OrderId = orderId },
    at: new DateTimeOffset(2025, 1, 15, 14, 30, 0, TimeSpan.Zero)
);

// Schedule for 1 hour from now
var schedulerId = await commandProcessor.SendAsync(
    new SendReminderCommand { UserId = userId },
    at: DateTimeOffset.UtcNow.AddHours(1)
);

TimeSpan delay

Specifies a relative delay from the current time:

// Schedule for 30 minutes from now
var schedulerId = await commandProcessor.SendAsync(
    new ProcessPaymentCommand { TransactionId = txId },
    delay: TimeSpan.FromMinutes(30)
);

// Schedule for 5 seconds from now (useful for retry)
var schedulerId = commandProcessor.Send(
    new RetryOperationCommand { AttemptNumber = 2 },
    delay: TimeSpan.FromSeconds(5)
);

Return Value: Scheduler ID

All scheduling methods return a string representing the scheduler ID. This ID can be used to:

  • Cancel a scheduled message before it executes

  • Reschedule a message to a different time (cancel + schedule new)

  • Track scheduled messages in your application

// Save the scheduler ID for later use
string schedulerId = await commandProcessor.SendAsync(
    new CancelableOperationCommand { OperationId = opId },
    delay: TimeSpan.FromMinutes(30)
);

// Later, cancel the scheduled message if needed
await scheduler.CancelAsync(schedulerId);

Note: The ability to cancel/reschedule depends on your chosen scheduler implementation.

How Scheduling Works Internally

When you call a scheduling method on the Command Processor, Brighter internally creates special scheduling messages that trigger your actual message at the specified time.

Internal Message Types

Brighter uses two internal message types for scheduling:

  1. FireSchedulerMessage: Used when scheduling messages to external brokers (with Post methods)

  2. FireSchedulerRequest: Used when scheduling in-process commands/events (with Send/Publish methods)

Scheduling Flow

Your Application

CommandProcessor.SendAsync(command, delay)

[Creates FireSchedulerRequest with your command]

Scheduler (e.g., Hangfire, Quartz)

[Waits for specified delay/time]

Scheduler triggers FireSchedulerRequest

CommandProcessor dispatches your original command

Your Handler executes

Configuration

To use scheduling, you need to configure a scheduler when setting up Brighter:

services.AddBrighter(options => { ... })
    .UseScheduler(scheduler: new HangfireMessageSchedulerFactory(
        connectionString: Configuration.GetConnectionString("Hangfire")
    ))
    .AutoFromAssemblies();

Native Transport Delay Support

Some message transports have native support for message delay, eliminating the need for an external scheduler in certain scenarios.

Transports with Native Delay Support

Transport
Native Delay Support
Max Delay
Notes

RabbitMQ

Yes

Unlimited

Azure Service Bus

Yes

Unlimited

Uses ScheduledEnqueueTimeUtc property

AWS SQS

Limited

15 minutes

Native delay only up to 15 minutes

AWS SNS

No

N/A

Requires scheduler

Kafka

No

N/A

Requires scheduler

Redis

No

N/A

Requires scheduler

When to Use Native Transport Delay

Use native transport delay when:

  • Your transport supports it (RabbitMQ, Azure Service Bus)

  • Delays are within transport limits (e.g., <15 min for SQS)

  • You don't need to cancel/reschedule messages

  • You want to minimize infrastructure dependencies

Use an external scheduler when:

  • Your transport doesn't support native delay

  • You need delays beyond transport limits (e.g., >15 min on SQS)

  • You need to cancel or reschedule messages

  • You need centralized scheduling management

Requeue with Delay

Requeue with Delay is a special feature that allows handlers to defer message processing when encountering transient failures.

How It Works

When your handler encounters a transient error (e.g., database temporarily unavailable), you can throw a DeferMessageAction exception to requeue the message with a delay:

public class ProcessOrderHandlerAsync : RequestHandlerAsync<ProcessOrderCommand>
{
    public override async Task<ProcessOrderCommand> HandleAsync(
        ProcessOrderCommand command,
        CancellationToken cancellationToken = default)
    {
        try
        {
            await _orderService.ProcessAsync(command.OrderId, cancellationToken);
            return await base.HandleAsync(command, cancellationToken);
        }
        catch (DatabaseUnavailableException ex)
        {
            // Requeue with delay to give database time to recover
            throw new DeferMessageAction();
        }
    }
}

Configuration

Configure requeue delay in your subscription:

var subscription = new Subscription<ProcessOrderCommand>(
    new SubscriptionName("order.processor"),
    channelName: new ChannelName("orders"),
    routingKey: new RoutingKey("order.process"),
    messagePumpType: MessagePumpType.Proactor,
    requeueCount: 3,                        // Retry up to 3 times
    requeueDelayInMilliseconds: 5000,       // Wait 5 seconds between retries
    timeOut: TimeSpan.FromMilliseconds(200)
);

Transport-Specific Behavior

Transports with Native Delay (RabbitMQ, Azure Service Bus):

  • Uses native transport delay mechanism

  • No external scheduler required

  • Message requeued directly on the broker

Transports without Native Delay (Kafka, AWS SNS, etc.):

  • Requires an external scheduler (Quartz, Hangfire, etc.)

  • Message is scheduled via the configured scheduler

  • Falls back to immediate requeue if no scheduler configured

Choosing a Scheduler

Brighter supports multiple scheduler implementations. Your choice depends on your deployment environment and requirements.

Scheduler Comparison

Scheduler
Production Use
Persistence
Cancellation
Reschedule
Cloud Native
Best For

Quartz.NET

Recommended

Database

Yes

Yes

No

General production use

Hangfire

Recommended

Database

Yes

Yes

No

.NET applications with dashboard

AWS Scheduler

Recommended

AWS

Limited

Limited

Yes

AWS deployments

Azure Service Bus

Recommended

Azure

No

No

Yes

Azure deployments

InMemory

Dev/Test Only

None

Yes

Yes

No

Testing, development

Scheduler Recommendations

For Production

Quartz.NET - Best for general production use:

  • Mature, battle-tested scheduling library

  • Supports persistent job stores (SQL, MongoDB, etc.)

  • Distributed scheduling with clustering

  • Full cancellation and reschedule support

Hangfire - Best for .NET applications needing a dashboard:

  • Easy setup and configuration

  • Built-in web dashboard for monitoring

  • Persistent job storage (SQL Server, PostgreSQL, Redis, etc.)

  • Background job processing beyond scheduling

  • Note: Brighter.Hangfire assembly is NOT strong-named due to Hangfire limitations

For Cloud Providers

AWS Scheduler - Best for AWS deployments:

  • Native AWS service (EventBridge Scheduler)

  • No infrastructure to manage

  • Direct integration with SNS/SQS

  • IAM-based security

  • Limited cancellation/reschedule support

Azure Service Bus Scheduler - Best for Azure deployments:

  • Built into Azure Service Bus

  • No additional infrastructure

  • Native message delay support

  • No direct cancellation support (must use separate fire scheduler topic/queue)

For Development and Testing

InMemory Scheduler - Only for dev/test environments:

  • No external dependencies

  • Fast and simple for unit tests

  • Supports cancellation and reschedule

  • NOT durable - crashes lose all scheduled messages

  • NOT for production unless data loss is acceptable

Decision Guide

┌─────────────────────────────────────────┐
│  Are you deploying to AWS?              │
└──────────────┬──────────────────────────┘
               │ Yes → AWS Scheduler

               │ No

┌─────────────────────────────────────────┐
│  Are you deploying to Azure?            │
└──────────────┬──────────────────────────┘
               │ Yes → Azure Service Bus Scheduler

               │ No

┌─────────────────────────────────────────┐
│  Do you need a management dashboard?    │
└──────────────┬──────────────────────────┘
               │ Yes → Hangfire

               │ No → Quartz.NET

┌─────────────────────────────────────────┐
│  Testing/Development only?              │
└──────────────┬──────────────────────────┘
               │ Yes → InMemory Scheduler

               │ No → Choose Quartz or Hangfire

Code Examples

Basic Scheduling with DateTimeOffset

Schedule a command for a specific absolute time:

public class OrderService
{
    private readonly IAmACommandProcessor _commandProcessor;

    public async Task CreateOrder(Order order)
    {
        // Save order
        await _repository.SaveAsync(order);

        // Schedule order processing for tomorrow at 9 AM
        var processTime = DateTime.UtcNow.Date.AddDays(1).AddHours(9);
        var schedulerId = await _commandProcessor.SendAsync(
            new ProcessOrderCommand { OrderId = order.Id },
            at: new DateTimeOffset(processTime)
        );

        // Store scheduler ID for potential cancellation
        order.ProcessSchedulerId = schedulerId;
    }
}

Basic Scheduling with TimeSpan

Schedule a command with a relative delay:

public class RegistrationService
{
    private readonly IAmACommandProcessor _commandProcessor;

    public async Task RegisterUser(User user)
    {
        // Create user account
        await _repository.SaveAsync(user);

        // Send welcome email immediately
        await _commandProcessor.SendAsync(new SendWelcomeEmailCommand { UserId = user.Id });

        // Schedule reminder email for 24 hours later
        await _commandProcessor.SendAsync(
            new SendReminderEmailCommand { UserId = user.Id },
            delay: TimeSpan.FromHours(24)
        );
    }
}

Scheduling with Post for External Bus

Schedule a message to an external broker:

public class NotificationService
{
    private readonly IAmACommandProcessor _commandProcessor;

    public async Task ScheduleNotification(NotificationRequest request)
    {
        // Schedule notification to be sent via external bus
        var schedulerId = await _commandProcessor.PostAsync(
            new NotificationEvent
            {
                UserId = request.UserId,
                Message = request.Message
            },
            delay: request.Delay
        );

        // Return scheduler ID for tracking
        return schedulerId;
    }
}

Cancelling a Scheduled Message

Cancel a previously scheduled message:

public class OrderService
{
    private readonly IMessageScheduler _scheduler;

    public async Task CancelOrder(Guid orderId)
    {
        var order = await _repository.GetAsync(orderId);

        // Cancel the scheduled order processing
        if (!string.IsNullOrEmpty(order.ProcessSchedulerId))
        {
            await _scheduler.CancelAsync(order.ProcessSchedulerId);
        }

        // Mark order as cancelled
        order.Status = OrderStatus.Cancelled;
        await _repository.UpdateAsync(order);
    }
}

Note: Cancellation support depends on your scheduler implementation. AWS Scheduler and Azure Service Bus Scheduler have limited or no cancellation support.

Retry with Exponential Backoff

Implement retry logic with increasing delays:

public class RetryService
{
    private readonly IAmACommandProcessor _commandProcessor;

    public async Task RetryWithBackoff(OperationCommand command, int attemptNumber)
    {
        // Calculate exponential backoff delay
        var delaySeconds = Math.Pow(2, attemptNumber); // 2^attempt seconds
        var maxDelay = TimeSpan.FromMinutes(30);
        var delay = TimeSpan.FromSeconds(Math.Min(delaySeconds, maxDelay.TotalSeconds));

        // Schedule retry
        await _commandProcessor.SendAsync(
            command with { AttemptNumber = attemptNumber + 1 },
            delay: delay
        );
    }
}

Using Requeue with Delay in a Handler

public class ProcessPaymentHandlerAsync : RequestHandlerAsync<ProcessPaymentCommand>
{
    private const int MaxRetries = 3;

    public override async Task<ProcessPaymentCommand> HandleAsync(
        ProcessPaymentCommand command,
        CancellationToken cancellationToken = default)
    {
        try
        {
            await _paymentGateway.ProcessAsync(command.PaymentId, cancellationToken);
            return await base.HandleAsync(command, cancellationToken);
        }
        catch (PaymentGatewayUnavailableException)
        {
            // Throw DeferMessageAction to requeue with configured delay
            // Subscription must have requeueCount and requeueDelayInMilliseconds configured
            throw new DeferMessageAction();
        }
        catch (PaymentDeclinedException ex)
        {
            // Don't requeue for business logic failures
            _logger.LogWarning(ex, "Payment declined for {PaymentId}", command.PaymentId);
            return await base.HandleAsync(command, cancellationToken);
        }
    }
}

Configuration Examples

Configuring with Hangfire

services.AddBrighter(options =>
{
    options.HandlerLifetime = ServiceLifetime.Scoped;
})
.UseScheduler(
    scheduler: new HangfireMessageSchedulerFactory(
        connectionString: Configuration.GetConnectionString("Hangfire")
    )
)
.AutoFromAssemblies();

Configuring with Quartz.NET

services.AddBrighter(options =>
{
    options.HandlerLifetime = ServiceLifetime.Scoped;
})
.UseScheduler(
    scheduler: new QuartzMessageSchedulerFactory(
        configuration: Configuration.GetSection("Quartz")
    )
)
.AutoFromAssemblies();

Configuring with InMemory (Development Only)

services.AddBrighter(options =>
{
    options.HandlerLifetime = ServiceLifetime.Scoped;
})
.UseScheduler(
    scheduler: new InMemorySchedulerFactory()
)
.AutoFromAssemblies();

Best Practices

  1. Always store scheduler IDs if you need to cancel or track scheduled messages

  2. Use DateTimeOffset for absolute times and TimeSpan for relative delays

  3. Consider time zones when scheduling with DateTimeOffset (use UTC when possible)

  4. Choose the right scheduler based on your deployment environment

  5. Use InMemory scheduler only for testing - it's not durable

  6. Configure requeue delay appropriately - too short can overwhelm the system, too long delays recovery

  7. Implement idempotency in handlers that process scheduled messages

  8. Monitor scheduled jobs using your scheduler's dashboard/tools (Hangfire dashboard, AWS Console, etc.)

  9. Set reasonable max delays for requeue to avoid indefinite retries

  10. Use native transport delay when available to simplify infrastructure

Summary

  • Brighter provides comprehensive scheduling support for deferred message execution

  • Choose between absolute time (DateTimeOffset) or relative delay (TimeSpan)

  • Native transport delay available for RabbitMQ and Azure Service Bus (with limitations on SQS)

  • External schedulers (Quartz, Hangfire) required for transports without native delay

  • Requeue with Delay enables sophisticated retry strategies for transient failures

  • Use production schedulers (Quartz, Hangfire, AWS/Azure) for reliable scheduling

  • InMemory scheduler is only suitable for development and testing

  • All scheduling methods return a scheduler ID for cancellation/tracking

Last updated

Was this helpful?