using System;
using System.Collections.Concurrent;
using System.Collections.Generic;
using System.Linq;
using System.Threading.Tasks;
using Jellyfin.Data.Events;
using MediaBrowser.Common.Configuration;
using MediaBrowser.Model.Tasks;
using Microsoft.Extensions.Logging;
namespace Emby.Server.Implementations.ScheduledTasks;
/// 
/// Class TaskManager.
/// 
public class TaskManager : ITaskManager
{
    /// 
    /// The _task queue.
    /// 
    private readonly ConcurrentQueue> _taskQueue =
        new ConcurrentQueue>();
    private readonly IApplicationPaths _applicationPaths;
    private readonly ILogger _logger;
    /// 
    /// Initializes a new instance of the  class.
    /// 
    /// The application paths.
    /// The logger.
    public TaskManager(
        IApplicationPaths applicationPaths,
        ILogger logger)
    {
        _applicationPaths = applicationPaths;
        _logger = logger;
        ScheduledTasks = [];
    }
    /// 
    public event EventHandler>? TaskExecuting;
    /// 
    public event EventHandler? TaskCompleted;
    /// 
    public IReadOnlyList ScheduledTasks { get; private set; }
    /// 
    public void CancelIfRunningAndQueue(TaskOptions options)
        where T : IScheduledTask
    {
        var task = ScheduledTasks.First(t => t.ScheduledTask.GetType() == typeof(T));
        ((ScheduledTaskWorker)task).CancelIfRunning();
        QueueScheduledTask(options);
    }
    /// 
    public void CancelIfRunningAndQueue()
            where T : IScheduledTask
    {
        CancelIfRunningAndQueue(new TaskOptions());
    }
    /// 
    public void CancelIfRunning()
                where T : IScheduledTask
    {
        var task = ScheduledTasks.First(t => t.ScheduledTask.GetType() == typeof(T));
        ((ScheduledTaskWorker)task).CancelIfRunning();
    }
    /// 
    public void QueueScheduledTask(TaskOptions options)
        where T : IScheduledTask
    {
        var scheduledTask = ScheduledTasks.FirstOrDefault(t => t.ScheduledTask.GetType() == typeof(T));
        if (scheduledTask is null)
        {
            _logger.LogError("Unable to find scheduled task of type {Type} in QueueScheduledTask.", typeof(T).Name);
        }
        else
        {
            QueueScheduledTask(scheduledTask, options);
        }
    }
    /// 
    public void QueueScheduledTask()
        where T : IScheduledTask
    {
        QueueScheduledTask(new TaskOptions());
    }
    /// 
    public void QueueIfNotRunning()
        where T : IScheduledTask
    {
        var task = ScheduledTasks.First(t => t.ScheduledTask.GetType() == typeof(T));
        if (task.State != TaskState.Running)
        {
            QueueScheduledTask(new TaskOptions());
        }
    }
    /// 
    public void Execute()
        where T : IScheduledTask
    {
        var scheduledTask = ScheduledTasks.FirstOrDefault(t => t.ScheduledTask.GetType() == typeof(T));
        if (scheduledTask is null)
        {
            _logger.LogError("Unable to find scheduled task of type {Type} in Execute.", typeof(T).Name);
        }
        else
        {
            var type = scheduledTask.ScheduledTask.GetType();
            _logger.LogDebug("Queuing task {Name}", type.Name);
            lock (_taskQueue)
            {
                if (scheduledTask.State == TaskState.Idle)
                {
                    Execute(scheduledTask, new TaskOptions());
                }
            }
        }
    }
    /// 
    public void QueueScheduledTask(IScheduledTask task, TaskOptions options)
    {
        var scheduledTask = ScheduledTasks.FirstOrDefault(t => t.ScheduledTask.GetType() == task.GetType());
        if (scheduledTask is null)
        {
            _logger.LogError("Unable to find scheduled task of type {Type} in QueueScheduledTask.", task.GetType().Name);
        }
        else
        {
            QueueScheduledTask(scheduledTask, options);
        }
    }
    /// 
    /// Queues the scheduled task.
    /// 
    /// The task.
    /// The task options.
    private void QueueScheduledTask(IScheduledTaskWorker task, TaskOptions options)
    {
        var type = task.ScheduledTask.GetType();
        _logger.LogDebug("Queuing task {Name}", type.Name);
        lock (_taskQueue)
        {
            if (task.State == TaskState.Idle)
            {
                Execute(task, options);
                return;
            }
            _taskQueue.Enqueue(new Tuple(type, options));
        }
    }
    /// 
    public void AddTasks(IEnumerable tasks)
    {
        var list = tasks.Select(t => new ScheduledTaskWorker(t, _applicationPaths, this, _logger));
        ScheduledTasks = ScheduledTasks.Concat(list).ToArray();
    }
    /// 
    public void Dispose()
    {
        Dispose(true);
        GC.SuppressFinalize(this);
    }
    /// 
    /// Releases unmanaged and - optionally - managed resources.
    /// 
    /// true to release both managed and unmanaged resources; false to release only unmanaged resources.
    protected virtual void Dispose(bool dispose)
    {
        foreach (var task in ScheduledTasks)
        {
            task.Dispose();
        }
    }
    /// 
    public void Cancel(IScheduledTaskWorker task)
    {
        ((ScheduledTaskWorker)task).Cancel();
    }
    /// 
    public Task Execute(IScheduledTaskWorker task, TaskOptions options)
    {
        return ((ScheduledTaskWorker)task).Execute(options);
    }
    /// 
    /// Called when [task executing].
    /// 
    /// The task.
    internal void OnTaskExecuting(IScheduledTaskWorker task)
    {
        TaskExecuting?.Invoke(this, new GenericEventArgs(task));
    }
    /// 
    /// Called when [task completed].
    /// 
    /// The task.
    /// The result.
    internal void OnTaskCompleted(IScheduledTaskWorker task, TaskResult result)
    {
        TaskCompleted?.Invoke(task, new TaskCompletionEventArgs(task, result));
        ExecuteQueuedTasks();
    }
    /// 
    /// Executes the queued tasks.
    /// 
    private void ExecuteQueuedTasks()
    {
        lock (_taskQueue)
        {
            var list = new List>();
            while (_taskQueue.TryDequeue(out var item))
            {
                if (list.All(i => i.Item1 != item.Item1))
                {
                    list.Add(item);
                }
            }
            foreach (var enqueuedType in list)
            {
                var scheduledTask = ScheduledTasks.First(t => t.ScheduledTask.GetType() == enqueuedType.Item1);
                if (scheduledTask.State == TaskState.Idle)
                {
                    Execute(scheduledTask, enqueuedType.Item2);
                }
            }
        }
    }
}