File: Tagging\AbstractAsynchronousTaggerProvider.TagSource.cs
Web Access
Project: ..\..\..\src\EditorFeatures\Core\Microsoft.CodeAnalysis.EditorFeatures.csproj (Microsoft.CodeAnalysis.EditorFeatures)
// Licensed to the .NET Foundation under one or more agreements.
// The .NET Foundation licenses this file to you under the MIT license.
// See the LICENSE file in the project root for more information.
 
using System;
using System.Collections.Generic;
using System.Collections.Immutable;
using System.Linq;
using System.Threading;
using System.Threading.Tasks;
using Microsoft.CodeAnalysis.Editor.Shared.Extensions;
using Microsoft.CodeAnalysis.Editor.Shared.Tagging;
using Microsoft.CodeAnalysis.Editor.Shared.Utilities;
using Microsoft.CodeAnalysis.Options;
using Microsoft.CodeAnalysis.Shared.TestHooks;
using Microsoft.CodeAnalysis.Text;
using Microsoft.CodeAnalysis.Workspaces;
using Microsoft.VisualStudio.Text;
using Microsoft.VisualStudio.Text.Editor;
using Microsoft.VisualStudio.Text.Tagging;
using Roslyn.Utilities;
 
namespace Microsoft.CodeAnalysis.Editor.Tagging
{
    internal partial class AbstractAsynchronousTaggerProvider<TTag>
    {
        /// <summary>
        /// <para>The <see cref="TagSource"/> is the core part of our asynchronous
        /// tagging infrastructure. It is the coordinator between <see cref="ProduceTagsAsync(TaggerContext{TTag}, CancellationToken)"/>s,
        /// <see cref="ITaggerEventSource"/>s, and <see cref="ITagger{T}"/>s.</para>
        /// 
        /// <para>The <see cref="TagSource"/> is the type that actually owns the
        /// list of cached tags. When an <see cref="ITaggerEventSource"/> says tags need to be  recomputed,
        /// the tag source starts the computation and calls <see cref="ProduceTagsAsync(TaggerContext{TTag}, CancellationToken)"/> to build
        /// the new list of tags. When that's done, the tags are stored in <see cref="CachedTagTrees"/>. The 
        /// tagger, when asked for tags from the editor, then returns the tags that are stored in 
        /// <see cref="CachedTagTrees"/></para>
        /// 
        /// <para>There is a one-to-many relationship between <see cref="TagSource"/>s
        /// and <see cref="ITagger{T}"/>s. Special cases, like reference highlighting (which processes multiple
        /// subject buffers at once) have their own providers and tag source derivations.</para>
        /// </summary>
        private sealed partial class TagSource
        {
            /// <summary>
            /// If we get more than this many differences, then we just issue it as a single change
            /// notification.  The number has been completely made up without any data to support it.
            /// 
            /// Internal for testing purposes.
            /// </summary>
            private const int CoalesceDifferenceCount = 10;
 
            #region Fields that can be accessed from either thread
 
            private readonly AbstractAsynchronousTaggerProvider<TTag> _dataSource;
 
            /// <summary>
            /// async operation notifier
            /// </summary>
            private readonly IAsynchronousOperationListener _asyncListener;
 
            /// <summary>
            /// Information about what workspace the buffer we're tagging is associated with.
            /// </summary>
            private readonly WorkspaceRegistration _workspaceRegistration;
 
            /// <summary>
            /// Work queue that collects high priority requests to call TagsChanged with.
            /// </summary>
            private readonly AsyncBatchingWorkQueue<NormalizedSnapshotSpanCollection> _highPriTagsChangedQueue;
 
            /// <summary>
            /// Work queue that collects normal priority requests to call TagsChanged with.
            /// </summary>
            private readonly AsyncBatchingWorkQueue<NormalizedSnapshotSpanCollection> _normalPriTagsChangedQueue;
 
            /// <summary>
            /// Boolean specifies if this is the initial set of tags being computed or not.  This queue is used to batch
            /// up event change notifications and only dispatch one recomputation every <see cref="EventChangeDelay"/>
            /// to actually produce the latest set of tags.
            /// </summary>
            private readonly AsyncBatchingWorkQueue<bool> _eventChangeQueue;
 
            #endregion
 
            #region Fields that can only be accessed from the foreground thread
 
            /// <summary>
            /// Cancellation token governing all our async work.  Canceled/disposed when we are <see cref="Dispose"/>'d.
            /// </summary>
            private readonly CancellationTokenSource _disposalTokenSource = new();
 
            private readonly ITextView? _textView;
            private readonly ITextBuffer _subjectBuffer;
 
            /// <summary>
            /// Used to keep track of if this <see cref="_subjectBuffer"/> is visible or not (e.g. is in some <see
            /// cref="ITextView"/> that has some part visible or not.  This is used so we can <see
            /// cref="PauseIfNotVisible"/> tagging when not visible to avoid wasting machine resources. Note: we do not
            /// examine <see cref="_textView"/> for this as that is only available for "view taggers" (taggers which
            /// only tag portions of the view) whereas we want this for all taggers (including just buffer taggers which
            /// tag the entire document).
            /// </summary>
            private readonly ITextBufferVisibilityTracker? _visibilityTracker;
 
            /// <summary>
            /// Callback to us when the visibility of our <see cref="_subjectBuffer"/> changes.
            /// </summary>
            private readonly Action _onVisibilityChanged;
 
            /// <summary>
            /// Our tagger event source that lets us know when we should call into the tag producer for
            /// new tags.
            /// </summary>
            private readonly ITaggerEventSource _eventSource;
 
            #region Mutable state.  Can only be accessed from the foreground thread
 
            /// <summary>
            /// accumulated text changes since last tag calculation
            /// </summary>
            private TextChangeRange? _accumulatedTextChanges_doNotAccessDirectly;
            private ImmutableDictionary<ITextBuffer, TagSpanIntervalTree<TTag>> _cachedTagTrees_doNotAccessDirectly = ImmutableDictionary.Create<ITextBuffer, TagSpanIntervalTree<TTag>>();
            private object? _state_doNotAccessDirecty;
 
            /// <summary>
            /// Keep track of if we are processing the first <see cref="ITagger{T}.GetTags"/> request.  If our provider returns 
            /// <see langword="true"/> for <see cref="AbstractAsynchronousTaggerProvider{TTag}.ComputeInitialTagsSynchronously"/>,
            /// then we'll want to synchronously block then and only then for tags.
            /// </summary>
            private bool _firstTagsRequest = true;
 
            /// <summary>
            /// Whether or not tag generation is paused.  We pause producing tags when documents become non-visible.
            /// See <see cref="_visibilityTracker"/>.
            /// </summary>
            private bool _paused = false;
 
            #endregion
 
            #endregion
 
            public TagSource(
                ITextView? textView,
                ITextBuffer subjectBuffer,
                ITextBufferVisibilityTracker? visibilityTracker,
                AbstractAsynchronousTaggerProvider<TTag> dataSource,
                IAsynchronousOperationListener asyncListener)
            {
                dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                if (dataSource.SpanTrackingMode == SpanTrackingMode.Custom)
                    throw new ArgumentException("SpanTrackingMode.Custom not allowed.", "spanTrackingMode");
 
                _textView = textView;
                _subjectBuffer = subjectBuffer;
                _visibilityTracker = visibilityTracker;
                _dataSource = dataSource;
                _asyncListener = asyncListener;
 
                _workspaceRegistration = Workspace.GetWorkspaceRegistration(subjectBuffer.AsTextContainer());
 
                // Collapse all booleans added to just a max of two ('true' or 'false') representing if we're being
                // asked for initial tags or not
                _eventChangeQueue = new AsyncBatchingWorkQueue<bool>(
                    dataSource.EventChangeDelay.ComputeTimeDelay(),
                    ProcessEventChangeAsync,
                    EqualityComparer<bool>.Default,
                    asyncListener,
                    _disposalTokenSource.Token);
 
                _highPriTagsChangedQueue = new AsyncBatchingWorkQueue<NormalizedSnapshotSpanCollection>(
                    TaggerDelay.NearImmediate.ComputeTimeDelay(),
                    ProcessTagsChangedAsync,
                    equalityComparer: null,
                    asyncListener,
                    _disposalTokenSource.Token);
 
                if (_dataSource.AddedTagNotificationDelay == TaggerDelay.NearImmediate)
                {
                    // if the tagger wants "added tags" to be reported "NearImmediate"ly, then just reuse
                    // the "high pri" queue as that already reports things at that cadence.
                    _normalPriTagsChangedQueue = _highPriTagsChangedQueue;
                }
                else
                {
                    _normalPriTagsChangedQueue = new AsyncBatchingWorkQueue<NormalizedSnapshotSpanCollection>(
                        _dataSource.AddedTagNotificationDelay.ComputeTimeDelay(),
                        ProcessTagsChangedAsync,
                        equalityComparer: null,
                        asyncListener,
                        _disposalTokenSource.Token);
                }
 
                DebugRecordInitialStackTrace();
 
                // Create the tagger-specific events that will cause the tagger to refresh.
                _eventSource = CreateEventSource();
 
                // any time visibility changes, resume tagging on all taggers.  Any non-visible taggers will pause
                // themselves immediately afterwards.
                _onVisibilityChanged = () => ResumeIfVisible();
 
                // Now hook up this tagger to all interesting events.
                Connect();
 
                // Now that we're all hooked up to the events we care about, start computing the initial set of tags at
                // high priority.  We want to get the UI to a complete state as soon as possible.
                EnqueueWork(highPriority: true);
 
                return;
 
                // Represented as a local function just so we can keep this in sync with Dispose.Disconnect below.
                void Connect()
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
 
                    // Register to hear about visibility changes so we can pause/resume this tagger.
                    _visibilityTracker?.RegisterForVisibilityChanges(subjectBuffer, _onVisibilityChanged);
 
                    _eventSource.Changed += OnEventSourceChanged;
 
                    if (_dataSource.TextChangeBehavior.HasFlag(TaggerTextChangeBehavior.TrackTextChanges))
                        _subjectBuffer.Changed += OnSubjectBufferChanged;
 
                    if (_dataSource.CaretChangeBehavior.HasFlag(TaggerCaretChangeBehavior.RemoveAllTagsOnCaretMoveOutsideOfTag))
                    {
                        if (_textView == null)
                        {
                            throw new ArgumentException(
                                nameof(_dataSource.CaretChangeBehavior) + " can only be specified for an " + nameof(IViewTaggerProvider));
                        }
 
                        _textView.Caret.PositionChanged += OnCaretPositionChanged;
                    }
 
                    // Tell the interaction object to start issuing events.
                    _eventSource.Connect();
                }
            }
 
            private void Dispose()
            {
                _disposalTokenSource.Cancel();
                _disposalTokenSource.Dispose();
 
                _dataSource.RemoveTagSource(_textView, _subjectBuffer);
                GC.SuppressFinalize(this);
 
                Disconnect();
 
                return;
 
                // Keep in sync with TagSource.Connect above (just performing the disconnect operations in the reverse order
                void Disconnect()
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
 
                    // Tell the interaction object to stop issuing events.
                    _eventSource.Disconnect();
 
                    if (_dataSource.CaretChangeBehavior.HasFlag(TaggerCaretChangeBehavior.RemoveAllTagsOnCaretMoveOutsideOfTag))
                    {
                        Contract.ThrowIfNull(_textView);
                        _textView.Caret.PositionChanged -= OnCaretPositionChanged;
                    }
 
                    if (_dataSource.TextChangeBehavior.HasFlag(TaggerTextChangeBehavior.TrackTextChanges))
                        _subjectBuffer.Changed -= OnSubjectBufferChanged;
 
                    _eventSource.Changed -= OnEventSourceChanged;
 
                    _visibilityTracker?.UnregisterForVisibilityChanges(_subjectBuffer, _onVisibilityChanged);
                }
            }
 
            private bool IsVisible()
                => _visibilityTracker == null || _visibilityTracker.IsVisible(_subjectBuffer);
 
            private void PauseIfNotVisible()
            {
                _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
 
                if (!IsVisible())
                {
                    _paused = true;
                    _eventSource.Pause();
                }
            }
 
            private void ResumeIfVisible()
            {
                _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
 
                // if we're not actually paused, no need to do anything.
                if (!_paused)
                    return;
 
                // If we're not visible, no need to resume.
                if (!IsVisible())
                    return;
 
                // Set us back to running, and kick off work to compute tags now that we're visible again.
                _paused = false;
                _eventSource.Resume();
 
                // We just transitioned to being visible, compute our tags at high priority so the view is updated as
                // quickly as possible.
                EnqueueWork(highPriority: true);
            }
 
            private ITaggerEventSource CreateEventSource()
            {
                Contract.ThrowIfTrue(_dataSource.Options.Any(o => o is not Option2<bool> and not PerLanguageOption2<bool>), "All options must be Option2<bool> or PerLanguageOption2<bool>");
 
                var eventSource = _dataSource.CreateEventSource(_textView, _subjectBuffer);
 
                // If there are any options specified for this tagger, then also hook up event
                // notifications for when those options change.
                var optionChangedEventSources = _dataSource.Options.Concat(_dataSource.FeatureOptions)
                    .Select(globalOption => TaggerEventSources.OnGlobalOptionChanged(_dataSource.GlobalOptions, globalOption))
                    .ToList();
 
                if (optionChangedEventSources.Count == 0)
                {
                    // No options specified for this tagger.  So just keep the event source as is.
                    return eventSource;
                }
 
                optionChangedEventSources.Add(eventSource);
                return TaggerEventSources.Compose(optionChangedEventSources);
            }
 
            private TextChangeRange? AccumulatedTextChanges
            {
                get
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    return _accumulatedTextChanges_doNotAccessDirectly;
                }
 
                set
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    _accumulatedTextChanges_doNotAccessDirectly = value;
                }
            }
 
            private ImmutableDictionary<ITextBuffer, TagSpanIntervalTree<TTag>> CachedTagTrees
            {
                get
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    return _cachedTagTrees_doNotAccessDirectly;
                }
 
                set
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    _cachedTagTrees_doNotAccessDirectly = value;
                }
            }
 
            private object? State
            {
                get
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    return _state_doNotAccessDirecty;
                }
 
                set
                {
                    _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                    _state_doNotAccessDirecty = value;
                }
            }
 
            private void RaiseTagsChanged(ITextBuffer buffer, DiffResult difference)
            {
                _dataSource.ThreadingContext.ThrowIfNotOnUIThread();
                if (difference.Count == 0)
                {
                    // nothing changed.
                    return;
                }
 
                OnTagsChangedForBuffer(SpecializedCollections.SingletonCollection(
                    new KeyValuePair<ITextBuffer, DiffResult>(buffer, difference)),
                    highPriority: false);
            }
        }
    }
}