protected override void DoBeginRead() { if (this.acceptInProgress) { return; } IQueue <object> inboundBuffer = this.inboundBuffer; if (inboundBuffer.IsEmpty) { this.acceptInProgress = true; return; } IChannelPipeline pipeline = this.Pipeline; for (;;) { if (!inboundBuffer.TryDequeue(out object m)) { break; } pipeline.FireChannelRead(m); } pipeline.FireChannelReadComplete(); }
void FinishPeerRead0(LocalChannel peer) { Task peerFinishReadFuture = peer.finishReadFuture; if (peerFinishReadFuture != null) { if (!peerFinishReadFuture.IsCompleted) { this.RunFinishPeerReadTask(peer); return; } else { // Lazy unset to make sure we don't prematurely unset it while scheduling a new task. Interlocked.CompareExchange(ref peer.finishReadFuture, null, peerFinishReadFuture); } } IChannelPipeline peerPipeline = peer.Pipeline; if (peer.readInProgress) { peer.readInProgress = false; while (peer.inboundBuffer.TryDequeue(out object received)) { peerPipeline.FireChannelRead(received); } peerPipeline.FireChannelReadComplete(); } }
void FinishRead(ReadOperation operation) { NativeChannel ch = this.Channel; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = this.RecvBufAllocHandle; IByteBuffer buffer = operation.Buffer; allocHandle.LastBytesRead = operation.Status; if (allocHandle.LastBytesRead <= 0) { // nothing was read -> release the buffer. buffer.SafeRelease(); } else { buffer.SetWriterIndex(buffer.WriterIndex + operation.Status); pipeline.FireChannelRead(buffer); } allocHandle.IncMessagesRead(1); allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (operation.Error != null) { pipeline.FireExceptionCaught(operation.Error); } if (operation.Error != null || operation.EndOfStream) { ch.DoClose(); } }
protected override void DoBeginRead() { if (this.readInProgress) { return; } IChannelPipeline pipeline = this.Pipeline; IQueue <object> inboundBuffer = this.inboundBuffer; if (inboundBuffer.IsEmpty) { this.readInProgress = true; return; } InternalThreadLocalMap threadLocals = InternalThreadLocalMap.Get(); int stackDepth = threadLocals.LocalChannelReaderStackDepth; if (stackDepth < MAX_READER_STACK_DEPTH) { threadLocals.LocalChannelReaderStackDepth = stackDepth + 1; try { for (;;) { if (!inboundBuffer.TryDequeue(out object received)) { break; } pipeline.FireChannelRead(received); } pipeline.FireChannelReadComplete(); } finally { threadLocals.LocalChannelReaderStackDepth = stackDepth; } } else { try { this.EventLoop.Execute(this.InternalRead); } catch (Exception ex) { Logger.Warn("Closing Local channels {}-{} because exception occurred!", this, this.peer, ex); this.CloseAsync(); this.peer.CloseAsync(); throw; } } }
// Read callback from libuv thread void INativeUnsafe.FinishRead(ReadOperation operation) { var ch = (NativeChannel)this.channel; IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; OperationException error = operation.Error; bool close = error != null || operation.EndOfStream; IRecvByteBufAllocatorHandle allocHandle = this.RecvBufAllocHandle; allocHandle.Reset(config); IByteBuffer buffer = operation.Buffer; Debug.Assert(buffer != null); allocHandle.LastBytesRead = operation.Status; if (allocHandle.LastBytesRead <= 0) { // nothing was read -> release the buffer. buffer.Release(); } else { buffer.SetWriterIndex(buffer.WriterIndex + operation.Status); allocHandle.IncMessagesRead(1); ch.ReadPending = false; pipeline.FireChannelRead(buffer); } allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (close) { if (error != null) { pipeline.FireExceptionCaught(new ChannelException(error)); } this.CloseSafe(); } else { // If read is called from channel read or read complete // do not stop reading if (!ch.ReadPending && !config.AutoRead) { ch.DoStopRead(); } } }
void Serve0(LocalChannel child) { this.inboundBuffer.TryEnqueue(child); if (this.acceptInProgress) { this.acceptInProgress = false; IChannelPipeline pipeline = this.Pipeline; while (this.inboundBuffer.TryDequeue(out object m)) { pipeline.FireChannelRead(m); } pipeline.FireChannelReadComplete(); } }
void InternalRead() { IChannelPipeline pipeline = this.Pipeline; for (;;) { if (!this.inboundBuffer.TryDequeue(out object m)) { break; } pipeline.FireChannelRead(m); } pipeline.FireChannelReadComplete(); }
/// <summary> /// Write messages to the inbound of this <see cref="IChannel" /> /// </summary> /// <param name="msgs">The messages to be written.</param> /// <returns><c>true</c> if the write operation did add something to the inbound buffer</returns> public bool WriteInbound(params object[] msgs) { EnsureOpen(); if (0u >= (uint)msgs.Length) { return(_inboundMessages.NonEmpty); } IChannelPipeline p = Pipeline; for (int i = 0; i < msgs.Length; i++) { _ = p.FireChannelRead(msgs[i]); } FlushInbound(false, VoidPromise()); return(_inboundMessages.NonEmpty); }
/// <summary> /// Write messages to the inbound of this <see cref="IChannel" /> /// </summary> /// <param name="msgs">The messages to be written.</param> /// <returns><c>true</c> if the write operation did add something to the inbound buffer</returns> public bool WriteInbound(params object[] msgs) { this.EnsureOpen(); if (msgs.Length == 0) { return(IsNotEmpty(this.inboundMessages)); } IChannelPipeline p = this.Pipeline; foreach (object m in msgs) { p.FireChannelRead(m); } p.FireChannelReadComplete(); this.RunPendingTasks(); this.CheckException(); return(IsNotEmpty(this.inboundMessages)); }
void HandleReadException(IChannelPipeline pipeline, IByteBuffer byteBuf, Exception cause, bool close) { if (byteBuf != null) { if (byteBuf.IsReadable()) { this.Channel.ReadPending = false; pipeline.FireChannelRead(byteBuf); } else { byteBuf.Release(); } } pipeline.FireChannelReadComplete(); pipeline.FireExceptionCaught(cause); if (close || cause is SocketException) { this.CloseOnRead(); } }
private void HandleReadException(IChannelPipeline pipeline, IByteBuf byteBuf, Exception cause, bool close) { if (byteBuf != null) { if (byteBuf.IsReadable()) { Channel.ReadPending = false; pipeline.FireChannelRead(byteBuf); } else { byteBuf.Release(); } } pipeline.FireChannelReadComplete(); pipeline.FireExceptionCaught(cause); if (close || cause is SocketException) { CloseOnRead(); } }
void HandleReadException(IChannelPipeline pipeline, IByteBuffer byteBuf, Exception cause, bool close, IRecvByteBufAllocatorHandle allocHandle) { if (byteBuf != null) { if (byteBuf.IsReadable()) { this.Channel.ReadPending = false; pipeline.FireChannelRead(byteBuf); } else { byteBuf.Release(); } } allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); pipeline.FireExceptionCaught(cause); if (close || cause is SocketException) { this.CloseOnRead(); } }
//new AbstractSocketMessageChannel Channel => (AbstractSocketMessageChannel)this.channel; public override void FinishRead(SocketChannelAsyncOperation <TChannel, TUnsafe> operation) { Debug.Assert(_channel.EventLoop.InEventLoop); var ch = _channel; if (0u >= (uint)(ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active)) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = ch.Unsafe.RecvBufAllocHandle; allocHandle.Reset(config); bool closed = false; Exception exception = null; try { try { do { int localRead = ch.DoReadMessages(_readBuf); uint uLocalRead = (uint)localRead; if (0u >= uLocalRead) { break; } if (uLocalRead > SharedConstants.TooBigOrNegative) // localRead < 0 { closed = true; break; } allocHandle.IncMessagesRead(localRead); }while (allocHandle.ContinueReading()); } catch (Exception t) { exception = t; } int size = _readBuf.Count; for (int i = 0; i < size; i++) { ch.ReadPending = false; _ = pipeline.FireChannelRead(_readBuf[i]); } _readBuf.Clear(); allocHandle.ReadComplete(); _ = pipeline.FireChannelReadComplete(); if (exception is object) { if (exception is SocketException asSocketException && asSocketException.SocketErrorCode != SocketError.TryAgain) // todo: other conditions for not closing message-based socket? { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) closed = !(ch is IServerChannel); } _ = pipeline.FireExceptionCaught(exception); } if (closed) { if (ch.Open) { Close(VoidPromise()); } } } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() in channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() in channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!closed && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { AbstractSocketByteChannel ch = this.Channel; ch.ResetState(StateFlags.ReadScheduled); IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IByteBufferAllocator allocator = config.Allocator; int maxMessagesPerRead = config.MaxMessagesPerRead; IRecvByteBufAllocatorHandle allocHandle = this.RecvBufAllocHandle; IByteBuffer byteBuf = null; int messages = 0; bool close = false; try { operation.Validate(); int totalReadAmount = 0; bool readPendingReset = false; do { byteBuf = allocHandle.Allocate(allocator); int writable = byteBuf.WritableBytes; int localReadAmount = ch.DoReadBytes(byteBuf); if (localReadAmount <= 0) { // not was read release the buffer byteBuf.Release(); byteBuf = null; close = localReadAmount < 0; break; } if (!readPendingReset) { readPendingReset = true; ch.ReadPending = false; } pipeline.FireChannelRead(byteBuf); byteBuf = null; if (totalReadAmount >= int.MaxValue - localReadAmount) { // Avoid overflow. totalReadAmount = int.MaxValue; break; } totalReadAmount += localReadAmount; // stop reading if (!config.AutoRead) { break; } if (localReadAmount < writable) { // Read less than what the buffer can hold, // which might mean we drained the recv buffer completely. break; } }while (++messages < maxMessagesPerRead); pipeline.FireChannelReadComplete(); allocHandle.Record(totalReadAmount); if (close) { this.CloseOnRead(); close = false; } } catch (Exception t) { this.HandleReadException(pipeline, byteBuf, t, close); } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() input channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() input channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!close && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { Contract.Assert(this.channel.EventLoop.InEventLoop); TcpServerSocketChannel ch = this.Channel; if ((ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active) == 0) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = this.Channel.Unsafe.RecvBufAllocHandle; allocHandle.Reset(config); bool closed = false; Exception exception = null; try { Socket connectedSocket = null; try { connectedSocket = operation.AcceptSocket; operation.AcceptSocket = null; operation.Validate(); var message = this.PrepareChannel(connectedSocket); connectedSocket = null; ch.ReadPending = false; pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); if (!config.AutoRead && !ch.ReadPending) { // ChannelConfig.setAutoRead(false) was called in the meantime. // Completed Accept has to be processed though. return; } while (allocHandle.ContinueReading()) { connectedSocket = ch.Socket.Accept(); message = this.PrepareChannel(connectedSocket); connectedSocket = null; ch.ReadPending = false; pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); } } catch (SocketException ex) when(ex.SocketErrorCode == SocketError.OperationAborted || ex.SocketErrorCode == SocketError.InvalidArgument) { closed = true; } catch (SocketException ex) when(ex.SocketErrorCode == SocketError.WouldBlock) { } catch (SocketException ex) { // socket exceptions here are internal to channel's operation and should not go through the pipeline // especially as they have no effect on overall channel's operation Logger.Info("Exception on accept.", ex); } catch (ObjectDisposedException) { closed = true; } catch (Exception ex) { exception = ex; } allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (exception != null) { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) pipeline.FireExceptionCaught(exception); } if (closed && ch.Open) { this.CloseSafe(); } } finally { // Check if there is a readPending which was not processed yet. if (!closed && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }
protected override void ExecuteInternal(IChannelPipeline pipeline) { pipeline.FireChannelRead(null); }
public override void FinishRead(SocketChannelAsyncOperation operation) { Contract.Requires(this._channel.EventLoop.InEventLoop); TcpServerSocketChannel ch = this.Channel; ch.ResetState(StateFlags.ReadScheduled); IChannelConfiguration config = ch.Configuration; int maxMessagesPerRead = config.MaxMessagesPerRead; IChannelPipeline pipeline = ch.Pipeline; bool closed = false; Exception exception = null; int messageCount = 0; try { Socket connectedSocket = null; try { connectedSocket = operation.AcceptSocket; operation.Validate(); operation.AcceptSocket = null; var message = new TcpSocketChannel(ch, connectedSocket, true); ch.ReadPending = false; pipeline.FireChannelRead(message); messageCount++; if (!config.AutoRead && !ch.ReadPending) { // ChannelConfig.setAutoRead(false) was called in the meantime. // Completed Accept has to be processed though. return; } while (messageCount < maxMessagesPerRead) { connectedSocket = null; connectedSocket = ch.Socket.Accept(); message = new TcpSocketChannel(ch, connectedSocket, true); pipeline.FireChannelRead(message); // stop reading and remove op if (!config.AutoRead) { break; } messageCount++; } } catch (ObjectDisposedException) { closed = true; } catch (Exception ex) { var asSocketException = ex as SocketException; if (asSocketException == null || asSocketException.SocketErrorCode != SocketError.WouldBlock) { Logger.Warning(ex, "Failed to create a new channel from an accepted socket."); if (connectedSocket != null) { try { connectedSocket.Close(); } catch (Exception ex2) { Logger.Warning(ex2, "Failed to close a socket."); } } exception = ex; } } pipeline.FireChannelReadComplete(); if (exception != null) { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) pipeline.FireExceptionCaught(exception); } if (closed) { if (ch.IsOpen) { this.CloseAsync(); } } } finally { // Check if there is a readPending which was not processed yet. if (!closed && (config.AutoRead || ch.ReadPending)) { ch.DoBeginRead(); } } }
// Read callback from libuv thread void INativeUnsafe.FinishRead(ReadOperation operation) { var ch = _channel; IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; OperationException error = operation.Error; bool close = error is object || operation.EndOfStream; IRecvByteBufAllocatorHandle allocHandle = RecvBufAllocHandle; allocHandle.Reset(config); IByteBuffer buffer = operation.Buffer; Debug.Assert(buffer is object); allocHandle.LastBytesRead = operation.Status; if (allocHandle.LastBytesRead <= 0) { // nothing was read -> release the buffer. _ = buffer.Release(); close = allocHandle.LastBytesRead < 0; if (close) { // There is nothing left to read as we received an EOF. ch.ReadPending = false; } } else { _ = buffer.SetWriterIndex(buffer.WriterIndex + operation.Status); allocHandle.IncMessagesRead(1); ch.ReadPending = false; _ = pipeline.FireChannelRead(buffer); } allocHandle.ReadComplete(); _ = pipeline.FireChannelReadComplete(); if (close) { if (error is object) { _ = pipeline.FireExceptionCaught(ThrowHelper.GetChannelException(error)); } if (ch.Open) { Close(VoidPromise()); } // ## 苦竹 修改 this.CloseSafe(); ## } else { // If read is called from channel read or read complete // do not stop reading if (!ch.ReadPending && !config.AutoRead) { ch.DoStopRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { Contract.Requires(this.channel.EventLoop.InEventLoop); AbstractSocketMessageChannel ch = this.Channel; ch.ResetState(StateFlags.ReadScheduled); IChannelConfiguration config = ch.Configuration; if (!config.AutoRead && !ch.ReadPending) { // ChannelConfig.setAutoRead(false) was called in the meantime //removeReadOp(); -- noop with IOCP, just don't schedule receive again return; } int maxMessagesPerRead = config.MaxMessagesPerRead; IChannelPipeline pipeline = ch.Pipeline; bool closed = false; Exception exception = null; try { try { while (true) { int localRead = ch.DoReadMessages(this.readBuf); if (localRead == 0) { break; } if (localRead < 0) { closed = true; break; } // stop reading and remove op if (!config.AutoRead) { break; } if (this.readBuf.Count >= maxMessagesPerRead) { break; } } } catch (Exception t) { exception = t; } ch.ReadPending = false; int size = this.readBuf.Count; for (int i = 0; i < size; i++) { pipeline.FireChannelRead(this.readBuf[i]); } this.readBuf.Clear(); pipeline.FireChannelReadComplete(); if (exception != null) { var asSocketException = exception as SocketException; if (asSocketException != null && asSocketException.SocketErrorCode != SocketError.TryAgain) // todo: other conditions for not closing message-based socket? { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) closed = !(ch is IServerChannel); } pipeline.FireExceptionCaught(exception); } if (closed) { if (ch.Open) { this.CloseAsync(); } } } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() in channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() in channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!closed && (config.AutoRead || ch.ReadPending)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation <TServerChannel, TcpServerSocketChannelUnsafe> operation) { Debug.Assert(_channel.EventLoop.InEventLoop); var ch = _channel; if (0u >= (uint)(ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active)) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = ch.Unsafe.RecvBufAllocHandle; allocHandle.Reset(config); var closed = false; var aborted = false; Exception exception = null; try { Socket connectedSocket = null; try { connectedSocket = operation.AcceptSocket; operation.AcceptSocket = null; operation.Validate(); var message = PrepareChannel(connectedSocket); connectedSocket = null; ch.ReadPending = false; _ = pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); if (!config.IsAutoRead && !ch.ReadPending) { // ChannelConfig.setAutoRead(false) was called in the meantime. // Completed Accept has to be processed though. return; } while (allocHandle.ContinueReading()) { connectedSocket = ch.Socket.Accept(); message = PrepareChannel(connectedSocket); connectedSocket = null; ch.ReadPending = false; _ = pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); } } catch (SocketException ex) when(ex.SocketErrorCode.IsSocketAbortError()) { ch.Socket.SafeClose(); // Unbind...... exception = ex; aborted = true; } catch (SocketException ex) when(ex.SocketErrorCode == SocketError.WouldBlock) { } catch (SocketException ex) { // socket exceptions here are internal to channel's operation and should not go through the pipeline // especially as they have no effect on overall channel's operation if (Logger.InfoEnabled) { Logger.ExceptionOnAccept(ex); } } catch (ObjectDisposedException) { closed = true; } catch (Exception ex) { exception = ex; } allocHandle.ReadComplete(); _ = pipeline.FireChannelReadComplete(); if (exception is object) { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) _ = pipeline.FireExceptionCaught(exception); } if (ch.IsOpen) { if (closed) { Close(VoidPromise()); } else if (aborted) { ch.CloseSafe(); } } } finally { // Check if there is a readPending which was not processed yet. if (!closed && (ch.ReadPending || config.IsAutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation <TChannel, TUnsafe> operation) { var ch = _channel; if (0u >= (uint)(ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active)) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; if (ch.ShouldBreakReadReady(config)) { ch.ClearReadPending(); return; } IChannelPipeline pipeline = ch.Pipeline; IByteBufferAllocator allocator = config.Allocator; IRecvByteBufAllocatorHandle allocHandle = RecvBufAllocHandle; allocHandle.Reset(config); IByteBuffer byteBuf = null; bool close = false; try { operation.Validate(); do { byteBuf = allocHandle.Allocate(allocator); allocHandle.LastBytesRead = ch.DoReadBytes(byteBuf); if ((uint)(allocHandle.LastBytesRead - 1) > SharedConstants.TooBigOrNegative) // <= 0 { // nothing was read -> release the buffer. _ = byteBuf.Release(); byteBuf = null; close = (uint)allocHandle.LastBytesRead > SharedConstants.TooBigOrNegative; // < 0 if (close) { // There is nothing left to read as we received an EOF. ch.ReadPending = false; } break; } allocHandle.IncMessagesRead(1); ch.ReadPending = false; _ = pipeline.FireChannelRead(byteBuf); byteBuf = null; }while (allocHandle.ContinueReading()); allocHandle.ReadComplete(); _ = pipeline.FireChannelReadComplete(); if (close) { CloseOnRead(); } } catch (Exception t) { HandleReadException(pipeline, byteBuf, t, close, allocHandle); } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() input channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() input channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!close && (ch.ReadPending || config.IsAutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { Contract.Assert(this.channel.EventLoop.InEventLoop); TcpServerSocketChannel ch = this.Channel; if ((ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active) == 0) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = this.Channel.Unsafe.RecvBufAllocHandle; allocHandle.Reset(config); bool closed = false; Exception exception = null; try { Socket connectedSocket = null; try { connectedSocket = operation.AcceptSocket; operation.Validate(); operation.AcceptSocket = null; var message = new TcpSocketChannel(ch, connectedSocket, true); ch.ReadPending = false; pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); if (!config.AutoRead && !ch.ReadPending) { // ChannelConfig.setAutoRead(false) was called in the meantime. // Completed Accept has to be processed though. return; } while (allocHandle.ContinueReading()) { connectedSocket = null; connectedSocket = ch.Socket.Accept(); message = new TcpSocketChannel(ch, connectedSocket, true); ch.ReadPending = false; pipeline.FireChannelRead(message); allocHandle.IncMessagesRead(1); } } catch (ObjectDisposedException) { closed = true; } catch (Exception ex) { var asSocketException = ex as SocketException; if (asSocketException == null || asSocketException.SocketErrorCode != SocketError.WouldBlock) { Logger.Warn("Failed to create a new channel from an accepted socket.", ex); if (connectedSocket != null) { try { connectedSocket.Dispose(); } catch (Exception ex2) { Logger.Warn("Failed to close a socket.", ex2); } } exception = ex; } } allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (exception != null) { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) pipeline.FireExceptionCaught(exception); } if (closed) { if (ch.Open) { this.CloseAsync(); } } } finally { // Check if there is a readPending which was not processed yet. if (!closed && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { Contract.Assert(this.channel.EventLoop.InEventLoop); AbstractSocketMessageChannel ch = this.Channel; ch.ResetState(StateFlags.ReadScheduled); IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IRecvByteBufAllocatorHandle allocHandle = this.Channel.Unsafe.RecvBufAllocHandle; allocHandle.Reset(config); bool closed = false; Exception exception = null; try { try { do { int localRead = ch.DoReadMessages(this.readBuf); if (localRead == 0) { break; } if (localRead < 0) { closed = true; break; } allocHandle.IncMessagesRead(localRead); }while (allocHandle.ContinueReading()); } catch (Exception t) { exception = t; } int size = this.readBuf.Count; for (int i = 0; i < size; i++) { ch.ReadPending = false; pipeline.FireChannelRead(this.readBuf[i]); } this.readBuf.Clear(); allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (exception != null) { var asSocketException = exception as SocketException; if (asSocketException != null && asSocketException.SocketErrorCode != SocketError.TryAgain) // todo: other conditions for not closing message-based socket? { // ServerChannel should not be closed even on SocketException because it can often continue // accepting incoming connections. (e.g. too many open files) closed = !(ch is IServerChannel); } pipeline.FireExceptionCaught(exception); } if (closed) { if (ch.Open) { this.CloseAsync(); } } } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() in channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() in channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!closed && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }
public override void FinishRead(SocketChannelAsyncOperation operation) { AbstractSocketByteChannel ch = this.Channel; if ((ch.ResetState(StateFlags.ReadScheduled) & StateFlags.Active) == 0) { return; // read was signaled as a result of channel closure } IChannelConfiguration config = ch.Configuration; IChannelPipeline pipeline = ch.Pipeline; IByteBufferAllocator allocator = config.Allocator; IRecvByteBufAllocatorHandle allocHandle = this.RecvBufAllocHandle; allocHandle.Reset(config); IByteBuffer byteBuf = null; bool close = false; try { operation.Validate(); do { byteBuf = allocHandle.Allocate(allocator); //int writable = byteBuf.WritableBytes; allocHandle.LastBytesRead = ch.DoReadBytes(byteBuf); if (allocHandle.LastBytesRead <= 0) { // nothing was read -> release the buffer. byteBuf.Release(); byteBuf = null; close = allocHandle.LastBytesRead < 0; break; } allocHandle.IncMessagesRead(1); this.Channel.ReadPending = false; pipeline.FireChannelRead(byteBuf); byteBuf = null; }while (allocHandle.ContinueReading()); allocHandle.ReadComplete(); pipeline.FireChannelReadComplete(); if (close) { this.CloseOnRead(); } } catch (Exception t) { this.HandleReadException(pipeline, byteBuf, t, close, allocHandle); } finally { // Check if there is a readPending which was not processed yet. // This could be for two reasons: // /// The user called Channel.read() or ChannelHandlerContext.read() input channelRead(...) method // /// The user called Channel.read() or ChannelHandlerContext.read() input channelReadComplete(...) method // // See https://github.com/netty/netty/issues/2254 if (!close && (ch.ReadPending || config.AutoRead)) { ch.DoBeginRead(); } } }