Versions in this module Expand all Collapse all v1 v1.0.1 Apr 30, 2024 Changes in this version + const PMTUDiscoveryDo + const PMTUDiscoveryDont + const PMTUDiscoveryProbe + const PMTUDiscoveryWant + const UseDefaultIPv4TTL + const UseDefaultIPv6HopLimit + var AsyncLoading sync.WaitGroup + func AddDanglingEndpoint(e Endpoint) + func DeleteDanglingEndpoint(e Endpoint) + func InitStatCounters(v reflect.Value) + func ReleaseDanglingEndpoints() + type ARPStats struct + DisabledPacketsReceived *StatCounter + MalformedPacketsReceived *StatCounter + OutgoingRepliesDropped *StatCounter + OutgoingRepliesSent *StatCounter + OutgoingRequestBadLocalAddressErrors *StatCounter + OutgoingRequestInterfaceHasNoLocalAddressErrors *StatCounter + OutgoingRequestsDropped *StatCounter + OutgoingRequestsSent *StatCounter + PacketsReceived *StatCounter + RepliesReceived *StatCounter + RequestsReceived *StatCounter + RequestsReceivedUnknownTargetAddress *StatCounter + type AddMembershipOption MembershipOption + type Address struct + func AddrFrom16(addr [16]byte) Address + func AddrFrom16Slice(addr []byte) Address + func AddrFrom4(addr [4]byte) Address + func AddrFrom4Slice(addr []byte) Address + func AddrFromSlice(addr []byte) Address + func (a *Address) AsSlice() []byte + func (a Address) As16() [16]byte + func (a Address) As4() [4]byte + func (a Address) BitLen() int + func (a Address) Equal(other Address) bool + func (a Address) Len() int + func (a Address) MatchingPrefix(b Address) uint8 + func (a Address) String() string + func (a Address) To4() Address + func (a Address) Unspecified() bool + func (a Address) WithPrefix() AddressWithPrefix + type AddressMask struct + func MaskFrom(str string) AddressMask + func MaskFromBytes(bs []byte) AddressMask + func (m *AddressMask) AsSlice() []byte + func (m AddressMask) BitLen() int + func (m AddressMask) Equal(other AddressMask) bool + func (m AddressMask) Len() int + func (m AddressMask) Prefix() int + func (m AddressMask) String() string + type AddressWithPrefix struct + Address Address + PrefixLen int + func (a AddressWithPrefix) String() string + func (a AddressWithPrefix) Subnet() Subnet + type Clock interface + AfterFunc func(d time.Duration, f func()) Timer + Now func() time.Time + NowMonotonic func() MonotonicTime + func NewStdClock() Clock + type CongestionControlOption string + type CongestionControlState int + const Disorder + const FastRecovery + const Open + const RTORecovery + const SACKRecovery + type DefaultSocketOptionsHandler struct + func (*DefaultSocketOptionsHandler) GetAcceptConn() bool + func (*DefaultSocketOptionsHandler) HasNIC(int32) bool + func (*DefaultSocketOptionsHandler) LastError() Error + func (*DefaultSocketOptionsHandler) OnCorkOptionSet(bool) + func (*DefaultSocketOptionsHandler) OnDelayOptionSet(bool) + func (*DefaultSocketOptionsHandler) OnKeepAliveSet(bool) + func (*DefaultSocketOptionsHandler) OnReuseAddressSet(bool) + func (*DefaultSocketOptionsHandler) OnReusePortSet(bool) + func (*DefaultSocketOptionsHandler) OnSetReceiveBufferSize(v, oldSz int64) (newSz int64, postSet func()) + func (*DefaultSocketOptionsHandler) OnSetSendBufferSize(v int64) (newSz int64) + func (*DefaultSocketOptionsHandler) UpdateLastError(Error) + func (*DefaultSocketOptionsHandler) WakeupWriters() + type DefaultTTLOption uint8 + type Endpoint interface + Abort func() + Accept func(peerAddr *FullAddress) (Endpoint, *waiter.Queue, Error) + Bind func(address FullAddress) Error + Close func() + Connect func(address FullAddress) Error + Disconnect func() Error + GetLocalAddress func() (FullAddress, Error) + GetRemoteAddress func() (FullAddress, Error) + GetSockOpt func(opt GettableSocketOption) Error + GetSockOptInt func(SockOptInt) (int, Error) + Info func() EndpointInfo + LastError func() Error + Listen func(backlog int) Error + ModerateRecvBuf func(copied int) + Read func(io.Writer, ReadOptions) (ReadResult, Error) + Readiness func(mask waiter.EventMask) waiter.EventMask + SetOwner func(owner PacketOwner) + SetSockOpt func(opt SettableSocketOption) Error + SetSockOptInt func(opt SockOptInt, v int) Error + Shutdown func(flags ShutdownFlags) Error + SocketOptions func() *SocketOptions + State func() uint32 + Stats func() EndpointStats + Write func(Payloader, WriteOptions) (int64, Error) + func GetDanglingEndpoints() []Endpoint + type EndpointInfo interface + IsEndpointInfo func() + type EndpointState uint8 + type EndpointStats interface + IsEndpointStats func() + type EndpointWithPreflight interface + Preflight func(WriteOptions) Error + type ErrAborted struct + func (*ErrAborted) IgnoreStats() bool + func (*ErrAborted) String() string + type ErrAddressFamilyNotSupported struct + func (*ErrAddressFamilyNotSupported) IgnoreStats() bool + func (*ErrAddressFamilyNotSupported) String() string + type ErrAlreadyBound struct + func (*ErrAlreadyBound) IgnoreStats() bool + func (*ErrAlreadyBound) String() string + type ErrAlreadyConnected struct + func (*ErrAlreadyConnected) IgnoreStats() bool + func (*ErrAlreadyConnected) String() string + type ErrAlreadyConnecting struct + func (*ErrAlreadyConnecting) IgnoreStats() bool + func (*ErrAlreadyConnecting) String() string + type ErrBadAddress struct + func (*ErrBadAddress) IgnoreStats() bool + func (*ErrBadAddress) String() string + type ErrBadBuffer struct + func (*ErrBadBuffer) IgnoreStats() bool + func (*ErrBadBuffer) String() string + type ErrBadLocalAddress struct + func (*ErrBadLocalAddress) IgnoreStats() bool + func (*ErrBadLocalAddress) String() string + type ErrBroadcastDisabled struct + func (*ErrBroadcastDisabled) IgnoreStats() bool + func (*ErrBroadcastDisabled) String() string + type ErrClosedForReceive struct + func (*ErrClosedForReceive) IgnoreStats() bool + func (*ErrClosedForReceive) String() string + type ErrClosedForSend struct + func (*ErrClosedForSend) IgnoreStats() bool + func (*ErrClosedForSend) String() string + type ErrConnectStarted struct + func (*ErrConnectStarted) IgnoreStats() bool + func (*ErrConnectStarted) String() string + type ErrConnectionAborted struct + func (*ErrConnectionAborted) IgnoreStats() bool + func (*ErrConnectionAborted) String() string + type ErrConnectionRefused struct + func (*ErrConnectionRefused) IgnoreStats() bool + func (*ErrConnectionRefused) String() string + type ErrConnectionReset struct + func (*ErrConnectionReset) IgnoreStats() bool + func (*ErrConnectionReset) String() string + type ErrDestinationRequired struct + func (*ErrDestinationRequired) IgnoreStats() bool + func (*ErrDestinationRequired) String() string + type ErrDuplicateAddress struct + func (*ErrDuplicateAddress) IgnoreStats() bool + func (*ErrDuplicateAddress) String() string + type ErrDuplicateNICID struct + func (*ErrDuplicateNICID) IgnoreStats() bool + func (*ErrDuplicateNICID) String() string + type ErrHostDown struct + func (*ErrHostDown) IgnoreStats() bool + func (*ErrHostDown) String() string + type ErrHostUnreachable struct + func (*ErrHostUnreachable) IgnoreStats() bool + func (*ErrHostUnreachable) String() string + type ErrInvalidEndpointState struct + func (*ErrInvalidEndpointState) IgnoreStats() bool + func (*ErrInvalidEndpointState) String() string + type ErrInvalidOptionValue struct + func (*ErrInvalidOptionValue) IgnoreStats() bool + func (*ErrInvalidOptionValue) String() string + type ErrInvalidPortRange struct + func (*ErrInvalidPortRange) IgnoreStats() bool + func (*ErrInvalidPortRange) String() string + type ErrMalformedHeader struct + func (*ErrMalformedHeader) IgnoreStats() bool + func (*ErrMalformedHeader) String() string + type ErrMessageTooLong struct + func (*ErrMessageTooLong) IgnoreStats() bool + func (*ErrMessageTooLong) String() string + type ErrMissingRequiredFields struct + func (*ErrMissingRequiredFields) IgnoreStats() bool + func (*ErrMissingRequiredFields) String() string + type ErrMulticastInputCannotBeOutput struct + func (*ErrMulticastInputCannotBeOutput) IgnoreStats() bool + func (*ErrMulticastInputCannotBeOutput) String() string + type ErrNetworkUnreachable struct + func (*ErrNetworkUnreachable) IgnoreStats() bool + func (*ErrNetworkUnreachable) String() string + type ErrNoBufferSpace struct + func (*ErrNoBufferSpace) IgnoreStats() bool + func (*ErrNoBufferSpace) String() string + type ErrNoNet struct + func (*ErrNoNet) IgnoreStats() bool + func (*ErrNoNet) String() string + type ErrNoPortAvailable struct + func (*ErrNoPortAvailable) IgnoreStats() bool + func (*ErrNoPortAvailable) String() string + type ErrNoSuchFile struct + func (*ErrNoSuchFile) IgnoreStats() bool + func (*ErrNoSuchFile) String() string + type ErrNotConnected struct + func (*ErrNotConnected) IgnoreStats() bool + func (*ErrNotConnected) String() string + type ErrNotPermitted struct + func (*ErrNotPermitted) IgnoreStats() bool + func (*ErrNotPermitted) String() string + type ErrNotSupported struct + func (*ErrNotSupported) IgnoreStats() bool + func (*ErrNotSupported) String() string + type ErrPortInUse struct + func (*ErrPortInUse) IgnoreStats() bool + func (*ErrPortInUse) String() string + type ErrQueueSizeNotSupported struct + func (*ErrQueueSizeNotSupported) IgnoreStats() bool + func (*ErrQueueSizeNotSupported) String() string + type ErrSaveRejection struct + Err error + func (e *ErrSaveRejection) Error() string + type ErrTimeout struct + func (*ErrTimeout) IgnoreStats() bool + func (*ErrTimeout) String() string + type ErrUnknownDevice struct + func (*ErrUnknownDevice) IgnoreStats() bool + func (*ErrUnknownDevice) String() string + type ErrUnknownNICID struct + func (*ErrUnknownNICID) IgnoreStats() bool + func (*ErrUnknownNICID) String() string + type ErrUnknownProtocol struct + func (*ErrUnknownProtocol) IgnoreStats() bool + func (*ErrUnknownProtocol) String() string + type ErrUnknownProtocolOption struct + func (*ErrUnknownProtocolOption) IgnoreStats() bool + func (*ErrUnknownProtocolOption) String() string + type ErrWouldBlock struct + func (*ErrWouldBlock) IgnoreStats() bool + func (*ErrWouldBlock) String() string + type Error interface + IgnoreStats func() bool + type FullAddress struct + Addr Address + LinkAddr LinkAddress + NIC NICID + Port uint16 + type GetReceiveBufferLimits func(StackHandler) ReceiveBufferSizeOption + type GetSendBufferLimits func(StackHandler) SendBufferSizeOption + type GettableNetworkProtocolOption interface + type GettableSocketOption interface + type GettableTransportProtocolOption interface + type ICMPStats struct + V4 ICMPv4Stats + V6 ICMPv6Stats + type ICMPv4PacketStats struct + DstUnreachable *StatCounter + EchoReply *StatCounter + EchoRequest *StatCounter + InfoReply *StatCounter + InfoRequest *StatCounter + ParamProblem *StatCounter + Redirect *StatCounter + SrcQuench *StatCounter + TimeExceeded *StatCounter + Timestamp *StatCounter + TimestampReply *StatCounter + type ICMPv4ReceivedPacketStats struct + Invalid *StatCounter + type ICMPv4SentPacketStats struct + Dropped *StatCounter + RateLimited *StatCounter + type ICMPv4Stats struct + PacketsReceived ICMPv4ReceivedPacketStats + PacketsSent ICMPv4SentPacketStats + type ICMPv6Filter struct + DenyType [8]uint32 + func (f *ICMPv6Filter) ShouldDeny(icmpType uint8) bool + type ICMPv6PacketStats struct + DstUnreachable *StatCounter + EchoReply *StatCounter + EchoRequest *StatCounter + MulticastListenerDone *StatCounter + MulticastListenerQuery *StatCounter + MulticastListenerReport *StatCounter + MulticastListenerReportV2 *StatCounter + NeighborAdvert *StatCounter + NeighborSolicit *StatCounter + PacketTooBig *StatCounter + ParamProblem *StatCounter + RedirectMsg *StatCounter + RouterAdvert *StatCounter + RouterSolicit *StatCounter + TimeExceeded *StatCounter + type ICMPv6ReceivedPacketStats struct + Invalid *StatCounter + RouterOnlyPacketsDroppedByHost *StatCounter + Unrecognized *StatCounter + type ICMPv6SentPacketStats struct + Dropped *StatCounter + RateLimited *StatCounter + type ICMPv6Stats struct + PacketsReceived ICMPv6ReceivedPacketStats + PacketsSent ICMPv6SentPacketStats + type IGMPPacketStats struct + LeaveGroup *StatCounter + MembershipQuery *StatCounter + V1MembershipReport *StatCounter + V2MembershipReport *StatCounter + V3MembershipReport *StatCounter + type IGMPReceivedPacketStats struct + ChecksumErrors *StatCounter + Invalid *StatCounter + Unrecognized *StatCounter + type IGMPSentPacketStats struct + Dropped *StatCounter + type IGMPStats struct + PacketsReceived IGMPReceivedPacketStats + PacketsSent IGMPSentPacketStats + type IPForwardingStats struct + Errors *StatCounter + ExhaustedTTL *StatCounter + ExtensionHeaderProblem *StatCounter + HostUnreachable *StatCounter + InitializingSource *StatCounter + LinkLocalDestination *StatCounter + LinkLocalSource *StatCounter + NoMulticastPendingQueueBufferSpace *StatCounter + OutgoingDeviceNoBufferSpace *StatCounter + PacketTooBig *StatCounter + UnexpectedMulticastInputInterface *StatCounter + UnknownOutputEndpoint *StatCounter + Unrouteable *StatCounter + type IPPacketInfo struct + DestinationAddr Address + LocalAddr Address + NIC NICID + type IPStats struct + DisabledPacketsReceived *StatCounter + Forwarding IPForwardingStats + IPTablesForwardDropped *StatCounter + IPTablesInputDropped *StatCounter + IPTablesOutputDropped *StatCounter + IPTablesPostroutingDropped *StatCounter + IPTablesPreroutingDropped *StatCounter + InvalidDestinationAddressesReceived *StatCounter + InvalidSourceAddressesReceived *StatCounter + MalformedFragmentsReceived *StatCounter + MalformedPacketsReceived *StatCounter + OptionRecordRouteReceived *StatCounter + OptionRouterAlertReceived *StatCounter + OptionTimestampReceived *StatCounter + OptionUnknownReceived *StatCounter + OutgoingPacketErrors *StatCounter + PacketsDelivered *StatCounter + PacketsReceived *StatCounter + PacketsSent *StatCounter + ValidPacketsReceived *StatCounter + type IPv6PacketInfo struct + Addr Address + NIC NICID + type IntegralStatCounterMap struct + func (m *IntegralStatCounterMap) Get(key uint64) (*StatCounter, bool) + func (m *IntegralStatCounterMap) Increment(key uint64) + func (m *IntegralStatCounterMap) Init() + func (m *IntegralStatCounterMap) Keys() []uint64 + type Job struct + func NewJob(c Clock, l sync.Locker, f func()) *Job + func (j *Job) Cancel() + func (j *Job) Schedule(d time.Duration) + type KeepaliveIdleOption time.Duration + type KeepaliveIntervalOption time.Duration + type LimitedWriter struct + N int64 + W io.Writer + func (l *LimitedWriter) Write(p []byte) (int, error) + type LingerOption struct + Enabled bool + Timeout time.Duration + type LinkAddress string + func ParseMACAddress(s string) (LinkAddress, error) + func (a LinkAddress) String() string + type LinkPacketInfo struct + PktType PacketType + Protocol NetworkProtocolNumber + type LocalSockError struct + func (*LocalSockError) Code() uint8 + func (*LocalSockError) Origin() SockErrOrigin + func (*LocalSockError) Type() uint8 + func (l *LocalSockError) Info() uint32 + type MembershipOption struct + InterfaceAddr Address + MulticastAddr Address + NIC NICID + type MonotonicTime struct + func MonotonicTimeInfinite() MonotonicTime + func (mt MonotonicTime) Add(d time.Duration) MonotonicTime + func (mt MonotonicTime) After(u MonotonicTime) bool + func (mt MonotonicTime) Before(u MonotonicTime) bool + func (mt MonotonicTime) Milliseconds() int64 + func (mt MonotonicTime) String() string + func (mt MonotonicTime) Sub(u MonotonicTime) time.Duration + type MultiCounterStat struct + func (m *MultiCounterStat) Increment() + func (m *MultiCounterStat) IncrementBy(v uint64) + func (m *MultiCounterStat) Init(a, b *StatCounter) + type MultiIntegralStatCounterMap struct + func (m *MultiIntegralStatCounterMap) Increment(key uint64) + func (m *MultiIntegralStatCounterMap) Init(a, b *IntegralStatCounterMap) + type MulticastInterfaceOption struct + InterfaceAddr Address + NIC NICID + type NICID int32 + type NICNeighborStats struct + DroppedConfirmationForNoninitiatedNeighbor *StatCounter + DroppedInvalidLinkAddressConfirmations *StatCounter + UnreachableEntryLookups *StatCounter + type NICPacketStats struct + Bytes *StatCounter + Packets *StatCounter + type NICStats struct + DisabledRx NICPacketStats + MalformedL4RcvdPackets *StatCounter + Neighbor NICNeighborStats + Rx NICPacketStats + Tx NICPacketStats + TxPacketsDroppedNoBufferSpace *StatCounter + UnknownL3ProtocolRcvdPacketCounts *IntegralStatCounterMap + UnknownL4ProtocolRcvdPacketCounts *IntegralStatCounterMap + func (s NICStats) FillIn() NICStats + type NetworkProtocolNumber uint32 + type OriginalDestinationOption FullAddress + type PacketOwner interface + KGID func() uint32 + KUID func() uint32 + type PacketType uint8 + const PacketBroadcast + const PacketHost + const PacketMulticast + const PacketOtherHost + const PacketOutgoing + type Payloader interface + Len func() int + type ProtocolAddress struct + AddressWithPrefix AddressWithPrefix + Protocol NetworkProtocolNumber + type ReadErrors struct + InvalidEndpointState StatCounter + NotConnected StatCounter + ReadClosed StatCounter + type ReadOptions struct + NeedLinkPacketInfo bool + NeedRemoteAddr bool + Peek bool + type ReadResult struct + ControlMessages ReceivableControlMessages + Count int + LinkPacketInfo LinkPacketInfo + RemoteAddr FullAddress + Total int + type ReceivableControlMessages struct + HasHopLimit bool + HasIPPacketInfo bool + HasIPv6PacketInfo bool + HasInq bool + HasOriginalDstAddress bool + HasTClass bool + HasTOS bool + HasTTL bool + HasTimestamp bool + HopLimit uint8 + IPv6PacketInfo IPv6PacketInfo + Inq int32 + OriginalDstAddress FullAddress + PacketInfo IPPacketInfo + SockErr *SockError + TClass uint32 + TOS uint8 + TTL uint8 + Timestamp time.Time + type ReceiveBufferSizeOption struct + Default int + Max int + Min int + func GetStackReceiveBufferLimits(so StackHandler) ReceiveBufferSizeOption + type ReceiveErrors struct + ChecksumErrors StatCounter + ClosedReceiver StatCounter + MalformedPacketsReceived StatCounter + ReceiveBufferOverflow StatCounter + type RemoveMembershipOption MembershipOption + type Route struct + Destination Subnet + Gateway Address + NIC NICID + SourceHint Address + func (r Route) Equal(to Route) bool + func (r Route) String() string + type SendBufferSizeOption struct + Default int + Max int + Min int + func GetStackSendBufferLimits(so StackHandler) SendBufferSizeOption + type SendErrors struct + NoRoute StatCounter + SendToNetworkFailed StatCounter + type SendableControlMessages struct + HasHopLimit bool + HasIPv6PacketInfo bool + HasTTL bool + HopLimit uint8 + IPv6PacketInfo IPv6PacketInfo + TTL uint8 + type SettableNetworkProtocolOption interface + type SettableSocketOption interface + type SettableTransportProtocolOption interface + type ShutdownFlags int + const ShutdownRead + const ShutdownWrite + type SliceWriter []byte + func (s *SliceWriter) Write(b []byte) (int, error) + type SockErrOrigin uint8 + const SockExtErrorOriginICMP + const SockExtErrorOriginICMP6 + const SockExtErrorOriginLocal + const SockExtErrorOriginNone + func (origin SockErrOrigin) IsICMPErr() bool + type SockError struct + Cause SockErrorCause + Dst FullAddress + Err Error + NetProto NetworkProtocolNumber + Offender FullAddress + Payload *buffer.View + type SockErrorCause interface + Code func() uint8 + Info func() uint32 + Origin func() SockErrOrigin + Type func() uint8 + type SockOptInt int + const IPv4TOSOption + const IPv4TTLOption + const IPv6Checksum + const IPv6HopLimitOption + const IPv6TrafficClassOption + const KeepaliveCountOption + const MTUDiscoverOption + const MaxSegOption + const MulticastTTLOption + const ReceiveQueueSizeOption + const SendQueueSizeOption + const TCPSynCountOption + const TCPWindowClampOption + type SocketDetachFilterOption int + type SocketOptions struct + func (*SocketOptions) GetOutOfBandInline() bool + func (*SocketOptions) SetOutOfBandInline(bool) + func (so *SocketOptions) DequeueErr() *SockError + func (so *SocketOptions) GetAcceptConn() bool + func (so *SocketOptions) GetBindToDevice() int32 + func (so *SocketOptions) GetBroadcast() bool + func (so *SocketOptions) GetCorkOption() bool + func (so *SocketOptions) GetDelayOption() bool + func (so *SocketOptions) GetHeaderIncluded() bool + func (so *SocketOptions) GetIPv4RecvError() bool + func (so *SocketOptions) GetIPv6ReceivePacketInfo() bool + func (so *SocketOptions) GetIPv6RecvError() bool + func (so *SocketOptions) GetKeepAlive() bool + func (so *SocketOptions) GetLastError() Error + func (so *SocketOptions) GetLinger() LingerOption + func (so *SocketOptions) GetMulticastLoop() bool + func (so *SocketOptions) GetNoChecksum() bool + func (so *SocketOptions) GetPassCred() bool + func (so *SocketOptions) GetQuickAck() bool + func (so *SocketOptions) GetRcvlowat() int32 + func (so *SocketOptions) GetReceiveBufferSize() int64 + func (so *SocketOptions) GetReceiveHopLimit() bool + func (so *SocketOptions) GetReceiveOriginalDstAddress() bool + func (so *SocketOptions) GetReceivePacketInfo() bool + func (so *SocketOptions) GetReceiveTClass() bool + func (so *SocketOptions) GetReceiveTOS() bool + func (so *SocketOptions) GetReceiveTTL() bool + func (so *SocketOptions) GetReuseAddress() bool + func (so *SocketOptions) GetReusePort() bool + func (so *SocketOptions) GetSendBufferSize() int64 + func (so *SocketOptions) GetV6Only() bool + func (so *SocketOptions) InitHandler(handler SocketOptionsHandler, stack StackHandler, ...) + func (so *SocketOptions) PeekErr() *SockError + func (so *SocketOptions) QueueErr(err *SockError) + func (so *SocketOptions) QueueLocalErr(err Error, net NetworkProtocolNumber, info uint32, dst FullAddress, ...) + func (so *SocketOptions) ReceiveBufferLimits() (min, max int64) + func (so *SocketOptions) SendBufferLimits() (min, max int64) + func (so *SocketOptions) SetBindToDevice(bindToDevice int32) Error + func (so *SocketOptions) SetBroadcast(v bool) + func (so *SocketOptions) SetCorkOption(v bool) + func (so *SocketOptions) SetDelayOption(v bool) + func (so *SocketOptions) SetHeaderIncluded(v bool) + func (so *SocketOptions) SetIPv4RecvError(v bool) + func (so *SocketOptions) SetIPv6ReceivePacketInfo(v bool) + func (so *SocketOptions) SetIPv6RecvError(v bool) + func (so *SocketOptions) SetKeepAlive(v bool) + func (so *SocketOptions) SetLastError(err Error) + func (so *SocketOptions) SetLinger(linger LingerOption) + func (so *SocketOptions) SetMulticastLoop(v bool) + func (so *SocketOptions) SetNoChecksum(v bool) + func (so *SocketOptions) SetPassCred(v bool) + func (so *SocketOptions) SetQuickAck(v bool) + func (so *SocketOptions) SetRcvlowat(rcvlowat int32) Error + func (so *SocketOptions) SetReceiveBufferSize(receiveBufferSize int64, notify bool) + func (so *SocketOptions) SetReceiveHopLimit(v bool) + func (so *SocketOptions) SetReceiveOriginalDstAddress(v bool) + func (so *SocketOptions) SetReceivePacketInfo(v bool) + func (so *SocketOptions) SetReceiveTClass(v bool) + func (so *SocketOptions) SetReceiveTOS(v bool) + func (so *SocketOptions) SetReceiveTTL(v bool) + func (so *SocketOptions) SetReuseAddress(v bool) + func (so *SocketOptions) SetReusePort(v bool) + func (so *SocketOptions) SetSendBufferSize(sendBufferSize int64, notify bool) + func (so *SocketOptions) SetV6Only(v bool) + type SocketOptionsHandler interface + GetAcceptConn func() bool + HasNIC func(v int32) bool + LastError func() Error + OnCorkOptionSet func(v bool) + OnDelayOptionSet func(v bool) + OnKeepAliveSet func(v bool) + OnReuseAddressSet func(v bool) + OnReusePortSet func(v bool) + OnSetReceiveBufferSize func(v, oldSz int64) (newSz int64, postSet func()) + OnSetSendBufferSize func(v int64) (newSz int64) + UpdateLastError func(err Error) + WakeupWriters func() + type StackHandler interface + Option func(option any) Error + TransportProtocolOption func(proto TransportProtocolNumber, option GettableTransportProtocolOption) Error + type StatCounter struct + func (s *StatCounter) Decrement() + func (s *StatCounter) Increment() + func (s *StatCounter) IncrementBy(v uint64) + func (s *StatCounter) String() string + func (s *StatCounter) Value() uint64 + type Stats struct + ARP ARPStats + DroppedPackets *StatCounter + ICMP ICMPStats + IGMP IGMPStats + IP IPStats + NICs NICStats + TCP TCPStats + UDP UDPStats + func (s Stats) FillIn() Stats + type Subnet struct + func NewSubnet(a Address, m AddressMask) (Subnet, error) + func (s *Subnet) Bits() (ones int, zeros int) + func (s *Subnet) Broadcast() Address + func (s *Subnet) Contains(a Address) bool + func (s *Subnet) ID() Address + func (s *Subnet) IsBroadcast(address Address) bool + func (s *Subnet) Mask() AddressMask + func (s *Subnet) Prefix() int + func (s Subnet) Equal(o Subnet) bool + func (s Subnet) String() string + type TCPAlwaysUseSynCookies bool + type TCPAvailableCongestionControlOption string + type TCPDeferAcceptOption time.Duration + type TCPDelayEnabled bool + type TCPInfoOption struct + CcState CongestionControlState + RTO time.Duration + RTT time.Duration + RTTVar time.Duration + ReorderSeen bool + SndCwnd uint32 + SndSsthresh uint32 + State EndpointState + type TCPLingerTimeoutOption time.Duration + type TCPMaxRTOOption time.Duration + type TCPMaxRetriesOption uint64 + type TCPMinRTOOption time.Duration + type TCPModerateReceiveBufferOption bool + type TCPReceiveBufferSizeRangeOption struct + Default int + Max int + Min int + type TCPRecovery int32 + const TCPRACKLossDetection + const TCPRACKNoDupTh + const TCPRACKStaticReoWnd + type TCPSACKEnabled bool + type TCPSendBufferSizeRangeOption struct + Default int + Max int + Min int + type TCPStats struct + ActiveConnectionOpenings *StatCounter + ChecksumErrors *StatCounter + CurrentConnected *StatCounter + CurrentEstablished *StatCounter + EstablishedClosed *StatCounter + EstablishedResets *StatCounter + EstablishedTimedout *StatCounter + FailedConnectionAttempts *StatCounter + FailedPortReservations *StatCounter + FastRecovery *StatCounter + FastRetransmit *StatCounter + ForwardMaxInFlightDrop *StatCounter + InvalidSegmentsReceived *StatCounter + ListenOverflowAckDrop *StatCounter + ListenOverflowInvalidSynCookieRcvd *StatCounter + ListenOverflowSynCookieRcvd *StatCounter + ListenOverflowSynCookieSent *StatCounter + ListenOverflowSynDrop *StatCounter + PassiveConnectionOpenings *StatCounter + ResetsReceived *StatCounter + ResetsSent *StatCounter + Retransmits *StatCounter + SACKRecovery *StatCounter + SegmentSendErrors *StatCounter + SegmentsAckedWithDSACK *StatCounter + SegmentsSent *StatCounter + SlowStartRetransmits *StatCounter + SpuriousRTORecovery *StatCounter + SpuriousRecovery *StatCounter + TLPRecovery *StatCounter + Timeouts *StatCounter + ValidSegmentsReceived *StatCounter + type TCPSynRetriesOption uint8 + type TCPTimeWaitReuseOption uint8 + const TCPTimeWaitReuseDisabled + const TCPTimeWaitReuseGlobal + const TCPTimeWaitReuseLoopbackOnly + type TCPTimeWaitTimeoutOption time.Duration + type TCPUserTimeoutOption time.Duration + type Timer interface + Reset func(d time.Duration) + Stop func() bool + func NewStdTimer(t *time.Timer) Timer + type TransportEndpointStats struct + PacketsReceived StatCounter + PacketsSent StatCounter + ReadErrors ReadErrors + ReceiveErrors ReceiveErrors + SendErrors SendErrors + WriteErrors WriteErrors + func (*TransportEndpointStats) IsEndpointStats() + func (src *TransportEndpointStats) Clone(dst *TransportEndpointStats) + type TransportProtocolNumber uint32 + type UDPStats struct + ChecksumErrors *StatCounter + MalformedPacketsReceived *StatCounter + PacketSendErrors *StatCounter + PacketsReceived *StatCounter + PacketsSent *StatCounter + ReceiveBufferErrors *StatCounter + UnknownPortErrors *StatCounter + type WriteErrors struct + InvalidArgs StatCounter + InvalidEndpointState StatCounter + WriteClosed StatCounter + type WriteOptions struct + Atomic bool + ControlMessages SendableControlMessages + EndOfRecord bool + More bool + To *FullAddress