// Licensed to the .NET Foundation under one or more agreements. // The .NET Foundation licenses this file to you under the Apache 2.0 License. // See the LICENSE file in the project root for more information. #if !NO_TPL using System.Reactive.Disposables; using System.Threading.Tasks; using System.Threading; using System.Reactive.Linq; using System.Reactive.Subjects; using System.Reactive.Concurrency; using System.Reactive.Linq.ObservableImpl; namespace System.Reactive.Threading.Tasks { /// /// Provides a set of static methods for converting tasks to observable sequences. /// public static class TaskObservableExtensions { /// /// Returns an observable sequence that signals when the task completes. /// /// Task to convert to an observable sequence. /// An observable sequence that produces a unit value when the task completes, or propagates the exception produced by the task. /// is null. /// If the specified task object supports cancellation, consider using instead. public static IObservable ToObservable(this Task task) { if (task == null) throw new ArgumentNullException(nameof(task)); return ToObservableImpl(task, null); } /// /// Returns an observable sequence that signals when the task completes. /// /// Task to convert to an observable sequence. /// Scheduler on which to notify observers about completion, cancellation or failure. /// An observable sequence that produces a unit value when the task completes, or propagates the exception produced by the task. /// is null or is null. /// If the specified task object supports cancellation, consider using instead. public static IObservable ToObservable(this Task task, IScheduler scheduler) { if (task == null) throw new ArgumentNullException(nameof(task)); if (scheduler == null) throw new ArgumentNullException(nameof(scheduler)); return ToObservableImpl(task, scheduler); } private static IObservable ToObservableImpl(Task task, IScheduler scheduler) { var res = default(IObservable); if (task.IsCompleted) { scheduler = scheduler ?? ImmediateScheduler.Instance; switch (task.Status) { case TaskStatus.RanToCompletion: res = new Return(Unit.Default, scheduler); break; case TaskStatus.Faulted: res = new Throw(task.Exception.InnerException, scheduler); break; case TaskStatus.Canceled: res = new Throw(new TaskCanceledException(task), scheduler); break; } } else { // // Separate method to avoid closure in synchronous completion case. // res = ToObservableSlow(task, scheduler); } return res; } private static IObservable ToObservableSlow(Task task, IScheduler scheduler) { var subject = new AsyncSubject(); var options = GetTaskContinuationOptions(scheduler); task.ContinueWith(t => ToObservableDone(task, subject), options); return ToObservableResult(subject, scheduler); } private static void ToObservableDone(Task task, IObserver subject) { switch (task.Status) { case TaskStatus.RanToCompletion: subject.OnNext(Unit.Default); subject.OnCompleted(); break; case TaskStatus.Faulted: subject.OnError(task.Exception.InnerException); break; case TaskStatus.Canceled: subject.OnError(new TaskCanceledException(task)); break; } } /// /// Returns an observable sequence that propagates the result of the task. /// /// The type of the result produced by the task. /// Task to convert to an observable sequence. /// An observable sequence that produces the task's result, or propagates the exception produced by the task. /// is null. /// If the specified task object supports cancellation, consider using instead. public static IObservable ToObservable(this Task task) { if (task == null) throw new ArgumentNullException(nameof(task)); return ToObservableImpl(task, null); } /// /// Returns an observable sequence that propagates the result of the task. /// /// The type of the result produced by the task. /// Task to convert to an observable sequence. /// Scheduler on which to notify observers about completion, cancellation or failure. /// An observable sequence that produces the task's result, or propagates the exception produced by the task. /// is null or is null. /// If the specified task object supports cancellation, consider using instead. public static IObservable ToObservable(this Task task, IScheduler scheduler) { if (task == null) throw new ArgumentNullException(nameof(task)); if (scheduler == null) throw new ArgumentNullException(nameof(scheduler)); return ToObservableImpl(task, scheduler); } private static IObservable ToObservableImpl(Task task, IScheduler scheduler) { var res = default(IObservable); if (task.IsCompleted) { scheduler = scheduler ?? ImmediateScheduler.Instance; switch (task.Status) { case TaskStatus.RanToCompletion: res = new Return(task.Result, scheduler); break; case TaskStatus.Faulted: res = new Throw(task.Exception.InnerException, scheduler); break; case TaskStatus.Canceled: res = new Throw(new TaskCanceledException(task), scheduler); break; } } else { // // Separate method to avoid closure in synchronous completion case. // res = ToObservableSlow(task, scheduler); } return res; } private static IObservable ToObservableSlow(Task task, IScheduler scheduler) { var subject = new AsyncSubject(); var options = GetTaskContinuationOptions(scheduler); task.ContinueWith(t => ToObservableDone(task, subject), options); return ToObservableResult(subject, scheduler); } private static void ToObservableDone(Task task, IObserver subject) { switch (task.Status) { case TaskStatus.RanToCompletion: subject.OnNext(task.Result); subject.OnCompleted(); break; case TaskStatus.Faulted: subject.OnError(task.Exception.InnerException); break; case TaskStatus.Canceled: subject.OnError(new TaskCanceledException(task)); break; } } private static TaskContinuationOptions GetTaskContinuationOptions(IScheduler scheduler) { var options = TaskContinuationOptions.None; if (scheduler != null) { // // We explicitly don't special-case the immediate scheduler here. If the user asks for a // synchronous completion, we'll try our best. However, there's no guarantee due to the // internal stack probing in the TPL, which may cause asynchronous completion on a thread // pool thread in order to avoid stack overflows. Therefore we can only attempt to be more // efficient in the case where the user specified a scheduler, hence we know that the // continuation will trigger a scheduling operation. In case of the immediate scheduler, // it really becomes "immediate scheduling" wherever the TPL decided to run the continuation, // i.e. not necessarily where the task was completed from. // options |= TaskContinuationOptions.ExecuteSynchronously; } return options; } private static IObservable ToObservableResult(AsyncSubject subject, IScheduler scheduler) { if (scheduler != null) { return subject.ObserveOn(scheduler); } else { return subject.AsObservable(); } } /// /// Returns a task that will receive the last value or the exception produced by the observable sequence. /// /// The type of the elements in the source sequence. /// Observable sequence to convert to a task. /// A task that will receive the last element or the exception produced by the observable sequence. /// is null. public static Task ToTask(this IObservable observable) { if (observable == null) throw new ArgumentNullException(nameof(observable)); return observable.ToTask(new CancellationToken(), null); } /// /// Returns a task that will receive the last value or the exception produced by the observable sequence. /// /// The type of the elements in the source sequence. /// Observable sequence to convert to a task. /// The state to use as the underlying task's AsyncState. /// A task that will receive the last element or the exception produced by the observable sequence. /// is null. public static Task ToTask(this IObservable observable, object state) { if (observable == null) throw new ArgumentNullException(nameof(observable)); return observable.ToTask(new CancellationToken(), state); } /// /// Returns a task that will receive the last value or the exception produced by the observable sequence. /// /// The type of the elements in the source sequence. /// Observable sequence to convert to a task. /// Cancellation token that can be used to cancel the task, causing unsubscription from the observable sequence. /// A task that will receive the last element or the exception produced by the observable sequence. /// is null. public static Task ToTask(this IObservable observable, CancellationToken cancellationToken) { if (observable == null) throw new ArgumentNullException(nameof(observable)); return observable.ToTask(cancellationToken, null); } private sealed class ToTaskObserver : IObserver { private readonly CancellationToken _ct; private readonly IDisposable _disposable; private readonly TaskCompletionSource _tcs; private readonly CancellationTokenRegistration _ctr = default(CancellationTokenRegistration); private bool _hasValue; private TResult _lastValue; public ToTaskObserver(TaskCompletionSource tcs, IDisposable disposable, CancellationToken ct) { this._ct = ct; this._tcs = tcs; this._disposable = disposable; if (ct.CanBeCanceled) { this._ctr = ct.Register(this.Cancel); } } public void OnNext(TResult value) { this._hasValue = true; this._lastValue = value; } public void OnError(Exception error) { this._tcs.TrySetException(error); this._ctr.Dispose(); // no null-check needed (struct) this._disposable.Dispose(); } public void OnCompleted() { if (this._hasValue) this._tcs.TrySetResult(this._lastValue); else this._tcs.TrySetException(new InvalidOperationException(Strings_Linq.NO_ELEMENTS)); this._ctr.Dispose(); // no null-check needed (struct) this._disposable.Dispose(); } private void Cancel() { this._disposable.Dispose(); this._tcs.TrySetCanceled(this._ct); } } /// /// Returns a task that will receive the last value or the exception produced by the observable sequence. /// /// The type of the elements in the source sequence. /// Observable sequence to convert to a task. /// Cancellation token that can be used to cancel the task, causing unsubscription from the observable sequence. /// The state to use as the underlying task's AsyncState. /// A task that will receive the last element or the exception produced by the observable sequence. /// is null. public static Task ToTask(this IObservable observable, CancellationToken cancellationToken, object state) { if (observable == null) throw new ArgumentNullException(nameof(observable)); var tcs = new TaskCompletionSource(state); var disposable = new SingleAssignmentDisposable(); var taskCompletionObserver = new ToTaskObserver(tcs, disposable, cancellationToken); // // Subtle race condition: if the source completes before we reach the line below, the SingleAssigmentDisposable // will already have been disposed. Upon assignment, the disposable resource being set will be disposed on the // spot, which may throw an exception. (Similar to TFS 487142) // try { // // [OK] Use of unsafe Subscribe: we're catching the exception here to set the TaskCompletionSource. // // Notice we could use a safe subscription to route errors through OnError, but we still need the // exception handling logic here for the reason explained above. We cannot afford to throw here // and as a result never set the TaskCompletionSource, so we tunnel everything through here. // disposable.Disposable = observable.Subscribe/*Unsafe*/(taskCompletionObserver); } catch (Exception ex) { tcs.TrySetException(ex); } return tcs.Task; } } } #endif