2021-09-07 05:15:45 +00:00
|
|
|
using System;
|
|
|
|
using System.Collections.Generic;
|
|
|
|
using System.Linq;
|
|
|
|
using System.Threading;
|
|
|
|
using System.Threading.Tasks;
|
2022-06-05 18:44:51 +00:00
|
|
|
|
2021-09-07 05:15:45 +00:00
|
|
|
using Gallium;
|
2022-06-05 18:44:51 +00:00
|
|
|
|
2021-09-07 05:15:45 +00:00
|
|
|
using Humanizer;
|
2022-06-05 18:44:51 +00:00
|
|
|
|
2021-09-07 05:15:45 +00:00
|
|
|
using Serilog;
|
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
namespace Nitride.Pipelines;
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// A wrapper class to handle a pipeline along with various methods for
|
|
|
|
/// tracking the operation of the pipeline and thread coordination.
|
|
|
|
/// </summary>
|
|
|
|
/// <remarks>
|
|
|
|
/// This is intended to only be used within a PipelineManager and there
|
|
|
|
/// should be little reason to use or extend this class.
|
|
|
|
/// </remarks>
|
|
|
|
public class PipelineRunner
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
|
|
|
/// <summary>
|
2022-06-05 18:44:51 +00:00
|
|
|
/// The manual reset event used to coordinate thread operations.
|
|
|
|
/// </summary>
|
|
|
|
private readonly ManualResetEventSlim blockDependencies;
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// A manual reset event to tell the thread when consumers are done.
|
|
|
|
/// </summary>
|
|
|
|
private readonly ManualResetEventSlim consumersDone;
|
|
|
|
|
|
|
|
private readonly ILogger logger;
|
|
|
|
|
|
|
|
private DateTime changed;
|
|
|
|
|
|
|
|
private bool signaledDoneWithInputs;
|
|
|
|
|
|
|
|
private DateTime started;
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// Contains the number of consumers we're currently waiting to finish
|
|
|
|
/// processing.
|
2021-09-07 05:15:45 +00:00
|
|
|
/// </summary>
|
2022-06-05 18:44:51 +00:00
|
|
|
private int waitingOnConsumers;
|
|
|
|
|
|
|
|
public PipelineRunner(ILogger logger, IPipeline pipeline)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
this.Pipeline = pipeline ?? throw new ArgumentNullException(nameof(pipeline));
|
|
|
|
this.Incoming = new List<PipelineRunner>();
|
|
|
|
this.Outgoing = new List<PipelineRunner>();
|
|
|
|
this.Outputs = new List<Entity>();
|
|
|
|
this.logger = logger.ForContext<PipelineRunner>();
|
|
|
|
this.blockDependencies = new ManualResetEventSlim(false);
|
|
|
|
this.consumersDone = new ManualResetEventSlim(false);
|
|
|
|
this.started = DateTime.Now;
|
|
|
|
this.changed = DateTime.Now;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Public factory method for creating a new pipeline manager entry.
|
|
|
|
/// </summary>
|
|
|
|
public delegate PipelineRunner Factory(IPipeline pipeline);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
public TimeSpan ElapsedFromInitialized => DateTime.Now - this.started;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
public TimeSpan ElapsedFromState => DateTime.Now - this.changed;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// A collection of incoming entries that produce data for the pipeline.
|
|
|
|
/// </summary>
|
|
|
|
public ICollection<PipelineRunner> Incoming { get; }
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Gets a value indicating whether the output of this entry is not
|
|
|
|
/// used by any other pipeline.
|
|
|
|
/// </summary>
|
|
|
|
public bool IsFinal => this.Outgoing.Count == 0;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Gets a value indicating whether this pipeline is done running.
|
|
|
|
/// </summary>
|
|
|
|
public bool IsFinished => this.State is PipelineRunnerState.Finalized or PipelineRunnerState.Errored;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Gets a value indicating whether this entry is a starting one
|
|
|
|
/// that consumes no data.
|
|
|
|
/// </summary>
|
|
|
|
public bool IsStarting => this.Incoming.Count == 0;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// The collection of outgoing entries that consume the results of
|
|
|
|
/// the pipeline in this entry.
|
|
|
|
/// </summary>
|
|
|
|
public ICollection<PipelineRunner> Outgoing { get; }
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Contains the list of all the outputs from this pipeline. This is
|
|
|
|
/// only ensured to be valid after the pipeline is in the `Providing`
|
|
|
|
/// state.
|
|
|
|
/// </summary>
|
|
|
|
public List<Entity> Outputs { get; }
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// The pipeline associated with the entry.
|
|
|
|
/// </summary>
|
|
|
|
public IPipeline Pipeline { get; }
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// Gets the current state of the pipeline.
|
|
|
|
/// </summary>
|
|
|
|
public PipelineRunnerState State { get; private set; }
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// A method that tells the pipeline that one of the dependencies has
|
|
|
|
/// completed consuming the input.
|
|
|
|
/// </summary>
|
|
|
|
public void ConsumerDoneWithOutputs()
|
|
|
|
{
|
|
|
|
int current = Interlocked.Decrement(ref this.waitingOnConsumers);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
this.logger.Verbose("{Pipeline:l}: Consumer signalled, waiting for {Count:n0}", this.Pipeline, current);
|
|
|
|
|
|
|
|
if (current == 0)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
this.consumersDone.Set();
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
2022-06-05 18:44:51 +00:00
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
/// <summary>
|
|
|
|
/// Initializes the runner after all external properties have been
|
|
|
|
/// set and configured.
|
|
|
|
/// </summary>
|
|
|
|
public void Initialize()
|
|
|
|
{
|
|
|
|
this.ChangeState(PipelineRunnerState.Initialized);
|
|
|
|
}
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// Executes the pipeline, including waiting for any or all
|
|
|
|
/// dependencies.
|
|
|
|
/// </summary>
|
|
|
|
public async Task RunAsync()
|
|
|
|
{
|
|
|
|
try
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
// Make sure we have a valid state.
|
|
|
|
switch (this.State)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
case PipelineRunnerState.Initialized:
|
|
|
|
case PipelineRunnerState.Finalized:
|
|
|
|
break;
|
|
|
|
|
|
|
|
default:
|
|
|
|
this.logger.Error(
|
|
|
|
"{Pipeline:l}: Pipeline cannot be started in a {State}"
|
|
|
|
+ " state (not Initialized or Finalized)",
|
|
|
|
this.Pipeline,
|
|
|
|
this.State);
|
|
|
|
break;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Prepare ourselves for running. We have a start/stop state because
|
|
|
|
// this may be non-zero time.
|
|
|
|
this.started = DateTime.Now;
|
|
|
|
this.changed = DateTime.Now;
|
|
|
|
this.ChangeState(PipelineRunnerState.Preparing);
|
|
|
|
this.signaledDoneWithInputs = false;
|
|
|
|
this.ChangeState(PipelineRunnerState.Prepared);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Go through the incoming and wait for each of the manual resets
|
|
|
|
// on the dependency pipelines.
|
|
|
|
if (this.WaitForDependencies())
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
|
|
|
this.SignalDoneWithInputs();
|
2022-06-05 18:44:51 +00:00
|
|
|
return;
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Grab the outputs from the incoming. They will be populated
|
|
|
|
// because we have waited for the reset events.
|
|
|
|
this.ChangeState(PipelineRunnerState.Started);
|
|
|
|
List<Entity> input = this.GatherDependencyOutputs();
|
|
|
|
|
|
|
|
// Run the pipeline. This may not be resolved until we gather
|
|
|
|
// the output below.
|
|
|
|
await this.RunPipeline(input);
|
|
|
|
|
|
|
|
// At this point, we are completely done with our inputs, so signal
|
|
|
|
// to them in case they have to clean up any of their structures.
|
|
|
|
this.SignalDoneWithInputs();
|
|
|
|
|
|
|
|
// If we have outgoing runners, provide them data until they are
|
|
|
|
// done.
|
|
|
|
this.SendToDependants();
|
|
|
|
|
|
|
|
// Finalize ourselves.
|
|
|
|
this.ChangeState(PipelineRunnerState.Finalized);
|
|
|
|
}
|
|
|
|
catch (Exception exception)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
// Report the exception.
|
|
|
|
this.logger.Error(exception, "{Pipeline:l}: There was an exception running pipeline", this.Pipeline);
|
|
|
|
|
|
|
|
// Change our state and then release any pipeline waiting for us
|
|
|
|
// so they can pick up the error and fail themselves.
|
|
|
|
this.ChangeState(PipelineRunnerState.Errored);
|
|
|
|
this.blockDependencies.Set();
|
|
|
|
this.SignalDoneWithInputs();
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
2022-06-05 18:44:51 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// A method to block the call until this runner is done processing and
|
|
|
|
/// is ready to provide output.
|
|
|
|
/// </summary>
|
|
|
|
public void WaitUntilProviding()
|
|
|
|
{
|
|
|
|
this.blockDependencies.Wait();
|
|
|
|
}
|
|
|
|
|
|
|
|
/// <summary>
|
|
|
|
/// Changes the state of the pipeline into a new state.
|
|
|
|
/// </summary>
|
|
|
|
/// <param name="newState">The state to change the pipeline into.</param>
|
|
|
|
private void ChangeState(PipelineRunnerState newState)
|
|
|
|
{
|
|
|
|
this.logger.Verbose(
|
|
|
|
"{Pipeline:l}: Switching from state {Old} to {New} (elapsed {Elapsed}, duration {Duration})",
|
|
|
|
this.Pipeline,
|
|
|
|
this.State,
|
|
|
|
newState,
|
|
|
|
this.ElapsedFromInitialized,
|
|
|
|
this.ElapsedFromState);
|
|
|
|
this.changed = DateTime.Now;
|
|
|
|
this.State = newState;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
private List<Entity> GatherDependencyOutputs()
|
|
|
|
{
|
|
|
|
if (this.Incoming.Count <= 0)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
return new List<Entity>();
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Report that we are gathering our outputs.
|
|
|
|
this.logger.Verbose(
|
|
|
|
"{Pipeline:l}: Gathering outputs from {Count:n0} dependencies",
|
|
|
|
this.Pipeline,
|
|
|
|
this.Incoming.Count);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
var input = this.Incoming.SelectMany(x => x.Outputs).ToList();
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
this.logger.Debug(
|
|
|
|
"{Pipeline:l}: Got {Count:l} from dependencies",
|
|
|
|
this.Pipeline,
|
|
|
|
"entity".ToQuantity(input.Count, "N0"));
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
return input;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
private async Task RunPipeline(List<Entity> input)
|
|
|
|
{
|
|
|
|
IEnumerable<Entity> output = await this.Pipeline.RunAsync(input);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Gather all the output.
|
|
|
|
this.logger.Debug("{Pipeline:l}: Gathering output", this.Pipeline);
|
|
|
|
this.Outputs.Clear();
|
|
|
|
this.Outputs.AddRange(output);
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
private void SendToDependants()
|
|
|
|
{
|
|
|
|
if (this.Outgoing.Count <= 0)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
return;
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Make sure our internal wait for the consumers it set.
|
|
|
|
this.logger.Verbose("{Pipeline:l}: Setting up internal thread controls", this.Pipeline);
|
|
|
|
this.waitingOnConsumers = this.Outgoing.Count;
|
|
|
|
this.consumersDone.Reset();
|
|
|
|
|
|
|
|
// Report how many files we're sending out and then use manual
|
|
|
|
// reset and the semaphore to control the threads.
|
|
|
|
this.logger.Debug(
|
|
|
|
"{Pipeline:l}: Output {Count:l} from pipeline",
|
|
|
|
this.Pipeline,
|
|
|
|
"entity".ToQuantity(this.Outputs.Count, "N0"));
|
|
|
|
|
|
|
|
// Release our manual reset to allow operations to continue.
|
|
|
|
this.ChangeState(PipelineRunnerState.Providing);
|
|
|
|
this.logger.Verbose("{Pipeline:l}: Release manual reset for consumers", this.Pipeline);
|
|
|
|
this.blockDependencies.Set();
|
|
|
|
|
|
|
|
// Wait until all consumers have finished processing.
|
|
|
|
this.consumersDone.Wait();
|
|
|
|
}
|
|
|
|
|
|
|
|
private void SignalDoneWithInputs()
|
|
|
|
{
|
|
|
|
if (this.Incoming.Count <= 0 || this.signaledDoneWithInputs)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
return;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
this.signaledDoneWithInputs = true;
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
this.logger.Debug("{Pipeline:l}: Signaling {Count:n0} dependencies done", this.Pipeline, this.Incoming.Count);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
foreach (PipelineRunner? dependency in this.Incoming)
|
|
|
|
{
|
|
|
|
dependency.ConsumerDoneWithOutputs();
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
2022-06-05 18:44:51 +00:00
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
private bool WaitForDependencies()
|
|
|
|
{
|
|
|
|
if (this.Incoming.Count <= 0)
|
2021-09-07 05:15:45 +00:00
|
|
|
{
|
2022-06-05 18:44:51 +00:00
|
|
|
return false;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Wait for the dependencies to run first.
|
|
|
|
this.ChangeState(PipelineRunnerState.Waiting);
|
|
|
|
this.logger.Verbose(
|
|
|
|
"{Pipeline:l}: Waiting for {Count:l} to complete",
|
|
|
|
this.Pipeline,
|
|
|
|
"dependency".ToQuantity(this.Incoming.Count));
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
foreach (PipelineRunner? dependency in this.Incoming)
|
|
|
|
{
|
|
|
|
dependency.WaitUntilProviding();
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
// Check for any error state in the dependency, if we have one,
|
|
|
|
// then we need to stop ourselves.
|
|
|
|
bool hasError = this.Incoming.Any(x => x.State == PipelineRunnerState.Errored);
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
if (!hasError)
|
|
|
|
{
|
|
|
|
return false;
|
|
|
|
}
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
this.logger.Error("{Pipeline:l}: There was an exception in an dependency", this.Pipeline);
|
|
|
|
this.ChangeState(PipelineRunnerState.Errored);
|
|
|
|
this.blockDependencies.Set();
|
2021-09-07 05:15:45 +00:00
|
|
|
|
2022-06-05 18:44:51 +00:00
|
|
|
return true;
|
2021-09-07 05:15:45 +00:00
|
|
|
}
|
|
|
|
}
|