Browse Source

Remove redundant qualifiers. (#652)

Daniel C. Weber 7 years ago
parent
commit
de57ac905f
45 changed files with 98 additions and 98 deletions
  1. 6 6
      Rx.NET/Source/src/System.Reactive/Concurrency/ConcurrencyAbstractionLayerImpl.cs
  2. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/CurrentThreadScheduler.cs
  3. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/DefaultScheduler.cs
  4. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/LocalScheduler.TimerQueue.cs
  5. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/SchedulerQueue.cs
  6. 2 2
      Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.ObserveOn.cs
  7. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.Synchronize.cs
  8. 2 2
      Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.cs
  9. 2 2
      Rx.NET/Source/src/System.Reactive/Concurrency/ThreadPoolScheduler.cs
  10. 1 1
      Rx.NET/Source/src/System.Reactive/Concurrency/VirtualTimeScheduler.cs
  11. 2 2
      Rx.NET/Source/src/System.Reactive/Disposables/AnonymousDisposable.cs
  12. 2 2
      Rx.NET/Source/src/System.Reactive/Disposables/CompositeDisposable.cs
  13. 1 1
      Rx.NET/Source/src/System.Reactive/Disposables/ContextDisposable.cs
  14. 2 2
      Rx.NET/Source/src/System.Reactive/Disposables/RefCountDisposable.cs
  15. 2 2
      Rx.NET/Source/src/System.Reactive/IEventSource.cs
  16. 1 1
      Rx.NET/Source/src/System.Reactive/Internal/AutoDetachObserver.cs
  17. 4 4
      Rx.NET/Source/src/System.Reactive/Internal/ScheduledObserver.cs
  18. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/IQbservable.cs
  19. 1 1
      Rx.NET/Source/src/System.Reactive/Linq/IQbservableProvider.cs
  20. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/IQueryLanguage.cs
  21. 3 3
      Rx.NET/Source/src/System.Reactive/Linq/Observable.Multiple.cs
  22. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable.Time.cs
  23. 1 1
      Rx.NET/Source/src/System.Reactive/Linq/Observable/AmbMany.cs
  24. 4 4
      Rx.NET/Source/src/System.Reactive/Linq/Observable/Collect.cs
  25. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/ConcatMany.cs
  26. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/Delay.cs
  27. 1 1
      Rx.NET/Source/src/System.Reactive/Linq/Observable/FromEventPattern.cs
  28. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/Latest.cs
  29. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/MostRecent.cs
  30. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/Next.cs
  31. 2 2
      Rx.NET/Source/src/System.Reactive/Linq/Observable/RefCount.cs
  32. 1 1
      Rx.NET/Source/src/System.Reactive/Linq/Observable/Repeat.cs
  33. 3 3
      Rx.NET/Source/src/System.Reactive/Linq/Observable/RepeatWhen.cs
  34. 5 5
      Rx.NET/Source/src/System.Reactive/Linq/Observable/RetryWhen.cs
  35. 3 3
      Rx.NET/Source/src/System.Reactive/Linq/Observable/TakeUntilPredicate.cs
  36. 1 1
      Rx.NET/Source/src/System.Reactive/Linq/Observable/ToObservable.cs
  37. 2 2
      Rx.NET/Source/src/System.Reactive/ListObservable.cs
  38. 8 8
      Rx.NET/Source/src/System.Reactive/NamespaceDocs.cs
  39. 1 1
      Rx.NET/Source/src/System.Reactive/Notification.cs
  40. 1 1
      Rx.NET/Source/src/System.Reactive/Observer.Extensions.cs
  41. 1 1
      Rx.NET/Source/src/System.Reactive/ObserverBase.cs
  42. 8 8
      Rx.NET/Source/src/System.Reactive/Subjects/AsyncSubject.cs
  43. 1 1
      Rx.NET/Source/src/System.Reactive/Threading/Tasks/NamespaceDoc.cs
  44. 1 1
      Rx.NET/Source/src/System.Reactive/Timestamped.cs
  45. 2 2
      Rx.NET/Source/src/System.Reactive/Unit.cs

+ 6 - 6
Rx.NET/Source/src/System.Reactive/Concurrency/ConcurrencyAbstractionLayerImpl.cs

@@ -20,8 +20,8 @@ namespace System.Reactive.Concurrency
         {
         {
             public WorkItem(Action<object> action, object state)
             public WorkItem(Action<object> action, object state)
             {
             {
-                this.Action = action;
-                this.State = state;
+                Action = action;
+                State = state;
             }
             }
 
 
             public Action<object> Action { get; }
             public Action<object> Action { get; }
@@ -51,7 +51,7 @@ namespace System.Reactive.Concurrency
 
 
         public IDisposable QueueUserWorkItem(Action<object> action, object state)
         public IDisposable QueueUserWorkItem(Action<object> action, object state)
         {
         {
-            System.Threading.ThreadPool.QueueUserWorkItem(itemObject =>
+            ThreadPool.QueueUserWorkItem(itemObject =>
             {
             {
                 var item = (WorkItem)itemObject;
                 var item = (WorkItem)itemObject;
 
 
@@ -61,7 +61,7 @@ namespace System.Reactive.Concurrency
             return Disposable.Empty;
             return Disposable.Empty;
         }
         }
 
 
-        public void Sleep(TimeSpan timeout) => System.Threading.Thread.Sleep(Normalize(timeout));
+        public void Sleep(TimeSpan timeout) => Thread.Sleep(Normalize(timeout));
 
 
         public IStopwatch StartStopwatch() => new StopwatchImpl();
         public IStopwatch StartStopwatch() => new StopwatchImpl();
 
 
@@ -163,7 +163,7 @@ namespace System.Reactive.Concurrency
                 _state = state;
                 _state = state;
                 _action = action;
                 _action = action;
 
 
-                Disposable.SetSingle(ref _timer, new System.Threading.Timer(_ => Tick(_), this, dueTime, TimeSpan.FromMilliseconds(System.Threading.Timeout.Infinite)));
+                Disposable.SetSingle(ref _timer, new System.Threading.Timer(_ => Tick(_), this, dueTime, TimeSpan.FromMilliseconds(Timeout.Infinite)));
             }
             }
 
 
             private static void Tick(object state)
             private static void Tick(object state)
@@ -239,7 +239,7 @@ namespace System.Reactive.Concurrency
             {
             {
                 _action = action;
                 _action = action;
                 
                 
-                new System.Threading.Thread(_ => Loop(_))
+                new Thread(_ => Loop(_))
                 {
                 {
                     Name = "Rx-FastPeriodicTimer",
                     Name = "Rx-FastPeriodicTimer",
                     IsBackground = true
                     IsBackground = true

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/CurrentThreadScheduler.cs

@@ -55,7 +55,7 @@ namespace System.Reactive.Concurrency
         /// <summary>
         /// <summary>
         /// Gets a value that indicates whether the caller must call a Schedule method.
         /// Gets a value that indicates whether the caller must call a Schedule method.
         /// </summary>
         /// </summary>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Performance", "CA1822:MarkMembersAsStatic", Justification = "Now marked as obsolete.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Performance", "CA1822:MarkMembersAsStatic", Justification = "Now marked as obsolete.")]
         [EditorBrowsable(EditorBrowsableState.Never)]
         [EditorBrowsable(EditorBrowsableState.Never)]
         [Obsolete(Constants_Core.OBSOLETE_SCHEDULEREQUIRED)] // Preferring static method call over instance method call.
         [Obsolete(Constants_Core.OBSOLETE_SCHEDULEREQUIRED)] // Preferring static method call over instance method call.
         public bool ScheduleRequired => IsScheduleRequired;
         public bool ScheduleRequired => IsScheduleRequired;

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/DefaultScheduler.cs

@@ -157,7 +157,7 @@ namespace System.Reactive.Concurrency
                     _state = state;
                     _state = state;
                     _action = action;
                     _action = action;
 
 
-                    DefaultScheduler.s_cal.StartThread(
+                    s_cal.StartThread(
                         @thisObject =>
                         @thisObject =>
                         {
                         {
                             var @this = (LongScheduledWorkItem<TState>)@thisObject;
                             var @this = (LongScheduledWorkItem<TState>)@thisObject;

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/LocalScheduler.TimerQueue.cs

@@ -104,7 +104,7 @@ namespace System.Reactive.Concurrency
         /// <summary>
         /// <summary>
         /// Creates a new local scheduler.
         /// Creates a new local scheduler.
         /// </summary>
         /// </summary>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Performance", "CA1810:InitializeReferenceTypeStaticFieldsInline", Justification = "We can't really lift this into a field initializer, and would end up checking for an initialization flag in every static method anyway (which is roughly what the JIT does in a thread-safe manner).")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Performance", "CA1810:InitializeReferenceTypeStaticFieldsInline", Justification = "We can't really lift this into a field initializer, and would end up checking for an initialization flag in every static method anyway (which is roughly what the JIT does in a thread-safe manner).")]
         protected LocalScheduler()
         protected LocalScheduler()
         {
         {
             //
             //

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/SchedulerQueue.cs

@@ -9,7 +9,7 @@ namespace System.Reactive.Concurrency
     /// </summary>
     /// </summary>
     /// <typeparam name="TAbsolute">Absolute time representation type.</typeparam>
     /// <typeparam name="TAbsolute">Absolute time representation type.</typeparam>
     /// <remarks>This type is not thread safe; users should ensure proper synchronization.</remarks>
     /// <remarks>This type is not thread safe; users should ensure proper synchronization.</remarks>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1711:IdentifiersShouldNotHaveIncorrectSuffix", Justification = "But it *is* a queue!")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1711:IdentifiersShouldNotHaveIncorrectSuffix", Justification = "But it *is* a queue!")]
     public class SchedulerQueue<TAbsolute>
     public class SchedulerQueue<TAbsolute>
         where TAbsolute : IComparable<TAbsolute>
         where TAbsolute : IComparable<TAbsolute>
     {
     {

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.ObserveOn.cs

@@ -24,7 +24,7 @@ namespace System.Reactive.Concurrency
 
 
             protected override ObserveOnObserverNew<TSource> CreateSink(IObserver<TSource> observer) => new ObserveOnObserverNew<TSource>(_scheduler, observer);
             protected override ObserveOnObserverNew<TSource> CreateSink(IObserver<TSource> observer) => new ObserveOnObserverNew<TSource>(_scheduler, observer);
 
 
-            [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
+            [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
             protected override void Run(ObserveOnObserverNew<TSource> sink) => sink.Run(_source);
             protected override void Run(ObserveOnObserverNew<TSource> sink) => sink.Run(_source);
         }
         }
 
 
@@ -41,7 +41,7 @@ namespace System.Reactive.Concurrency
 
 
             protected override _ CreateSink(IObserver<TSource> observer) => new _(_context, observer);
             protected override _ CreateSink(IObserver<TSource> observer) => new _(_context, observer);
 
 
-            [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
+            [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
             protected override void Run(_ sink) => sink.Run(_source);
             protected override void Run(_ sink) => sink.Run(_source);
 
 
             internal sealed class _ : IdentitySink<TSource>
             internal sealed class _ : IdentitySink<TSource>

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.Synchronize.cs

@@ -22,7 +22,7 @@ namespace System.Reactive.Concurrency
 
 
         protected override _ CreateSink(IObserver<TSource> observer) => new _(this, observer);
         protected override _ CreateSink(IObserver<TSource> observer) => new _(this, observer);
 
 
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1062:Validate arguments of public methods", MessageId = "2", Justification = "Visibility restricted to friend assemblies. Those should be correct by inspection.")]
         protected override void Run(_ sink) => sink.Run(_source);
         protected override void Run(_ sink) => sink.Run(_source);
 
 
         internal sealed class _ : IdentitySink<TSource>
         internal sealed class _ : IdentitySink<TSource>

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Concurrency/Synchronization.cs

@@ -138,8 +138,8 @@ namespace System.Reactive.Concurrency
 
 
             public SubscribeOnCtxObservable(IObservable<TSource> source, SynchronizationContext context)
             public SubscribeOnCtxObservable(IObservable<TSource> source, SynchronizationContext context)
             {
             {
-                this._source = source;
-                this._context = context;
+                _source = source;
+                _context = context;
             }
             }
 
 
             protected override IDisposable SubscribeCore(IObserver<TSource> observer)
             protected override IDisposable SubscribeCore(IObserver<TSource> observer)

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Concurrency/ThreadPoolScheduler.cs

@@ -175,7 +175,7 @@ namespace System.Reactive.Concurrency
             private Func<TState, TState> _action;
             private Func<TState, TState> _action;
 
 
             private readonly AsyncLock _gate;
             private readonly AsyncLock _gate;
-            private volatile System.Threading.Timer _timer;
+            private volatile Timer _timer;
 
 
             public PeriodicTimer(TState state, TimeSpan period, Func<TState, TState> action)
             public PeriodicTimer(TState state, TimeSpan period, Func<TState, TState> action)
             {
             {
@@ -188,7 +188,7 @@ namespace System.Reactive.Concurrency
                 // Rooting of the timer happens through the this.Tick delegate's target object,
                 // Rooting of the timer happens through the this.Tick delegate's target object,
                 // which is the current instance and has a field to store the Timer instance.
                 // which is the current instance and has a field to store the Timer instance.
                 //
                 //
-                _timer = new System.Threading.Timer(@this => ((PeriodicTimer<TState>)@this).Tick(), this, period, period);
+                _timer = new Timer(@this => ((PeriodicTimer<TState>)@this).Tick(), this, period, period);
             }
             }
 
 
             private void Tick()
             private void Tick()

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Concurrency/VirtualTimeScheduler.cs

@@ -290,7 +290,7 @@ namespace System.Reactive.Concurrency
         /// Gets the next scheduled item to be executed.
         /// Gets the next scheduled item to be executed.
         /// </summary>
         /// </summary>
         /// <returns>The next scheduled item.</returns>
         /// <returns>The next scheduled item.</returns>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "By design. Side-effecting operation to retrieve the next element.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "By design. Side-effecting operation to retrieve the next element.")]
         protected abstract IScheduledItem<TAbsolute> GetNext();
         protected abstract IScheduledItem<TAbsolute> GetNext();
 
 
         object IServiceProvider.GetService(Type serviceType) => GetService(serviceType);
         object IServiceProvider.GetService(Type serviceType) => GetService(serviceType);

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Disposables/AnonymousDisposable.cs

@@ -19,7 +19,7 @@ namespace System.Reactive.Disposables
         /// <param name="dispose">Disposal action which will be run upon calling Dispose.</param>
         /// <param name="dispose">Disposal action which will be run upon calling Dispose.</param>
         public AnonymousDisposable(Action dispose)
         public AnonymousDisposable(Action dispose)
         {
         {
-            System.Diagnostics.Debug.Assert(dispose != null);
+            Diagnostics.Debug.Assert(dispose != null);
 
 
             _dispose = dispose;
             _dispose = dispose;
         }
         }
@@ -53,7 +53,7 @@ namespace System.Reactive.Disposables
         /// <param name="dispose">Disposal action which will be run upon calling Dispose.</param>
         /// <param name="dispose">Disposal action which will be run upon calling Dispose.</param>
         public AnonymousDisposable(TState state, Action<TState> dispose)
         public AnonymousDisposable(TState state, Action<TState> dispose)
         {
         {
-            System.Diagnostics.Debug.Assert(dispose != null);
+            Diagnostics.Debug.Assert(dispose != null);
 
 
             _state = state;
             _state = state;
             _dispose = dispose;
             _dispose = dispose;

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Disposables/CompositeDisposable.cs

@@ -12,7 +12,7 @@ namespace System.Reactive.Disposables
     /// <summary>
     /// <summary>
     /// Represents a group of disposable resources that are disposed together.
     /// Represents a group of disposable resources that are disposed together.
     /// </summary>
     /// </summary>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "Backward compat + ideally want to get rid of the ICollection nature of the type.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "Backward compat + ideally want to get rid of the ICollection nature of the type.")]
     public sealed class CompositeDisposable : ICollection<IDisposable>, ICancelable
     public sealed class CompositeDisposable : ICollection<IDisposable>, ICancelable
     {
     {
         private readonly object _gate = new object();
         private readonly object _gate = new object();
@@ -382,7 +382,7 @@ namespace System.Reactive.Disposables
             public CompositeEnumerator(IDisposable[] disposables)
             public CompositeEnumerator(IDisposable[] disposables)
             {
             {
                 this.disposables = disposables;
                 this.disposables = disposables;
-                this.index = -1;
+                index = -1;
             }
             }
 
 
             public IDisposable Current => disposables[index];
             public IDisposable Current => disposables[index];

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Disposables/ContextDisposable.cs

@@ -46,7 +46,7 @@ namespace System.Reactive.Disposables
         /// </summary>
         /// </summary>
         public void Dispose()
         public void Dispose()
         {
         {
-            Disposable.TryRelease(ref _disposable, this.Context, (disposable, context) => context.PostWithStartComplete(d => d.Dispose(), disposable));
+            Disposable.TryRelease(ref _disposable, Context, (disposable, context) => context.PostWithStartComplete(d => d.Dispose(), disposable));
         }
         }
     }
     }
 }
 }

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Disposables/RefCountDisposable.cs

@@ -55,7 +55,7 @@ namespace System.Reactive.Disposables
         /// </summary>
         /// </summary>
         /// <returns>A dependent disposable contributing to the reference count that manages the underlying disposable's lifetime.</returns>
         /// <returns>A dependent disposable contributing to the reference count that manages the underlying disposable's lifetime.</returns>
         /// <exception cref="ObjectDisposedException">This instance has been disposed and is configured to throw in this case by <see cref="RefCountDisposable(IDisposable, bool)"/>.</exception>
         /// <exception cref="ObjectDisposedException">This instance has been disposed and is configured to throw in this case by <see cref="RefCountDisposable(IDisposable, bool)"/>.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "Backward compat + non-trivial work for a property getter.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "Backward compat + non-trivial work for a property getter.")]
         public IDisposable GetDisposable()
         public IDisposable GetDisposable()
         {
         {
             // the current state
             // the current state
@@ -142,7 +142,7 @@ namespace System.Reactive.Disposables
                 // keep the main disposed state but decrement the counter
                 // keep the main disposed state but decrement the counter
                 // in theory, active should be always > 0 at this point,
                 // in theory, active should be always > 0 at this point,
                 // guaranteed by the InnerDisposable.Dispose's Exchange operation.
                 // guaranteed by the InnerDisposable.Dispose's Exchange operation.
-                System.Diagnostics.Debug.Assert(active > 0);
+                Diagnostics.Debug.Assert(active > 0);
                 var u = main | (active - 1);
                 var u = main | (active - 1);
 
 
                 var b = Interlocked.CompareExchange(ref _count, u, cnt);
                 var b = Interlocked.CompareExchange(ref _count, u, cnt);

+ 2 - 2
Rx.NET/Source/src/System.Reactive/IEventSource.cs

@@ -16,8 +16,8 @@ namespace System.Reactive
         /// <summary>
         /// <summary>
         /// Event signaling the next element in the data stream.
         /// Event signaling the next element in the data stream.
         /// </summary>
         /// </summary>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "By design.")]
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1009:DeclareEventHandlersCorrectly", Justification = "Can't do this for Action<T>.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "By design.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1009:DeclareEventHandlersCorrectly", Justification = "Can't do this for Action<T>.")]
         event Action<T> OnNext;
         event Action<T> OnNext;
     }
     }
 }
 }

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Internal/AutoDetachObserver.cs

@@ -100,7 +100,7 @@ namespace System.Reactive
 
 
             if (disposing)
             if (disposing)
             {
             {
-                Disposables.Disposable.TryDispose(ref _disposable);
+                Disposable.TryDispose(ref _disposable);
             }
             }
         }
         }
     }
     }

+ 4 - 4
Rx.NET/Source/src/System.Reactive/Internal/ScheduledObserver.cs

@@ -9,8 +9,8 @@ using System.Threading;
 
 
 namespace System.Reactive
 namespace System.Reactive
 {
 {
-    using System.Collections.Concurrent;
-    using System.Diagnostics;
+    using Collections.Concurrent;
+    using Diagnostics;
 
 
     internal class ScheduledObserver<T> : ObserverBase<T>, IScheduledObserver<T>
     internal class ScheduledObserver<T> : ObserverBase<T>, IScheduledObserver<T>
     {
     {
@@ -410,8 +410,8 @@ namespace System.Reactive
         {
         {
             this.downstream = downstream;
             this.downstream = downstream;
             this.scheduler = scheduler;
             this.scheduler = scheduler;
-            this.longRunning = scheduler.AsLongRunning();
-            this.queue = new ConcurrentQueue<T>();
+            longRunning = scheduler.AsLongRunning();
+            queue = new ConcurrentQueue<T>();
         }
         }
 
 
         public void Run(IObservable<T> source)
         public void Run(IObservable<T> source)

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/IQbservable.cs

@@ -13,7 +13,7 @@ namespace System.Reactive.Linq
     /// The type of the data in the data source.
     /// The type of the data in the data source.
     /// This type parameter is covariant. That is, you can use either the type you specified or any type that is more derived. For more information about covariance and contravariance, see Covariance and Contravariance in Generics.
     /// This type parameter is covariant. That is, you can use either the type you specified or any type that is more derived. For more information about covariance and contravariance, see Covariance and Contravariance in Generics.
     /// </typeparam>
     /// </typeparam>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
     public interface IQbservable<out T> : IQbservable, IObservable<T>
     public interface IQbservable<out T> : IQbservable, IObservable<T>
     {
     {
     }
     }
@@ -21,7 +21,7 @@ namespace System.Reactive.Linq
     /// <summary>
     /// <summary>
     /// Provides functionality to evaluate queries against a specific data source wherein the type of the data is not specified.
     /// Provides functionality to evaluate queries against a specific data source wherein the type of the data is not specified.
     /// </summary>
     /// </summary>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
     public interface IQbservable
     public interface IQbservable
     {
     {
         /// <summary>
         /// <summary>

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Linq/IQbservableProvider.cs

@@ -9,7 +9,7 @@ namespace System.Reactive.Linq
     /// <summary>
     /// <summary>
     /// Defines methods to create and execute queries that are described by an IQbservable object.
     /// Defines methods to create and execute queries that are described by an IQbservable object.
     /// </summary>
     /// </summary>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Qbservable", Justification = "What a pleasure to write 'by design' here.")]
     public interface IQbservableProvider
     public interface IQbservableProvider
     {
     {
         /// <summary>
         /// <summary>

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/IQueryLanguage.cs

@@ -713,8 +713,8 @@ namespace System.Reactive.Linq
         IObservable<TSource> Throttle<TSource>(IObservable<TSource> source, TimeSpan dueTime);
         IObservable<TSource> Throttle<TSource>(IObservable<TSource> source, TimeSpan dueTime);
         IObservable<TSource> Throttle<TSource>(IObservable<TSource> source, TimeSpan dueTime, IScheduler scheduler);
         IObservable<TSource> Throttle<TSource>(IObservable<TSource> source, TimeSpan dueTime, IScheduler scheduler);
         IObservable<TSource> Throttle<TSource, TThrottle>(IObservable<TSource> source, Func<TSource, IObservable<TThrottle>> throttleDurationSelector);
         IObservable<TSource> Throttle<TSource, TThrottle>(IObservable<TSource> source, Func<TSource, IObservable<TThrottle>> throttleDurationSelector);
-        IObservable<System.Reactive.TimeInterval<TSource>> TimeInterval<TSource>(IObservable<TSource> source);
-        IObservable<System.Reactive.TimeInterval<TSource>> TimeInterval<TSource>(IObservable<TSource> source, IScheduler scheduler);
+        IObservable<TimeInterval<TSource>> TimeInterval<TSource>(IObservable<TSource> source);
+        IObservable<TimeInterval<TSource>> TimeInterval<TSource>(IObservable<TSource> source, IScheduler scheduler);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime, IScheduler scheduler);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime, IScheduler scheduler);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime, IObservable<TSource> other);
         IObservable<TSource> Timeout<TSource>(IObservable<TSource> source, TimeSpan dueTime, IObservable<TSource> other);

+ 3 - 3
Rx.NET/Source/src/System.Reactive/Linq/Observable.Multiple.cs

@@ -21,7 +21,7 @@ namespace System.Reactive.Linq
         /// <param name="second">Second observable sequence.</param>
         /// <param name="second">Second observable sequence.</param>
         /// <returns>An observable sequence that surfaces either of the given sequences, whichever reacted first.</returns>
         /// <returns>An observable sequence that surfaces either of the given sequences, whichever reacted first.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="first"/> or <paramref name="second"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="first"/> or <paramref name="second"/> is null.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
         public static IObservable<TSource> Amb<TSource>(this IObservable<TSource> first, IObservable<TSource> second)
         public static IObservable<TSource> Amb<TSource>(this IObservable<TSource> first, IObservable<TSource> second)
         {
         {
             if (first == null)
             if (first == null)
@@ -39,7 +39,7 @@ namespace System.Reactive.Linq
         /// <param name="sources">Observable sources competing to react first.</param>
         /// <param name="sources">Observable sources competing to react first.</param>
         /// <returns>An observable sequence that surfaces any of the given sequences, whichever reacted first.</returns>
         /// <returns>An observable sequence that surfaces any of the given sequences, whichever reacted first.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="sources"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="sources"/> is null.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
         public static IObservable<TSource> Amb<TSource>(params IObservable<TSource>[] sources)
         public static IObservable<TSource> Amb<TSource>(params IObservable<TSource>[] sources)
         {
         {
             if (sources == null)
             if (sources == null)
@@ -55,7 +55,7 @@ namespace System.Reactive.Linq
         /// <param name="sources">Observable sources competing to react first.</param>
         /// <param name="sources">Observable sources competing to react first.</param>
         /// <returns>An observable sequence that surfaces any of the given sequences, whichever reacted first.</returns>
         /// <returns>An observable sequence that surfaces any of the given sequences, whichever reacted first.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="sources"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="sources"/> is null.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Amb", Justification = "In honor of McCarthy.")]
         public static IObservable<TSource> Amb<TSource>(this IEnumerable<IObservable<TSource>> sources)
         public static IObservable<TSource> Amb<TSource>(this IEnumerable<IObservable<TSource>> sources)
         {
         {
             if (sources == null)
             if (sources == null)

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable.Time.cs

@@ -1248,7 +1248,7 @@ namespace System.Reactive.Linq
         /// <param name="source">Source sequence to record time intervals for.</param>
         /// <param name="source">Source sequence to record time intervals for.</param>
         /// <returns>An observable sequence with time interval information on elements.</returns>
         /// <returns>An observable sequence with time interval information on elements.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="source"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="source"/> is null.</exception>
-        public static IObservable<System.Reactive.TimeInterval<TSource>> TimeInterval<TSource>(this IObservable<TSource> source)
+        public static IObservable<TimeInterval<TSource>> TimeInterval<TSource>(this IObservable<TSource> source)
         {
         {
             if (source == null)
             if (source == null)
                 throw new ArgumentNullException(nameof(source));
                 throw new ArgumentNullException(nameof(source));
@@ -1264,7 +1264,7 @@ namespace System.Reactive.Linq
         /// <param name="scheduler">Scheduler used to compute time intervals.</param>
         /// <param name="scheduler">Scheduler used to compute time intervals.</param>
         /// <returns>An observable sequence with time interval information on elements.</returns>
         /// <returns>An observable sequence with time interval information on elements.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="source"/> or <paramref name="scheduler"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="source"/> or <paramref name="scheduler"/> is null.</exception>
-        public static IObservable<System.Reactive.TimeInterval<TSource>> TimeInterval<TSource>(this IObservable<TSource> source, IScheduler scheduler)
+        public static IObservable<TimeInterval<TSource>> TimeInterval<TSource>(this IObservable<TSource> source, IScheduler scheduler)
         {
         {
             if (source == null)
             if (source == null)
                 throw new ArgumentNullException(nameof(source));
                 throw new ArgumentNullException(nameof(source));

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Linq/Observable/AmbMany.cs

@@ -146,7 +146,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public InnerObserver(AmbCoordinator<T> parent, int index)
             public InnerObserver(AmbCoordinator<T> parent, int index)
             {
             {
-                this.downstream = parent.downstream;
+                downstream = parent.downstream;
                 this.parent = parent;
                 this.parent = parent;
                 this.index = index;
                 this.index = index;
             }
             }

+ 4 - 4
Rx.NET/Source/src/System.Reactive/Linq/Observable/Collect.cs

@@ -63,14 +63,14 @@ namespace System.Reactive.Linq.ObservableImpl
                         _error = ex;
                         _error = ex;
                         _hasFailed = true;
                         _hasFailed = true;
 
 
-                        base.Dispose();
+                        Dispose();
                     }
                     }
                 }
                 }
             }
             }
 
 
             public override void OnError(Exception error)
             public override void OnError(Exception error)
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 lock (_gate)
                 lock (_gate)
                 {
                 {
@@ -81,7 +81,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnCompleted()
             public override void OnCompleted()
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 lock (_gate)
                 lock (_gate)
                 {
                 {
@@ -121,7 +121,7 @@ namespace System.Reactive.Linq.ObservableImpl
                             }
                             }
                             catch
                             catch
                             {
                             {
-                                base.Dispose();
+                                Dispose();
                                 throw;
                                 throw;
                             }
                             }
                         }
                         }

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/ConcatMany.cs

@@ -50,8 +50,8 @@ namespace System.Reactive.Linq.ObservableImpl
             internal ConcatManyOuterObserver(IObserver<T> downstream)
             internal ConcatManyOuterObserver(IObserver<T> downstream)
             {
             {
                 this.downstream = downstream;
                 this.downstream = downstream;
-                this.queue = new ConcurrentQueue<IObservable<T>>();
-                this.innerObserver = new InnerObserver(this);
+                queue = new ConcurrentQueue<IObservable<T>>();
+                innerObserver = new InnerObserver(this);
             }
             }
 
 
             internal void OnSubscribe(IDisposable d)
             internal void OnSubscribe(IDisposable d)

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/Delay.cs

@@ -454,7 +454,7 @@ namespace System.Reactive.Linq.ObservableImpl
                 _dueTime = dueTime;
                 _dueTime = dueTime;
             }
             }
 
 
-            protected override _ CreateSink(IObserver<TSource> observer) => _scheduler.AsLongRunning() != null ? (Base<Absolute>._)new L(this, observer) : new S(this, observer);
+            protected override _ CreateSink(IObserver<TSource> observer) => _scheduler.AsLongRunning() != null ? (_)new L(this, observer) : new S(this, observer);
 
 
             protected override void Run(_ sink) => sink.Run(this);
             protected override void Run(_ sink) => sink.Run(this);
 
 
@@ -558,7 +558,7 @@ namespace System.Reactive.Linq.ObservableImpl
                 _dueTime = dueTime;
                 _dueTime = dueTime;
             }
             }
 
 
-            protected override _ CreateSink(IObserver<TSource> observer) => _scheduler.AsLongRunning() != null ? (Base<Relative>._)new L(this, observer) : new S(this, observer);
+            protected override _ CreateSink(IObserver<TSource> observer) => _scheduler.AsLongRunning() != null ? (_)new L(this, observer) : new S(this, observer);
 
 
             protected override void Run(_ sink) => sink.Run(this);
             protected override void Run(_ sink) => sink.Run(this);
 
 

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Linq/Observable/FromEventPattern.cs

@@ -126,7 +126,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
                 public RemoveHandlerDisposable(Action removeHandler)
                 public RemoveHandlerDisposable(Action removeHandler)
                 {
                 {
-                    Volatile.Write(ref this._removeHandler, removeHandler);
+                    Volatile.Write(ref _removeHandler, removeHandler);
                 }
                 }
 
 
                 public void Dispose()
                 public void Dispose()

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/Latest.cs

@@ -52,7 +52,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnError(Exception error)
             public override void OnError(Exception error)
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 var lackedValue = false;
                 var lackedValue = false;
                 lock (_gate)
                 lock (_gate)
@@ -69,7 +69,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnCompleted()
             public override void OnCompleted()
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 var lackedValue = false;
                 var lackedValue = false;
                 lock (_gate)
                 lock (_gate)

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/MostRecent.cs

@@ -40,7 +40,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnError(Exception error)
             public override void OnError(Exception error)
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 _error = error;
                 _error = error;
                 _kind = NotificationKind.OnError;      // Write last!
                 _kind = NotificationKind.OnError;      // Write last!
@@ -48,7 +48,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnCompleted()
             public override void OnCompleted()
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 _kind = NotificationKind.OnCompleted;  // Write last!
                 _kind = NotificationKind.OnCompleted;  // Write last!
             }
             }

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/Next.cs

@@ -52,7 +52,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnError(Exception error)
             public override void OnError(Exception error)
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 lock (_gate)
                 lock (_gate)
                 {
                 {
@@ -71,7 +71,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public override void OnCompleted()
             public override void OnCompleted()
             {
             {
-                base.Dispose();
+                Dispose();
 
 
                 lock (_gate)
                 lock (_gate)
                 {
                 {

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Linq/Observable/RefCount.cs

@@ -38,7 +38,7 @@ namespace System.Reactive.Linq.ObservableImpl
                 public _(IObserver<TSource> observer, Eager parent)
                 public _(IObserver<TSource> observer, Eager parent)
                     : base(observer)
                     : base(observer)
                 {
                 {
-                    this._parent = parent;
+                    _parent = parent;
                 }
                 }
 
 
                 public void Run()
                 public void Run()
@@ -148,7 +148,7 @@ namespace System.Reactive.Linq.ObservableImpl
                                     {
                                     {
                                         lock (tuple2.closureParent._gate)
                                         lock (tuple2.closureParent._gate)
                                         {
                                         {
-                                            if (object.ReferenceEquals(Volatile.Read(ref tuple2.closureParent._serial), tuple2.cancelable))
+                                            if (ReferenceEquals(Volatile.Read(ref tuple2.closureParent._serial), tuple2.cancelable))
                                             {
                                             {
                                                 tuple2.closureParent._connectableSubscription.Dispose();
                                                 tuple2.closureParent._connectableSubscription.Dispose();
                                                 tuple2.closureParent._connectableSubscription = null;
                                                 tuple2.closureParent._connectableSubscription = null;

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Linq/Observable/Repeat.cs

@@ -59,7 +59,7 @@ namespace System.Reactive.Linq.ObservableImpl
                     while (!cancel.IsDisposed)
                     while (!cancel.IsDisposed)
                         ForwardOnNext(value);
                         ForwardOnNext(value);
 
 
-                    base.Dispose();
+                    Dispose();
                 }
                 }
             }
             }
         }
         }

+ 3 - 3
Rx.NET/Source/src/System.Reactive/Linq/Observable/RepeatWhen.cs

@@ -80,7 +80,7 @@ namespace System.Reactive.Linq.ObservableImpl
             {
             {
                 this.source = source;
                 this.source = source;
                 this.errorSignal = errorSignal;
                 this.errorSignal = errorSignal;
-                this.handlerObserver = new HandlerObserver(this);
+                handlerObserver = new HandlerObserver(this);
             }
             }
 
 
             protected override void Dispose(bool disposing)
             protected override void Dispose(bool disposing)
@@ -109,7 +109,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public void OnNext(T value)
             public void OnNext(T value)
             {
             {
-                HalfSerializer.ForwardOnNext(this, value, ref halfSerializer, ref this.error);
+                HalfSerializer.ForwardOnNext(this, value, ref halfSerializer, ref error);
             }
             }
 
 
             internal void HandlerError(Exception error)
             internal void HandlerError(Exception error)
@@ -119,7 +119,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             internal void HandlerComplete()
             internal void HandlerComplete()
             {
             {
-                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref this.error);
+                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref error);
             }
             }
 
 
             internal void HandlerNext()
             internal void HandlerNext()

+ 5 - 5
Rx.NET/Source/src/System.Reactive/Linq/Observable/RetryWhen.cs

@@ -80,7 +80,7 @@ namespace System.Reactive.Linq.ObservableImpl
             {
             {
                 this.source = source;
                 this.source = source;
                 this.errorSignal = errorSignal;
                 this.errorSignal = errorSignal;
-                this.handlerObserver = new HandlerObserver(this);
+                handlerObserver = new HandlerObserver(this);
             }
             }
 
 
             protected override void Dispose(bool disposing)
             protected override void Dispose(bool disposing)
@@ -95,7 +95,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public void OnCompleted()
             public void OnCompleted()
             {
             {
-                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref this.error);
+                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref error);
             }
             }
 
 
             public void OnError(Exception error)
             public void OnError(Exception error)
@@ -108,7 +108,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             public void OnNext(T value)
             public void OnNext(T value)
             {
             {
-                HalfSerializer.ForwardOnNext(this, value, ref halfSerializer, ref this.error);
+                HalfSerializer.ForwardOnNext(this, value, ref halfSerializer, ref error);
             }
             }
 
 
             internal void HandlerError(Exception error)
             internal void HandlerError(Exception error)
@@ -118,7 +118,7 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
             internal void HandlerComplete()
             internal void HandlerComplete()
             {
             {
-                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref this.error);
+                HalfSerializer.ForwardOnCompleted(this, ref halfSerializer, ref error);
             }
             }
 
 
             internal void HandlerNext()
             internal void HandlerNext()
@@ -183,7 +183,7 @@ namespace System.Reactive.Linq.ObservableImpl
         internal RedoSerializedObserver(IObserver<X> downstream)
         internal RedoSerializedObserver(IObserver<X> downstream)
         {
         {
             this.downstream = downstream;
             this.downstream = downstream;
-            this.queue = new ConcurrentQueue<X>();
+            queue = new ConcurrentQueue<X>();
         }
         }
 
 
         public void OnCompleted()
         public void OnCompleted()

+ 3 - 3
Rx.NET/Source/src/System.Reactive/Linq/Observable/TakeUntilPredicate.cs

@@ -21,8 +21,8 @@ namespace System.Reactive.Linq.ObservableImpl
 
 
         public TakeUntilPredicate(IObservable<TSource> source, Func<TSource, bool> stopPredicate)
         public TakeUntilPredicate(IObservable<TSource> source, Func<TSource, bool> stopPredicate)
         {
         {
-            this._source = source;
-            this._stopPredicate = stopPredicate;
+            _source = source;
+            _stopPredicate = stopPredicate;
         }
         }
 
 
         protected override TakeUntilPredicateObserver CreateSink(IObserver<TSource> observer) => new TakeUntilPredicateObserver(observer, _stopPredicate);
         protected override TakeUntilPredicateObserver CreateSink(IObserver<TSource> observer) => new TakeUntilPredicateObserver(observer, _stopPredicate);
@@ -36,7 +36,7 @@ namespace System.Reactive.Linq.ObservableImpl
             public TakeUntilPredicateObserver(IObserver<TSource> downstream, 
             public TakeUntilPredicateObserver(IObserver<TSource> downstream, 
                 Func<TSource, bool> predicate) : base (downstream)
                 Func<TSource, bool> predicate) : base (downstream)
             {
             {
-                this._stopPredicate = predicate;
+                _stopPredicate = predicate;
             }
             }
 
 
             public override void OnCompleted()
             public override void OnCompleted()

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Linq/Observable/ToObservable.cs

@@ -160,7 +160,7 @@ namespace System.Reactive.Linq.ObservableImpl
                 }
                 }
 
 
                 enumerator.Dispose();
                 enumerator.Dispose();
-                base.Dispose();
+                Dispose();
             }
             }
         }
         }
     }
     }

+ 2 - 2
Rx.NET/Source/src/System.Reactive/ListObservable.cs

@@ -16,7 +16,7 @@ namespace System.Reactive
     /// Represents an object that retains the elements of the observable sequence and signals the end of the sequence.
     /// Represents an object that retains the elements of the observable sequence and signals the end of the sequence.
     /// </summary>
     /// </summary>
     /// <typeparam name="T">The type of elements received from the source sequence.</typeparam>
     /// <typeparam name="T">The type of elements received from the source sequence.</typeparam>
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "By design; Observable suffix takes precedence.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1710:IdentifiersShouldHaveCorrectSuffix", Justification = "By design; Observable suffix takes precedence.")]
     [Experimental]
     [Experimental]
     public class ListObservable<T> : IList<T>, IObservable<object>
     public class ListObservable<T> : IList<T>, IObservable<object>
     {
     {
@@ -207,4 +207,4 @@ namespace System.Reactive
             return StableCompositeDisposable.Create(subscription, subject.Subscribe(observer));
             return StableCompositeDisposable.Create(subscription, subject.Subscribe(observer));
         }
         }
     }
     }
-}
+}

+ 8 - 8
Rx.NET/Source/src/System.Reactive/NamespaceDocs.cs

@@ -7,7 +7,7 @@ namespace System.Reactive
     /// <summary>
     /// <summary>
     /// The <b>System.Reactive</b> namespace contains interfaces and classes used throughout the Reactive Extensions library.
     /// The <b>System.Reactive</b> namespace contains interfaces and classes used throughout the Reactive Extensions library.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -20,7 +20,7 @@ namespace System.Reactive.Concurrency
     /// process event streams. Schedulers are used to parameterize the concurrency introduced by query operators, provide means to virtualize time, to process historical data,
     /// process event streams. Schedulers are used to parameterize the concurrency introduced by query operators, provide means to virtualize time, to process historical data,
     /// and to write unit tests for functionality built using Reactive Extensions constructs.
     /// and to write unit tests for functionality built using Reactive Extensions constructs.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -33,7 +33,7 @@ namespace System.Reactive.Disposables
     /// management in Reactive Extensions. Those types are used extensively within the implementation of Reactive Extensions and are useful when writing custom query operators or
     /// management in Reactive Extensions. Those types are used extensively within the implementation of Reactive Extensions and are useful when writing custom query operators or
     /// schedulers.
     /// schedulers.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -45,7 +45,7 @@ namespace System.Reactive.Linq
     /// The <b>System.Reactive.Linq</b> namespace contains interfaces and classes that support expressing queries over observable sequences, using Language Integrated Query (LINQ).
     /// The <b>System.Reactive.Linq</b> namespace contains interfaces and classes that support expressing queries over observable sequences, using Language Integrated Query (LINQ).
     /// Query operators are made available as extension methods for <see cref="IObservable{T}"/> and <see cref="IQbservable{T}"/> defined on the Observable and Qbservable classes, respectively.
     /// Query operators are made available as extension methods for <see cref="IObservable{T}"/> and <see cref="IQbservable{T}"/> defined on the Observable and Qbservable classes, respectively.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -58,7 +58,7 @@ namespace System.Reactive.Subjects
     /// Subjects are often used as sources of events, allowing one party to raise events and allowing another party to write queries over the event stream. Because of their ability to
     /// Subjects are often used as sources of events, allowing one party to raise events and allowing another party to write queries over the event stream. Because of their ability to
     /// have multiple registered observers, subjects are also used as a facility to provide multicast behavior for event streams in queries.
     /// have multiple registered observers, subjects are also used as a facility to provide multicast behavior for event streams in queries.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -70,7 +70,7 @@ namespace System.Reactive.PlatformServices
     /// The <b>System.Reactive.PlatformServices</b> namespace contains interfaces and classes used by the runtime infrastructure of Reactive Extensions.
     /// The <b>System.Reactive.PlatformServices</b> namespace contains interfaces and classes used by the runtime infrastructure of Reactive Extensions.
     /// Those are not intended to be used directly from user code and are subject to change in future releases of the product.
     /// Those are not intended to be used directly from user code and are subject to change in future releases of the product.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
@@ -81,8 +81,8 @@ namespace System.Reactive.Joins
     /// <summary>
     /// <summary>
     /// The <b>System.Reactive.Joins</b> namespace contains classes used to express join patterns over observable sequences using fluent method syntax.
     /// The <b>System.Reactive.Joins</b> namespace contains classes used to express join patterns over observable sequences using fluent method syntax.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }
-}
+}

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Notification.cs

@@ -41,7 +41,7 @@ namespace System.Reactive
 #if !NO_SERIALIZABLE
 #if !NO_SERIALIZABLE
     [Serializable]
     [Serializable]
 #endif
 #endif
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA2218:OverrideGetHashCodeOnOverridingEquals", Justification = "Resembles a discriminated union with finite number of subclasses (external users shouldn't create their own subtypes), each of which does override GetHashCode itself.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA2218:OverrideGetHashCodeOnOverridingEquals", Justification = "Resembles a discriminated union with finite number of subclasses (external users shouldn't create their own subtypes), each of which does override GetHashCode itself.")]
     public abstract class Notification<T> : IEquatable<Notification<T>>
     public abstract class Notification<T> : IEquatable<Notification<T>>
     {
     {
         /// <summary>
         /// <summary>

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Observer.Extensions.cs

@@ -38,7 +38,7 @@ namespace System.Reactive
         /// <param name="observer">Observer object.</param>
         /// <param name="observer">Observer object.</param>
         /// <returns>The action that forwards its input notification to the underlying observer.</returns>
         /// <returns>The action that forwards its input notification to the underlying observer.</returns>
         /// <exception cref="ArgumentNullException"><paramref name="observer"/> is null.</exception>
         /// <exception cref="ArgumentNullException"><paramref name="observer"/> is null.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Notifier", Justification = "Backward compat.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Notifier", Justification = "Backward compat.")]
         public static Action<Notification<T>> ToNotifier<T>(this IObserver<T> observer)
         public static Action<Notification<T>> ToNotifier<T>(this IObserver<T> observer)
         {
         {
             if (observer == null)
             if (observer == null)

+ 1 - 1
Rx.NET/Source/src/System.Reactive/ObserverBase.cs

@@ -63,7 +63,7 @@ namespace System.Reactive
         /// </summary>
         /// </summary>
         /// <param name="error">The error that has occurred.</param>
         /// <param name="error">The error that has occurred.</param>
         /// <remarks>This method only gets called when the observer hasn't stopped yet, and causes the observer to stop.</remarks>
         /// <remarks>This method only gets called when the observer hasn't stopped yet, and causes the observer to stop.</remarks>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1716:IdentifiersShouldNotMatchKeywords", MessageId = "Error", Justification = "Same name as in the IObserver<T> definition of OnError in the BCL.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1716:IdentifiersShouldNotMatchKeywords", MessageId = "Error", Justification = "Same name as in the IObserver<T> definition of OnError in the BCL.")]
         protected abstract void OnErrorCore(Exception error);
         protected abstract void OnErrorCore(Exception error);
 
 
         /// <summary>
         /// <summary>

+ 8 - 8
Rx.NET/Source/src/System.Reactive/Subjects/AsyncSubject.cs

@@ -77,7 +77,7 @@ namespace System.Reactive.Subjects
         {
         {
             for (; ; )
             for (; ; )
             {
             {
-                var observers = Volatile.Read(ref this._observers);
+                var observers = Volatile.Read(ref _observers);
                 if (observers == DISPOSED)
                 if (observers == DISPOSED)
                 {
                 {
                     _exception = null;
                     _exception = null;
@@ -90,10 +90,10 @@ namespace System.Reactive.Subjects
                 }
                 }
                 if (Interlocked.CompareExchange(ref _observers, TERMINATED, observers) == observers)
                 if (Interlocked.CompareExchange(ref _observers, TERMINATED, observers) == observers)
                 {
                 {
-                    var hasValue = this._hasValue;
+                    var hasValue = _hasValue;
                     if (hasValue)
                     if (hasValue)
                     {
                     {
-                        var value = this._value;
+                        var value = _value;
 
 
                         foreach (var o in observers)
                         foreach (var o in observers)
                         {
                         {
@@ -130,7 +130,7 @@ namespace System.Reactive.Subjects
 
 
             for (; ; )
             for (; ; )
             {
             {
-                var observers = Volatile.Read(ref this._observers);
+                var observers = Volatile.Read(ref _observers);
                 if (observers == DISPOSED)
                 if (observers == DISPOSED)
                 {
                 {
                     _exception = null;
                     _exception = null;
@@ -142,10 +142,10 @@ namespace System.Reactive.Subjects
                 {
                 {
                     break;
                     break;
                 }
                 }
-                this._exception = error;
+                _exception = error;
                 if (Interlocked.CompareExchange(ref _observers, TERMINATED, observers) == observers)
                 if (Interlocked.CompareExchange(ref _observers, TERMINATED, observers) == observers)
                 {
                 {
-                    var ex = this._exception;
+                    var ex = _exception;
                     foreach (var o in observers)
                     foreach (var o in observers)
                     {
                     {
                         if (!o.IsDisposed())
                         if (!o.IsDisposed())
@@ -164,7 +164,7 @@ namespace System.Reactive.Subjects
         /// <param name="value">The value to store in the subject.</param>
         /// <param name="value">The value to store in the subject.</param>
         public override void OnNext(T value)
         public override void OnNext(T value)
         {
         {
-            var observers = Volatile.Read(ref this._observers);
+            var observers = Volatile.Read(ref _observers);
             if (observers == DISPOSED)
             if (observers == DISPOSED)
             {
             {
                 _value = default(T);
                 _value = default(T);
@@ -424,7 +424,7 @@ namespace System.Reactive.Subjects
         /// </summary>
         /// </summary>
         /// <returns>The last element of the subject. Throws an InvalidOperationException if no element was received.</returns>
         /// <returns>The last element of the subject. Throws an InvalidOperationException if no element was received.</returns>
         /// <exception cref="InvalidOperationException">The source sequence is empty.</exception>
         /// <exception cref="InvalidOperationException">The source sequence is empty.</exception>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "Await pattern for C# and VB compilers.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Design", "CA1024:UsePropertiesWhereAppropriate", Justification = "Await pattern for C# and VB compilers.")]
         public T GetResult()
         public T GetResult()
         {
         {
             if (Volatile.Read(ref _observers) != TERMINATED)
             if (Volatile.Read(ref _observers) != TERMINATED)

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Threading/Tasks/NamespaceDoc.cs

@@ -7,7 +7,7 @@ namespace System.Reactive.Threading.Tasks
     /// <summary>
     /// <summary>
     /// The <b>System.Reactive.Threading.Tasks</b> namespace contains helpers for the conversion between tasks and observable sequences.
     /// The <b>System.Reactive.Threading.Tasks</b> namespace contains helpers for the conversion between tasks and observable sequences.
     /// </summary>
     /// </summary>
-    [System.Runtime.CompilerServices.CompilerGenerated]
+    [Runtime.CompilerServices.CompilerGenerated]
     class NamespaceDoc
     class NamespaceDoc
     {
     {
     }
     }

+ 1 - 1
Rx.NET/Source/src/System.Reactive/Timestamped.cs

@@ -15,7 +15,7 @@ namespace System.Reactive
 #if !NO_SERIALIZABLE
 #if !NO_SERIALIZABLE
     [Serializable]
     [Serializable]
 #endif
 #endif
-    [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Timestamped", Justification = "Reviewed and agreed upon.")]
+    [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Naming", "CA1704:IdentifiersShouldBeSpelledCorrectly", MessageId = "Timestamped", Justification = "Reviewed and agreed upon.")]
     public struct Timestamped<T> : IEquatable<Timestamped<T>>
     public struct Timestamped<T> : IEquatable<Timestamped<T>>
     {
     {
         /// <summary>
         /// <summary>

+ 2 - 2
Rx.NET/Source/src/System.Reactive/Unit.cs

@@ -44,7 +44,7 @@ namespace System.Reactive
         /// <param name="first">The first <see cref="Unit"/> value to compare.</param>
         /// <param name="first">The first <see cref="Unit"/> value to compare.</param>
         /// <param name="second">The second <see cref="Unit"/> value to compare.</param>
         /// <param name="second">The second <see cref="Unit"/> value to compare.</param>
         /// <returns>Because <see cref="Unit"/> has a single value, this always returns <c>true</c>.</returns>
         /// <returns>Because <see cref="Unit"/> has a single value, this always returns <c>true</c>.</returns>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "first", Justification = "Parameter required for operator overloading."), System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "second", Justification = "Parameter required for operator overloading.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "first", Justification = "Parameter required for operator overloading."), Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "second", Justification = "Parameter required for operator overloading.")]
         public static bool operator ==(Unit first, Unit second) => true;
         public static bool operator ==(Unit first, Unit second) => true;
 
 
         /// <summary>
         /// <summary>
@@ -53,7 +53,7 @@ namespace System.Reactive
         /// <param name="first">The first <see cref="Unit"/> value to compare.</param>
         /// <param name="first">The first <see cref="Unit"/> value to compare.</param>
         /// <param name="second">The second <see cref="Unit"/> value to compare.</param>
         /// <param name="second">The second <see cref="Unit"/> value to compare.</param>
         /// <returns>Because <see cref="Unit"/> has a single value, this always returns <c>false</c>.</returns>
         /// <returns>Because <see cref="Unit"/> has a single value, this always returns <c>false</c>.</returns>
-        [System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "first", Justification = "Parameter required for operator overloading."), System.Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "second", Justification = "Parameter required for operator overloading.")]
+        [Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "first", Justification = "Parameter required for operator overloading."), Diagnostics.CodeAnalysis.SuppressMessage("Microsoft.Usage", "CA1801:ReviewUnusedParameters", MessageId = "second", Justification = "Parameter required for operator overloading.")]
         public static bool operator !=(Unit first, Unit second) => false;
         public static bool operator !=(Unit first, Unit second) => false;
 
 
         /// <summary>
         /// <summary>