Ephemeral Signals - Turning Atoms into a Sensing Network (English)

Ephemeral Signals - Turning Atoms into a Sensing Network

Friday, 12 December 2025

//

22 minute read

A tiny primitive that turns concurrent work into a coordinated, adaptive system.

"The Ephemeral Signals Pattern"

In Part 1 we built ephemeral execution - bounded, private, self-cleaning async workflows. In Part 2 we turned that into a reusable library with coordinators, keyed pipelines, and DI integration.

This article adds one small feature that changes everything: signals.

NUGET!!!

This is now in the mostlylucid.ephemerals Nuget package also more than 20 mostlylucid.ephemerals patterns and 'atoms'.

NuGet License

Source Files

The full source code is in the mostlylucid.atoms GitHub repository

The signal infrastructure lives in:

File Purpose
Signals.cs SignalEvent, SignalRetractedEvent, SignalPropagation, SignalConstraints, SignalSink, ISignalEmitter, AsyncSignalProcessor
EphemeralOperation.cs Signal emission and retraction from operations
EphemeralOptions.cs Signal-reactive configuration (CancelOnSignals, DeferOnSignals, OnSignal, OnSignalRetracted)
StringPatternMatcher.cs Glob-style pattern matching for signal filtering
SignalDispatcher.cs Async signal routing with pattern matching (supports *, ?, comma lists, deterministic order)
Examples/SignalingHttpClient.cs Sample fine-grained signal emission for HTTP calls
Examples/AdaptiveTranslationService.cs Adaptive rate limiting with signal-based deferral
Examples/SignalBasedCircuitBreaker.cs Circuit breaker reading ephemeral signal window
Examples/TelemetrySignalHandler.cs Async signal processing with telemetry integration

The Problem: Isolated Atoms

Our ephemeral coordinators are great at processing work, but they're isolated. Each coordinator knows about its own operations, but has no awareness of what's happening elsewhere in the system.

// Translation coordinator has no idea that...
await translationCoordinator.EnqueueAsync(request);

// ...the API just hit a rate limit
// ...another service is experiencing backpressure
// ...a downstream dependency is slow

We could wire up explicit dependencies, but that creates coupling. What we want is ambient awareness - coordinators that can sense their environment without being directly connected.

Signals let execution atoms leave traces in their ephemeral window. Those traces behave like short-lived facts:

  • "This API just rate-limited"
  • "This user has failed 3 times"
  • "A sibling operation is still waiting on the gateway"

Coordinators can then change their behaviour based on the signals visible in their window. That's ambient awareness without dependencies.


The Solution: Signals on Operations

From Signals.cs:

public readonly record struct SignalEvent(
    string Signal,
    long OperationId,
    string? Key,
    DateTimeOffset Timestamp,
    SignalPropagation? Propagation = null)
{
    public int Depth => Propagation?.Depth ?? 0;
    public bool WouldCycle(string signal) => Propagation?.Contains(signal) == true;
    public bool Is(string name) => Signal == name;
    public bool StartsWith(string prefix) => Signal.StartsWith(prefix, StringComparison.Ordinal);
}

An operation can raise signals during execution. Those signals live in the ephemeral window alongside the operation. When the operation ages out, the signals go with it.

That's it. No message broker. No separate infrastructure. Just strings attached to operations.

Because signals live inside the ephemeral window, they inherit its guarantees: bounded size, automatic ageing, and zero lifecycle overhead.


The Ephemeral Signal Laws

Law 1 — Signals Never Implicitly Trigger Execution

A signal, by itself, does not cause execution. It only records a fact in the ephemeral window. Nothing runs because a signal was emitted.

Law 2 — OnSignal Is Explicit, Local, and Optional

If a coordinator defines an OnSignal handler, it runs synchronously when a signal is emitted — but only because the coordinator chose to attach it. Emitters do not know or care. Removing all handlers leaves core behaviour unchanged.

Law 3 — Signals Are Local to the Atom

A signal is attached only to the atom/operation that emitted it. No signal ever mutates or annotates another atom. There is no shared writable bus.

Law 4 — Signals Are Append-Only Facts

Emitting a signal appends a fact to the atom’s history. Signals are never updated or overwritten. Retractions remove only the emitter’s own signals.

Law 5 — The Signal Surface Is Bounded and Time-Limited

Signals exist only within the coordinator’s ephemeral window. They expire automatically as the window ages out. Nothing is persisted unless you explicitly build persistence.

Law 6 — Observers Read, They Do Not Write

When a coordinator “checks signals for key K”, it scans:

the atoms in its window

and the signals local to those atoms Observers never modify an atom’s signal state.

Law 7 — Event-like Behaviour Is a Layer, Not a Primitive

If you want signals to drive async workflows, you must use:

SignalDispatcher

AsyncSignalProcessor

or other adapters.

These are optional layers built on top of signals, not part of their semantics.

Law 8 — No Cross-Atom Mutation Under Any Circumstances

No atom may alter the snapshot, state, signals, or metadata of another atom. Coordination occurs through:

  • signals

  • sensing

  • windows

  • policies

Not through writes.

Law 9 — Global Views Are Derived, Never Mutable

A SignalSink or swarm-aggregated surface may show a combined view of signals — but it is always read-only, never authoritative, never writable.

Law 10 — Removing Handlers Yields the Same Core System

If all handlers (OnSignal, dispatchers, processors) are detached, the system remains fully correct and predictable. Signals still have meaning because they are facts, not triggers.

The Best Analogy: Footprints, Not Instructions

Events are like a phone call:

"I'm calling you right now. Pick up and react."

Signals are like footprints in the snow:

"I left footprints. If you want to know where I went — look. If you don't care — ignore it."

This is why signals never break, never block, and never interact with control flow unless you choose to poll them.

What This Removes

The distinction matters because signals eliminate:

Problem Events Have It Signals Avoid It
Coupling Publisher → Subscribers None
Timing dependencies Immediate reaction required Ambient, poll when ready
Feedback loops Handlers can trigger handlers No loops unless explicitly asked
Ordering semantics Order matters Irrelevant
Delivery guarantees Must be delivered/handled No delivery, just existence
Error propagation Handler errors propagate Isolated
Reentrancy hazards Common Impossible
Cascaded failures One handler fails, chain breaks No chain to break

Quick Comparison

Feature Events Signals
Coupling Strong (publisher → subscribers) None
Timing Immediate Ambient
Delivery Guaranteed/attempted No delivery, just existence
Reaction Required Optional
Data Payload Often heavy Tiny string metadata
Storage None Sliding LRU-style window
Lifetime Instantaneous Decays automatically
Failure modes Many Almost none

The Difference in Code

Events approach (classic):

public event Action RateLimited;

try
{
    await CallApiAsync();
}
catch (RateLimitException)
{
    RateLimited?.Invoke(); // Makes someone else act right now
}

Problems:

  • Who reacts?
  • In what order?
  • What if two handlers conflict?
  • What if a handler throws?
  • What if it's the wrong time?
  • What if the caller doesn't want this behaviour?

Signal approach (ephemeral):

try
{
    await CallApiAsync(ct);
}
catch (RateLimitException ex)
{
    op.Signal($"rate-limit:{ex.RetryAfterMs}ms");
    throw;
}

Nothing happens here. Later, somewhere totally different:

if (translator.HasSignal("rate-limit"))
{
    await Task.Delay(1000);   // Act when *we* choose
}

Notes:

  • No direct coupling
  • No surprise calls
  • No execution jumps
  • No callback hell
  • No cross-thread weirdness
  • Only reacts when we ask to look

The "Aha!" Line

Events transfer control. Signals transfer context.

That's the entire mental model in one sentence.

What Signals Really Are

Depending on your background:

Audience Definition
Systems Thinkers A stigmergic substrate for indirect coordination
Engineers Lightweight metadata attached to operations in a bounded sliding window
PL/Concurrency Nerds An implicit, temporal blackboard paired with bounded concurrency semantics
Framework Users An in-process, self-cleaning state surface you can query at any time

Signals are traces left in a shared, bounded memory surface. Anyone can look at them. No one is obligated to react. This is a fundamentally stigmergic model of coordination — the same one ants use, the same one blackboard systems used in early AI, and the same one modern CRDT gossip networks hint at.


How This Compares to Other Approaches

Application Insights / OpenTelemetry

using var activity = source.StartActivity("ProcessOrder");
activity?.SetTag("order.id", orderId);
activity?.SetTag("rate.limited", true);

Best for: Distributed tracing across services, long-term telemetry storage, correlation IDs.

Use telemetry when: You need to trace requests across multiple services, store metrics for analysis, or integrate with monitoring tools.

Use Ephemeral signals when: You need in-process ambient awareness, reactive coordination, or don't want telemetry infrastructure.

Reactive Extensions (Rx)

var rateLimits = Observable.FromEventPattern<RateLimitEventArgs>(
    h => api.RateLimitHit += h,
    h => api.RateLimitHit -= h);

rateLimits
    .Throttle(TimeSpan.FromSeconds(1))
    .Subscribe(e => HandleRateLimit(e));

Best for: Complex event processing, time-based operations, combining multiple event streams.

Use Rx when: You need complex temporal queries (windowing, debouncing, combining streams).

Use Ephemeral signals when: You want simpler polling-based sensing, automatic cleanup, or integration with operation tracking.

MediatR Notifications

public class RateLimitNotification : INotification
{
    public int RetryAfterMs { get; init; }
}

await _mediator.Publish(new RateLimitNotification { RetryAfterMs = 5000 });

Best for: Decoupled in-process event handling with multiple handlers.

Use MediatR when: You want multiple handlers to react to the same event synchronously.

Use Ephemeral signals when: You want ambient sensing without explicit subscription, self-cleaning history, or integration with bounded execution.

Polly Circuit Breaker

var circuitBreaker = Policy
    .Handle<HttpRequestException>()
    .CircuitBreakerAsync(5, TimeSpan.FromSeconds(30));

Best for: Resilience around individual calls with automatic state management.

Use Polly when: You need per-call resilience with automatic half-open/closed transitions.

Use Ephemeral signals when: You want ambient awareness across many operations, custom circuit logic, or integration with operation tracking.

Combine them: Use Polly inside your work body, emit signals when circuits trip.

Comparison Table

Approach Self-Cleaning Ambient Sensing Decoupled Custom Logic Integration
OpenTelemetry External tools
Reactive Extensions Complex
MediatR Manual
Polly Circuit Breaker Per-call
Ephemeral Signals Built-in

Raising and Retracting Signals

Operations implement ISignalEmitter:

public interface ISignalEmitter
{
    // Emit signals
    void Emit(string signal);
    bool EmitCaused(string signal, SignalPropagation? cause);

    // Retract (remove) signals
    bool Retract(string signal);
    int RetractMatching(string pattern);
    bool HasSignal(string signal);

    long OperationId { get; }
    string? Key { get; }
}

Inside your work body:

await coordinator.ProcessAsync(async (item, op, ct) =>
{
    try
    {
        var result = await CallExternalApiAsync(item, ct);

        if (result.WasCached)
            op.Signal("cache-hit");

        if (result.Duration > TimeSpan.FromSeconds(2))
            op.Signal("slow-response");
    }
    catch (RateLimitException ex)
    {
        op.Signal("rate-limit");
        op.Signal($"rate-limit:{ex.RetryAfterMs}ms");
        throw;
    }
    catch (TimeoutException)
    {
        op.Signal("timeout");
        throw;
    }
});

Signals are just strings. Use simple names ("rate-limit") or structured names ("rate-limit:5000ms"). Pattern filters use glob semantics (*, ?) and support comma lists ("error.*,timeout"). Matching is deterministic and allocation-light via StringPatternMatcher.

Fine-Grained Signal Example: HTTP Calls

For very detailed observability, you can emit signals at each stage of an operation. The library includes a sample SignalingHttpClient that demonstrates this pattern:

using Mostlylucid.Helpers.Ephemeral.Examples;

// Inside your work body where you have access to the operation's emitter:
await coordinator.ProcessAsync(async (request, op, ct) =>
{
    var data = await SignalingHttpClient.DownloadWithSignalsAsync(
        httpClient,
        new HttpRequestMessage(HttpMethod.Get, request.Url),
        op,  // ISignalEmitter
        ct);

    // Process the downloaded data...
});

This emits signals at each stage:

Signal When
stage.starting Before the request begins
progress:0 Initial progress mark
stage.request HTTP request sent
stage.headers Response headers received
stage.reading Starting to read body
progress:XX Progress percentage (0-100) during download
stage.completed Download finished

You can then query these with pattern matching:

// Find all stage transitions
var stages = coordinator.GetSignalsByPattern("stage.*");

// Check download progress
var progress = coordinator.GetSignalsByPattern("progress:*");

// Check if any download is still in progress
if (coordinator.HasSignalMatching("stage.reading") &&
    !coordinator.HasSignalMatching("stage.completed"))
{
    // Download in progress
}

Retracting Signals

Operations can also remove their own signals. This is useful for temporary states:

await coordinator.ProcessAsync(async (item, op, ct) =>
{
    // Mark as processing
    op.Emit("processing");

    try
    {
        await ProcessItemAsync(item, ct);

        // Success - retract the processing signal
        op.Retract("processing");
        op.Emit("completed");
    }
    catch (RetryableException)
    {
        // Keep processing signal, add retry info
        op.Emit("retrying");
    }
    catch (Exception)
    {
        // Remove all temporary signals
        op.RetractMatching("processing*");
        op.Emit("failed");
        throw;
    }
});

Retraction Events

Just like signal emission, retractions can trigger callbacks:

var coordinator = new EphemeralWorkCoordinator<Request>(
    body,
    new EphemeralOptions
    {
        // Sync retraction handler
        OnSignalRetracted = evt =>
        {
            _metrics.DecrementGauge(evt.Signal);
            Console.WriteLine($"Signal {evt.Signal} retracted from op {evt.OperationId}");

            if (evt.WasPatternMatch)
                Console.WriteLine($"  (matched pattern: {evt.Pattern})");
        },

        // Async retraction handler
        OnSignalRetractedAsync = async (evt, ct) =>
        {
            await _telemetry.TrackRetraction(evt.Signal, evt.OperationId, ct);
        }
    });

The SignalRetractedEvent includes:

  • Signal - The retracted signal name
  • OperationId - The operation that retracted it
  • Key - The operation's key (if any)
  • Timestamp - When retraction occurred
  • WasPatternMatch - True if retracted via RetractMatching
  • Pattern - The pattern used (if pattern match)

Real-World Example: Rate Limit Recovery

await coordinator.ProcessAsync(async (request, op, ct) =>
{
    // Check if we already have a rate limit signal
    if (op.HasSignal("rate-limited"))
    {
        // We're in recovery mode
        await Task.Delay(1000, ct);
    }

    try
    {
        var response = await _api.SendAsync(request, ct);

        // Success! Remove any rate limit signal
        if (op.Retract("rate-limited"))
        {
            op.Emit("rate-limit-cleared");
        }
    }
    catch (RateLimitException ex)
    {
        op.Emit("rate-limited");
        op.Emit($"rate-limit:{ex.RetryAfterMs}ms");
        throw;
    }
});

Sensing Signals

All coordinators provide optimised signal querying:

// Check if any recent operation hit a rate limit
if (coordinator.HasSignal("rate-limit"))
{
    await Task.Delay(1000);
}

// Count slow responses in the window
var slowCount = coordinator.CountSignals("slow-response");
if (slowCount > 10)
{
    await ThrottleAsync();
}

// Get signals by pattern
var httpErrors = coordinator.GetSignalsByPattern("http.error.*");

// Get signals since a time
var recentSignals = coordinator.GetSignalsSince(DateTimeOffset.UtcNow.AddMinutes(-1));

// Get signals for a specific key
var userSignals = coordinator.GetSignalsByKey("user-123");

Signal-Reactive Processing

From EphemeralOptions.cs:

Coordinators can automatically react to signals:

var coordinator = new EphemeralWorkCoordinator<Request>(
    body,
    new EphemeralOptions
    {
        // Cancel new work if these signals are present
        CancelOnSignals = new HashSet<string> { "system-overload", "circuit-open" },

        // Defer new work while these signals are present
        DeferOnSignals = new HashSet<string> { "rate-limit" },
        MaxDeferAttempts = 10,
        DeferCheckInterval = TimeSpan.FromMilliseconds(100)
    });

When a signal in CancelOnSignals is detected, new items are skipped (counted as failed). When a signal in DeferOnSignals is detected, new items wait until the signal clears.


Real-World Example: Adaptive Rate Limiting

From AdaptiveTranslationService.cs:

public class AdaptiveTranslationService : IAsyncDisposable
{
    private readonly EphemeralWorkCoordinator<TranslationRequest> _coordinator;
    private readonly ITranslationApi _translationApi;

    public AdaptiveTranslationService(ITranslationApi translationApi)
    {
        _translationApi = translationApi;

        _coordinator = new EphemeralWorkCoordinator<TranslationRequest>(
            ProcessTranslationAsync,
            new EphemeralOptions
            {
                MaxConcurrency = 8,
                MaxTrackedOperations = 100,

                // New work is deferred while any "rate-limit" or "rate-limit:*" signal is present
                DeferOnSignals = new HashSet<string> { "rate-limit", "rate-limit:*" },
                MaxDeferAttempts = 10,
                DeferCheckInterval = TimeSpan.FromMilliseconds(100)
            });
    }

    public async Task TranslateAsync(TranslationRequest request)
    {
        // Optional: extra politeness based on most recent retry-after
        var rateLimitSignals = _coordinator.GetSignalsByPattern("rate-limit:*");
        if (rateLimitSignals.Count > 0)
        {
            var latest = rateLimitSignals
                .OrderByDescending(s => s.Timestamp)
                .First()
                .Signal; // "rate-limit:5000ms"

            if (TryParseRetryAfter(latest, out var delay))
            {
                await Task.Delay(delay);
            }
        }

        await _coordinator.EnqueueAsync(request);
    }

    public static bool TryParseRetryAfter(string signal, out TimeSpan delay)
    {
        delay = default;
        var parts = signal.Split(':', 2);
        if (parts.Length != 2) return false;

        var payload = parts[1].Trim();
        if (!payload.EndsWith("ms", StringComparison.OrdinalIgnoreCase)) return false;

        var numPart = payload[..^2];
        if (!int.TryParse(numPart, out var ms) || ms < 0) return false;

        delay = TimeSpan.FromMilliseconds(ms);
        return true;
    }
}

Every instance of this service automatically backs off when rate limits are hit. No shared state. No message passing. Just reading the ephemeral window.


Real-World Example: Cross-Coordinator Awareness

Multiple coordinators can sense each other through a shared SignalSink:

public class OrderProcessingSystem
{
    private readonly SignalSink _sharedSignals = new(maxCapacity: 1000);

    private readonly EphemeralWorkCoordinator<Order> _orderProcessor;
    private readonly EphemeralWorkCoordinator<PaymentRequest> _paymentProcessor;

    public OrderProcessingSystem()
    {
        var options = new EphemeralOptions { Signals = _sharedSignals };

        _orderProcessor = new EphemeralWorkCoordinator<Order>(
            ProcessOrderAsync, options);

        _paymentProcessor = new EphemeralWorkCoordinator<PaymentRequest>(
            ProcessPaymentAsync, options);
    }

    public async Task ProcessOrderAsync(Order order)
    {
        // Check shared signals for payment gateway issues
        if (_sharedSignals.Detect("gateway-error"))
        {
            await _retryQueue.EnqueueAsync(order);
            return;
        }

        await _orderProcessor.EnqueueAsync(order);
    }
}

Real-World Example: Health Monitoring

[HttpGet("/health/detailed")]
public IActionResult GetDetailedHealth()
{
    return Ok(new
    {
        translation = new
        {
            pending = _translationCoordinator.PendingCount,
            active = _translationCoordinator.ActiveCount,
            recentRateLimits = _translationCoordinator.CountSignals("rate-limit"),
            recentTimeouts = _translationCoordinator.CountSignals("timeout"),
            recentSuccess = _translationCoordinator.CountSignals("success"),
            hasErrors = _translationCoordinator.HasSignalMatching("error.*")
        },
        payment = new
        {
            pending = _paymentCoordinator.PendingCount,
            gatewayErrors = _paymentCoordinator.CountSignals("gateway-error"),
            declines = _paymentCoordinator.CountSignals("declined"),
            approvals = _paymentCoordinator.CountSignals("approved")
        }
    });
}

No metrics library needed. Just query the ephemeral window.


Real-World Example: Signal-Based Circuit Breaking

From SignalBasedCircuitBreaker.cs:

public class SignalBasedCircuitBreaker
{
    private readonly string _failureSignal;
    private readonly int _threshold;
    private readonly TimeSpan _windowSize;

    public SignalBasedCircuitBreaker(
        string failureSignal = "failure",
        int threshold = 5,
        TimeSpan? windowSize = null)
    {
        _failureSignal = failureSignal;
        _threshold = threshold;
        _windowSize = windowSize ?? TimeSpan.FromSeconds(30);
    }

    public bool IsOpen<T>(EphemeralWorkCoordinator<T> coordinator)
    {
        var recentFailures = coordinator.GetSignalsSince(
            DateTimeOffset.UtcNow - _windowSize);

        return recentFailures.Count(s => s.Signal == _failureSignal) >= _threshold;
    }

    public int GetFailureCount<T>(EphemeralWorkCoordinator<T> coordinator)
    {
        var recentFailures = coordinator.GetSignalsSince(
            DateTimeOffset.UtcNow - _windowSize);

        return recentFailures.Count(s => s.Signal == _failureSignal);
    }
}

// Usage
var circuitBreaker = new SignalBasedCircuitBreaker("api-error", threshold: 3);

if (circuitBreaker.IsOpen(_coordinator))
{
    throw new CircuitOpenException("Too many recent API errors");
}

await _coordinator.EnqueueAsync(request);

The circuit breaker has no state of its own - it just reads the ephemeral window.


Signal Constraints: Preventing Infinite Loops

From Signals.cs:

When signals can cause other signals, you risk infinite loops. SignalConstraints prevents this:

var options = new EphemeralOptions
{
    SignalConstraints = new SignalConstraints
    {
        // Max propagation depth before blocking
        MaxDepth = 10,

        // Prevent A → B → A cycles
        BlockCycles = true,

        // Signals that end propagation chains
        TerminalSignals = new HashSet<string> { "completed", "failed", "resolved" },

        // Signals that emit but don't propagate
        LeafSignals = new HashSet<string> { "logged", "metric" },

        // Callback when a signal is blocked
        OnBlocked = (signal, reason) =>
        {
            _logger.LogWarning("Signal {Signal} blocked: {Reason}",
                signal.Signal, reason);
        }
    }
};

Signal Propagation

Track causality with EmitCaused:

public void HandleSignal(SignalEvent evt, ISignalEmitter emitter)
{
    if (evt.Is("order-placed"))
    {
        // This signal carries the propagation chain
        // Will be blocked if it would create a cycle
        emitter.EmitCaused("inventory-reserved", evt.Propagation);
    }
}

The propagation chain tracks the path: order-placed → inventory-reserved → ...

If inventory-reserved tried to emit order-placed, it would be blocked (cycle detected).


The SignalSink: Global Signal Space

From Signals.cs:

For signals that need to be visible across coordinators:

public sealed class SignalSink
{
    private readonly ConcurrentQueue<SignalEvent> _window;
    private readonly int _maxCapacity;
    private readonly TimeSpan _maxAge;

    public SignalSink(int maxCapacity = 1000, TimeSpan? maxAge = null);

    // Raise signals
    public void Raise(SignalEvent signal);
    public void Raise(string signal, string? key = null);

    // Sense signals
    public IReadOnlyList<SignalEvent> Sense();
    public IReadOnlyList<SignalEvent> Sense(Func<SignalEvent, bool> predicate);
    public bool Detect(string signalName);
    public bool Detect(Func<SignalEvent, bool> predicate);

    public int Count { get; }
}

Usage:

// Create a shared sink
var sink = new SignalSink(maxCapacity: 1000, maxAge: TimeSpan.FromMinutes(2));

// Configure coordinators to use it
var options = new EphemeralOptions { Signals = sink };

// Or raise signals directly
sink.Raise("system-maintenance");

// Sense from anywhere
if (sink.Detect("system-maintenance"))
{
    await DeferWorkAsync();
}

Pattern Matching with StringPatternMatcher

From StringPatternMatcher.cs:

Glob-style matching for signal filtering:

// Exact match
coordinator.HasSignal("rate-limit");

// Wildcard patterns
coordinator.HasSignalMatching("http.*");           // http.timeout, http.error
coordinator.HasSignalMatching("error.*.critical"); // error.payment.critical
coordinator.HasSignalMatching("user-???-failed");  // user-123-failed

// Comma-separated patterns in CancelOnSignals/DeferOnSignals
new EphemeralOptions
{
    CancelOnSignals = new HashSet<string>
    {
        "system-overload, circuit-open",  // Either pattern
        "error.*"                          // Any error signal
    }
}

Signal Naming Conventions

Keep signals simple and consistent:

// Good - simple, categorical
op.Signal("success");
op.Signal("failure");
op.Signal("rate-limit");
op.Signal("timeout");
op.Signal("cache-hit");

// Good - structured for parsing
op.Signal("rate-limit:5000ms");
op.Signal("retry:attempt-3");
op.Signal("slow:2500ms");
op.Signal("http.error:429");

// Good - hierarchical for pattern matching
op.Signal("payment.declined");
op.Signal("payment.approved");
op.Signal("payment.gateway-error");

// Avoid - entity identification belongs in Key, not signals
op.Signal("user-123-rate-limited");  // Bad

// Instead
op.Key = "user-123";
op.Signal("rate-limit");

Async Signal Handling

Synchronous signal handlers (OnSignal) run on the operation's thread—keep them fast. To do I/O-bound work, fan signals into an async path with SignalDispatcher (pattern matching, deterministic order) or AsyncSignalProcessor.

SignalDispatcher fan-out

await using var dispatcher = new SignalDispatcher(new EphemeralOptions
{
    MaxConcurrency = Environment.ProcessorCount,
    MaxConcurrencyPerKey = 1  // sequential per signal name by default
});

dispatcher.Register("error.*", evt => _alerts.SendAsync(evt.Signal));
dispatcher.Register("progress:*", evt => _metrics.Record(evt.Signal));

// In coordinator options, keep OnSignal cheap and enqueue
var coordinator = new EphemeralWorkCoordinator<Request>(
    body,
    new EphemeralOptions
    {
        OnSignal = dispatcher.Dispatch
    });

Patterns support *, ?, and comma lists ("error.*,timeout"). All matching handlers run in registration order on a background keyed coordinator; emit remains synchronous.

AsyncSignalProcessor

For standalone async processing:

await using var processor = new AsyncSignalProcessor(
    async (signal, ct) =>
    {
        await _externalService.LogAsync(signal, ct);
    },
    maxConcurrency: 4,
    maxQueueSize: 1000);

// Enqueue signals (returns immediately)
processor.Enqueue(new SignalEvent(
    "rate-limit",
    operationId,
    key,
    DateTimeOffset.UtcNow));

TelemetrySignalHandler Example

A complete example combining async signal processing with telemetry integration:

Source: TelemetrySignalHandler.cs

public class TelemetrySignalHandler : IAsyncDisposable
{
    private readonly AsyncSignalProcessor _processor;
    private readonly ITelemetryClient _telemetry;

    public TelemetrySignalHandler(ITelemetryClient telemetry)
    {
        _telemetry = telemetry;
        _processor = new AsyncSignalProcessor(
            HandleSignalAsync,
            maxConcurrency: 8,
            maxQueueSize: 5000);
    }

    // Synchronous entry point - returns immediately
    public bool OnSignal(SignalEvent signal) => _processor.Enqueue(signal);

    private async Task HandleSignalAsync(SignalEvent signal, CancellationToken ct)
    {
        var properties = new Dictionary<string, string>
        {
            ["signal"] = signal.Signal,
            ["operationId"] = signal.OperationId.ToString(),
            ["key"] = signal.Key ?? "none"
        };

        await _telemetry.TrackEventAsync("EphemeralSignal", properties, ct);

        // Categorized tracking based on signal prefix
        if (signal.StartsWith("error"))
            await _telemetry.TrackExceptionAsync(signal.Signal, properties, ct);
        else if (signal.StartsWith("perf"))
            await _telemetry.TrackMetricAsync(signal.Signal, 1, ct);
    }

    // Expose stats for monitoring
    public int QueuedCount => _processor.QueuedCount;
    public long ProcessedCount => _processor.ProcessedCount;
    public long DroppedCount => _processor.DroppedCount;

    public async ValueTask DisposeAsync() => await _processor.DisposeAsync();
}

Wire it up to your coordinator:

await using var telemetryHandler = new TelemetrySignalHandler(telemetryClient);

await using var coordinator = new EphemeralWorkCoordinator<Request>(
    ProcessAsync,
    new EphemeralOptions
    {
        OnSignal = signal => telemetryHandler.OnSignal(signal)
    });

The handler:

  • Never blocks the operation thread - OnSignal returns immediately
  • Categorizes signals by prefix for different telemetry types
  • Exposes metrics (queued, processed, dropped) for monitoring health
  • Bounds memory - drops oldest signals if queue fills up

Why This Works

Signals are powerful because they're ephemeral:

Property Benefit
Bounded Can't grow unbounded - old signals age out
Self-cleaning No cleanup code needed
Decoupled Emitters don't know about listeners
Observable Any code can sense the current state
Private No user data - just signal names
Fast O(1) detection with short-circuiting

The ephemeral window is already there for debugging. Signals just give it semantic meaning.


Conclusion

Signals turn isolated execution atoms into a sensing network. Each coordinator can:

  • Emit signals about what it experienced
  • Sense signals from its own history or a shared sink
  • React automatically via CancelOnSignals and DeferOnSignals

No message broker. No shared state. No coordination protocol. Just operations with metadata that naturally decays.

The atoms don't talk to each other directly - they just leave traces in the ephemeral window that others can observe. It's stigmergy for async systems.

Fire... Signal... Sense... Forget.


logo

© 2025 Scott Galloway — Unlicense — All content and source code on this site is free to use, copy, modify, and sell.