2using System.Collections.Generic;
3using System.Globalization;
7using System.Threading.Tasks;
9using Microsoft.Extensions.Logging;
10using Microsoft.Extensions.Logging.Abstractions;
39 internal static bool LogTopicRequests {
get;
set; } =
true;
50 throw new InvalidOperationException(
"ApiValidated cannot be checked while Lifetime is incomplete!");
88 var tcs =
new TaskCompletionSource<Task>();
91 var toAwait = await tcs.Task;
96 tcs.SetResult(Interlocked.Exchange(ref
rebootGate, Wrap()));
288 ILogger<SessionController> logger,
289 Func<ValueTask> postLifetimeCallback,
290 uint? startupTimeout,
295 ReattachInformation = reattachInformation ??
throw new ArgumentNullException(nameof(reattachInformation));
296 this.metadata =
metadata ??
throw new ArgumentNullException(nameof(
metadata));
297 this.process =
process ??
throw new ArgumentNullException(nameof(
process));
301 ArgumentNullException.ThrowIfNull(bridgeRegistrar);
303 this.chat =
chat ??
throw new ArgumentNullException(nameof(
chat));
304 ArgumentNullException.ThrowIfNull(assemblyInformationProvider);
318 primeTcs =
new TaskCompletionSource();
339 "Not registering session with {reasonWhyDmApiIsBad} DMAPI version for interop!",
342 : $
"incompatible ({reattachInformation.Dmb.CompileJob.DMApiVersion})");
344 async Task<int?> WrapLifetime()
347 await postLifetimeCallback();
357 assemblyInformationProvider,
364 "Created session controller. CommsKey: {accessIdentifier}, Port: {port}",
366 reattachInformation.
Port);
379 Logger.LogTrace(
"Disposing...");
382 var cancellationToken = CancellationToken.None;
400 if (initialDmb !=
null)
401 await initialDmb.DisposeAsync();
403 await regularDmbDisposeTask;
411 (await semaphoreLockTask).Dispose();
420 ArgumentNullException.ThrowIfNull(parameters);
424 Logger.LogTrace(
"Handling bridge request...");
451 =>
SendCommand(parameters,
false, cancellationToken);
459 Logger.LogTrace(
"Changing reboot state to {newRebootState}", newRebootState);
461 ReattachInformation.RebootState = newRebootState;
466 return result !=
null && result.ErrorMessage ==
null;
473 Logger.LogTrace(
"Resetting reboot state...");
474 ReattachInformation.RebootState =
RebootState.Normal;
490 ReattachInformation.Dmb = dmbProvider ??
throw new ArgumentNullException(nameof(dmbProvider));
495 public async ValueTask
InstanceRenamed(
string newInstanceName, CancellationToken cancellationToken)
498 if (runtimeInformation !=
null)
499 runtimeInformation.InstanceName = newInstanceName;
507 public async ValueTask
UpdateChannels(IEnumerable<ChannelRepresentation> newChannels, CancellationToken cancellationToken)
514 public ValueTask
CreateDump(
string outputFile,
bool minidump, CancellationToken cancellationToken)
534 uint? startupTimeout,
538 var startTime = DateTimeOffset.UtcNow;
539 var useBridgeRequestForLaunchResult = !reattached && (apiValidate ||
DMApiAvailable);
540 var startupTask = useBridgeRequestForLaunchResult
541 ? initialBridgeRequestTcs.Task
545 if (startupTimeout.HasValue)
546 toAwait = Task.WhenAny(
549 TimeSpan.FromSeconds(startupTimeout.Value),
550 CancellationToken.None)
554 "Waiting for LaunchResult based on {launchResultCompletionCause}{possibleTimeout}...",
555 useBridgeRequestForLaunchResult ?
"initial bridge request" :
"process startup",
556 startupTimeout.HasValue ? $
" with a timeout of {startupTimeout.Value}s" : String.Empty);
562 ExitCode = process.Lifetime.IsCompleted ? await process.Lifetime :
null,
563 StartupTime = startupTask.IsCompleted ? (DateTimeOffset.UtcNow - startTime) :
null,
566 Logger.LogTrace(
"Launch result: {launchResult}", result);
568 if (!result.ExitCode.HasValue && reattached && !
disposed)
572 assemblyInformationProvider.
Version,
577 if (reattachResponse !=
null)
579 if (reattachResponse?.CustomCommands !=
null)
580 chatTrackingContext.CustomCommands = reattachResponse.CustomCommands;
581 else if (reattachResponse !=
null)
586 "DMAPI Interop v{interopVersion} isn't returning the TGS custom commands list. Functionality added in v5.2.0.",
606 Logger.LogTrace(
"Entered post validation terminate task.");
607 if (!await proceedTask)
609 Logger.LogTrace(
"Not running post validation terminate task for repeated bridge request.");
613 const int GracePeriodSeconds = 30;
614 Logger.LogDebug(
"Server will terminated in {gracePeriodSeconds}s if it does not exit...", GracePeriodSeconds);
615 var delayTask =
asyncDelayer.
Delay(TimeSpan.FromSeconds(GracePeriodSeconds), CancellationToken.None).AsTask();
620 Logger.LogWarning(
"DMAPI took too long to shutdown server after validation request!");
625 Logger.LogTrace(
"Server exited properly post validation.");
634#pragma warning disable CA1502
645 return BridgeError(
"Missing channelIds field in chatMessage!");
647 if (parameters.
ChatMessage.
ChannelIds.Any(channelIdString => !UInt64.TryParse(channelIdString, out var _)))
648 return BridgeError(
"Invalid channelIds in chatMessage!");
651 return BridgeError(
"Missing message field in chatMessage!");
653 var anyFailed =
false;
657 anyFailed |= !UInt64.TryParse(channelString, out var channelId);
662 return BridgeError(
"Failed to parse channelIds as U64!");
669 Interlocked.Exchange(ref
primeTcs,
new TaskCompletionSource()).SetResult();
672 Logger.LogInformation(
"Bridge requested process termination!");
673 chatTrackingContext.Active =
false;
678 return BridgeError(
"Port switching is no longer supported!");
684 var proceedTcs =
new TaskCompletionSource<bool>();
686 proceedTcs.SetResult(firstValidationRequest);
688 if (!firstValidationRequest)
689 return BridgeError(
"Startup bridge request was repeated!");
692 if (parameters.
Version ==
null)
717 return BridgeError(
"Missing minimumSecurityLevel field!");
719 return BridgeError(
"Invalid minimumSecurityLevel!");
737 var newTopicPort = parameters.
TopicPort.Value;
738 Logger.LogInformation(
"Server is requesting use of port {topicPort} for topic communications", newTopicPort);
739 ReattachInformation.TopicPort = newTopicPort;
743 chatTrackingContext.CustomCommands = parameters.CustomCommands ?? Array.Empty<
CustomCommand>();
744 chatTrackingContext.Active =
true;
745 Interlocked.Exchange(ref
startupTcs,
new TaskCompletionSource()).SetResult();
751 chatTrackingContext.Active =
false;
752 Interlocked.Exchange(ref
rebootTcs,
new TaskCompletionSource()).SetResult();
753 await
RebootGate.WaitAsync(cancellationToken);
768 return BridgeError($
"commandType {parameters.CommandType} not supported!");
773#pragma warning restore CA1502
782 Logger.LogWarning(
"Bridge request error: {message}", message);
785 ErrorMessage = message,
800 if (LogTopicRequests)
801 Logger.LogTrace(
"Topic request: {json}", json);
802 var fullCommandByteCount = Encoding.UTF8.GetByteCount(fullCommandString);
805 return await
SendRawTopic(fullCommandString, topicPriority, cancellationToken);
807 var interopChunkingVersion =
new Version(5, 6, 0);
811 "Cannot send topic request as it is exceeds the single request limit of {limitBytes}B ({actualBytes}B) and requires chunking and the current compile job's interop version must be at least {chunkingVersionRequired}!",
813 fullCommandByteCount,
814 interopChunkingVersion);
821 parameters.AccessIdentifier =
null!;
826 var fullPayloadSize = (uint)json.Length;
828 List<string>? chunkQueryStrings =
null;
829 for (var chunkCount = 2; chunkQueryStrings ==
null; ++chunkCount)
831 var standardChunkSize = fullPayloadSize / chunkCount;
832 var bigChunkSize = standardChunkSize + (fullPayloadSize % chunkCount);
836 chunkQueryStrings =
new List<string>();
837 for (var i = 0U; i < chunkCount; ++i)
839 var startIndex = i * standardChunkSize;
840 var subStringLength = Math.Min(
841 fullPayloadSize - startIndex,
844 : standardChunkSize);
845 var chunkPayload = json.Substring((
int)startIndex, (int)subStringLength);
849 Payload = chunkPayload,
850 PayloadId = payloadId,
852 TotalChunks = (uint)chunkCount,
864 chunkQueryStrings =
null;
868 chunkQueryStrings.Add(chunkCommandString);
872 Logger.LogTrace(
"Chunking topic request ({totalChunks} total)...", chunkQueryStrings.Count);
875 bool LogRequestIssue(
bool possiblyFromCompletedRequest)
880 "Topic request {chunkingStatus} failed!{potentialRequestError}",
881 possiblyFromCompletedRequest ?
"final chunk" :
"chunking",
883 ? $
" Request error: {combinedResponse.InteropResponse.ErrorMessage}"
891 foreach (var chunkCommandString
in chunkQueryStrings)
893 combinedResponse = await
SendRawTopic(chunkCommandString, topicPriority, cancellationToken);
894 if (LogRequestIssue(chunkCommandString == chunkQueryStrings.Last()))
898 while ((combinedResponse?.InteropResponse?.MissingChunks?.Count ?? 0) > 0)
900 Logger.LogWarning(
"DD is still missing some chunks of topic request P{payloadId}! Sending missing chunks...", payloadId);
901 var missingChunks = combinedResponse!.InteropResponse!.MissingChunks!;
902 var lastIndex = missingChunks.Last();
903 foreach (var missingChunkIndex
in missingChunks)
905 var chunkCommandString = chunkQueryStrings[(int)missingChunkIndex];
906 combinedResponse = await
SendRawTopic(chunkCommandString, topicPriority, cancellationToken);
907 if (LogRequestIssue(missingChunkIndex == lastIndex))
912 return combinedResponse;
924 var commandString = String.Format(
925 CultureInfo.InvariantCulture,
929 return commandString;
939 async ValueTask<CombinedTopicResponse?>
SendRawTopic(
string queryString,
bool priority, CancellationToken cancellationToken)
944 "Attempted to send a topic on a disposed SessionController");
949 Byond.TopicSender.TopicResponse? byondResponse;
955 : NullLogger.Instance,
961 if (byondResponse ==
null)
965 "Unable to send priority topic \"{queryString}\"!",
971 var topicReturn = byondResponse.StringData;
974 if (topicReturn !=
null)
981 Logger.LogWarning(ex,
"Invalid interop response: {topicReturnString}", topicReturn);
996 ArgumentNullException.ThrowIfNull(parameters);
1001 "Attempted to send a command to an inactive SessionController: {commandType}",
1008 Logger.LogTrace(
"Not sending topic request {commandType} to server without/with incompatible DMAPI!", parameters.
CommandType);
1013 if (!bypassLaunchResult)
1015 var launchResult = await
LaunchResult.WaitAsync(cancellationToken);
1016 if (launchResult.ExitCode.HasValue)
1018 Logger.LogDebug(
"Not sending topic request {commandType} to server that failed to launch!", parameters.
CommandType);
1026 Logger.LogDebug(
"Not sending topic request {commandType} to server that is rebooting/starting.", parameters.
CommandType);
1030 using var cts = CancellationTokenSource.CreateLinkedTokenSource(cancellationToken);
1031 var combinedCancellationToken = cts.Token;
1032 async ValueTask CancelIfLifetimeElapses()
1036 var completed = await Task.WhenAny(
Lifetime, reboot).WaitAsync(combinedCancellationToken);
1039 "Server {action}, cancelling pending command: {commandType}",
1046 catch (OperationCanceledException)
1052 Logger.LogError(ex,
"Error in CancelIfLifetimeElapses!");
1057 var lifetimeWatchingTask = CancelIfLifetimeElapses();
1060 var combinedResponse = await
SendTopicRequest(parameters, combinedCancellationToken);
1062 void LogCombinedResponse()
1064 if (LogTopicRequests && combinedResponse !=
null)
1065 Logger.LogTrace(
"Topic response: {topicString}", combinedResponse.ByondTopicResponse.StringData ??
"(NO STRING DATA)");
1068 LogCombinedResponse();
1070 if (combinedResponse?.InteropResponse?.
Chunk !=
null)
1072 Logger.LogTrace(
"Topic response is chunked...");
1074 ChunkData? nextChunk = combinedResponse.InteropResponse.Chunk;
1077 var nextRequest = await ProcessChunk<TopicResponse, ChunkedTopicParameters>(
1078 (completedResponse, _) =>
1080 fullResponse = completedResponse;
1085 Logger.LogWarning(
"Topic response chunking error: {message}", error);
1088 combinedResponse?.InteropResponse?.
Chunk,
1089 combinedCancellationToken);
1091 if (nextRequest !=
null)
1093 nextRequest.PayloadId = nextChunk.
PayloadId;
1094 combinedResponse = await
SendTopicRequest(nextRequest, combinedCancellationToken);
1095 LogCombinedResponse();
1096 nextChunk = combinedResponse?.InteropResponse?.Chunk;
1101 while (nextChunk !=
null);
1104 fullResponse = combinedResponse?.InteropResponse;
1106 catch (OperationCanceledException ex)
1110 "Topic request {cancellationType}!",
1111 combinedCancellationToken.IsCancellationRequested
1112 ? cancellationToken.IsCancellationRequested
1118 cancellationToken.ThrowIfCancellationRequested();
1123 await lifetimeWatchingTask;
1126 if (fullResponse?.ErrorMessage !=
null)
1128 "Errored topic response for command {commandType}: {errorMessage}",
1132 return fullResponse;
1142 if (invocation ==
null)
1146 if (eventName ==
null)
1150 if (!notifyCompletion.HasValue)
1153 var eventParams =
new List<string>
1158 eventParams.AddRange(invocation
1160 .Where(param => param !=
null)
1162 ?? Enumerable.Empty<
string>());
1164 var eventId = Guid.NewGuid();
1165 Logger.LogInformation(
"Triggering custom event \"{eventName}\": {eventId}", eventName, eventId);
1170 async Task ProcessEvent()
1174 await eventTask.Value;
1176 if (notifyCompletion.Value)
1181 Logger.LogTrace(
"Finished custom event {eventId}, not sending notification.", eventId);
1183 catch (OperationCanceledException ex)
1185 Logger.LogDebug(ex,
"Custom event invocation {eventId} aborted!", eventId);
1189 Logger.LogWarning(ex,
"Custom event invocation {eventId} errored!", eventId);
1193 if (!eventTask.HasValue)
1194 return BridgeError(
"Event refused to execute due to matching a TGS event!");
1199 var eventProcessingTask = ProcessEvent();
1205 EventId = notifyCompletion.Value
1206 ? eventId.ToString()
Information about an engine installation.
EngineType? Engine
The EngineType.
Metadata about a server instance.
Represents a deployment run.
virtual ? Version DMApiVersion
The DMAPI Version.
Represents a command made from DM code.
Parameters for a bridge request.
BridgeCommandType? CommandType
The BridgeCommandType.
ChatMessage? ChatMessage
The Interop.ChatMessage for BridgeCommandType.ChatSend requests.
CustomEventInvocation? EventInvocation
The Bridge.CustomEventInvocation being triggered.
ushort? TopicPort
The port that should be used to send world topics, if not the default.
DreamDaemonSecurity? MinimumSecurityLevel
The minimum required DreamDaemonSecurity level for BridgeCommandType.Startup requests.
ChunkData? Chunk
The ChunkData for BridgeCommandType.Chunk requests.
Version? Version
The DMAPI global::System.Version for BridgeCommandType.Startup requests.
A response to a bridge request.
Parameters for invoking a custom event.
string? EventName
The name of the event being invoked.
bool? NotifyCompletion
If the DMAPI should be notified when the event compeletes.
ICollection< string >? ChannelIds
The ICollection<T> of Chat.ChannelRepresentation.Ids to sent the MessageContent to....
Represents an update of ChannelRepresentations.
A packet of a split serialized set of data.
uint? PayloadId
The ID of the full request to differentiate different chunkings.Nullable to prevent default value omi...
Class that deserializes chunked interop payloads.
ILogger< Chunker > Logger
The ILogger for the Chunker.
uint NextPayloadId
Gets a payload ID for use in a new ChunkSetInfo.
Constants used for communication with the DMAPI.
static readonly JsonSerializerSettings SerializerSettings
JsonSerializerSettings for use when communicating with the DMAPI.
const uint MaximumTopicRequestLength
The maximum length in bytes of a Byond.TopicSender.ITopicClient payload.
static readonly Version InteropVersion
The DMAPI InteropVersion being used.
const string TopicData
Parameter json is encoded in for topic requests.
Common base for interop parameters.
string AccessIdentifier
Used to identify and authenticate the DreamDaemon instance.
string? ErrorMessage
Any errors in the client's parameters.
string? Text
The message string.
TopicParameters for TopicCommandType.ReceiveChunk.
Parameters for a topic request.
static TopicParameters CreateInstanceRenamedTopicParameters(string newInstanceName)
Initializes a new instance of the TopicParameters class.
TopicCommandType? CommandType
The TopicCommandType.
ChunkData? Chunk
The ChunkData for a partial request.
bool IsPriority
Whether or not the TopicParameters constitute a priority request.
A response to a topic request.
Combines a Byond.TopicSender.TopicResponse with a TopicResponse.
TopicResponse? InteropResponse
The interop TopicResponse, if any.
Represents the result of trying to start a DD process.
async ValueTask InstanceRenamed(string newInstanceName, CancellationToken cancellationToken)
Called when the owning Instance is renamed.A ValueTask representing the running operation.
ValueTask< TopicResponse?> SendCommand(TopicParameters parameters, CancellationToken cancellationToken)
Sends a command to DreamDaemon through /world/Topic().A ValueTask<TResult> resulting in the TopicResp...
async ValueTask< BridgeResponse?> ProcessBridgeCommand(BridgeParameters parameters, CancellationToken cancellationToken)
Handle a set of bridge parameters .
readonly Byond.TopicSender.ITopicClient byondTopicSender
The Byond.TopicSender.ITopicClient for the SessionController.
string DumpFileExtension
The file extension to use for process dumps created from this session.
ApiValidationStatus apiValidationStatus
The ApiValidationStatus for the SessionController.
async ValueTask DisposeAsync()
readonly object synchronizationLock
lock object for port updates and disposed.
DateTimeOffset? LaunchTime
When the process was started.
void AdjustPriority(bool higher)
Set's the owned global::System.Diagnostics.Process.PriorityClass to a non-normal value.
async ValueTask< TopicResponse?> SendCommand(TopicParameters parameters, bool bypassLaunchResult, CancellationToken cancellationToken)
Sends a command to DreamDaemon through /world/Topic().
volatile uint rebootBridgeRequestsProcessing
The number of currently active calls to ProcessBridgeRequest(BridgeParameters, CancellationToken) fro...
readonly IDotnetDumpService dotnetDumpService
The IDotnetDumpService for the SessionController.
readonly Api.Models.Instance metadata
The Instance metadata.
Task OnReboot
A Task that completes when the server calls /world/TgsReboot().
bool DMApiAvailable
If the DMAPI may be used this session.
readonly TaskCompletionSource initialBridgeRequestTcs
The TaskCompletionSource that completes when DD makes it's first bridge request.
bool terminationWasIntentional
Backing field for overriding TerminationWasIntentional.
bool disposed
If the SessionController has been disposed.
void SuspendProcess()
Suspends the process.
void ResetRebootState()
Changes RebootState to RebootState.Normal without telling the DMAPI.
readonly IEngineExecutableLock engineLock
The IEngineExecutableLock for the SessionController.
readonly IAsyncDelayer asyncDelayer
The IAsyncDelayer for the SessionController.
async ValueTask< BridgeResponse?> ProcessBridgeRequest(BridgeParameters parameters, CancellationToken cancellationToken)
Handle a set of bridge parameters .A ValueTask<TResult> resulting in the BridgeResponse for the reque...
ReattachInformation ReattachInformation
The up to date Session.ReattachInformation.
volatile Task rebootGate
Backing field for RebootGate.
bool TerminationWasIntentional
If the DreamDaemon instance sent a.
readonly IEventConsumer eventConsumer
The IEventConsumer for the SessionController.
BridgeResponse BridgeError(string message)
Log and return a BridgeResponse for a given message .
bool released
If process should be kept alive instead.
readonly IChatManager chat
The IChatManager for the SessionController.
readonly IChatTrackingContext chatTrackingContext
The IChatTrackingContext for the SessionController.
Task< int?> Lifetime
The Task<TResult> resulting in the exit code of the process or null if the process was detached.
readonly CancellationTokenSource sessionDurationCts
A CancellationTokenSource used for tasks that should not exceed the lifetime of the session.
ValueTask CreateDump(string outputFile, bool minidump, CancellationToken cancellationToken)
Create a dump file of the process.A ValueTask representing the running operation.
volatile TaskCompletionSource startupTcs
The TaskCompletionSource that completes when DD sends a valid startup bridge request.
async Task PostValidationShutdown(Task< bool > proceedTask)
Terminates the server after ten seconds if it does not exit.
void ResumeProcess()
Resumes the process.
SessionController(ReattachInformation reattachInformation, Api.Models.Instance metadata, IProcess process, IEngineExecutableLock engineLock, Byond.TopicSender.ITopicClient byondTopicSender, IChatTrackingContext chatTrackingContext, IBridgeRegistrar bridgeRegistrar, IChatManager chat, IAssemblyInformationProvider assemblyInformationProvider, IAsyncDelayer asyncDelayer, IDotnetDumpService dotnetDumpService, IEventConsumer eventConsumer, ILogger< SessionController > logger, Func< ValueTask > postLifetimeCallback, uint? startupTimeout, bool reattached, bool apiValidate)
Initializes a new instance of the SessionController class.
readonly bool apiValidationSession
If this session is meant to validate the presence of the DMAPI.
FifoSemaphore TopicSendSemaphore
The FifoSemaphore used to prevent concurrent calls into /world/Topic().
async ValueTask UpdateChannels(IEnumerable< ChannelRepresentation > newChannels, CancellationToken cancellationToken)
Called when newChannels are set.A ValueTask representing the running operation.
string GenerateQueryString(TopicParameters parameters, out string json)
Generates a Byond.TopicSender.ITopicClient query string for a given set of parameters .
void CheckDisposed()
Throws an ObjectDisposedException if DisposeAsync has been called.
readonly? IBridgeRegistration bridgeRegistration
The IBridgeRegistration for the SessionController.
long? MemoryUsage
Gets the process' memory usage in bytes.
async Task< LaunchResult > GetLaunchResult(IAssemblyInformationProvider assemblyInformationProvider, IAsyncDelayer asyncDelayer, uint? startupTimeout, bool reattached, bool apiValidate)
The Task<TResult> for LaunchResult.
IAsyncDisposable ReplaceDmbProvider(IDmbProvider dmbProvider)
Replace the IDmbProvider in use with a given newProvider , disposing the old one.An IAsyncDisposable ...
Task OnStartup
A Task that completes when the server calls /world/TgsNew().
bool ProcessingRebootBridgeRequest
If the ISessionController is currently processing a bridge request from TgsReboot().
ValueTask Release()
Releases the IProcess without terminating it. Also calls IDisposable.Dispose.A ValueTask representing...
volatile? Task postValidationShutdownTask
Task for shutting down the server if it is taking too long after validation.
volatile Task customEventProcessingTask
The Task representing calls to TriggerCustomEvent(CustomEventInvocation?).
Task OnPrime
A Task that completes when the server calls /world/TgsInitializationComplete().
async ValueTask< CombinedTopicResponse?> SendTopicRequest(TopicParameters parameters, CancellationToken cancellationToken)
Send a topic request for given parameters to DreamDaemon, chunking it if necessary.
volatile TaskCompletionSource rebootTcs
The TaskCompletionSource that completes when DD tells us about a reboot.
async ValueTask< CombinedTopicResponse?> SendRawTopic(string queryString, bool priority, CancellationToken cancellationToken)
Send a given queryString to DreamDaemon's /world/Topic.
volatile TaskCompletionSource primeTcs
The TaskCompletionSource that completes when DD tells us it's primed.
async ValueTask< bool > SetRebootState(RebootState newRebootState, CancellationToken cancellationToken)
Attempts to change the current RebootState to newRebootState .A ValueTask<TResult> resulting in true ...
Task RebootGate
A Task that must complete before a TgsReboot() bridge request can complete.
Version? DMApiVersion
The DMAPI Version.
readonly IProcess process
The IProcess for the SessionController.
BridgeResponse TriggerCustomEvent(CustomEventInvocation? invocation)
Trigger a custom event from a given invocation .
A first-in first-out async semaphore.
async ValueTask< SemaphoreSlimContext > Lock(CancellationToken cancellationToken)
Locks the FifoSemaphore.
Helpers for manipulating the Serilog.Context.LogContext.
const string InstanceIdContextProperty
The Serilog.Context.LogContext property name for Models.Instance Api.Models.EntityId....
Notifyee of when ChannelRepresentations in a IChatTrackingContext are updated.
For managing connected chat services.
void QueueMessage(MessageContent message, IEnumerable< ulong > channelIds)
Queue a chat message to a given set of channelIds .
Represents a tracking of dynamic chat json files.
bool Active
If the CustomCommands should be used.
void SetChannelSink(IChannelSink channelSink)
Sets the channelSink for the IChatTrackingContext.
Provides absolute paths to the latest compiled .dmbs.
void KeepAlive()
Disposing the IDmbProvider won't cause a cleanup of the working directory.
EngineVersion EngineVersion
The Api.Models.EngineVersion used to build the .dmb.
string Directory
The primary game directory.
Models.CompileJob CompileJob
The CompileJob of the .dmb.
Represents usage of the two primary BYOND server executables.
void DoNotDeleteThisSession()
Call if, during a detach, this version should not be deleted.
bool UseDotnetDump
If dotnet-dump should be used to create process dumps for this installation.
ValueTask StopServerProcess(ILogger logger, IProcess process, string accessIdentifier, ushort port, CancellationToken cancellationToken)
Kills a given engine server process .
Consumes EventTypes and takes the appropriate actions.
ValueTask? HandleCustomEvent(string eventName, IEnumerable< string?> parameters, CancellationToken cancellationToken)
Handles a given custom event.
Registers IBridgeHandlers.
IBridgeRegistration RegisterHandler(IBridgeHandler bridgeHandler)
Register a given bridgeHandler .
Represents a registration of an interop session.
Handles communication with a DreamDaemon IProcess.
Service for managing the dotnet-dump installation.
ValueTask Dump(IProcess process, string outputFile, bool minidump, CancellationToken cancellationToken)
Attempt to dump a given process .
void SuspendProcess()
Suspends the process.
void ResumeProcess()
Resumes the process.
void AdjustPriority(bool higher)
Set's the owned global::System.Diagnostics.Process.PriorityClass to a non-normal value.
long? MemoryUsage
Gets the process' memory usage in bytes.
DateTimeOffset? LaunchTime
When the process was started.
ValueTask CreateDump(string outputFile, bool minidump, CancellationToken cancellationToken)
Create a dump file of the process.
Task< int?> Lifetime
The Task<TResult> resulting in the exit code of the process or null if the process was detached.
Abstraction over a global::System.Diagnostics.Process.
Task Startup
The Task representing the time until the IProcess becomes "idle".
void Terminate()
Asycnhronously terminates the process.
For waiting asynchronously.
ValueTask Delay(TimeSpan timeSpan, CancellationToken cancellationToken)
Create a Task that completes after a given timeSpan .
DreamDaemonSecurity
DreamDaemon's security level.
EngineType
The type of engine the codebase is using.
@ Byond
Build your own net dream.
BridgeCommandType
Represents the BridgeParameters.CommandType.
@ Chunk
DreamDaemon attempting to send a longer bridge message.
RebootState
Represents the action to take when /world/Reboot() is called.
ApiValidationStatus
Status of DMAPI validation.