459 references to Interop
System.Net.Sockets (459)
src\libraries\Common\src\Interop\Unix\Interop.Errors.cs (6)
123_error = Interop.Sys.ConvertErrorPlatformToPal(errno); 140get { return _rawErrno == -1 ? (_rawErrno = Interop.Sys.ConvertErrorPalToPlatform(_error)) : _rawErrno; } 145return Interop.Sys.StrError(RawErrno); 219public static Interop.ErrorInfo Info(this Interop.Error error) 221return new Interop.ErrorInfo(error);
src\libraries\Common\src\System\Net\InteropIPAddressExtensions.Unix.cs (6)
11public static unsafe Interop.Sys.IPAddress GetNativeIPAddress(this IPAddress ipAddress) 13var nativeIPAddress = default(Interop.Sys.IPAddress); 15ipAddress.TryWriteBytes(new Span<byte>(nativeIPAddress.Address, Interop.Sys.IPv6AddressBytes), out int bytesWritten); 16Debug.Assert(bytesWritten == sizeof(uint) || bytesWritten == Interop.Sys.IPv6AddressBytes, $"Unexpected length: {bytesWritten}"); 27public static unsafe IPAddress GetIPAddress(this Interop.Sys.IPAddress nativeIPAddress) 37new ReadOnlySpan<byte>(nativeIPAddress.Address, Interop.Sys.IPv6AddressBytes),
src\libraries\Common\src\System\Net\SocketAddressPal.Unix.cs (23)
26Interop.Error err = Interop.Sys.GetSocketAddressSizes(&ipv4, &ipv6, &uds, &max); 27Debug.Assert(err == Interop.Error.SUCCESS, $"Unexpected err: {err}"); 39private static void ThrowOnFailure(Interop.Error err) 43case Interop.Error.SUCCESS: 46case Interop.Error.EFAULT: 50case Interop.Error.EAFNOSUPPORT: 63Interop.Error err; 66err = Interop.Sys.GetAddressFamily(rawAddress, buffer.Length, (int*)&family); 75Interop.Error err; 81err = Interop.Sys.SetAddressFamily(rawAddress, buffer.Length, (int)family); 91Interop.Error err; 94err = Interop.Sys.GetPort(rawAddress, buffer.Length, &port); 103Interop.Error err; 106err = Interop.Sys.SetPort(rawAddress, buffer.Length, port); 115Interop.Error err; 118err = Interop.Sys.GetIPv4Address(rawAddress, buffer.Length, &ipAddress); 128Interop.Error err; 132err = Interop.Sys.GetIPv6Address(rawAddress, buffer.Length, ipAddress, address.Length, &localScope); 141Interop.Error err; 144err = Interop.Sys.SetIPv4Address(rawAddress, buffer.Length, address); 167Interop.Error err; 170err = Interop.Sys.SetIPv6Address(rawAddress, buffer.Length, address, addressLength, scope);
src\libraries\Common\src\System\Net\SocketProtocolSupportPal.Unix.cs (5)
25Interop.Error result = Interop.Sys.Socket((int)af, DgramSocketType, 0, &socket); 27return result != Interop.Error.EAFNOSUPPORT && result != Interop.Error.EPROTONOSUPPORT; 33Interop.Sys.Close(socket);
src\libraries\Common\src\System\Net\Sockets\SocketErrorPal.Unix.cs (92)
34private static readonly Dictionary<Interop.Error, SocketError> s_nativeErrorToSocketError = new Dictionary<Interop.Error, SocketError>(NativeErrorToSocketErrorCount) 36{ Interop.Error.EACCES, SocketError.AccessDenied }, 37{ Interop.Error.EADDRINUSE, SocketError.AddressAlreadyInUse }, 38{ Interop.Error.EADDRNOTAVAIL, SocketError.AddressNotAvailable }, 39{ Interop.Error.EAFNOSUPPORT, SocketError.AddressFamilyNotSupported }, 40{ Interop.Error.EAGAIN, SocketError.WouldBlock }, 41{ Interop.Error.EALREADY, SocketError.AlreadyInProgress }, 42{ Interop.Error.EBADF, SocketError.OperationAborted }, 43{ Interop.Error.ECANCELED, SocketError.OperationAborted }, 44{ Interop.Error.ECONNABORTED, SocketError.ConnectionAborted }, 45{ Interop.Error.ECONNREFUSED, SocketError.ConnectionRefused }, 46{ Interop.Error.ECONNRESET, SocketError.ConnectionReset }, 47{ Interop.Error.EDESTADDRREQ, SocketError.DestinationAddressRequired }, 48{ Interop.Error.EFAULT, SocketError.Fault }, 49{ Interop.Error.EHOSTDOWN, SocketError.HostDown }, 50{ Interop.Error.ENXIO, SocketError.HostNotFound }, // not perfect, but closest match available 51{ Interop.Error.EHOSTUNREACH, SocketError.HostUnreachable }, 52{ Interop.Error.EINPROGRESS, SocketError.InProgress }, 53{ Interop.Error.EINTR, SocketError.Interrupted }, 54{ Interop.Error.EINVAL, SocketError.InvalidArgument }, 55{ Interop.Error.EISCONN, SocketError.IsConnected }, 56{ Interop.Error.EMFILE, SocketError.TooManyOpenSockets }, 57{ Interop.Error.EMSGSIZE, SocketError.MessageSize }, 58{ Interop.Error.ENETDOWN, SocketError.NetworkDown }, 59{ Interop.Error.ENETRESET, SocketError.NetworkReset }, 60{ Interop.Error.ENETUNREACH, SocketError.NetworkUnreachable }, 61{ Interop.Error.ENFILE, SocketError.TooManyOpenSockets }, 62{ Interop.Error.ENOBUFS, SocketError.NoBufferSpaceAvailable }, 63{ Interop.Error.ENODATA, SocketError.NoData }, 64{ Interop.Error.ENOENT, SocketError.AddressNotAvailable }, 65{ Interop.Error.ENOPROTOOPT, SocketError.ProtocolOption }, 66{ Interop.Error.ENOTCONN, SocketError.NotConnected }, 67{ Interop.Error.ENOTSOCK, SocketError.NotSocket }, 68{ Interop.Error.ENOTSUP, SocketError.OperationNotSupported }, 69{ Interop.Error.EPERM, SocketError.AccessDenied }, 70{ Interop.Error.EPIPE, SocketError.Shutdown }, 71{ Interop.Error.EPFNOSUPPORT, SocketError.ProtocolFamilyNotSupported }, 72{ Interop.Error.EPROTONOSUPPORT, SocketError.ProtocolNotSupported }, 73{ Interop.Error.EPROTOTYPE, SocketError.ProtocolType }, 74{ Interop.Error.ESOCKTNOSUPPORT, SocketError.SocketNotSupported }, 75{ Interop.Error.ESHUTDOWN, SocketError.Disconnecting }, 76{ Interop.Error.SUCCESS, SocketError.Success }, 77{ Interop.Error.ETIMEDOUT, SocketError.TimedOut }, 80private static readonly Dictionary<SocketError, Interop.Error> s_socketErrorToNativeError = new Dictionary<SocketError, Interop.Error>(SocketErrorToNativeErrorCount) 88{ SocketError.AccessDenied, Interop.Error.EACCES}, // could also have been EPERM 89{ SocketError.AddressAlreadyInUse, Interop.Error.EADDRINUSE }, 90{ SocketError.AddressNotAvailable, Interop.Error.EADDRNOTAVAIL }, 91{ SocketError.AddressFamilyNotSupported, Interop.Error.EAFNOSUPPORT }, 92{ SocketError.AlreadyInProgress, Interop.Error.EALREADY }, 93{ SocketError.ConnectionAborted, Interop.Error.ECONNABORTED }, 94{ SocketError.ConnectionRefused, Interop.Error.ECONNREFUSED }, 95{ SocketError.ConnectionReset, Interop.Error.ECONNRESET }, 96{ SocketError.DestinationAddressRequired, Interop.Error.EDESTADDRREQ }, 97{ SocketError.Disconnecting, Interop.Error.ESHUTDOWN }, 98{ SocketError.Fault, Interop.Error.EFAULT }, 99{ SocketError.HostDown, Interop.Error.EHOSTDOWN }, 100{ SocketError.HostNotFound, Interop.Error.EHOSTNOTFOUND }, 101{ SocketError.HostUnreachable, Interop.Error.EHOSTUNREACH }, 102{ SocketError.InProgress, Interop.Error.EINPROGRESS }, 103{ SocketError.Interrupted, Interop.Error.EINTR }, 104{ SocketError.InvalidArgument, Interop.Error.EINVAL }, 105{ SocketError.IOPending, Interop.Error.EINPROGRESS }, 106{ SocketError.IsConnected, Interop.Error.EISCONN }, 107{ SocketError.MessageSize, Interop.Error.EMSGSIZE }, 108{ SocketError.NetworkDown, Interop.Error.ENETDOWN }, 109{ SocketError.NetworkReset, Interop.Error.ENETRESET }, 110{ SocketError.NetworkUnreachable, Interop.Error.ENETUNREACH }, 111{ SocketError.NoBufferSpaceAvailable, Interop.Error.ENOBUFS }, 112{ SocketError.NoData, Interop.Error.ENODATA }, 113{ SocketError.NotConnected, Interop.Error.ENOTCONN }, 114{ SocketError.NotSocket, Interop.Error.ENOTSOCK }, 115{ SocketError.OperationAborted, Interop.Error.ECANCELED }, 116{ SocketError.OperationNotSupported, Interop.Error.ENOTSUP }, 117{ SocketError.ProtocolFamilyNotSupported, Interop.Error.EPFNOSUPPORT }, 118{ SocketError.ProtocolNotSupported, Interop.Error.EPROTONOSUPPORT }, 119{ SocketError.ProtocolOption, Interop.Error.ENOPROTOOPT }, 120{ SocketError.ProtocolType, Interop.Error.EPROTOTYPE }, 121{ SocketError.Shutdown, Interop.Error.EPIPE }, 122{ SocketError.SocketNotSupported, Interop.Error.ESOCKTNOSUPPORT }, 123{ SocketError.Success, Interop.Error.SUCCESS }, 124{ SocketError.TimedOut, Interop.Error.ETIMEDOUT }, 125{ SocketError.TooManyOpenSockets, Interop.Error.ENFILE }, // could also have been EMFILE 126{ SocketError.TryAgain, Interop.Error.EAGAIN }, // not a perfect mapping, but better than nothing 127{ SocketError.WouldBlock, Interop.Error.EAGAIN }, 128{ SocketError.SocketError, Interop.Error.ESOCKETERROR }, 131internal static SocketError GetSocketErrorForNativeError(Interop.Error errno) 139internal static Interop.Error GetNativeErrorForSocketError(SocketError error) 141Interop.Error errno; 145errno = (Interop.Error)(int)error; 150internal static bool TryGetNativeErrorForSocketError(SocketError error, out Interop.Error errno)
src\libraries\Common\src\System\Net\Sockets\SocketExceptionFactory.Unix.cs (1)
13if (SocketErrorPal.TryGetNativeErrorForSocketError((SocketError)socketError, out Interop.Error interopErr))
System\Net\Sockets\SafeSocketHandle.Unix.cs (23)
199int fdFlags = Interop.Sys.Fcntl.GetFD(handle); 208Interop.Error err = Interop.Sys.GetSockOpt(handle, SocketOptionLevel.Socket, SocketOptionName.Type, (byte*)&type, &optLen); 209if (err == Interop.Error.SUCCESS) 215Interop.Sys.Disconnect(handle); 219Interop.Sys.Shutdown(handle, SocketShutdown.Both); 228Interop.Error errorCode = Interop.Error.SUCCESS; 244if (errorCode != Interop.Error.EWOULDBLOCK) 251if (Interop.Sys.Fcntl.DangerousSetIsNonBlocking(handle, 0) == 0) 261var linger = new Interop.Sys.LingerOption 267errorCode = Interop.Sys.SetLingerOption(handle, &linger); 275case Interop.Error.SUCCESS: 276case Interop.Error.EINVAL: 277case Interop.Error.ENOPROTOOPT: 278case Interop.Error.ENOTSOCK: 288private Interop.Error CloseHandle(IntPtr handle) 290Interop.Error errorCode = Interop.Error.SUCCESS; 293if (Interop.Sys.Close(handle) != 0) 295errorCode = Interop.Sys.GetLastError(); 296if (errorCode == Interop.Error.ECONNRESET) 302errorCode = Interop.Error.SUCCESS;
System\Net\Sockets\Socket.Unix.cs (8)
64if (Interop.Sys.FStat(handle, out Interop.Sys.FileStatus stat) == -1) 68isSocket = (stat.Mode & Interop.Sys.FileTypes.S_IFSOCK) == Interop.Sys.FileTypes.S_IFSOCK; 78Interop.Error e = Interop.Sys.GetSocketType(handle, out addressFamily, out socketType, out protocolType, out isListening); 79Debug.Assert(e == Interop.Error.SUCCESS, e.ToString()); 97int rv = Interop.Sys.Fcntl.GetIsNonBlocking(handle, out nonBlocking);
System\Net\Sockets\SocketAsyncContext.Unix.cs (31)
837if (!context.IsRegistered && !context.TryRegister(out Interop.Error error)) 921static void HandleFailedRegistration(SocketAsyncContext context, TOperation operation, Interop.Error error) 923Debug.Assert(error != Interop.Error.SUCCESS); 926if (error == Interop.Error.EPIPE) 936if (error == Interop.Error.ENOMEM || error == Interop.Error.ENOSPC) 1284private bool TryRegister(out Interop.Error error) 1317error = Interop.Error.SUCCESS; 1351if (Interop.Sys.Fcntl.SetIsNonBlocking(_socket, 1) != 0) 1353throw new SocketException((int)SocketPal.GetSocketErrorForErrorCode(Interop.Sys.GetLastError())); 2167public Interop.Sys.SocketEvents HandleSyncEventsSpeculatively(Interop.Sys.SocketEvents events) 2169if ((events & Interop.Sys.SocketEvents.Error) != 0) 2173events ^= Interop.Sys.SocketEvents.Error; 2174events |= Interop.Sys.SocketEvents.Read | Interop.Sys.SocketEvents.Write; 2177if ((events & Interop.Sys.SocketEvents.Read) != 0 && 2181events ^= Interop.Sys.SocketEvents.Read; 2184if ((events & Interop.Sys.SocketEvents.Write) != 0 && 2188events ^= Interop.Sys.SocketEvents.Write; 2195public void HandleEventsInline(Interop.Sys.SocketEvents events) 2197if ((events & Interop.Sys.SocketEvents.Error) != 0) 2201events ^= Interop.Sys.SocketEvents.Error; 2202events |= Interop.Sys.SocketEvents.Read | Interop.Sys.SocketEvents.Write; 2205if ((events & Interop.Sys.SocketEvents.Read) != 0) 2211if ((events & Interop.Sys.SocketEvents.Write) != 0) 2219public unsafe void HandleEvents(Interop.Sys.SocketEvents events) 2221Debug.Assert((events & Interop.Sys.SocketEvents.Error) == 0); 2224(events & Interop.Sys.SocketEvents.Read) != 0 ? _receiveQueue.ProcessSyncEventOrGetAsyncEvent(this) : null; 2226(events & Interop.Sys.SocketEvents.Write) != 0 ? _sendQueue.ProcessSyncEventOrGetAsyncEvent(this) : null;
System\Net\Sockets\SocketAsyncEngine.Unix.cs (25)
78private readonly Interop.Sys.SocketEvent* _buffer; 111public static bool TryRegisterSocket(IntPtr socketHandle, SocketAsyncContext context, out SocketAsyncEngine? engine, out Interop.Error error) 120private bool TryRegisterCore(IntPtr socketHandle, SocketAsyncContext context, out Interop.Error error) 130error = Interop.Sys.TryChangeSocketEventRegistration(_port, socketHandle, Interop.Sys.SocketEvents.None, 131Interop.Sys.SocketEvents.Read | Interop.Sys.SocketEvents.Write, socketHandle); 132if (error == Interop.Error.SUCCESS) 154Interop.Error err; 157err = Interop.Sys.CreateSocketEventPort(portPtr); 158if (err != Interop.Error.SUCCESS) 164fixed (Interop.Sys.SocketEvent** bufferPtr = &_buffer) 166err = Interop.Sys.CreateSocketEventBuffer(EventBufferCount, bufferPtr); 167if (err != Interop.Error.SUCCESS) 195Interop.Error err = Interop.Sys.WaitForSocketEvents(_port, handler.Buffer, &numEvents); 196if (err != Interop.Error.SUCCESS) 310Interop.Sys.FreeSocketEventBuffer(_buffer); 314Interop.Sys.CloseSocketEventPort(_port); 325public Interop.Sys.SocketEvent* Buffer { get; } 341foreach (var socketEvent in new ReadOnlySpan<Interop.Sys.SocketEvent>(Buffer, numEvents)) 353Interop.Sys.SocketEvents events = context.HandleSyncEventsSpeculatively(socketEvent.Events); 355if (events != Interop.Sys.SocketEvents.None) 383public Interop.Sys.SocketEvents Events { get; } 385public SocketIOEvent(SocketAsyncContext context, Interop.Sys.SocketEvents events)
System\Net\Sockets\SocketPal.Unix.cs (238)
19public static readonly int MaximumAddressSize = Interop.Sys.GetMaximumAddressSize(); 27Interop.Sys.PlatformSupportsDualModeIPv4PacketInfo() != 0; 28public static SocketError GetSocketErrorForErrorCode(Interop.Error errorCode) 41private static unsafe IPPacketInformation GetIPPacketInformation(Interop.Sys.MessageHeader* messageHeader, bool isIPv4, bool isIPv6) 48Interop.Sys.IPPacketInformation nativePacketInfo = default; 49if (!Interop.Sys.TryGetIPPacketInformation(messageHeader, isIPv4, &nativePacketInfo)) 63Interop.Error error = Interop.Sys.Socket((int)addressFamily, (int)socketType, (int)protocolType, &fd); 64if (error == Interop.Error.SUCCESS) 75error = Interop.Sys.SetSockOpt(fd, SocketOptionLevel.IPv6, SocketOptionName.IPv6Only, (byte*)&on, sizeof(int)); 76if (error != Interop.Error.SUCCESS) 78Interop.Sys.Close(fd); 102private static unsafe int SysRead(SafeSocketHandle handle, Span<byte> buffer, out Interop.Error errno) 110received = Interop.Sys.Read(handle, b, buffer.Length); 111errno = received != -1 ? Interop.Error.SUCCESS : Interop.Sys.GetLastError(); 117private static unsafe int SysReceive(SafeSocketHandle socket, SocketFlags flags, Span<byte> buffer, out Interop.Error errno) 125errno = Interop.Sys.Receive( 133if (errno != Interop.Error.SUCCESS) 141private static unsafe int SysReceive(SafeSocketHandle socket, SocketFlags flags, Span<byte> buffer, Span<byte> socketAddress, out int socketAddressLen, out SocketFlags receivedFlags, out Interop.Error errno) 150var iov = new Interop.Sys.IOVector { 157var messageHeader = new Interop.Sys.MessageHeader { 164errno = Interop.Sys.ReceiveMessage( 174if (errno != Interop.Error.SUCCESS) 182private static unsafe int SysWrite(SafeSocketHandle handle, ReadOnlySpan<byte> buffer, ref int offset, ref int count, out Interop.Error errno) 190sent = Interop.Sys.Write(handle, b + offset, count); 193errno = Interop.Sys.GetLastError(); 197errno = Interop.Error.SUCCESS; 211private static unsafe int SysSend(SafeSocketHandle socket, SocketFlags flags, ReadOnlySpan<byte> buffer, ref int offset, ref int count, out Interop.Error errno) 220errno = Interop.Sys.Send( 228if (errno != Interop.Error.SUCCESS) 238private static unsafe int SysSend(SafeSocketHandle socket, SocketFlags flags, ReadOnlySpan<byte> buffer, ref int offset, ref int count, ReadOnlySpan<byte> socketAddress, out Interop.Error errno) 248var iov = new Interop.Sys.IOVector 254var messageHeader = new Interop.Sys.MessageHeader 263errno = Interop.Sys.SendMessage( 272if (errno != Interop.Error.SUCCESS) 282private static unsafe int SysSend(SafeSocketHandle socket, SocketFlags flags, IList<ArraySegment<byte>> buffers, ref int bufferIndex, ref int offset, ReadOnlySpan<byte> socketAddress, out Interop.Error errno) 292Span<Interop.Sys.IOVector> iovecs = allocOnStack ? stackalloc Interop.Sys.IOVector[IovStackThreshold] : new Interop.Sys.IOVector[maxBuffers]; 311fixed (Interop.Sys.IOVector* iov = iovecs) 313var messageHeader = new Interop.Sys.MessageHeader { 321errno = Interop.Sys.SendMessage( 339if (errno != Interop.Error.SUCCESS) 363private static unsafe long SendFile(SafeSocketHandle socket, SafeFileHandle fileHandle, ref long offset, ref long count, out Interop.Error errno) 366errno = Interop.Sys.SendFile(socket, fileHandle, offset, count, out bytesSent); 372private static unsafe int SysReceive(SafeSocketHandle socket, SocketFlags flags, IList<ArraySegment<byte>> buffers, Span<byte> socketAddress, out int socketAddressLen, out SocketFlags receivedFlags, out Interop.Error errno) 383errno = Interop.Sys.GetBytesAvailable(socket, &available); 384if (errno != Interop.Error.SUCCESS) 399Span<Interop.Sys.IOVector> iovecs = allocOnStack ? stackalloc Interop.Sys.IOVector[IovStackThreshold] : new Interop.Sys.IOVector[maxBuffers]; 432fixed (Interop.Sys.IOVector* iov = iovecs) 434var messageHeader = new Interop.Sys.MessageHeader { 441errno = Interop.Sys.ReceiveMessage( 462if (errno != Interop.Error.SUCCESS) 470private static unsafe int SysReceiveMessageFrom(SafeSocketHandle socket, SocketFlags flags, Span<byte> buffer, Span<byte> socketAddress, out int socketAddressLen, bool isIPv4, bool isIPv6, out SocketFlags receivedFlags, out IPPacketInformation ipPacketInformation, out Interop.Error errno) 474int cmsgBufferLen = Interop.Sys.GetControlMessageBufferSize(Convert.ToInt32(isIPv4), Convert.ToInt32(isIPv6)); 477Interop.Sys.MessageHeader messageHeader; 483var iov = new Interop.Sys.IOVector { 490messageHeader = new Interop.Sys.MessageHeader { 499errno = Interop.Sys.ReceiveMessage( 509if (errno != Interop.Error.SUCCESS) 528out SocketFlags receivedFlags, out IPPacketInformation ipPacketInformation, out Interop.Error errno) 535Span<Interop.Sys.IOVector> iovecs = allocOnStack ? stackalloc Interop.Sys.IOVector[IovStackThreshold] : new Interop.Sys.IOVector[buffersCount]; 553fixed (Interop.Sys.IOVector* iov = iovecs) 555int cmsgBufferLen = Interop.Sys.GetControlMessageBufferSize(Convert.ToInt32(isIPv4), Convert.ToInt32(isIPv6)); 558var messageHeader = new Interop.Sys.MessageHeader 569errno = Interop.Sys.ReceiveMessage( 578if (errno == Interop.Error.SUCCESS) 610Interop.Error errno; 616errno = Interop.Sys.Accept(socket, rawSocketAddress, &sockAddrLen, &fd); 629if (errno == Interop.Error.SUCCESS) 640if (errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 663Interop.Error err; 669err = Interop.Sys.Connectx(socket, rawSocketAddress, socketAddress.Length, data, data.Length, tfo ? 1 : 0, &sentBytes); 674err = Interop.Sys.Connect(socket, rawSocketAddress, socketAddress.Length); 678if (err == Interop.Error.SUCCESS) 684if (err != Interop.Error.EINPROGRESS) 696Interop.Error socketError = default; 697Interop.Error err; 705Interop.PollEvents outEvents; 706err = Interop.Sys.Poll(socket, Interop.PollEvents.POLLOUT, timeout: 0, out outEvents); 707if (err == Interop.Error.SUCCESS) 709if (outEvents == Interop.PollEvents.POLLNONE) 711socketError = Interop.Error.EINPROGRESS; 715err = Interop.Sys.GetSocketErrorOption(socket, &socketError); 726if (err != Interop.Error.SUCCESS) 728Debug.Assert(err == Interop.Error.EBADF, $"Unexpected err: {err}"); 733if (socketError == Interop.Error.SUCCESS) 738else if (socketError == Interop.Error.EINPROGRESS) 758Interop.Error errno; 795if (errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 817Interop.Error errno; 864if (errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 888Interop.Error errno; 909if (errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 956Interop.Error errno; 982if (!successfulSend && errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 1022Interop.Error errno; 1035if (errno != Interop.Error.SUCCESS) 1037if (errno != Interop.Error.EAGAIN && errno != Interop.Error.EWOULDBLOCK) 1064Interop.Error err = Interop.Sys.GetSockName(handle, buffer, nameLen); 1065return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1071Interop.Error err = Interop.Sys.GetBytesAvailable(handle, &value); 1074return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1080Interop.Error err = Interop.Sys.GetAtOutOfBandMark(handle, &value); 1083return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1088Interop.Error err; 1092err = Interop.Sys.GetPeerName(handle, rawBuffer, &addrLen); 1096return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1101Interop.Error err = Interop.Sys.Bind(handle, socketProtocolType, buffer); 1103return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1108Interop.Error err = Interop.Sys.Listen(handle, backlog); 1109return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1400private static SocketError GetErrorAndTrackSetting(SafeSocketHandle handle, SocketOptionLevel optionLevel, SocketOptionName optionName, Interop.Error err) 1402if (err == Interop.Error.SUCCESS) 1412Interop.Error err; 1419err = Interop.Sys.SetReceiveTimeout(handle, optionValue); 1425err = Interop.Sys.SetSendTimeout(handle, optionValue); 1438var opt = new Interop.Sys.IPv4MulticastOption 1445err = Interop.Sys.SetIPv4MulticastOption(handle, Interop.Sys.MulticastOption.MULTICAST_IF, &opt); 1451err = Interop.Sys.SetSockOpt(handle, optionLevel, optionName, (byte*)&optionValue, sizeof(int)); 1453if (err == Interop.Error.SUCCESS) 1485Interop.Error err = Interop.Sys.SetSockOpt(handle, optionLevel, optionName, pinnedValue, optionValue != null ? optionValue.Length : 0); 1494Interop.Error err = Interop.Sys.SetRawSockOpt(handle, optionLevel, optionName, optionValuePtr, optionValue.Length); 1496if (err == Interop.Error.SUCCESS) 1515Interop.Sys.MulticastOption optName = optionName == SocketOptionName.AddMembership ? 1516Interop.Sys.MulticastOption.MULTICAST_ADD : 1517Interop.Sys.MulticastOption.MULTICAST_DROP; 1522var opt = new Interop.Sys.IPv4MulticastOption 1530Interop.Error err = Interop.Sys.SetIPv4MulticastOption(handle, optName, &opt); 1538Interop.Sys.MulticastOption optName = optionName == SocketOptionName.AddMembership ? 1539Interop.Sys.MulticastOption.MULTICAST_ADD : 1540Interop.Sys.MulticastOption.MULTICAST_DROP; 1542var opt = new Interop.Sys.IPv6MulticastOption { 1547Interop.Error err = Interop.Sys.SetIPv6MulticastOption(handle, optName, &opt); 1553var opt = new Interop.Sys.LingerOption { 1558Interop.Error err = Interop.Sys.SetLingerOption(handle, &opt); 1597Interop.Error socketError = default(Interop.Error); 1598Interop.Error getErrorError = Interop.Sys.GetSocketErrorOption(handle, &socketError); 1600return getErrorError == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(getErrorError); 1605Interop.Error err = Interop.Sys.GetSockOpt(handle, optionLevel, optionName, (byte*)&value, &optLen); 1619return err == Interop.Error.SUCCESS ? SocketError.Success : GetSocketErrorForErrorCode(err); 1626Interop.Error err; 1630err = Interop.Sys.GetSockOpt(handle, optionLevel, optionName, null, &optLen); 1650err = Interop.Sys.GetSockOpt(handle, optionLevel, optionName, pinnedValue, &optLen); 1654if (err == Interop.Error.SUCCESS) 1670Interop.Error err = Interop.Sys.GetRawSockOpt(handle, optionLevel, optionName, pinnedValue, &optLen); 1672if (err == Interop.Error.SUCCESS) 1686Interop.Sys.MulticastOption optName = optionName == SocketOptionName.AddMembership ? 1687Interop.Sys.MulticastOption.MULTICAST_ADD : 1688Interop.Sys.MulticastOption.MULTICAST_DROP; 1690Interop.Sys.IPv4MulticastOption opt = default; 1691Interop.Error err = Interop.Sys.GetIPv4MulticastOption(handle, optName, &opt); 1692if (err != Interop.Error.SUCCESS) 1711Interop.Sys.MulticastOption optName = optionName == SocketOptionName.AddMembership ? 1712Interop.Sys.MulticastOption.MULTICAST_ADD : 1713Interop.Sys.MulticastOption.MULTICAST_DROP; 1715Interop.Sys.IPv6MulticastOption opt = default; 1716Interop.Error err = Interop.Sys.GetIPv6MulticastOption(handle, optName, &opt); 1717if (err != Interop.Error.SUCCESS) 1729Interop.Sys.LingerOption opt = default; 1730Interop.Error err = Interop.Sys.GetLingerOption(handle, &opt); 1731if (err != Interop.Error.SUCCESS) 1743Interop.PollEvents inEvent = Interop.PollEvents.POLLNONE; 1746case SelectMode.SelectRead: inEvent = Interop.PollEvents.POLLIN; break; 1747case SelectMode.SelectWrite: inEvent = Interop.PollEvents.POLLOUT; break; 1748case SelectMode.SelectError: inEvent = Interop.PollEvents.POLLPRI; break; 1753Interop.PollEvents outEvents; 1754Interop.Error err = Interop.Sys.Poll(handle, inEvent, milliseconds, out outEvents); 1755if (err != Interop.Error.SUCCESS) 1763case SelectMode.SelectRead: status = (outEvents & (Interop.PollEvents.POLLIN | Interop.PollEvents.POLLHUP)) != 0; break; 1764case SelectMode.SelectWrite: status = (outEvents & Interop.PollEvents.POLLOUT) != 0; break; 1765case SelectMode.SelectError: status = (outEvents & (Interop.PollEvents.POLLERR | Interop.PollEvents.POLLPRI)) != 0; break; 1788Interop.PollEvent* eventsOnStack = stackalloc Interop.PollEvent[count]; 1797var eventsOnHeap = new Interop.PollEvent[count]; 1798fixed (Interop.PollEvent* eventsOnHeapPtr = &eventsOnHeap[0]) 1813Interop.PollEvent* events, int eventsLength, 1824AddToPollArray(events, eventsLength, checkRead, ref offset, Interop.PollEvents.POLLIN | Interop.PollEvents.POLLHUP, ref refsAdded); 1825AddToPollArray(events, eventsLength, checkWrite, ref offset, Interop.PollEvents.POLLOUT, ref refsAdded); 1826AddToPollArray(events, eventsLength, checkError, ref offset, Interop.PollEvents.POLLPRI, ref refsAdded); 1833Interop.Error err = Interop.Sys.Poll(events, (uint)eventsLength, milliseconds, &triggered); 1834if (err != Interop.Error.SUCCESS) 1852FilterPollList(checkRead, events, checkReadInitialCount - 1, Interop.PollEvents.POLLIN | Interop.PollEvents.POLLHUP, ref refsAdded); 1853FilterPollList(checkWrite, events, checkWriteInitialCount + checkReadInitialCount - 1, Interop.PollEvents.POLLOUT, ref refsAdded); 1854FilterPollList(checkError, events, checkErrorInitialCount + checkWriteInitialCount + checkReadInitialCount - 1, Interop.PollEvents.POLLERR | Interop.PollEvents.POLLPRI, ref refsAdded); 1870private static unsafe void AddToPollArray(Interop.PollEvent* arr, int arrLength, IList? socketList, ref int arrOffset, Interop.PollEvents events, ref int refsAdded) 1890arr[arrOffset++] = new Interop.PollEvent { Events = events, FileDescriptor = fd }; 1895private static unsafe void FilterPollList(IList? socketList, Interop.PollEvent* arr, int arrEndOffset, Interop.PollEvents desiredEvents, ref int refsAdded) 1928Interop.Error err = Interop.Sys.Shutdown(handle, how); 1929if (err == Interop.Error.SUCCESS) 1938if (err == Interop.Error.ENOTCONN && (isConnected || isDisconnected)) 2054Interop.Error err = Interop.Sys.Poll(handle, Interop.PollEvents.POLLOUT, timeout: 0, out Interop.PollEvents outEvents); 2055if (err != Interop.Error.SUCCESS) 2061if ((outEvents & Interop.PollEvents.POLLOUT) == 0)
System\Net\Sockets\UnixDomainSocketEndPoint.Unix.cs (1)
24Interop.Sys.GetDomainSocketSizes(pathOffset, pathLength, addressSize);