Skip to content

Commit

Permalink
Merged PR 3557: Revert "Wait to Complete Pipe"
Browse files Browse the repository at this point in the history
  • Loading branch information
BrennanConroy authored and Andrew Stanton-Nurse committed Oct 11, 2019
1 parent 7fd42c4 commit 57e68b0
Show file tree
Hide file tree
Showing 8 changed files with 12 additions and 164 deletions.
6 changes: 0 additions & 6 deletions eng/PatchConfig.props
Expand Up @@ -44,10 +44,4 @@ Later on, this will be checked using this condition:
Microsoft.AspNetCore.CookiePolicy;
</PackagesInPatch>
</PropertyGroup>
<PropertyGroup Condition=" '$(VersionPrefix)' == '2.1.14' ">
<PackagesInPatch>
Microsoft.AspNetCore.Http.Connections;
Microsoft.AspNetCore.SignalR.Core;
</PackagesInPatch>
</PropertyGroup>
</Project>
23 changes: 1 addition & 22 deletions src/SignalR/clients/ts/FunctionalTests/selenium/run-tests.ts
@@ -1,25 +1,14 @@
import { ChildProcess, spawn } from "child_process";
import * as _fs from "fs";
import * as fs from "fs";
import { EOL } from "os";
import * as path from "path";
import { promisify } from "util";
import { PassThrough, Readable } from "stream";

import { run } from "../../webdriver-tap-runner/lib";

import * as _debug from "debug";
const debug = _debug("signalr-functional-tests:run");

const ARTIFACTS_DIR = path.resolve(__dirname, "..", "..", "..", "..", "artifacts");
const LOGS_DIR = path.resolve(ARTIFACTS_DIR, "logs");

// Promisify things from fs we want to use.
const fs = {
createWriteStream: _fs.createWriteStream,
exists: promisify(_fs.exists),
mkdir: promisify(_fs.mkdir),
};

process.on("unhandledRejection", (reason) => {
console.error(`Unhandled promise rejection: ${reason}`);
process.exit(1);
Expand Down Expand Up @@ -113,13 +102,6 @@ if (chromePath) {
try {
const serverPath = path.resolve(__dirname, "..", "bin", configuration, "netcoreapp2.1", "FunctionalTests.dll");

if (!await fs.exists(ARTIFACTS_DIR)) {
await fs.mkdir(ARTIFACTS_DIR);
}
if (!await fs.exists(LOGS_DIR)) {
await fs.mkdir(LOGS_DIR);
}

debug(`Launching Functional Test Server: ${serverPath}`);
const dotnet = spawn("dotnet", [serverPath], {
env: {
Expand All @@ -135,9 +117,6 @@ if (chromePath) {
}
}

const logStream = fs.createWriteStream(path.resolve(LOGS_DIR, "ts.functionaltests.dotnet.log"));
dotnet.stdout.pipe(logStream);

process.on("SIGINT", cleanup);
process.on("exit", cleanup);

Expand Down
Expand Up @@ -274,35 +274,13 @@ private async Task WaitOnTasks(Task applicationTask, Task transportTask, bool cl
// Cancel any pending flushes from back pressure
Application?.Output.CancelPendingFlush();

// Normally it isn't safe to try and acquire this lock because the Send can hold onto it for a long time if there is backpressure
// It is safe to wait for this lock now because the Send will be in one of 4 states
// 1. In the middle of a write which is in the middle of being canceled by the CancelPendingFlush above, when it throws
// an OperationCanceledException it will complete the PipeWriter which will make any other Send waiting on the lock
// throw an InvalidOperationException if they call Write
// 2. About to write and see that there is a pending cancel from the CancelPendingFlush, go to 1 to see what happens
// 3. Enters the Send and sees the Dispose state from DisposeAndRemoveAsync and releases the lock
// 4. No Send in progress
await WriteLock.WaitAsync();
try
{
// Complete the applications read loop
Application?.Output.Complete(transportTask.Exception?.InnerException);
}
finally
{
WriteLock.Release();
}

Log.WaitingForTransportAndApplication(_logger, TransportType);

// Wait for application so we can complete the writer safely
await applicationTask.NoThrow();

// Shutdown application side now that it's finished
// Shutdown both sides and wait for nothing
Transport?.Output.Complete(applicationTask.Exception?.InnerException);
Application?.Output.Complete(transportTask.Exception?.InnerException);

try
{
Log.WaitingForTransportAndApplication(_logger, TransportType);
// A poorly written application *could* in theory get stuck forever and it'll show up as a memory leak
await Task.WhenAll(applicationTask, transportTask);
}
Expand Down
Expand Up @@ -511,14 +511,6 @@ private async Task ProcessSend(HttpContext context, HttpConnectionDispatcherOpti

context.Response.StatusCode = StatusCodes.Status404NotFound;
context.Response.ContentType = "text/plain";

// There are no writes anymore (since this is the write "loop")
// So it is safe to complete the writer
// We complete the writer here because we already have the WriteLock acquired
// and it's unsafe to complete outside of the lock
// Other code isn't guaranteed to be able to acquire the lock before another write
// even if CancelPendingFlush is called, and the other write could hang if there is backpressure
connection.Application.Output.Complete();
return;
}

Expand Down Expand Up @@ -557,8 +549,11 @@ private async Task ProcessDeleteAsync(HttpContext context)

Log.TerminatingConection(_logger);

// Dispose the connection, but don't wait for it. We assign it here so we can wait in tests
connection.DisposeAndRemoveTask = _manager.DisposeAndRemoveAsync(connection, closeGracefully: false);
// Complete the receiving end of the pipe
connection.Application.Output.Complete();

// Dispose the connection gracefully, but don't wait for it. We assign it here so we can wait in tests
connection.DisposeAndRemoveTask = _manager.DisposeAndRemoveAsync(connection, closeGracefully: true);

context.Response.StatusCode = StatusCodes.Status202Accepted;
context.Response.ContentType = "text/plain";
Expand Down
27 changes: 0 additions & 27 deletions src/SignalR/common/Http.Connections/src/Internal/TaskExtensions.cs

This file was deleted.

12 changes: 2 additions & 10 deletions src/SignalR/common/Shared/PipeWriterStream.cs
@@ -1,4 +1,4 @@
// Copyright (c) .NET Foundation. All rights reserved.
// Copyright (c) .NET Foundation. All rights reserved.
// Licensed under the Apache License, Version 2.0. See License.txt in the project root for license information.

using System;
Expand Down Expand Up @@ -76,15 +76,7 @@ private ValueTask WriteCoreAsync(ReadOnlyMemory<byte> source, CancellationToken

_length += source.Length;
var task = _pipeWriter.WriteAsync(source);
if (task.IsCompletedSuccessfully)
{
// Cancellation can be triggered by PipeWriter.CancelPendingFlush
if (task.Result.IsCanceled)
{
throw new OperationCanceledException();
}
}
else if (!task.IsCompletedSuccessfully)
if (!task.IsCompletedSuccessfully)
{
return WriteSlowAsync(task);
}
Expand Down
61 changes: 0 additions & 61 deletions src/SignalR/server/Core/src/HubConnectionContext.cs
Expand Up @@ -33,7 +33,6 @@ public class HubConnectionContext

private long _lastSendTimestamp = Stopwatch.GetTimestamp();
private ReadOnlyMemory<byte> _cachedPingMessage;
private volatile bool _connectionAborted;

/// <summary>
/// Initializes a new instance of the <see cref="HubConnectionContext"/> class.
Expand Down Expand Up @@ -100,12 +99,6 @@ public virtual ValueTask WriteAsync(HubMessage message, CancellationToken cancel
return new ValueTask(WriteSlowAsync(message));
}

if (_connectionAborted)
{
_writeLock.Release();
return default;
}

// This method should never throw synchronously
var task = WriteCore(message);

Expand Down Expand Up @@ -136,12 +129,6 @@ public virtual ValueTask WriteAsync(SerializedHubMessage message, CancellationTo
return new ValueTask(WriteSlowAsync(message));
}

if (_connectionAborted)
{
_writeLock.Release();
return default;
}

// This method should never throw synchronously
var task = WriteCore(message);

Expand Down Expand Up @@ -171,8 +158,6 @@ private ValueTask<FlushResult> WriteCore(HubMessage message)
{
Log.FailedWritingMessage(_logger, ex);

Abort();

return new ValueTask<FlushResult>(new FlushResult(isCanceled: false, isCompleted: true));
}
}
Expand All @@ -190,8 +175,6 @@ private ValueTask<FlushResult> WriteCore(SerializedHubMessage message)
{
Log.FailedWritingMessage(_logger, ex);

Abort();

return new ValueTask<FlushResult>(new FlushResult(isCanceled: false, isCompleted: true));
}
}
Expand All @@ -205,8 +188,6 @@ private async Task CompleteWriteAsync(ValueTask<FlushResult> task)
catch (Exception ex)
{
Log.FailedWritingMessage(_logger, ex);

Abort();
}
finally
{
Expand All @@ -220,20 +201,13 @@ private async Task WriteSlowAsync(HubMessage message)
await _writeLock.WaitAsync();
try
{
if (_connectionAborted)
{
return;
}

// Failed to get the lock immediately when entering WriteAsync so await until it is available

await WriteCore(message);
}
catch (Exception ex)
{
Log.FailedWritingMessage(_logger, ex);

Abort();
}
finally
{
Expand All @@ -245,11 +219,6 @@ private async Task WriteSlowAsync(SerializedHubMessage message)
{
try
{
if (_connectionAborted)
{
return;
}

// Failed to get the lock immediately when entering WriteAsync so await until it is available
await _writeLock.WaitAsync();

Expand All @@ -258,8 +227,6 @@ private async Task WriteSlowAsync(SerializedHubMessage message)
catch (Exception ex)
{
Log.FailedWritingMessage(_logger, ex);

Abort();
}
finally
{
Expand All @@ -283,20 +250,13 @@ private async Task TryWritePingSlowAsync()
{
try
{
if (_connectionAborted)
{
return;
}

await _connectionContext.Transport.Output.WriteAsync(_cachedPingMessage);

Log.SentPing(_logger);
}
catch (Exception ex)
{
Log.FailedWritingMessage(_logger, ex);

Abort();
}
finally
{
Expand Down Expand Up @@ -333,12 +293,6 @@ private async Task WriteHandshakeResponseAsync(HandshakeResponseMessage message)
/// </summary>
public virtual void Abort()
{
_connectionAborted = true;

// Cancel any current writes or writes that are about to happen and have already gone past the _connectionAborted bool
// We have to do this outside of the lock otherwise it could hang if the write is observing backpressure
_connectionContext.Transport.Output.CancelPendingFlush();

// If we already triggered the token then noop, this isn't thread safe but it's good enough
// to avoid spawning a new task in the most common cases
if (_connectionAbortedTokenSource.IsCancellationRequested)
Expand Down Expand Up @@ -469,24 +423,9 @@ internal void Abort(Exception exception)
internal Task AbortAsync()
{
Abort();

// Acquire lock to make sure all writes are completed
if (!_writeLock.Wait(0))
{
return AbortAsyncSlow();
}

_writeLock.Release();
return _abortCompletedTcs.Task;
}

private async Task AbortAsyncSlow()
{
await _writeLock.WaitAsync();
_writeLock.Release();
await _abortCompletedTcs.Task;
}

private void KeepAliveTick()
{
var timestamp = Stopwatch.GetTimestamp();
Expand Down
4 changes: 1 addition & 3 deletions src/SignalR/server/SignalR/test/HubConnectionHandlerTests.cs
Expand Up @@ -79,11 +79,9 @@ public async Task AbortFromHubMethodForcesClientDisconnect()
{
var connectionHandlerTask = await client.ConnectAsync(connectionHandler);

await client.SendInvocationAsync(nameof(AbortHub.Kill));
await client.InvokeAsync(nameof(AbortHub.Kill));

await connectionHandlerTask.OrTimeout();

Assert.Null(client.TryRead());
}
}

Expand Down

0 comments on commit 57e68b0

Please sign in to comment.