477 references to TotalMilliseconds
AnalyzerRunner (3)
DiagnosticAnalyzerRunner.cs (2)
447WriteLine($"Execution time (ms): {telemetry.ExecutionTime.TotalMilliseconds}", ConsoleColor.White); 476WriteLine($"{analyzerName}:{padding} {telemetry.ExecutionTime.TotalMilliseconds,7:0}", ConsoleColor.White);
PerformanceTracker.cs (1)
54return $"{Elapsed.TotalMilliseconds:0}ms";
Aspire.Dashboard (3)
Model\Otlp\SpanWaterfallViewModel.cs (3)
137var rootDuration = span.Trace.Duration.TotalMilliseconds; 139var leftOffset = relativeStart.TotalMilliseconds / rootDuration * 100; 140var width = span.Duration.TotalMilliseconds / rootDuration * 100;
Aspire.Dashboard.Components.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Dashboard.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.EndToEnd.Tests (1)
tests\Shared\TemplatesTesting\ToolCommand.cs (1)
87cts.CancelAfter((int)_timeout.Value.TotalMilliseconds);
Aspire.Hosting (2)
Dcp\DcpPipelineBuilder.cs (2)
53retry.Duration.TotalMilliseconds, 78retry.Duration.TotalMilliseconds,
Aspire.Hosting.Garnet (1)
GarnetBuilderExtensions.cs (1)
156var interval = (persistenceAnnotation.Interval ?? TimeSpan.FromSeconds(60)).TotalMilliseconds.ToString(CultureInfo.InvariantCulture);
Aspire.Hosting.Kafka.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.MySql.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.NodeJs.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.PostgreSQL.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.RabbitMQ.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Hosting.Valkey.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Playground.Tests (2)
tests\Shared\AsyncTestHelpers.cs (2)
195? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 196: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Aspire.Templates.Tests (1)
tests\Shared\TemplatesTesting\ToolCommand.cs (1)
87cts.CancelAfter((int)_timeout.Value.TotalMilliseconds);
Client.ExpectedExceptions.IntegrationTests (4)
ExpectedExceptionTests.4.0.0.cs (2)
274if ((endOfOpeningStall - startOfOpeningStall).TotalMilliseconds > timeoutMs) 344double elapsedMs = (DateTime.Now - endOfOpeningStall).TotalMilliseconds;
ExpectedExceptionTests.4.1.0.cs (2)
528if ((endOfOpeningStall - startOfOpeningStall).TotalMilliseconds > timeoutMs) 598double elapsedMs = (DateTime.Now - endOfOpeningStall).TotalMilliseconds;
dotnet-getdocument (1)
Exe.cs (1)
52if (!process.WaitForExit((int)(TimeSpan.FromMinutes(2).TotalMilliseconds)))
dotnet-svcutil-lib (3)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\TimeoutHelper.cs (1)
50_cancellationToken = await TimeoutTokenSource.FromTimeoutAsync((int)timeout.TotalMilliseconds);
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\ReliableSessionBindingElement.cs (1)
453UInt64 milliseconds = Convert.ToUInt64(timeSpan.TotalMilliseconds);
FrameworkFork\System.ServiceModel\System\ServiceModel\Diagnostics\TraceUtility.cs (1)
76return (long)elapsedTime.TotalMilliseconds;
GenerateDocumentationAndConfigFiles (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
IIS.FunctionalTests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
IIS.LongTests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
IIS.NewHandler.FunctionalTests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
IIS.NewShim.FunctionalTests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
IIS.ShadowCopy.Tests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
IISExpress.FunctionalTests (3)
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\AppVerifier.cs (1)
54if (!process.WaitForExit((int)timeout.TotalMilliseconds))
src\Servers\IIS\IIS\test\Common.FunctionalTests\Infrastructure\Helpers.cs (2)
133return Retry(func, (int)(maxTime.TotalMilliseconds / 200), 200); 160Assert.True(hostProcess.WaitForExit(timeout ?? (int)TimeoutExtensions.DefaultTimeoutValue.TotalMilliseconds));
Infrastructure.Common (1)
xunit\WcfTestCase.cs (1)
58(int)_failFastDuration.TotalMilliseconds,
InteropTests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Metrics (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Metrics.Legacy (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.AspNetCore.Components.Endpoints (1)
DependencyInjection\RazorComponentsServiceOptions.cs (1)
81ArgumentOutOfRangeException.ThrowIfLessThanOrEqual(value.TotalMilliseconds, 0);
Microsoft.AspNetCore.Components.Endpoints.Tests (1)
RazorComponentResultTest.cs (1)
493} while (timeoutRemaining.TotalMilliseconds > 0);
Microsoft.AspNetCore.Components.Server (2)
Circuits\RemoteRenderer.cs (2)
409=> CompletingBatchWithError(logger, batchId, errorMessage, elapsedTime.TotalMilliseconds); 415=> CompletingBatchWithoutError(logger, batchId, elapsedTime.TotalMilliseconds);
Microsoft.AspNetCore.ConcurrencyLimiter (1)
ConcurrencyLimiterEventSource.cs (1)
81var duration = _timer.Value.GetElapsedTime().TotalMilliseconds;
Microsoft.AspNetCore.Hosting (2)
Internal\HostingRequestFinishedLog.cs (2)
350 => new KeyValuePair<string, object?>("ElapsedMilliseconds", Elapsed.TotalMilliseconds), 66_cachedToString = $"Request finished {request.Protocol} {request.Method} {request.Scheme}://{request.Host.Value}{request.PathBase.Value}{request.Path.Value}{request.QueryString.Value} - {response.StatusCode.ToString(CultureInfo.InvariantCulture)} {ValueOrEmptyMarker(response.ContentLength)} {EscapedValueOrEmptyMarker(response.ContentType)} {Elapsed.TotalMilliseconds.ToString("0.0000", CultureInfo.InvariantCulture)}ms";
Microsoft.AspNetCore.Http.Connections (1)
Internal\HttpConnectionsEventSource.cs (1)
46_connectionDuration!.WriteMetric(duration.TotalMilliseconds);
Microsoft.AspNetCore.HttpLogging (2)
HttpLoggingInterceptorContext.cs (1)
150return TimeProvider.GetElapsedTime(StartTimestamp).TotalMilliseconds;
W3CLoggingMiddleware.cs (1)
219shouldLog |= AddToList(elements, _timeTakenIndex, stopWatch.GetElapsedTime().TotalMilliseconds.ToString(CultureInfo.InvariantCulture));
Microsoft.AspNetCore.Identity (2)
SignInManager.cs (2)
632Timeout = (uint)Options.Passkey.Timeout.TotalMilliseconds, 716Timeout = (uint)Options.Passkey.Timeout.TotalMilliseconds,
Microsoft.AspNetCore.Identity.Test (2)
SignInManagerTest.cs (2)
1429Assert.Equal((uint)identityOptions.Passkey.Timeout.TotalMilliseconds, (uint)optionsJson["timeout"]); 1483Assert.Equal((uint)identityOptions.Passkey.Timeout.TotalMilliseconds, (uint)optionsJson["timeout"]);
Microsoft.AspNetCore.InternalTesting (2)
src\Shared\TaskExtensions.cs (2)
145? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 146: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Microsoft.AspNetCore.Mvc.Core (3)
Infrastructure\ControllerActionInvoker.cs (1)
650ActionMethodExecuted(logger, actionName, Convert.ToString(result, CultureInfo.InvariantCulture), timeSpan.TotalMilliseconds);
Infrastructure\ResourceInvoker.Log.cs (2)
105PageExecuted(logger, action.DisplayName, timeSpan.TotalMilliseconds); 109ActionExecuted(logger, action.DisplayName, timeSpan.TotalMilliseconds);
Microsoft.AspNetCore.Mvc.Razor.RuntimeCompilation (1)
RuntimeViewCompiler.cs (1)
424GeneratedCodeToAssemblyCompilationEnd(logger, filePath, elapsed.TotalMilliseconds);
Microsoft.AspNetCore.Mvc.ViewFeatures (5)
PartialViewResultExecutor.cs (2)
200PartialViewFound(logger, view.Path, timespan.TotalMilliseconds); 211PartialViewResultExecuted(logger, partialViewName, timespan.TotalMilliseconds);
ViewComponents\DefaultViewComponentInvoker.cs (1)
263timespan.TotalMilliseconds,
ViewResultExecutor.cs (2)
200ViewFound(logger, view.Path, timespan.TotalMilliseconds); 211ViewResultExecuted(logger, viewName, timespan.TotalMilliseconds);
Microsoft.AspNetCore.OutputCaching.StackExchangeRedis (1)
RedisOutputCacheStore.cs (1)
310(long)((DateTime.UtcNow + timeout) - DateTime.UnixEpoch).TotalMilliseconds;
Microsoft.AspNetCore.Server.IntegrationTesting (3)
ApplicationPublisher.cs (1)
80if (hostProcess.WaitForExit(milliseconds: (int)timeout.TotalMilliseconds))
Deployers\NginxDeployer.cs (1)
20private readonly int _waitTime = (int)TimeSpan.FromSeconds(30).TotalMilliseconds;
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Microsoft.AspNetCore.Server.IntegrationTesting.IIS (1)
IISExpressDeployer.cs (1)
559if (!hostProcess.WaitForExit((int)ShutdownTimeSpan.TotalMilliseconds))
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (6)
HeartbeatTests.cs (5)
47Logger.LogInformation($"Heartbeat split: {split.TotalMilliseconds}ms"); 76ts => AssertApproxEqual(intervalMs, ts.TotalMilliseconds), 77ts => AssertApproxEqual(intervalMs, ts.TotalMilliseconds), 78ts => AssertApproxEqual(intervalMs, ts.TotalMilliseconds), 79ts => AssertApproxEqual(intervalMs, ts.TotalMilliseconds));
Http1\Http1ConnectionTests.cs (1)
1095var delay = (int)Math.Ceiling(timeout.TotalMilliseconds / MaxWaitLoop);
Microsoft.AspNetCore.Shared.Tests (1)
ValueStopwatchTest.cs (1)
36Assert.True(stopwatch.GetElapsedTime().TotalMilliseconds > 0);
Microsoft.AspNetCore.SignalR.Client.Core (2)
HubConnection.cs (1)
2391$"Server timeout ({_hubConnection.ServerTimeout.TotalMilliseconds:0.00}ms) elapsed without receiving a message from the server.");
HubConnection.Log.cs (1)
202StartingServerTimeoutTimer(logger, serverTimeout.TotalMilliseconds);
Microsoft.AspNetCore.SignalR.Client.Tests (2)
HubConnectionTests.cs (2)
370Assert.Equal($"Server timeout ({hubConnection.ServerTimeout.TotalMilliseconds:0.00}ms) elapsed without receiving a message from the server.", exception.Message); 424Assert.Equal($"Server timeout ({hubConnection.ServerTimeout.TotalMilliseconds:0.00}ms) elapsed without receiving a message from the server.", exception.Message);
Microsoft.AspNetCore.SignalR.Specification.Tests (4)
Internal\TaskExtensions.cs (2)
62? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 63: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
src\Shared\TaskExtensions.cs (2)
145? $"The operation timed out after reaching the limit of {timeout.TotalMilliseconds}ms." 146: $"The operation at {filePath}:{lineNumber} timed out after reaching the limit of {timeout.TotalMilliseconds}ms.";
Microsoft.AspNetCore.SignalR.StackExchangeRedis (1)
Internal\AckHandler.cs (1)
13private readonly long _ackThreshold = (long)TimeSpan.FromSeconds(30).TotalMilliseconds;
Microsoft.AspNetCore.SignalR.StackExchangeRedis.Tests (1)
Docker.cs (1)
176if (!process.WaitForExit((int)timeout.TotalMilliseconds))
Microsoft.AspNetCore.SignalR.Tests (1)
HubConnectionHandlerTests.cs (1)
2708while ((DateTime.UtcNow - start).TotalMilliseconds <= 500.0)
Microsoft.Build (16)
BackEnd\Components\Communications\NodeEndpointInProc.cs (1)
393if (!_packetPump.Join((int)new TimeSpan(0, 0, BuildParameters.EndpointShutdownTimeout).TotalMilliseconds))
BackEnd\Components\Scheduler\Scheduler.cs (2)
2448double utilizationPercent = (double)nodeActiveTimes[i].TotalMilliseconds / (double)totalDuration.TotalMilliseconds;
BackEnd\Components\Scheduler\SchedulingPlan.cs (1)
466accumulatedTimeByConfiguration[request.BuildRequest.ConfigurationId] = accumulatedTime + request.GetTimeSpentInState(SchedulableRequestState.Executing).TotalMilliseconds;
Evaluation\Profiler\EvaluationLocationPrettyPrinterBase.cs (3)
36return Math.Round(timeSpan.TotalMilliseconds, 0, MidpointRounding.AwayFromZero); 42var percentage = (time.TotalMilliseconds / total.TotalMilliseconds) * 100;
Logging\BaseConsoleLogger.cs (1)
812"{0,5}", Math.Round(elapsedTime.TotalMilliseconds, 0));
Logging\ParallelLogger\ParallelConsoleLogger.cs (1)
1744"{0,5}", Math.Round(elapsedTime.TotalMilliseconds, 0));
Logging\ProfilerLogger.cs (2)
264return profiledData.InclusiveTime.TotalMilliseconds < 1 || 265profiledData.ExclusiveTime.TotalMilliseconds < 1;
NodeEndpointOutOfProcBase.cs (1)
366int waitTimeRemaining = Math.Max(0, CommunicationsUtilities.NodeConnectionTimeout - (int)usedWaitTime.TotalMilliseconds);
TelemetryInfra\TelemetryDataUtils.cs (4)
142writer.WriteNumber(nameof(valuePair.Value.CumulativeExecutionTime.TotalMilliseconds), valuePair.Value.CumulativeExecutionTime.TotalMilliseconds); 321writer.WriteNumber(nameof(stats.CumulativeExecutionTime.TotalMilliseconds), stats.CumulativeExecutionTime.TotalMilliseconds);
Microsoft.Build.Engine.UnitTests (2)
BackEnd\KnownTelemetry_Tests.cs (2)
92properties["BuildDurationInMilliseconds"] = (finishedAt - startAt).TotalMilliseconds.ToString(CultureInfo.InvariantCulture); 93properties["InnerBuildDurationInMilliseconds"] = (finishedAt - innerStartAt).TotalMilliseconds.ToString(CultureInfo.InvariantCulture);
Microsoft.Build.Framework (6)
Telemetry\BuildCheckTelemetry.cs (2)
58properties["TotalRuntimeInMilliseconds"] = totalRuntime.TotalMilliseconds.ToString(CultureInfo.InvariantCulture); 85properties["TotalRuntimeInMilliseconds"] = buildCheckRuleTelemetryData.TotalRuntime.TotalMilliseconds.ToString(CultureInfo.InvariantCulture);
Telemetry\BuildTelemetry.cs (4)
110properties[TelemetryConstants.BuildDurationPropertyName] = (FinishedAt.Value - StartAt.Value).TotalMilliseconds.ToString(CultureInfo.InvariantCulture); 115properties[TelemetryConstants.InnerBuildDurationPropertyName] = (FinishedAt.Value - InnerStartAt.Value).TotalMilliseconds.ToString(CultureInfo.InvariantCulture); 181telemetryItems.Add(new TelemetryItem(TelemetryConstants.BuildDurationPropertyName, (FinishedAt.Value - StartAt.Value).TotalMilliseconds, false)); 186telemetryItems.Add(new TelemetryItem(TelemetryConstants.InnerBuildDurationPropertyName, (FinishedAt.Value - InnerStartAt.Value).TotalMilliseconds, false));
Microsoft.Build.Tasks.Core (1)
NodePipeServer.cs (1)
95int waitTimeRemaining = Math.Max(0, CommunicationsUtilities.NodeConnectionTimeout - (int)usedWaitTime.TotalMilliseconds);
Microsoft.Build.Tasks.UnitTests (1)
Unzip_Tests.cs (1)
170process.WaitForExit((int)TimeSpan.FromSeconds(2).TotalMilliseconds).ShouldBeTrue();
Microsoft.Build.UnitTests.Shared (1)
ObjectModelHelpers.cs (1)
1998? timeSpan.TotalMilliseconds // powershell can't handle floating point seconds, so give it milliseconds
Microsoft.CodeAnalysis.Analyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.AnalyzerUtilities (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.BannedApiAnalyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.CodeStyle (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.CSharp.Semantic.UnitTests (2)
SourceGeneration\SyntaxAwareGeneratorTests.cs (2)
2109Assert.True(timing1.ElapsedTime.TotalMilliseconds >= sleepTimeInMs); 2116Assert.True(timing2.ElapsedTime.TotalMilliseconds >= sleepTimeInMs * 2);
Microsoft.CodeAnalysis.EditorFeatures (2)
InlineRename\UI\SmartRename\SmartRenameViewModel_Telemetry.cs (2)
57m["smartRenameSemanticContextDelay"] = _semanticContextDelay.TotalMilliseconds; 72m["smartRenameSemanticContextDelay"] = _semanticContextDelay.TotalMilliseconds;
Microsoft.CodeAnalysis.EditorFeatures.UnitTests (1)
Utilities\AsynchronousOperationListenerTests.cs (1)
73task.Wait((int)timeToSleep.TotalMilliseconds);
Microsoft.CodeAnalysis.Features (5)
ChangeSignature\ChangeSignatureTelemetryLogger.cs (1)
147s_statisticLogAggregator.AddDataPoint(ActionInfo.CommittedSessionCommitElapsedMS, (int)elapsedTime.TotalMilliseconds);
Copilot\CopilotChangeAnalysisUtilities.cs (1)
138return timeSpan.TotalMilliseconds.ToString("G17");
EditAndContinue\DebuggingSessionTelemetry.cs (2)
124map["EmitDifferenceMilliseconds"] = (long)editSessionData.EmitDifferenceTime.TotalMilliseconds; 130map["TotalAnalysisMilliseconds"] = (long)editSessionData.AnalysisTime.TotalMilliseconds;
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingIdleProcessor.cs (1)
106var delayTimeSpan = TimeSpan.FromMilliseconds(Math.Max(s_minimumDelay.TotalMilliseconds, timeLeft.TotalMilliseconds));
Microsoft.CodeAnalysis.InteractiveHost (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.LanguageServer.Protocol (2)
Handler\Telemetry\RequestTelemetryLogger.cs (2)
69m[TelemetryLogging.KeyValue] = (long)queuedDuration.TotalMilliseconds; 77m[TelemetryLogging.KeyValue] = (long)requestDuration.TotalMilliseconds;
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.PublicApiAnalyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.Remote.ServiceHub (2)
Services\DiagnosticAnalyzer\PerformanceQueue.cs (2)
176map[assignedAnalyzerNumber] = (timeSpan.TotalMilliseconds - minSpan.TotalMilliseconds) / fileCount;
Microsoft.CodeAnalysis.ResxSourceGenerator (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.Threading.Package (1)
TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Microsoft.CodeAnalysis.Workspaces (4)
Log\HistogramLogAggregator.cs (1)
45counter.IncreaseCount((int)timeSpan.TotalMilliseconds);
Log\StatisticLogAggregator.cs (1)
22AddDataPoint(key, (int)timeSpan.TotalMilliseconds);
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Storage\SQLite\v2\Interop\SqlConnection.cs (1)
110NativeMethods.sqlite3_busy_timeout(handle, (int)TimeSpan.FromMinutes(1).TotalMilliseconds);
Microsoft.DotNet.Open.Api.Tools.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Microsoft.Extensions.AI.Integration.Tests (2)
ChatClientIntegrationTests.cs (1)
919Assert.True(activity.Duration.TotalMilliseconds > 0);
EmbeddingGeneratorIntegrationTests.cs (1)
133Assert.True(activity.Duration.TotalMilliseconds > 0);
Microsoft.Extensions.AI.OpenAI (2)
src\Shared\ServerSentEvents\SseFormatter.cs (1)
132bufferWriter.WriteUtf8Number((long)retry.TotalMilliseconds);
src\Shared\ServerSentEvents\SseParser_1.cs (1)
47private readonly long TimeSpan_MaxValueMilliseconds = (long)TimeSpan.MaxValue.TotalMilliseconds;
Microsoft.Extensions.AI.Tests (2)
ChatCompletion\OpenTelemetryChatClientTests.cs (1)
179Assert.True(activity.Duration.TotalMilliseconds > 0);
Embeddings\OpenTelemetryEmbeddingGeneratorTests.cs (1)
96Assert.True(activity.Duration.TotalMilliseconds > 0);
Microsoft.Extensions.ApiDescription.Client.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Microsoft.Extensions.Diagnostics.HealthChecks (9)
DefaultHealthCheckService.cs (5)
209HealthCheckProcessingEnd(logger, status, duration.TotalMilliseconds); 238HealthCheckEndHealthy(logger, registration.Name, entry.Status, duration.TotalMilliseconds, entry.Description); 242HealthCheckEndDegraded(logger, registration.Name, entry.Status, duration.TotalMilliseconds, entry.Description, entry.Exception); 246HealthCheckEndUnhealthy(logger, registration.Name, entry.Status, duration.TotalMilliseconds, entry.Description, entry.Exception); 255HealthCheckError(logger, registration.Name, duration.TotalMilliseconds, exception);
HealthCheckPublisherHostedService.cs (4)
256HealthCheckPublisherProcessingEnd(logger, duration.TotalMilliseconds, exception); 265HealthCheckPublisherEnd(logger, HealthCheckPublisher, duration.TotalMilliseconds); 271HealthCheckPublisherError(logger, publisher, duration.TotalMilliseconds, exception); 278HealthCheckPublisherTimeout(logger, publisher, duration.TotalMilliseconds);
Microsoft.Extensions.Diagnostics.ResourceMonitoring (2)
ResourceMonitorService.cs (2)
80var bufferSize = (int)(_collectionWindow.TotalMilliseconds / _samplingInterval.TotalMilliseconds);
Microsoft.Extensions.Http (6)
DefaultHttpClientFactory.cs (2)
359_cleanupCycleEnd(logger, duration.TotalMilliseconds, disposedCount, finalCount, null); 375_handlerExpired(logger, lifetime.TotalMilliseconds, clientName, null);
Logging\LogHelper.cs (4)
89_requestEnd(logger, duration.TotalMilliseconds, (int)response.StatusCode, null); 103_requestFailed(logger, duration.TotalMilliseconds, exception); 128_requestPipelineEnd(logger, duration.TotalMilliseconds, (int)response.StatusCode, null); 142_requestPipelineFailed(logger, duration.TotalMilliseconds, exception);
Microsoft.Extensions.Http.Diagnostics (1)
Logging\Internal\HttpClientLogger.cs (1)
239logRecord.Duration = (long)elapsed.TotalMilliseconds;
Microsoft.Extensions.Http.Resilience (3)
Hedging\Internals\Validators\HttpStandardHedgingResilienceOptionsCustomValidator.cs (2)
24var timeout = TimeSpan.FromMilliseconds(options.Endpoint.Timeout.Timeout.TotalMilliseconds * CircuitBreakerTimeoutMultiplier); 36var maxHedgingDelay = TimeSpan.FromMilliseconds(options.Hedging.MaxHedgedAttempts * options.Hedging.Delay.TotalMilliseconds);
Resilience\Internal\Validators\HttpStandardResilienceOptionsCustomValidator.cs (1)
24if (options.CircuitBreaker.SamplingDuration < TimeSpan.FromMilliseconds(options.AttemptTimeout.Timeout.TotalMilliseconds * CircuitBreakerTimeoutMultiplier))
Microsoft.Extensions.Http.Resilience.Tests (6)
Hedging\HttpStandardHedgingResilienceOptionsCustomValidatorTests.cs (3)
47options.Endpoint.CircuitBreaker.SamplingDuration = TimeSpan.FromMilliseconds(options.Endpoint.Timeout.Timeout.TotalMilliseconds * 2); 53TimeSpan.FromMilliseconds(options.Endpoint.Timeout.Timeout.TotalMilliseconds * 2) + TimeSpan.FromMilliseconds(10); 92options.Endpoint.CircuitBreaker.SamplingDuration = TimeSpan.FromMilliseconds(options.Endpoint.Timeout.Timeout.TotalMilliseconds / 2);
Resilience\HttpStandardResilienceOptionsCustomValidatorTests.cs (3)
53options.CircuitBreaker.SamplingDuration = TimeSpan.FromMilliseconds(options.AttemptTimeout.Timeout.TotalMilliseconds * 2); 58options.CircuitBreaker.SamplingDuration = TimeSpan.FromMilliseconds(options.AttemptTimeout.Timeout.TotalMilliseconds * 2) + TimeSpan.FromMilliseconds(10); 93options.CircuitBreaker.SamplingDuration = TimeSpan.FromMilliseconds(options.AttemptTimeout.Timeout.TotalMilliseconds / 2);
Microsoft.Extensions.ML (6)
ModelLoaders\FileModelLoader.cs (3)
186_fileLoadEnd(logger, filePath, duration.TotalMilliseconds, null); 191_fileReloadError(logger, filePath, duration.TotalMilliseconds, exception); 196_fileReLoad(logger, filePath, duration.TotalMilliseconds, null);
ModelLoaders\UriModelLoader.cs (3)
122_reloadTimer = new Timer(ReloadTimerTick, this, Convert.ToInt32(_timerPeriod.Value.TotalMilliseconds), Timeout.Infinite); 220_uriReloadEnd(logger, uri, duration.TotalMilliseconds, null); 225_uriReloadError(logger, uri, duration.TotalMilliseconds, exception);
Microsoft.Extensions.TimeProvider.Testing (2)
Timer.cs (2)
32var dueTimeMs = (long)dueTime.TotalMilliseconds; 33var periodMs = (long)period.TotalMilliseconds;
Microsoft.Extensions.TimeProvider.Testing.Tests (4)
FakeTimeProviderTests.cs (4)
178Assert.Equal(1234D, utcDelta.TotalMilliseconds); 180Assert.Equal(1234, elapsedTime.TotalMilliseconds); 202Assert.Equal(1234D, utcDelta.TotalMilliseconds); 204Assert.Equal(1234, elapsedTime.TotalMilliseconds);
Microsoft.Maui (1)
Animations\AnimationManager.cs (1)
84 var milliseconds = TimeSpan.FromMilliseconds(now - _lastUpdate).TotalMilliseconds;
Microsoft.Maui.Controls (1)
TimePicker\TimePicker.cs (1)
27 return time.TotalHours < 24 && time.TotalMilliseconds >= 0;
Microsoft.Maui.Controls.Build.Tasks (1)
PerformanceProvider.cs (1)
66 double total = TimeSpan.FromTicks(kvp.Value.TotalTime).TotalMilliseconds;
Microsoft.Maui.Essentials (1)
Vibration\Vibration.shared.cs (1)
112 if (duration.TotalMilliseconds < 0)
Microsoft.ML.AutoML (1)
AutoMLExperiment\IPerformanceMonitor.cs (1)
124var cpuUsedMs = elapseCpuProcessorTime.TotalMilliseconds;
Microsoft.ML.Samples.OneDal (3)
Program.cs (3)
183Console.WriteLine($"Random Forest Binary,{mainWatch.Elapsed.TotalMilliseconds},{metrics[0]},{metrics[1]},{metrics[2]},{metrics[3]}"); 190Console.WriteLine($"Random Forest Regression,{mainWatch.Elapsed.TotalMilliseconds},{metrics[0]},{metrics[1]},{metrics[2]},{metrics[3]}"); 198Console.WriteLine($"OLS Regression,{mainWatch.Elapsed.TotalMilliseconds},{metrics[0]},{metrics[1]},{metrics[2]},{metrics[3]}");
Microsoft.VisualStudio.LanguageServices.CSharp (1)
SemanticSearch\SemanticSearchQueryExecutor.cs (1)
157map["EmitTime"] = (long)emitTime.TotalMilliseconds;
MSBuild (5)
NodeEndpointOutOfProcBase.cs (1)
366int waitTimeRemaining = Math.Max(0, CommunicationsUtilities.NodeConnectionTimeout - (int)usedWaitTime.TotalMilliseconds);
XMake.cs (4)
446Console.WriteLine("||{0,50}|{1,20:N0}|{2,8}|", "Peak Privileged Processor Time", currentProcess.PrivilegedProcessorTime.TotalMilliseconds, "ms"); 447Console.WriteLine("||{0,50}|{1,20:N0}|{2,8}|", "Peak User Processor Time", currentProcess.UserProcessorTime.TotalMilliseconds, "ms"); 448Console.WriteLine("||{0,50}|{1,20:N0}|{2,8}|", "Peak Total Processor Time", currentProcess.TotalProcessorTime.TotalMilliseconds, "ms"); 938AppendOutputFile(timerOutputFilename, (long)elapsedTime.TotalMilliseconds);
MSBuildTaskHost (1)
NodeEndpointOutOfProcBase.cs (1)
366int waitTimeRemaining = Math.Max(0, CommunicationsUtilities.NodeConnectionTimeout - (int)usedWaitTime.TotalMilliseconds);
PresentationCore (127)
System\Windows\Media\Animation\Generated\BooleanAnimationUsingKeyFrames.cs (6)
393currentSegmentProgress = currentTime.TotalMilliseconds 394/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 406currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 407/ segmentDuration.TotalMilliseconds; 652keyTime.Percent * calculationDuration.TotalMilliseconds); 888(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\ByteAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\CharAnimationUsingKeyFrames.cs (6)
393currentSegmentProgress = currentTime.TotalMilliseconds 394/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 406currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 407/ segmentDuration.TotalMilliseconds; 652keyTime.Percent * calculationDuration.TotalMilliseconds); 888(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\ColorAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\DecimalAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\DoubleAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Int16AnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Int32AnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Int64AnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\MatrixAnimationUsingKeyFrames.cs (6)
393currentSegmentProgress = currentTime.TotalMilliseconds 394/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 406currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 407/ segmentDuration.TotalMilliseconds; 652keyTime.Percent * calculationDuration.TotalMilliseconds); 888(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\ObjectAnimationUsingKeyFrames.cs (6)
393currentSegmentProgress = currentTime.TotalMilliseconds 394/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 406currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 407/ segmentDuration.TotalMilliseconds; 652keyTime.Percent * calculationDuration.TotalMilliseconds); 888(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Point3DAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\PointAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\QuaternionAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\RectAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Rotation3DAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\SingleAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\SizeAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\StringAnimationUsingKeyFrames.cs (6)
393currentSegmentProgress = currentTime.TotalMilliseconds 394/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 406currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 407/ segmentDuration.TotalMilliseconds; 652keyTime.Percent * calculationDuration.TotalMilliseconds); 888(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\Vector3DAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\Animation\Generated\VectorAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
System\Windows\Media\MediaContext.cs (1)
642EventTrace.EasyTraceEvent(EventTrace.Keyword.KeywordGraphics, EventTrace.Event.WClientScheduleRender, nextTickNeeded.TotalMilliseconds);
PresentationFramework (6)
System\Windows\Media\Animation\Generated\ThicknessAnimationUsingKeyFrames.cs (6)
404currentSegmentProgress = currentTime.TotalMilliseconds 405/ _sortedResolvedKeyFrames[0]._resolvedKeyTime.TotalMilliseconds; 417currentSegmentProgress = segmentCurrentTime.TotalMilliseconds 418/ segmentDuration.TotalMilliseconds; 744keyTime.Percent * calculationDuration.TotalMilliseconds); 980(segmentLengths[i] / totalLength) * pacedBlockDuration.TotalMilliseconds);
Roslyn.Diagnostics.Analyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
RunTests (3)
AssemblyScheduler.cs (2)
100var averageExecutionTime = TimeSpan.FromMilliseconds(testHistory.Values.Average(t => t.TotalMilliseconds)); 153var totalExpectedRunTime = TimeSpan.FromMilliseconds(updated.Values.SelectMany(types => types).SelectMany(type => type.Tests).Sum(test => test.ExecutionTime.TotalMilliseconds));
TestHistoryManager.cs (1)
122var totalTestRuntime = TimeSpan.FromMilliseconds(testInfos.Values.Sum(t => t.TotalMilliseconds));
Security.TransportSecurity.IntegrationTests (1)
Tcp\StreamingTests.4.1.0.cs (1)
240serviceOperationTimeout.TotalMilliseconds,
Shared (2)
ServerSentEvents\SseFormatter.cs (1)
132bufferWriter.WriteUtf8Number((long)retry.TotalMilliseconds);
ServerSentEvents\SseParser_1.cs (1)
47private readonly long TimeSpan_MaxValueMilliseconds = (long)TimeSpan.MaxValue.TotalMilliseconds;
Sockets.FunctionalTests (2)
src\Servers\Kestrel\test\FunctionalTests\MaxRequestBufferSizeTests.cs (2)
120var bytesWrittenPollingInterval = TimeSpan.FromMilliseconds(bytesWrittenTimeout.TotalMilliseconds / 10); 213var bytesWrittenPollingInterval = TimeSpan.FromMilliseconds(bytesWrittenTimeout.TotalMilliseconds / 10);
System.Collections.Concurrent (5)
System\Collections\Concurrent\BlockingCollection.cs (5)
328return TryAddWithNoTimeValidation(item, (int)timeout.TotalMilliseconds, CancellationToken.None); 580return TryTakeWithNoTimeValidation(out item, (int)timeout.TotalMilliseconds, CancellationToken.None, null); 865return TryAddToAnyCore(collections, item, (int)timeout.TotalMilliseconds, CancellationToken.None); 1227return TryTakeFromAnyCore(collections, out item, (int)timeout.TotalMilliseconds, false, CancellationToken.None); 1698long totalMilliseconds = (long)timeout.TotalMilliseconds;
System.ComponentModel.TypeConverter (1)
System\Timers\Timer.cs (1)
71public Timer(TimeSpan interval) : this(interval.TotalMilliseconds)
System.Diagnostics.DiagnosticSource (2)
System\Diagnostics\Metrics\AggregationManager.cs (2)
184_pollingTimer = new Timer(CollectOnTimer, null, (int)delayTime.TotalMilliseconds, 0); 306_pollingTimer!.Change((int)delayTime.TotalMilliseconds, 0);
System.Diagnostics.Process (2)
System\Diagnostics\Process.cs (1)
1449long totalMilliseconds = (long)timeout.TotalMilliseconds;
System\Diagnostics\ProcessWaitState.Unix.cs (1)
427(int)Math.Max(millisecondsTimeout - Stopwatch.GetElapsedTime(startTime).TotalMilliseconds, 0);
System.IO.FileSystem.Watcher (1)
System\IO\FileSystemWatcher.cs (1)
614long totalMilliseconds = (long)timeout.TotalMilliseconds;
System.IO.Pipes (1)
System\IO\Pipes\NamedPipeClientStream.cs (1)
206long totalMilliseconds = (long)timeout.TotalMilliseconds;
System.Net.Http (15)
System\Net\Http\HttpTelemetry.AnyOS.cs (1)
36double timeOnQueueMs = duration.TotalMilliseconds;
System\Net\Http\SocketsHttpHandler\ChunkedEncodingReadStream.cs (1)
511cts = new CancellationTokenSource((int)drainTime.TotalMilliseconds);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionPool.cs (2)
872return connection.GetLifetimeTicks(Environment.TickCount64) > pooledConnectionLifetime.TotalMilliseconds; 883return lifetime == TimeSpan.Zero || connection.GetLifetimeTicks(Environment.TickCount64) > lifetime.TotalMilliseconds;
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionWaiter.cs (1)
92pool.Settings._connectTimeout != Timeout.InfiniteTimeSpan && timeout > (int)pool.Settings._connectTimeout.TotalMilliseconds) // Do not override shorter ConnectTimeout
System\Net\Http\SocketsHttpHandler\ContentLengthReadStream.cs (1)
223cts = new CancellationTokenSource((int)drainTime.TotalMilliseconds);
System\Net\Http\SocketsHttpHandler\Http2Connection.cs (1)
176double milliseconds = value.TotalMilliseconds;
System\Net\Http\SocketsHttpHandler\Http2StreamWindowManager.cs (1)
277if (NetEventSource.Log.IsEnabled()) connection.Trace($"[FlowControl] Updated MinRtt: {MinRtt.TotalMilliseconds} ms");
System\Net\Http\SocketsHttpHandler\HttpConnectionBase.cs (2)
229if (idleTicks > pooledConnectionIdleTimeout.TotalMilliseconds) 240if (lifetimeTicks > pooledConnectionLifetime.TotalMilliseconds)
System\Net\Http\SocketsHttpHandler\HttpConnectionPoolManager.cs (2)
117long heartBeatInterval = (long)Math.Max(1000, Math.Min(_settings._keepAlivePingDelay.TotalMilliseconds, _settings._keepAlivePingTimeout.TotalMilliseconds) / 4);
System\Net\Http\SocketsHttpHandler\SocketsHttpHandler.cs (3)
179(value.TotalMilliseconds > int.MaxValue)) 248(value.TotalMilliseconds > int.MaxValue)) 264(value.TotalMilliseconds > int.MaxValue))
System.Net.NameResolution (1)
System\Net\NameResolutionTelemetry.cs (1)
106_lookupsDuration?.WriteMetric(duration.TotalMilliseconds);
System.Net.Ping (3)
System\Net\NetworkInformation\Ping.cs (1)
657long totalMilliseconds = (long)timeout.TotalMilliseconds;
System\Net\NetworkInformation\Ping.RawSocket.cs (2)
235long roundTripTime = (long)Stopwatch.GetElapsedTime(startingTimestamp).TotalMilliseconds; 266while (Stopwatch.GetElapsedTime(startingTimestamp).TotalMilliseconds < timeout)
System.Net.Quic (6)
System\Net\Quic\Internal\MsQuicConfiguration.cs (3)
151? (ulong)options.IdleTimeout.TotalMilliseconds 159? (uint)options.KeepAliveInterval.TotalMilliseconds 179? (ulong)options.HandshakeTimeout.TotalMilliseconds
System\Net\Quic\NetEventSource.Quic.Counters.cs (1)
240if (s_countersLastFetched == 0 || Stopwatch.GetElapsedTime(s_countersLastFetched).TotalMilliseconds > 50)
System\Net\Quic\QuicStream.Stream.cs (2)
54return (int)_readTimeout.TotalMilliseconds; 73return (int)_writeTimeout.TotalMilliseconds;
System.Net.Requests (4)
System\Net\FtpWebRequest.cs (4)
547_remainingTimeout = Timeout - (int)((DateTime.UtcNow - _startTime).TotalMilliseconds); 734_remainingTimeout = Timeout - (int)((DateTime.UtcNow - _startTime).TotalMilliseconds); 875_remainingTimeout = Timeout - (int)((DateTime.UtcNow - _startTime).TotalMilliseconds); 900_remainingTimeout = Timeout - (int)((DateTime.UtcNow - _startTime).TotalMilliseconds);
System.Net.Security (3)
src\libraries\Common\src\System\Net\Http\X509ResourceClient.cs (1)
57long totalMillis = (long)downloadTimeout.TotalMilliseconds;
System\Net\Security\NetSecurityTelemetry.cs (2)
168HandshakeFailed(isServer, Stopwatch.GetElapsedTime(startingTimestamp).TotalMilliseconds, exceptionMessage); 216double duration = Stopwatch.GetElapsedTime(startingTimestamp).TotalMilliseconds;
System.Net.ServerSentEvents (2)
System\Net\ServerSentEvents\SseFormatter.cs (1)
129bufferWriter.WriteUtf8Number((long)retry.TotalMilliseconds);
System\Net\ServerSentEvents\SseParser_1.cs (1)
32private readonly long TimeSpan_MaxValueMilliseconds = (long)TimeSpan.MaxValue.TotalMilliseconds;
System.Net.Sockets (1)
System\Net\Sockets\NetworkStream.cs (1)
380long totalMilliseconds = (long)timeout.TotalMilliseconds;
System.Net.WebSockets (2)
System\Net\WebSockets\ManagedWebSocket.cs (1)
171long heartBeatIntervalMs = (long)keepAliveInterval.TotalMilliseconds;
System\Net\WebSockets\ManagedWebSocket.KeepAlive.cs (1)
151static int TimeSpanToMs(TimeSpan value) => (int)Math.Clamp((long)value.TotalMilliseconds, MinIntervalMs, int.MaxValue);
System.Private.CoreLib (34)
src\libraries\System.Private.CoreLib\src\System\Diagnostics\Tracing\CounterGroup.cs (3)
263delta = _pollingIntervalInMilliseconds > delta.TotalMilliseconds ? TimeSpan.FromMilliseconds(_pollingIntervalInMilliseconds) : delta; 265_nextPollingTimeStamp += TimeSpan.FromMilliseconds(_pollingIntervalInMilliseconds * Math.Ceiling(delta.TotalMilliseconds / _pollingIntervalInMilliseconds)); 301int millisecondsTillNextPoll = (int)((counterGroup._nextPollingTimeStamp - now).TotalMilliseconds);
src\libraries\System.Private.CoreLib\src\System\Diagnostics\Tracing\RuntimeEventSource.cs (2)
108_totalGcPauseTimeCounter ??= new IncrementingPollingCounter("total-pause-time-by-gc", this, () => GC.GetTotalPauseDuration().TotalMilliseconds) { DisplayName = "Time paused by GC", DisplayUnits = "ms" }; 118_jitTimeCounter ??= new IncrementingPollingCounter("time-in-jit", this, () => Runtime.JitInfo.GetCompilationTime().TotalMilliseconds) { DisplayName = "Time spent in JIT", DisplayUnits = "ms", DisplayRateTimeScale = new TimeSpan(0, 0, 1) };
src\libraries\System.Private.CoreLib\src\System\Threading\CancellationTokenSource.cs (3)
151/// <exception cref="ArgumentOutOfRangeException"><paramref name="delay"/>'s <see cref="TimeSpan.TotalMilliseconds"/> is less than -1 or greater than <see cref="uint.MaxValue"/> - 1.</exception> 162long totalMilliseconds = (long)delay.TotalMilliseconds; 379long totalMilliseconds = (long)delay.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\Lock.cs (1)
204/// of milliseconds by casting <see cref="TimeSpan.TotalMilliseconds"/> of the timeout to an integer value. A value
src\libraries\System.Private.CoreLib\src\System\Threading\ManualResetEventSlim.cs (2)
404long totalMilliseconds = (long)timeout.TotalMilliseconds; 437long totalMilliseconds = (long)timeout.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\PeriodicTimer.cs (1)
112long ms = (long)value.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\ReaderWriterLockSlim.cs (1)
240long ltm = (long)timeout.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\SemaphoreSlim.cs (6)
223long totalMilliseconds = (long)timeout.TotalMilliseconds; 231return Wait((int)timeout.TotalMilliseconds, CancellationToken.None); 257long totalMilliseconds = (long)timeout.TotalMilliseconds; 265return Wait((int)timeout.TotalMilliseconds, cancellationToken); 590long totalMilliseconds = (long)timeout.TotalMilliseconds; 598return WaitAsync((int)timeout.TotalMilliseconds, cancellationToken);
src\libraries\System.Private.CoreLib\src\System\Threading\SpinLock.cs (2)
225long totalMilliseconds = (long)timeout.TotalMilliseconds; 233TryEnter((int)timeout.TotalMilliseconds, ref lockTaken);
src\libraries\System.Private.CoreLib\src\System\Threading\SpinWait.cs (1)
286long totalMilliseconds = (long)timeout.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Task.cs (6)
2680long totalMilliseconds = (long)timeout.TotalMilliseconds; 4776long totalMilliseconds = (long)timeout.TotalMilliseconds; 5217long totalMilliseconds = (long)timeout.TotalMilliseconds; 5692/// <exception cref="ArgumentOutOfRangeException"><paramref name="delay"/>'s <see cref="TimeSpan.TotalMilliseconds"/> property is greater than 4294967294.</exception> 5723/// <exception cref="ArgumentOutOfRangeException"><paramref name="delay"/>'s <see cref="TimeSpan.TotalMilliseconds"/> property is greater than 4294967294.</exception> 5781long totalMilliseconds = (long)timeout.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\ThreadPoolWorkQueue.cs (2)
1801long tm = (long)timeout.TotalMilliseconds; 1823long tm = (long)timeout.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\Timer.cs (3)
498long tm = (long)time.TotalMilliseconds; 856long dueTm = (long)dueTime.TotalMilliseconds; 860long periodTm = (long)period.TotalMilliseconds;
src\libraries\System.Private.CoreLib\src\System\Threading\WaitHandle.cs (1)
81long timeoutMilliseconds = (long)timeout.TotalMilliseconds;
System.Runtime.Caching (2)
System\Runtime\Caching\Configuration\ConfigUtil.cs (1)
74double milliseconds = tValue.TotalMilliseconds;
System\Runtime\Caching\MemoryCacheStatistics.cs (1)
141double milliseconds = element.PollingInterval.TotalMilliseconds;
System.Security.Cryptography (1)
src\libraries\Common\src\System\Net\Http\X509ResourceClient.cs (1)
57long totalMillis = (long)downloadTimeout.TotalMilliseconds;
System.Text.RegularExpressions (2)
System\Text\RegularExpressions\RegexRunner.cs (1)
350_timeout = (int)(timeout.TotalMilliseconds + 0.5); // Round;
System\Text\RegularExpressions\Symbolic\SymbolicRegexMatcher.cs (1)
176_timeout = (int)(matchTimeout.TotalMilliseconds + 0.5); // Round up, so it will be at least 1ms
System.Threading (5)
System\Threading\Barrier.cs (2)
568long totalMilliseconds = (long)timeout.TotalMilliseconds; 574return SignalAndWait((int)timeout.TotalMilliseconds, cancellationToken);
System\Threading\CountdownEvent.cs (2)
459long totalMilliseconds = (long)timeout.TotalMilliseconds; 490long totalMilliseconds = (long)timeout.TotalMilliseconds;
System\Threading\ReaderWriterLock.cs (1)
1109var timeoutMilliseconds = (long)timeout.TotalMilliseconds;
System.Threading.Tasks.Dataflow (2)
Base\DataflowBlock.cs (1)
1003int millisecondsTimeout = (int)timeout.TotalMilliseconds;
Internal\Common.cs (1)
422long millisecondsTimeout = (long)timeout.TotalMilliseconds;
System.Windows.Forms.UI.IntegrationTests (3)
Infra\ScreenRecordService.cs (3)
489if (delay.TotalMilliseconds > ushort.MaxValue) 493WritePngUInt16(stream, buffer, crc, checked((ushort)(delay.TotalMilliseconds / 100))); 501WritePngUInt16(stream, buffer, crc, checked((ushort)delay.TotalMilliseconds));
Templates.Blazor.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Templates.Blazor.WebAssembly.Auth.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Templates.Blazor.WebAssembly.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Templates.Mvc.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Templates.Tests (1)
src\Shared\Process\ProcessExtensions.cs (1)
109if (process.WaitForExit((int)timeout.TotalMilliseconds))
Test.Utilities (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
Text.Analyzers (1)
src\Dependencies\Threading\TestHooks\IExpeditableDelaySource.cs (1)
26/// <para>The <paramref name="delay"/> argument's <see cref="TimeSpan.TotalMilliseconds"/> property is greater than <see cref="int.MaxValue"/>.</para>
VBCSCompiler (1)
src\Compilers\Server\VBCSCompiler\BuildServerController.cs (1)
129compilerServerHost.Logger.Log("Keep alive timeout is: {0} milliseconds.", keepAlive?.TotalMilliseconds ?? 0);
VBCSCompiler.UnitTests (2)
BuildClientTests.cs (1)
146Assert.False(await tryConnectToNamedPipe((int)oneSec.TotalMilliseconds, cancellationToken: default));
BuildServerConnectionTests.cs (1)
101timeoutOverride: (int)TimeSpan.FromSeconds(2).TotalMilliseconds,
Wasm.Performance.ConsoleHost (1)
Scenarios\ComponentRenderingScenarioBase.cs (1)
37var durationPerCycle = (duration / numCycles).TotalMilliseconds;