R3Async 0.0.4
dotnet add package R3Async --version 0.0.4
NuGet\Install-Package R3Async -Version 0.0.4
<PackageReference Include="R3Async" Version="0.0.4" />
<PackageVersion Include="R3Async" Version="0.0.4" />
<PackageReference Include="R3Async" />
paket add R3Async --version 0.0.4
#r "nuget: R3Async, 0.0.4"
#:package R3Async@0.0.4
#addin nuget:?package=R3Async&version=0.0.4
#tool nuget:?package=R3Async&version=0.0.4
R3Async
R3Async is the async version of R3, a Reactive Extensions library for .NET. While R3 provides synchronous reactive programming primitives, R3Async is built from the ground up to support fully asynchronous reactive streams using ValueTask and IAsyncDisposable.
Quick Examples
R3Async provides LINQ-style operators for composing asynchronous reactive streams:
using R3Async;
// Filter, transform, and subscribe to an observable stream
var subscription = await AsyncObservable.Interval(TimeSpan.FromSeconds(1))
.Where(x => x % 2 == 0)
.Select(x => x * 10)
.SubscribeAsync(value => Console.WriteLine($"Even value: {value}"));
// Get the first 5 items that match a condition
var result = await AsyncObservable.Interval(TimeSpan.FromMilliseconds(100))
.Where(x => x > 3)
.Take(5)
.ToListAsync(CancellationToken.None);
// result: [4, 5, 6, 7, 8]
// Process async operations in sequence
var count = await AsyncObservable.CreateAsBackgroundJob<string>(async (observer, ct) =>
{
await observer.OnNextAsync("Hello", ct);
await observer.OnNextAsync("World", ct);
await observer.OnNextAsync("R3Async", ct);
await observer.OnCompletedAsync(Result.Success);
})
.Select(s => s.ToUpper())
.Do(s => Console.WriteLine(s))
.CountAsync(CancellationToken.None);
// Prints: HELLO, WORLD, R3ASYNC
// count: 3
// Chain async transformations
var firstLong = await AsyncObservable.Return(5)
.Select(async (x, ct) =>
{
await Task.Delay(100, ct);
return x.ToString();
})
.Where(s => s.Length > 0)
.FirstAsync(CancellationToken.None);
// firstLong: "5"
Core Abstractions
R3Async is built on two fundamental abstractions:
AsyncObservable<T>
The core observable type that represents an asynchronous reactive stream. It provides:
SubscribeAsync- Subscribe to the observable stream with an observer or lambda callbacks
public abstract class AsyncObservable<T>
{
public ValueTask<IAsyncDisposable> SubscribeAsync(
AsyncObserver<T> observer,
CancellationToken cancellationToken);
}
SubscribeAsync also has convenient overloads that accept lambda functions instead of requiring a full observer implementation:
// Subscribe with async lambdas for all callbacks
await observable.SubscribeAsync(
onNextAsync: async (value, ct) =>
{
await ProcessValueAsync(value, ct);
Console.WriteLine(value);
},
onErrorResumeAsync: async (error, ct) =>
{
await LogErrorAsync(error, ct);
Console.WriteLine($"Error: {error}");
},
onCompletedAsync: async (result) =>
{
Console.WriteLine($"Completed with {result}");
},
cancellationToken: cancellationToken
);
// Subscribe with simple async lambda
await observable.SubscribeAsync(async (value, ct) =>
{
Console.WriteLine(value);
}, cancellationToken);
// Subscribe with sync action
await observable.SubscribeAsync(value => Console.WriteLine(value));
Important: The CancellationToken parameter in SubscribeAsync is used only for the subscription operation itself, not for canceling the observable stream. To cancel an active subscription and stop the observable, await the DisposeAsync() method on the returned subscription:
var subscription = await observable.SubscribeAsync(observer, cancellationToken);
// Later, to cancel the observable:
await subscription.DisposeAsync();
AsyncObserver<T>
The observer that receives asynchronous notifications from an observable stream. It implements IAsyncDisposable and provides three core async methods:
OnNextAsync- Receives the next value in the stream asynchronouslyOnErrorResumeAsync- Handles errors asynchronously (resume-based error handling)OnCompletedAsync- Notifies when the stream completes asynchronously
public abstract class AsyncObserver<T> : IAsyncDisposable
{
public ValueTask OnNextAsync(T value, CancellationToken cancellationToken);
public ValueTask OnErrorResumeAsync(Exception error, CancellationToken cancellationToken);
public ValueTask OnCompletedAsync(Result result);
}
Key Differences from R3
- Fully Asynchronous: All operations return
ValueTaskinstead of being synchronous - Cancellation Support: Built-in
CancellationTokensupport throughout the API - AsyncDisposable: Uses
IAsyncDisposablefor proper async resource cleanup - Proper Cancellation Awaiting: One key consequence of asynchronous support is the ability to wait for tasks to be actually canceled. For example, the
Switchoperator waits for the previous task to be fully canceled before starting the next one. In contrast, R3 and Rx.NET'sSwitchoperators only initiate cancellation without waiting for completion, potentially leading to overlapping operations
Features
Factory Methods
Create observable streams from various sources:
Create- Create custom observablesCreateAsBackgroundJob- Create observables that run as background jobs, allowing proper cancellation handling and cleanupDefer- Defer observable creation until subscriptionEmpty- Empty observable that completes immediatelyNever- Observable that never completesReturn- Return a single valueFromAsync- Convert async operations to observablesInterval- Emit values at specified intervalsToAsyncObservable- Convert from various sources
Operators
Transform and compose observable streams:
Filtering
Where- Filter values based on a predicateOfType- Filter by typeDistinct/DistinctUntilChanged- Remove duplicatesSkip/Take- Control stream length
Transformation
Select- Transform valuesCast- Cast to a different typeScan- Accumulate values
Combination
Concat- Concatenate sequencesMerge- Merge multiple sequencesSwitch- Switch to latest sequencePrepend- Add values at the startCombineLatest- Combine multiple observables and emit their latest notified values
Error Handling
Catch- Handle and recover from errorsFinally- Execute cleanup logic
Side Effects
Do- Perform side effectsWrap- Wrap observer calls
Concurrency & Scheduling
ObserveOn- Control execution context for downstream operators
Aggregation & Terminal Operations
Async methods that consume the observable and return results:
FirstAsync/FirstOrDefaultAsync- Get first elementLastAsync/LastOrDefaultAsync- Get last elementSingleAsync/SingleOrDefaultAsync- Get single elementAnyAsync/AllAsync- Test conditionsContainsAsync- Check for elementCountAsync/LongCountAsync- Count elementsForEachAsync- Execute action for each elementToListAsync- Collect to listToDictionaryAsync- Collect to dictionaryToAsyncEnumerable- Convert to async enumerable using System.Threading.Channels
ToAsyncEnumerable and Channel Selection
There is no "one way" to convert an async observable to an async enumerable - the behavior depends on backpressure semantics. For this reason, ToAsyncEnumerable accepts a channel factory function, allowing you to choose the appropriate channel type:
// Rendezvous channel (capacity = 0) - strict backpressure
// Producer waits until consumer reads each item
await foreach (var x in observable.ToAsyncEnumerable(() => Channel.CreateBounded<int>(0)))
{
// Process item
}
// Bounded channel - limited backpressure buffer
await foreach (var x in observable.ToAsyncEnumerable(() => Channel.CreateBounded<int>(10)))
{
// Process item - producer can stay up to 10 items ahead
}
// Unbounded channel - no backpressure
// Producer never waits, all items are buffered
await foreach (var x in observable.ToAsyncEnumerable(() => Channel.CreateUnbounded<int>()))
{
// Process item
}
Channels already encode the desired conversion semantics, so you have full control over buffering and backpressure behavior.
ObserveOn and AsyncContext
The ObserveOn operator controls the async context for downstream operators. R3Async's ObserveOn is based on actual async behavior in .NET, leveraging SynchronizationContext and TaskScheduler.
AsyncContext
AsyncContext is a discriminated union that encapsulates either a SynchronizationContext or a TaskScheduler:
// Create from SynchronizationContext
var context = AsyncContext.From(SynchronizationContext.Current);
// Create from TaskScheduler
var context = AsyncContext.From(TaskScheduler.Current);
// Get the current context
var context = AsyncContext.GetCurrent();
AsyncContext provides a utility method SwitchContextAsync() that returns an awaitable. When awaited, it runs the continuation on the actual context (either the SynchronizationContext or TaskScheduler):
var context = AsyncContext.From(uiSyncContext);
await context.SwitchContextAsync(forceYielding: false, cancellationToken);
// Code after this point executes on the UI context
When you call ObserveOn(asyncContext), all downstream observer calls (OnNextAsync, OnErrorResumeAsync, OnCompletedAsync) will be executed on that context - either by posting to the SynchronizationContext or starting a task on the TaskScheduler.
Context Preservation
A fundamental property of ObserveOn in R3Async is that it does not lose context. Because the implementation never uses ConfigureAwait(false), when you chain operators after ObserveOn, they continue to execute on the specified async context:
await observable
.ObserveOn(uiContext) // Switch to UI context
.Select(async (x, ct) => await Something(x, ct)) // Still executes on UI context
.Where(x => x > 10) // Still executes on UI context
.SubscribeAsync(value => // Still executes on UI context
{
uiControl.Text = value.ToString(); // Safe to update UI
});
This behavior is similar to how synchronous Rx's ObserveOn works, where the scheduler context flows through the entire chain of downstream operators.
Force Yielding
The forceYielding parameter controls whether ObserveOn always yields execution, even if already on the target context:
// Only switch if not already on the context
observable.ObserveOn(context, forceYielding: false)
// Always yield, even if already on the context
observable.ObserveOn(context, forceYielding: true)
Subjects
Hot observables that can be controlled imperatively:
public interface ISubject<T>
{
AsyncObservable<T> Values { get; }
ValueTask OnNextAsync(T value, CancellationToken cancellationToken);
ValueTask OnErrorResumeAsync(Exception error, CancellationToken cancellationToken);
ValueTask OnCompletedAsync(Result result);
}
Subject
Subjects can be created using the static Subject.Create<T>() factory method with optional creation options:
// Create with default options (Serial publishing)
var subject = Subject.Create<int>();
// Create with explicit options
var concurrentSubject = Subject.Create<string>(new SubjectCreationOptions
{
PublishingOption = PublishingOption.Concurrent
});
Publishing Options:
PublishingOption.Serial(default) - Observers are notified serially, one after anotherPublishingOption.Concurrent- Observers are notified concurrently, allowing parallel execution
Once created, push values through the subject and subscribe to its Values observable:
var subject = Subject.Create<int>();
// Subscribe to the subject
await using var subscription = await subject.Values.SubscribeAsync(
async (value, ct) => Console.WriteLine($"Received: {value}")
);
// Push values
await subject.OnNextAsync(1, CancellationToken.None);
await subject.OnNextAsync(2, CancellationToken.None);
await subject.OnCompletedAsync(Result.Success);
BehaviorSubject
BehaviorSubject is a type of subject that stores the latest value and emits it to new subscribers immediately upon subscription. It can be created using the static Subject.CreateBehavior<T>() factory method:
// Create with initial value and default options (Serial publishing)
var behaviorSubject = Subject.CreateBehavior<int>(0);
// Create with explicit options
var concurrentBehaviorSubject = Subject.CreateBehavior<string>("initial", new BehaviorSubjectCreationOptions
{
PublishingOption = PublishingOption.Concurrent
});
The BehaviorSubject stores the latest emitted value and immediately sends it to new subscribers:
var subject = Subject.CreateBehavior<int>(42);
// First subscriber receives the initial value (42)
await using var sub1 = await subject.Values.SubscribeAsync(
async (value, ct) => Console.WriteLine($"Sub1: {value}")
);
// Output: Sub1: 42
// Emit new values
await subject.OnNextAsync(100, CancellationToken.None);
// Output: Sub1: 100
await subject.OnNextAsync(200, CancellationToken.None);
// Output: Sub1: 200
// New subscriber receives the latest value (200) immediately
await using var sub2 = await subject.Values.SubscribeAsync(
async (value, ct) => Console.WriteLine($"Sub2: {value}")
);
// Output: Sub2: 200
// Subsequent values are sent to all subscribers
await subject.OnNextAsync(300, CancellationToken.None);
// Output: Sub1: 300
// Output: Sub2: 300
Disposables
Async disposable utilities for resource management:
AsyncDisposable- Create custom async disposablesCompositeAsyncDisposable- Dispose multiple resources togetherSerialAsyncDisposable- Replace disposables seriallySingleAssignmentDisposable- Single assignment semantics
Usage Example
using R3Async;
// Create an observable from an async enumerable
var observable = AsyncObservable.Create<int>(async (observer, ct) =>
{
await observer.OnNextAsync(1, ct);
await observer.OnNextAsync(2, ct);
await observer.OnNextAsync(3, ct);
await observer.OnCompletedAsync(Result.Success);
return AsyncDisposable.Empty;
});
// Subscribe and process values
await using var subscription = await observable
.Where(x => x % 2 == 0)
.Select(x => x * 10)
.SubscribeAsync(async (value, ct) =>
{
Console.WriteLine($"Received: {value}");
await Task.CompletedTask;
});
// Using a Subject
var subject = new Subject<string>();
await using var sub = await subject.Values.SubscribeAsync(
async (value, ct) => Console.WriteLine(value)
);
await subject.OnNextAsync("Hello", CancellationToken.None);
await subject.OnNextAsync("World", CancellationToken.None);
await subject.OnCompletedAsync(Result.Success);
Background Jobs with AsyncEnumerable Interop
R3Async provides advanced features for background processing with proper cancellation handling and backpressure control using System.Threading.Channels:
using System.Threading.Channels;
using R3Async;
// Create a background job observable that properly handles cancellation
var obs = AsyncObservable.CreateAsBackgroundJob<int>(async (observer, token) =>
{
try
{
var i = 0;
while (true)
{
token.ThrowIfCancellationRequested();
await observer.OnNextAsync(i++, token);
}
}
catch (OperationCanceledException)
{
Console.WriteLine("Canceling");
// Simulate cleanup work
await Task.Delay(2000);
Console.WriteLine("Canceled");
throw;
}
});
// Convert to async enumerable with bounded channel for backpressure
await foreach (var x in obs.ToAsyncEnumerable(() => Channel.CreateBounded<int>(0)))
{
Console.WriteLine($"Consumed {x}");
var line = Console.ReadLine();
if (line == "exit")
break;
}
Console.WriteLine("Exited");
This example demonstrates:
- CreateAsBackgroundJob - Creates an observable that runs in the background
- Channel-based backpressure - Using
Channel.CreateBounded<int>(0)ensures the producer waits when the consumer is slow - Graceful cancellation - When the consumer breaks, the producer can perform cleanup before fully terminating. Exited is printed after Canceled
Concurrency Protection
R3Async includes built-in protection against concurrent observer calls. Concurrent calls to OnNextAsync, OnErrorResumeAsync, or OnCompletedAsync on the same observer instance will route a ConcurrentObserverCallsException to the UnhandledExceptionHandler (they don't stop the observable chain).
Unhandled Exception Handling
By default, unhandled exceptions in R3Async are written to the console. You can customize this behavior by registering a custom handler:
UnhandledExceptionHandler.Register(exception =>
{
// Custom exception handling logic
MyLogger.LogError(exception);
});
Note: OperationCanceledException is automatically ignored by the unhandled exception handler.
Missing Features
R3Async is currently under development and some features from R3 and Rx.NET are not yet implemented:
- Publish / IConnectableObservable - Hot observable multicasting support
- Throttle / Debounce - Time-based filtering operators
- Zip - Combine multiple observables pairwise
- Race (Amb) - Return the first observable to emit
- Others..
Design Decisions
- No ConfigureAwait(false) - By design, R3Async does not use
ConfigureAwait(false). This is a deliberate choice to maintain context flow and avoid potential issues with context loss. For more context on this decision, see dotnet/runtime#113567 and dotnet/reactive#1967. This design choice is particularly important forObserveOn, which preserves execution context throughout the operator chain.
These features may be added in future releases.
Related Projects
- R3 - The synchronous Reactive Extensions library that R3Async is based on
License
See LICENSE file in the repository.
| Product | Versions Compatible and additional computed target framework versions. |
|---|---|
| .NET | net5.0 was computed. net5.0-windows was computed. net6.0 is compatible. net6.0-android was computed. net6.0-ios was computed. net6.0-maccatalyst was computed. net6.0-macos was computed. net6.0-tvos was computed. net6.0-windows was computed. net7.0 was computed. net7.0-android was computed. net7.0-ios was computed. net7.0-maccatalyst was computed. net7.0-macos was computed. net7.0-tvos was computed. net7.0-windows was computed. net8.0 is compatible. net8.0-android was computed. net8.0-browser was computed. net8.0-ios was computed. net8.0-maccatalyst was computed. net8.0-macos was computed. net8.0-tvos was computed. net8.0-windows was computed. net9.0 was computed. net9.0-android was computed. net9.0-browser was computed. net9.0-ios was computed. net9.0-maccatalyst was computed. net9.0-macos was computed. net9.0-tvos was computed. net9.0-windows was computed. net10.0 was computed. net10.0-android was computed. net10.0-browser was computed. net10.0-ios was computed. net10.0-maccatalyst was computed. net10.0-macos was computed. net10.0-tvos was computed. net10.0-windows was computed. |
| .NET Core | netcoreapp3.0 was computed. netcoreapp3.1 was computed. |
| .NET Standard | netstandard2.1 is compatible. |
| MonoAndroid | monoandroid was computed. |
| MonoMac | monomac was computed. |
| MonoTouch | monotouch was computed. |
| Tizen | tizen60 was computed. |
| Xamarin.iOS | xamarinios was computed. |
| Xamarin.Mac | xamarinmac was computed. |
| Xamarin.TVOS | xamarintvos was computed. |
| Xamarin.WatchOS | xamarinwatchos was computed. |
-
.NETStandard 2.1
- Microsoft.Bcl.TimeProvider (>= 8.0.0)
- System.Collections.Immutable (>= 9.0.0)
- System.ComponentModel.Annotations (>= 5.0.0)
- System.Runtime.CompilerServices.Unsafe (>= 6.0.0)
- System.Threading.Channels (>= 8.0.0)
-
net6.0
- Microsoft.Bcl.TimeProvider (>= 8.0.0)
- System.Collections.Immutable (>= 9.0.0)
-
net8.0
- System.Collections.Immutable (>= 9.0.0)
NuGet packages
This package is not used by any NuGet packages.
GitHub repositories
This package is not used by any popular GitHub repositories.