#[non_exhaustive]pub enum Error {
Show 655 variants
ErrBufferFull,
ErrBufferClosed,
ErrBufferShort,
ErrPacketTooBig,
ErrTimeout,
ErrClosedListener,
ErrListenQueueExceeded,
ErrClosedListenerAcceptCh,
ErrObsCannotBeNil,
ErrUseClosedNetworkConn,
ErrAddrNotUdpAddr,
ErrLocAddr,
ErrAlreadyClosed,
ErrNoRemAddr,
ErrAddressAlreadyInUse,
ErrNoSuchUdpConn,
ErrCannotRemoveUnspecifiedIp,
ErrNoAddressAssigned,
ErrNatRequriesMapping,
ErrMismatchLengthIp,
ErrNonUdpTranslationNotSupported,
ErrNoAssociatedLocalAddress,
ErrNoNatBindingFound,
ErrHasNoPermission,
ErrHostnameEmpty,
ErrFailedToParseIpaddr,
ErrNoInterface,
ErrNotFound,
ErrUnexpectedNetwork,
ErrCantAssignRequestedAddr,
ErrUnknownNetwork,
ErrNoRouterLinked,
ErrInvalidPortNumber,
ErrUnexpectedTypeSwitchFailure,
ErrBindFailed,
ErrEndPortLessThanStart,
ErrPortSpaceExhausted,
ErrVnetDisabled,
ErrInvalidLocalIpInStaticIps,
ErrLocalIpBeyondStaticIpsSubset,
ErrLocalIpNoStaticsIpsAssociated,
ErrRouterAlreadyStarted,
ErrRouterAlreadyStopped,
ErrStaticIpIsBeyondSubnet,
ErrAddressSpaceExhausted,
ErrNoIpaddrEth0,
ErrInvalidMask,
HandshakeInProgress,
ContextUnsupported,
ReservedExportKeyingMaterial,
CipherSuiteUnset,
Hash(String),
PoisonError(String),
WrongMarshalSize,
InvalidTotalLost,
InvalidHeader,
EmptyCompound,
BadFirstPacket,
MissingCname,
PacketBeforeCname,
TooManyReports,
TooManyChunks,
TooManySources,
PacketTooShort,
BufferTooShort,
WrongType,
SdesTextTooLong,
SdesMissingType,
ReasonTooLong,
BadVersion,
WrongPadding,
WrongFeedbackType,
WrongPayloadType,
HeaderTooSmall,
SsrcMustBeZero,
MissingRembIdentifier,
SsrcNumAndLengthMismatch,
InvalidSizeOrStartIndex,
DeltaExceedLimit,
PacketStatusChunkLength,
InvalidBitrate,
WrongChunkType,
BadStructMemberType,
BadReadParameter,
InvalidBlockSize,
ErrHeaderSizeInsufficient,
ErrHeaderSizeInsufficientForExtension,
ErrBufferTooSmall,
ErrHeaderExtensionsNotEnabled,
ErrHeaderExtensionNotFound,
ErrRfc8285oneByteHeaderIdrange,
ErrRfc8285oneByteHeaderSize,
ErrRfc8285twoByteHeaderIdrange,
ErrRfc8285twoByteHeaderSize,
ErrRfc3550headerIdrange,
ErrShortPacket,
ErrNilPacket,
ErrTooManyPDiff,
ErrTooManySpatialLayers,
ErrUnhandledNaluType,
ErrH265CorruptedPacket,
ErrInvalidH265PacketType,
ErrPayloadTooSmallForObuExtensionHeader,
ErrPayloadTooSmallForObuPayloadSize,
HeaderExtensionPayloadNot32BitWords,
AudioLevelOverflow,
PlayoutDelayOverflow,
PayloadIsNotLargeEnough,
StapASizeLargerThanBuffer(usize, usize),
NaluTypeIsNotHandled(u8),
ErrDuplicated,
ErrShortSrtpMasterKey,
ErrShortSrtpMasterSalt,
ErrNoSuchSrtpProfile,
ErrNonZeroKdrNotSupported,
ErrExporterWrongLabel,
ErrNoConfig,
ErrNoConn,
ErrFailedToVerifyAuthTag,
ErrTooShortRtp,
ErrTooShortRtcp,
ErrPayloadDiffers,
ErrStartedChannelUsedIncorrectly,
ErrStreamNotInited,
ErrStreamAlreadyClosed,
ErrStreamAlreadyInited,
ErrFailedTypeAssertion,
ErrExceededMaxPackets,
UnsupportedIndexOverKdr,
InvalidMasterKeyLength,
InvalidMasterSaltLength,
UnsupportedOutLength,
SrtpMasterKeyLength(usize, usize),
SrtpSaltLength(usize, usize),
ExtMapParse(String),
SsrcMissingFromSrtp(u32),
SrtpSsrcDuplicated(u32, u16),
SrtcpSsrcDuplicated(u32, usize),
SsrcMissingFromSrtcp(u32),
StreamWithSsrcExists(u32),
SessionRtpRtcpTypeMismatch,
SessionEof,
SrtpTooSmall(usize, usize),
SrtcpTooSmall(usize, usize),
RtpFailedToVerifyAuthTag,
RtcpInvalidLengthAuthTag(usize, usize),
RtcpFailedToVerifyAuthTag,
SessionSrtpAlreadyClosed,
InvalidRtpStream,
InvalidRtcpStream,
ErrAttributeNotFound,
ErrTransactionStopped,
ErrTransactionNotExists,
ErrTransactionExists,
ErrAgentClosed,
ErrTransactionTimeOut,
ErrNoDefaultReason,
ErrUnexpectedEof,
ErrAttributeSizeInvalid,
ErrAttributeSizeOverflow,
ErrDecodeToNil,
ErrUnexpectedHeaderEof,
ErrIntegrityMismatch,
ErrFingerprintMismatch,
ErrFingerprintBeforeIntegrity,
ErrBadUnknownAttrsSize,
ErrBadIpLength,
ErrNoConnection,
ErrClientClosed,
ErrNoAgent,
ErrCollectorClosed,
ErrUnsupportedNetwork,
ErrInvalidUrl,
ErrSchemeType,
ErrHost,
ErrRelayAddressInvalid,
ErrNoAvailableConns,
ErrConnUnset,
ErrListenerUnset,
ErrListeningAddressInvalid,
ErrRelayAddressGeneratorUnset,
ErrMaxRetriesExceeded,
ErrMaxPortNotZero,
ErrMinPortNotZero,
ErrMaxPortLessThanMinPort,
ErrNilConn,
ErrTodo,
ErrAlreadyListening,
ErrFailedToClose,
ErrFailedToRetransmitTransaction,
ErrAllRetransmissionsFailed,
ErrChannelBindNotFound,
ErrStunserverAddressNotSet,
ErrOneAllocateOnly,
ErrAlreadyAllocated,
ErrNonStunmessage,
ErrFailedToDecodeStun,
ErrUnexpectedStunrequestMessage,
ErrInvalidChannelNumber,
ErrBadChannelDataLength,
ErrInvalidRequestedFamilyValue,
ErrFakeErr,
ErrClosed,
ErrUdpaddrCast,
ErrDoubleLock,
ErrTransactionClosed,
ErrWaitForResultOnNonResultTransaction,
ErrFailedToBuildRefreshRequest,
ErrFailedToRefreshAllocation,
ErrFailedToGetLifetime,
ErrShortBuffer,
ErrUnexpectedResponse,
ErrAllocatePacketConnMustBeSet,
ErrAllocateConnMustBeSet,
ErrLeveledLoggerMustBeSet,
ErrSameChannelDifferentPeer,
ErrNilFiveTuple,
ErrNilFiveTupleSrcAddr,
ErrNilFiveTupleDstAddr,
ErrNilTurnSocket,
ErrLifetimeZero,
ErrDupeFiveTuple,
ErrFailedToCastUdpaddr,
ErrFailedToGenerateNonce,
ErrFailedToSendError,
ErrDuplicatedNonce,
ErrNoSuchUser,
ErrUnexpectedClass,
ErrUnexpectedMethod,
ErrFailedToHandle,
ErrUnhandledStunpacket,
ErrUnableToHandleChannelData,
ErrFailedToCreateStunpacket,
ErrFailedToCreateChannelData,
ErrRelayAlreadyAllocatedForFiveTuple,
ErrRequestedTransportMustBeUdp,
ErrNoDontFragmentSupport,
ErrRequestWithReservationTokenAndEvenPort,
ErrNoAllocationFound,
ErrNoPermission,
ErrShortWrite,
ErrNoSuchChannelBind,
ErrFailedWriteSocket,
ErrUnknownType,
ErrStunQuery,
ErrInvalidQuery,
ErrPort,
ErrLocalUfragInsufficientBits,
ErrLocalPwdInsufficientBits,
ErrProtoType,
ErrNoCandidatePairs,
ErrCanceledByCaller,
ErrMultipleStart,
ErrRemoteUfragEmpty,
ErrRemotePwdEmpty,
ErrNoOnCandidateHandler,
ErrMultipleGatherAttempted,
ErrUsernameEmpty,
ErrPasswordEmpty,
ErrAddressParseFailed,
ErrLiteUsingNonHostCandidates,
ErrLiteSupportOnly,
ErrUselessUrlsProvided,
ErrUnsupportedNat1to1IpCandidateType,
ErrInvalidNat1to1IpMapping,
ErrExternalMappedIpNotFound,
ErrMulticastDnsWithNat1to1IpMapping,
ErrIneffectiveNat1to1IpMappingHost,
ErrIneffectiveNat1to1IpMappingSrflx,
ErrInvalidMulticastDnshostName,
ErrMulticastDnsNotSupported,
ErrRestartWhenGathering,
ErrRunCanceled,
ErrTcpMuxNotInitialized,
ErrTcpRemoteAddrAlreadyExists,
ErrSendPacket,
ErrAttributeTooShortIceCandidate,
ErrParseComponent,
ErrParsePriority,
ErrParsePort,
ErrParseRelatedAddr,
ErrParseType,
ErrUnknownCandidateType,
ErrGetXorMappedAddrResponse,
ErrConnectionAddrAlreadyExist,
ErrReadingStreamingPacket,
ErrWriting,
ErrClosingConnection,
ErrDetermineNetworkType,
ErrMissingProtocolScheme,
ErrTooManyColonsAddr,
ErrRead,
ErrUnknownRole,
ErrMismatchUsername,
ErrIceWriteStunMessage,
ErrUrlParse,
ErrCandidateIpNotFound,
ErrConnClosed,
ErrDeadlineExceeded,
ErrContextUnsupported,
ErrDtlspacketInvalidLength,
ErrHandshakeInProgress,
ErrInvalidContentType,
ErrInvalidMac,
ErrInvalidPacketLength,
ErrReservedExportKeyingMaterial,
ErrCertificateVerifyNoCertificate,
ErrCipherSuiteNoIntersection,
ErrCipherSuiteUnset,
ErrClientCertificateNotVerified,
ErrClientCertificateRequired,
ErrClientNoMatchingSrtpProfile,
ErrClientRequiredButNoServerEms,
ErrCompressionMethodUnset,
ErrCookieMismatch,
ErrCookieTooLong,
ErrIdentityNoPsk,
ErrInvalidCertificate,
ErrInvalidCipherSpec,
ErrInvalidCipherSuite,
ErrInvalidClientKeyExchange,
ErrInvalidCompressionMethod,
ErrInvalidEcdsasignature,
ErrInvalidEllipticCurveType,
ErrInvalidExtensionType,
ErrInvalidHashAlgorithm,
ErrInvalidNamedCurve,
ErrInvalidPrivateKey,
ErrNamedCurveAndPrivateKeyMismatch,
ErrInvalidSniFormat,
ErrInvalidSignatureAlgorithm,
ErrKeySignatureMismatch,
ErrNilNextConn,
ErrNoAvailableCipherSuites,
ErrNoAvailableSignatureSchemes,
ErrNoCertificates,
ErrNoConfigProvided,
ErrNoSupportedEllipticCurves,
ErrUnsupportedProtocolVersion,
ErrPskAndCertificate,
ErrPskAndIdentityMustBeSetForClient,
ErrRequestedButNoSrtpExtension,
ErrServerMustHaveCertificate,
ErrServerNoMatchingSrtpProfile,
ErrServerRequiredButNoClientEms,
ErrVerifyDataMismatch,
ErrHandshakeMessageUnset,
ErrInvalidFlight,
ErrKeySignatureGenerateUnimplemented,
ErrKeySignatureVerifyUnimplemented,
ErrLengthMismatch,
ErrNotEnoughRoomForNonce,
ErrNotImplemented,
ErrSequenceNumberOverflow,
ErrUnableToMarshalFragmented,
ErrInvalidFsmTransition,
ErrApplicationDataEpochZero,
ErrUnhandledContextType,
ErrContextCanceled,
ErrEmptyFragment,
ErrAlertFatalOrClose,
ErrFragmentBufferOverflow {
new_size: usize,
max_size: usize,
},
ErrClientTransportNotSet,
EndpointStopping,
TooManyConnections,
InvalidDnsName(String),
InvalidRemoteAddress(SocketAddr),
NoClientConfig,
NoServerConfig,
ErrChunkHeaderTooSmall,
ErrChunkHeaderNotEnoughSpace,
ErrChunkHeaderPaddingNonZero,
ErrChunkHeaderInvalidLength,
ErrChunkTypeNotAbort,
ErrBuildAbortChunkFailed,
ErrChunkTypeNotCookieAck,
ErrChunkTypeNotCookieEcho,
ErrChunkTypeNotCt,
ErrBuildErrorChunkFailed,
ErrMarshalStreamFailed,
ErrChunkTooShort,
ErrChunkTypeNotForwardTsn,
ErrChunkTypeNotHeartbeat,
ErrChunkTypeNotHeartbeatAck,
ErrHeartbeatNotLongEnoughInfo,
ErrParseParamTypeFailed,
ErrHeartbeatParam,
ErrHeartbeatChunkUnmarshal,
ErrUnimplemented,
ErrHeartbeatAckParams,
ErrHeartbeatAckNotHeartbeatInfo,
ErrHeartbeatAckMarshalParam,
ErrErrorCauseTooSmall,
ErrParamTypeUnhandled {
typ: u16,
},
ErrParamTypeUnexpected,
ErrParamHeaderTooShort,
ErrParamHeaderSelfReportedLengthShorter,
ErrParamHeaderSelfReportedLengthLonger,
ErrParamHeaderParseFailed,
ErrParamPacketTooShort,
ErrSsnResetRequestParamTooShort,
ErrReconfigRespParamTooShort,
ErrInvalidAlgorithmType,
ErrInitChunkParseParamTypeFailed,
ErrInitChunkUnmarshalParam,
ErrInitAckMarshalParam,
ErrChunkTypeNotTypeInit,
ErrChunkValueNotLongEnough,
ErrChunkTypeInitFlagZero,
ErrChunkTypeInitUnmarshalFailed,
ErrChunkTypeInitMarshalFailed,
ErrChunkTypeInitInitiateTagZero,
ErrInitInboundStreamRequestZero,
ErrInitOutboundStreamRequestZero,
ErrInitAdvertisedReceiver1500,
ErrChunkPayloadSmall,
ErrChunkTypeNotPayloadData,
ErrChunkTypeNotReconfig,
ErrChunkReconfigInvalidParamA,
ErrChunkParseParamTypeFailed,
ErrChunkMarshalParamAReconfigFailed,
ErrChunkMarshalParamBReconfigFailed,
ErrChunkTypeNotSack,
ErrSackSizeNotLargeEnoughInfo,
ErrInvalidChunkSize,
ErrChunkTypeNotShutdown,
ErrChunkTypeNotShutdownAck,
ErrChunkTypeNotShutdownComplete,
ErrPacketRawTooSmall,
ErrParseSctpChunkNotEnoughData,
ErrUnmarshalUnknownChunkType,
ErrChecksumMismatch,
ErrUnexpectedChuckPoppedUnordered,
ErrUnexpectedChuckPoppedOrdered,
ErrUnexpectedQState,
ErrTryAgain,
ErrAbortChunk(String),
ErrShutdownNonEstablished,
ErrAssociationClosedBeforeConn,
ErrAssociationInitFailed,
ErrAssociationHandshakeClosed,
ErrSilentlyDiscard,
ErrInitNotStoredToSend,
ErrCookieEchoNotStoredToSend,
ErrSctpPacketSourcePortZero,
ErrSctpPacketDestinationPortZero,
ErrInitChunkBundled,
ErrInitChunkVerifyTagNotZero,
ErrHandleInitState,
ErrInitAckNoCookie,
ErrStreamAlreadyExist,
ErrStreamCreateFailed,
ErrInflightQueueTsnPop,
ErrTsnRequestNotExist,
ErrResetPacketInStateNotExist,
ErrParameterType,
ErrPayloadDataStateNotExist,
ErrChunkTypeUnhandled,
ErrHandshakeInitAck,
ErrHandshakeCookieEcho,
ErrOutboundPacketTooLarge,
ErrStreamClosed,
ErrStreamNotExisted,
ErrAssociationNotExisted,
ErrTransportNoExisted,
ErrEof,
ErrInvalidSystemTime,
ErrNetConnRead,
ErrMaxDataChannelID,
UnexpectedEndOfBuffer {
expected: usize,
actual: usize,
},
InvalidMessageType(u8),
InvalidChannelType(u8),
InvalidPayloadProtocolIdentifier(u8),
UnknownProtocol,
ErrNilStream,
ErrIncompleteFrameHeader,
ErrIncompleteFrameData,
ErrIncompleteFileHeader,
ErrSignatureMismatch,
ErrUnknownIVFVersion,
ErrFileNotOpened,
ErrInvalidNilPacket,
ErrBadIDPageSignature,
ErrBadIDPageType,
ErrBadIDPageLength,
ErrBadIDPagePayloadSignature,
ErrShortPageHeader,
ErrDataIsNotH264Stream,
ErrDataIsNotH265Stream,
ErrIoEOF,
ErrConnectionClosed,
ErrDataChannelClosed,
ErrDataChannelNotExisted,
ErrCertificateExpired,
ErrNoTurnCredentials,
ErrTurnCredentials,
ErrExistingTrack,
ErrTrackNotExisted,
ErrPrivateKeyType,
ErrModifyingPeerIdentity,
ErrModifyingCertificates,
ErrNonCertificate,
ErrModifyingBundlePolicy,
ErrModifyingRTCPMuxPolicy,
ErrModifyingICECandidatePoolSize,
ErrStringSizeLimit,
ErrNegotiatedWithoutID,
ErrRetransmitsOrPacketLifeTime,
ErrCodecNotFound,
ErrNoRemoteDescription,
ErrIncorrectSDPSemantics,
ErrIncorrectSignalingState,
ErrProtocolTooLarge,
ErrSenderNotCreatedByConnection,
ErrSenderInitialTrackIdAlreadySet,
ErrSessionDescriptionNoFingerprint,
ErrSessionDescriptionInvalidFingerprint,
ErrSessionDescriptionConflictingFingerprints,
ErrSessionDescriptionMissingIceUfrag,
ErrSessionDescriptionMissingIcePwd,
ErrSessionDescriptionConflictingIceUfrag,
ErrSessionDescriptionConflictingIcePwd,
ErrNoSRTPProtectionProfile,
ErrFailedToGenerateCertificateFingerprint,
ErrNoCodecsAvailable,
ErrUnsupportedCodec,
InvalidStateError,
InvalidModificationError,
RangeError(String),
ErrSenderWithNoCodecs,
ErrSenderWithNoSSRCs,
ErrRTPSenderNewTrackHasIncorrectKind,
ErrRTPSenderNewTrackHasIncorrectEnvelope,
ErrRTPSenderDataSent,
ErrRTPSenderSeqTransEnabled,
ErrUnbindFailed,
ErrNoPayloaderForCodec,
ErrRegisterHeaderExtensionInvalidDirection,
ErrInvalidDirection,
ErrRegisterHeaderExtensionNoFreeID,
ErrSimulcastProbeOverflow,
ErrDetachNotEnabled,
ErrDetachBeforeOpened,
ErrDtlsTransportNotStarted,
ErrDtlsKeyExtractionFailed,
ErrFailedToStartSRTP,
ErrFailedToStartSRTCP,
ErrInvalidDTLSStart,
ErrNoRemoteCertificate,
ErrIdentityProviderNotImplemented,
ErrNoMatchingCertificateFingerprint,
ErrUnsupportedFingerprintAlgorithm,
ErrICEConnectionNotStarted,
ErrICECandidateTypeUnknown,
ErrICEInvalidConvertCandidateType,
ErrICEAgentNotExist,
ErrICECandidatesConversionFailed,
ErrICERoleUnknown,
ErrICEProtocolUnknown,
ErrICEGathererNotStarted,
ErrNetworkTypeUnknown,
ErrSDPDoesNotMatchOffer,
ErrSDPDoesNotMatchAnswer,
ErrPeerConnSDPTypeInvalidValue,
ErrPeerConnStateChangeInvalid,
ErrPeerConnStateChangeUnhandled,
ErrPeerConnSDPTypeInvalidValueSetLocalDescription,
ErrPeerConnRemoteDescriptionWithoutMidValue,
ErrPeerConnRemoteDescriptionNil,
ErrPeerConnLocalDescriptionNil,
ErrPeerConnSingleMediaSectionHasExplicitSSRC,
ErrPeerConnRemoteSSRCAddTransceiver,
ErrPeerConnSimulcastMidRTPExtensionRequired,
ErrPeerConnSimulcastStreamIDRTPExtensionRequired,
ErrPeerConnSimulcastIncomingSSRCFailed,
ErrPeerConnStatsCollectionFailed,
ErrPeerConnAddTransceiverFromKindOnlyAcceptsOne,
ErrPeerConnAddTransceiverFromTrackOnlyAcceptsOne,
ErrPeerConnAddTransceiverFromKindSupport,
ErrPeerConnAddTransceiverFromTrackSupport,
ErrPeerConnSetIdentityProviderNotImplemented,
ErrPeerConnWriteRTCPOpenWriteStream,
ErrPeerConnTransceiverMidNil,
ErrRTPReceiverDTLSTransportNil,
ErrRTPReceiverReceiveAlreadyCalled,
ErrRTPReceiverWithSSRCTrackStreamNotFound,
ErrRTPReceiverForSSRCTrackStreamNotFound,
ErrRTPReceiverForRIDTrackStreamNotFound,
ErrRTPReceiverStateChangeInvalid,
ErrRTPSenderTrackNil,
ErrRTPSenderNotExisted,
ErrRTPSenderRidNil,
ErrRTPSenderNoBaseEncoding,
ErrRTPSenderBaseEncodingMismatch,
ErrRTPSenderRIDCollision,
ErrRTPSenderNoTrackForRID,
ErrRTPReceiverNotExisted,
ErrRTPSenderDTLSTransportNil,
ErrRTPSenderSendAlreadyCalled,
ErrRTPTransceiverCannotChangeMid,
ErrRTPTransceiverSetSendingInvalidState,
ErrRTPTransceiverCodecUnsupported,
ErrSCTPTransportDTLS,
ErrSDPZeroTransceivers,
ErrSDPMediaSectionMediaDataChanInvalid,
ErrSDPMediaSectionTrackInvalid,
ErrSettingEngineSetAnsweringDTLSRole,
ErrSignalingStateCannotRollback,
ErrSignalingStateProposedTransitionInvalid(String),
ErrStatsICECandidateStateInvalid,
ErrICETransportNotInNew,
ErrCertificatePEMFormatError,
ErrSCTPNotEstablished,
ErrClosedPipe,
ErrInterceptorNotBind,
ErrExcessiveRetries,
ErrRTPTooShort,
SimulcastRidParseErrorSyntaxIdDirSplit,
SimulcastRidParseErrorUnknownDirection,
CodecNotFound,
MissingWhitespace,
MissingColon,
PayloadTypeNotFound,
SdpInvalidSyntax(String),
SdpInvalidValue(String),
SdpEmptyTimeDescription,
ParseExtMap(String),
SyntaxError {
s: String,
p: usize,
},
Sec1(Error),
P256(P256Error),
RcGen(Error),
InvalidPEM(String),
AesGcm(Error),
ParseIp(AddrParseError),
ParseInt(ParseIntError),
Io(IoError),
Url(ParseError),
Utf8(FromUtf8Error),
Std(StdError),
Aes(InvalidLength),
OtherRtcpErr(String),
OtherRtpErr(String),
OtherSrtpErr(String),
OtherStunErr(String),
OtherTurnErr(String),
OtherIceErr(String),
OtherDtlsErr(String),
OtherSctpErr(String),
OtherDataChannelErr(String),
OtherInterceptorErr(String),
OtherMediaErr(String),
OtherMdnsErr(String),
OtherSdpErr(String),
OtherPeerConnectionErr(String),
Other(String),
}Variants (Non-exhaustive)§
This enum is marked as non-exhaustive
ErrBufferFull
ErrBufferClosed
ErrBufferShort
ErrPacketTooBig
ErrTimeout
ErrClosedListener
ErrListenQueueExceeded
ErrClosedListenerAcceptCh
ErrObsCannotBeNil
ErrUseClosedNetworkConn
ErrAddrNotUdpAddr
ErrLocAddr
ErrAlreadyClosed
ErrNoRemAddr
ErrAddressAlreadyInUse
ErrNoSuchUdpConn
ErrCannotRemoveUnspecifiedIp
ErrNoAddressAssigned
ErrNatRequriesMapping
ErrMismatchLengthIp
ErrNonUdpTranslationNotSupported
ErrNoAssociatedLocalAddress
ErrNoNatBindingFound
ErrHasNoPermission
ErrHostnameEmpty
ErrFailedToParseIpaddr
ErrNoInterface
ErrNotFound
ErrUnexpectedNetwork
ErrCantAssignRequestedAddr
ErrUnknownNetwork
ErrNoRouterLinked
ErrInvalidPortNumber
ErrUnexpectedTypeSwitchFailure
ErrBindFailed
ErrEndPortLessThanStart
ErrPortSpaceExhausted
ErrVnetDisabled
ErrInvalidLocalIpInStaticIps
ErrLocalIpBeyondStaticIpsSubset
ErrLocalIpNoStaticsIpsAssociated
ErrRouterAlreadyStarted
ErrRouterAlreadyStopped
ErrStaticIpIsBeyondSubnet
ErrAddressSpaceExhausted
ErrNoIpaddrEth0
ErrInvalidMask
HandshakeInProgress
ContextUnsupported
ReservedExportKeyingMaterial
CipherSuiteUnset
Hash(String)
PoisonError(String)
WrongMarshalSize
Wrong marshal size.
InvalidTotalLost
Packet lost exceeds maximum amount of packets that can possibly be lost.
InvalidHeader
Packet contains an invalid header.
EmptyCompound
Packet contains empty compound.
BadFirstPacket
Invalid first packet in compound packets. First packet should either be a SenderReport packet or ReceiverReport
MissingCname
CNAME was not defined.
PacketBeforeCname
Packet was defined before CNAME.
TooManyReports
Too many reports.
TooManyChunks
Too many chunks.
TooManySources
Too many sources.
PacketTooShort
Packet received is too short.
BufferTooShort
Buffer is too short.
WrongType
Wrong packet type.
SdesTextTooLong
SDES received is too long.
SdesMissingType
SDES type is missing.
ReasonTooLong
Reason is too long.
BadVersion
Invalid packet version.
WrongPadding
Invalid padding value.
WrongFeedbackType
Wrong feedback message type.
WrongPayloadType
Wrong payload type.
HeaderTooSmall
Header length is too small.
SsrcMustBeZero
Media ssrc was defined as zero.
MissingRembIdentifier
Missing REMB identifier.
SsrcNumAndLengthMismatch
SSRC number and length mismatches.
InvalidSizeOrStartIndex
Invalid size or start index.
DeltaExceedLimit
Delta exceeds limit.
PacketStatusChunkLength
Packet status chunk is not 2 bytes.
InvalidBitrate
WrongChunkType
BadStructMemberType
BadReadParameter
InvalidBlockSize
ErrHeaderSizeInsufficient
ErrHeaderSizeInsufficientForExtension
ErrBufferTooSmall
ErrHeaderExtensionsNotEnabled
ErrHeaderExtensionNotFound
ErrRfc8285oneByteHeaderIdrange
ErrRfc8285oneByteHeaderSize
ErrRfc8285twoByteHeaderIdrange
ErrRfc8285twoByteHeaderSize
ErrRfc3550headerIdrange
ErrShortPacket
ErrNilPacket
ErrTooManyPDiff
ErrTooManySpatialLayers
ErrUnhandledNaluType
ErrH265CorruptedPacket
ErrInvalidH265PacketType
ErrPayloadTooSmallForObuExtensionHeader
ErrPayloadTooSmallForObuPayloadSize
HeaderExtensionPayloadNot32BitWords
AudioLevelOverflow
PlayoutDelayOverflow
PayloadIsNotLargeEnough
StapASizeLargerThanBuffer(usize, usize)
NaluTypeIsNotHandled(u8)
ErrDuplicated
ErrShortSrtpMasterKey
ErrShortSrtpMasterSalt
ErrNoSuchSrtpProfile
ErrNonZeroKdrNotSupported
ErrExporterWrongLabel
ErrNoConfig
ErrNoConn
ErrFailedToVerifyAuthTag
ErrTooShortRtp
ErrTooShortRtcp
ErrPayloadDiffers
ErrStartedChannelUsedIncorrectly
ErrStreamNotInited
ErrStreamAlreadyClosed
ErrStreamAlreadyInited
ErrFailedTypeAssertion
ErrExceededMaxPackets
UnsupportedIndexOverKdr
InvalidMasterKeyLength
InvalidMasterSaltLength
UnsupportedOutLength
SrtpMasterKeyLength(usize, usize)
SrtpSaltLength(usize, usize)
ExtMapParse(String)
SsrcMissingFromSrtp(u32)
SrtpSsrcDuplicated(u32, u16)
SrtcpSsrcDuplicated(u32, usize)
SsrcMissingFromSrtcp(u32)
StreamWithSsrcExists(u32)
SessionRtpRtcpTypeMismatch
SessionEof
SrtpTooSmall(usize, usize)
SrtcpTooSmall(usize, usize)
RtpFailedToVerifyAuthTag
RtcpInvalidLengthAuthTag(usize, usize)
RtcpFailedToVerifyAuthTag
SessionSrtpAlreadyClosed
InvalidRtpStream
InvalidRtcpStream
ErrAttributeNotFound
ErrTransactionStopped
ErrTransactionNotExists
ErrTransactionExists
ErrAgentClosed
ErrTransactionTimeOut
ErrNoDefaultReason
ErrUnexpectedEof
ErrAttributeSizeInvalid
ErrAttributeSizeOverflow
ErrDecodeToNil
ErrUnexpectedHeaderEof
ErrIntegrityMismatch
ErrFingerprintMismatch
ErrFingerprintBeforeIntegrity
ErrBadUnknownAttrsSize
ErrBadIpLength
ErrNoConnection
ErrClientClosed
ErrNoAgent
ErrCollectorClosed
ErrUnsupportedNetwork
ErrInvalidUrl
ErrSchemeType
ErrHost
ErrRelayAddressInvalid
ErrNoAvailableConns
ErrConnUnset
ErrListenerUnset
ErrListeningAddressInvalid
ErrRelayAddressGeneratorUnset
ErrMaxRetriesExceeded
ErrMaxPortNotZero
ErrMinPortNotZero
ErrMaxPortLessThanMinPort
ErrNilConn
ErrTodo
ErrAlreadyListening
ErrFailedToClose
ErrFailedToRetransmitTransaction
ErrAllRetransmissionsFailed
ErrChannelBindNotFound
ErrStunserverAddressNotSet
ErrOneAllocateOnly
ErrAlreadyAllocated
ErrNonStunmessage
ErrFailedToDecodeStun
ErrUnexpectedStunrequestMessage
ErrInvalidChannelNumber
ErrBadChannelDataLength
ErrInvalidRequestedFamilyValue
ErrFakeErr
ErrClosed
ErrUdpaddrCast
ErrDoubleLock
ErrTransactionClosed
ErrWaitForResultOnNonResultTransaction
ErrFailedToBuildRefreshRequest
ErrFailedToRefreshAllocation
ErrFailedToGetLifetime
ErrShortBuffer
ErrUnexpectedResponse
ErrAllocatePacketConnMustBeSet
ErrAllocateConnMustBeSet
ErrLeveledLoggerMustBeSet
ErrSameChannelDifferentPeer
ErrNilFiveTuple
ErrNilFiveTupleSrcAddr
ErrNilFiveTupleDstAddr
ErrNilTurnSocket
ErrLifetimeZero
ErrDupeFiveTuple
ErrFailedToCastUdpaddr
ErrFailedToGenerateNonce
ErrFailedToSendError
ErrDuplicatedNonce
ErrNoSuchUser
ErrUnexpectedClass
ErrUnexpectedMethod
ErrFailedToHandle
ErrUnhandledStunpacket
ErrUnableToHandleChannelData
ErrFailedToCreateStunpacket
ErrFailedToCreateChannelData
ErrRelayAlreadyAllocatedForFiveTuple
ErrRequestedTransportMustBeUdp
ErrNoDontFragmentSupport
ErrRequestWithReservationTokenAndEvenPort
ErrNoAllocationFound
ErrNoPermission
ErrShortWrite
ErrNoSuchChannelBind
ErrFailedWriteSocket
ErrUnknownType
Indicates an error with Unknown info.
ErrStunQuery
Indicates query arguments are provided in a STUN URL.
ErrInvalidQuery
Indicates an malformed query is provided.
ErrPort
Indicates malformed port is provided.
ErrLocalUfragInsufficientBits
Indicates local username fragment insufficient bits are provided. Have to be at least 24 bits long.
ErrLocalPwdInsufficientBits
Indicates local passoword insufficient bits are provided. Have to be at least 128 bits long.
ErrProtoType
Indicates an unsupported transport type was provided.
ErrNoCandidatePairs
Indicates agent does not have a valid candidate pair.
ErrCanceledByCaller
Indicates agent connection was canceled by the caller.
ErrMultipleStart
Indicates agent was started twice.
ErrRemoteUfragEmpty
Indicates agent was started with an empty remote ufrag.
ErrRemotePwdEmpty
Indicates agent was started with an empty remote pwd.
ErrNoOnCandidateHandler
Indicates agent was started without on_candidate.
ErrMultipleGatherAttempted
Indicates GatherCandidates has been called multiple times.
ErrUsernameEmpty
Indicates agent was give TURN URL with an empty Username.
ErrPasswordEmpty
Indicates agent was give TURN URL with an empty Password.
ErrAddressParseFailed
Indicates we were unable to parse a candidate address.
ErrLiteUsingNonHostCandidates
Indicates that non host candidates were selected for a lite agent.
ErrLiteSupportOnly
Indicates that current ice agent supports Lite only
ErrUselessUrlsProvided
Indicates that one or more URL was provided to the agent but no host candidate required them.
ErrUnsupportedNat1to1IpCandidateType
Indicates that the specified NAT1To1IPCandidateType is unsupported.
ErrInvalidNat1to1IpMapping
Indicates that the given 1:1 NAT IP mapping is invalid.
ErrExternalMappedIpNotFound
IPNotFound in NAT1To1IPMapping.
ErrMulticastDnsWithNat1to1IpMapping
Indicates that the mDNS gathering cannot be used along with 1:1 NAT IP mapping for host candidate.
ErrIneffectiveNat1to1IpMappingHost
Indicates that 1:1 NAT IP mapping for host candidate is requested, but the host candidate type is disabled.
ErrIneffectiveNat1to1IpMappingSrflx
Indicates that 1:1 NAT IP mapping for srflx candidate is requested, but the srflx candidate type is disabled.
ErrInvalidMulticastDnshostName
Indicates an invalid MulticastDNSHostName.
ErrMulticastDnsNotSupported
Indicates mdns is not supported.
ErrRestartWhenGathering
Indicates Restart was called when Agent is in GatheringStateGathering.
ErrRunCanceled
Indicates a run operation was canceled by its individual done.
ErrTcpMuxNotInitialized
Initialized Indicates TCPMux is not initialized and that invalidTCPMux is used.
ErrTcpRemoteAddrAlreadyExists
Indicates we already have the connection with same remote addr.
ErrSendPacket
ErrAttributeTooShortIceCandidate
ErrParseComponent
ErrParsePriority
ErrParsePort
ErrParseRelatedAddr
ErrParseType
ErrUnknownCandidateType
ErrGetXorMappedAddrResponse
ErrConnectionAddrAlreadyExist
ErrReadingStreamingPacket
ErrWriting
ErrClosingConnection
ErrDetermineNetworkType
ErrMissingProtocolScheme
ErrTooManyColonsAddr
ErrRead
ErrUnknownRole
ErrMismatchUsername
ErrIceWriteStunMessage
ErrUrlParse
ErrCandidateIpNotFound
ErrConnClosed
ErrDeadlineExceeded
ErrContextUnsupported
ErrDtlspacketInvalidLength
ErrHandshakeInProgress
ErrInvalidContentType
ErrInvalidMac
ErrInvalidPacketLength
ErrReservedExportKeyingMaterial
ErrCertificateVerifyNoCertificate
ErrCipherSuiteNoIntersection
ErrCipherSuiteUnset
ErrClientCertificateNotVerified
ErrClientCertificateRequired
ErrClientNoMatchingSrtpProfile
ErrClientRequiredButNoServerEms
ErrCompressionMethodUnset
ErrCookieMismatch
ErrCookieTooLong
ErrIdentityNoPsk
ErrInvalidCertificate
ErrInvalidCipherSpec
ErrInvalidCipherSuite
ErrInvalidClientKeyExchange
ErrInvalidCompressionMethod
ErrInvalidEcdsasignature
ErrInvalidEllipticCurveType
ErrInvalidExtensionType
ErrInvalidHashAlgorithm
ErrInvalidNamedCurve
ErrInvalidPrivateKey
ErrNamedCurveAndPrivateKeyMismatch
ErrInvalidSniFormat
ErrInvalidSignatureAlgorithm
ErrKeySignatureMismatch
ErrNilNextConn
ErrNoAvailableCipherSuites
ErrNoAvailableSignatureSchemes
ErrNoCertificates
ErrNoConfigProvided
ErrNoSupportedEllipticCurves
ErrUnsupportedProtocolVersion
ErrPskAndCertificate
ErrPskAndIdentityMustBeSetForClient
ErrRequestedButNoSrtpExtension
ErrServerMustHaveCertificate
ErrServerNoMatchingSrtpProfile
ErrServerRequiredButNoClientEms
ErrVerifyDataMismatch
ErrHandshakeMessageUnset
ErrInvalidFlight
ErrKeySignatureGenerateUnimplemented
ErrKeySignatureVerifyUnimplemented
ErrLengthMismatch
ErrNotEnoughRoomForNonce
ErrNotImplemented
ErrSequenceNumberOverflow
ErrUnableToMarshalFragmented
ErrInvalidFsmTransition
ErrApplicationDataEpochZero
ErrUnhandledContextType
ErrContextCanceled
ErrEmptyFragment
ErrAlertFatalOrClose
ErrFragmentBufferOverflow
ErrClientTransportNotSet
EndpointStopping
The endpoint can no longer create new connections
Indicates that a necessary component of the endpoint has been dropped or otherwise disabled.
TooManyConnections
The number of active connections on the local endpoint is at the limit
Try using longer connection IDs.
InvalidDnsName(String)
The domain name supplied was malformed
InvalidRemoteAddress(SocketAddr)
The remote SocketAddr supplied was malformed
Examples include attempting to connect to port 0, or using an inappropriate address family.
NoClientConfig
No client configuration was set up
NoServerConfig
No server configuration was set up
ErrChunkHeaderTooSmall
ErrChunkHeaderNotEnoughSpace
ErrChunkHeaderPaddingNonZero
ErrChunkHeaderInvalidLength
ErrChunkTypeNotAbort
ErrBuildAbortChunkFailed
ErrChunkTypeNotCookieAck
ErrChunkTypeNotCookieEcho
ErrChunkTypeNotCt
ErrBuildErrorChunkFailed
ErrMarshalStreamFailed
ErrChunkTooShort
ErrChunkTypeNotForwardTsn
ErrChunkTypeNotHeartbeat
ErrChunkTypeNotHeartbeatAck
ErrHeartbeatNotLongEnoughInfo
ErrParseParamTypeFailed
ErrHeartbeatParam
ErrHeartbeatChunkUnmarshal
ErrUnimplemented
ErrHeartbeatAckParams
ErrHeartbeatAckNotHeartbeatInfo
ErrHeartbeatAckMarshalParam
ErrErrorCauseTooSmall
ErrParamTypeUnhandled
ErrParamTypeUnexpected
ErrParamHeaderTooShort
ErrParamHeaderSelfReportedLengthShorter
ErrParamHeaderSelfReportedLengthLonger
ErrParamHeaderParseFailed
ErrParamPacketTooShort
ErrSsnResetRequestParamTooShort
ErrReconfigRespParamTooShort
ErrInvalidAlgorithmType
ErrInitChunkParseParamTypeFailed
ErrInitChunkUnmarshalParam
ErrInitAckMarshalParam
ErrChunkTypeNotTypeInit
ErrChunkValueNotLongEnough
ErrChunkTypeInitFlagZero
ErrChunkTypeInitUnmarshalFailed
ErrChunkTypeInitMarshalFailed
ErrChunkTypeInitInitiateTagZero
ErrInitInboundStreamRequestZero
ErrInitOutboundStreamRequestZero
ErrInitAdvertisedReceiver1500
ErrChunkPayloadSmall
ErrChunkTypeNotPayloadData
ErrChunkTypeNotReconfig
ErrChunkReconfigInvalidParamA
ErrChunkParseParamTypeFailed
ErrChunkMarshalParamAReconfigFailed
ErrChunkMarshalParamBReconfigFailed
ErrChunkTypeNotSack
ErrSackSizeNotLargeEnoughInfo
ErrInvalidChunkSize
ErrChunkTypeNotShutdown
ErrChunkTypeNotShutdownAck
ErrChunkTypeNotShutdownComplete
ErrPacketRawTooSmall
ErrParseSctpChunkNotEnoughData
ErrUnmarshalUnknownChunkType
ErrChecksumMismatch
ErrUnexpectedChuckPoppedUnordered
ErrUnexpectedChuckPoppedOrdered
ErrUnexpectedQState
ErrTryAgain
ErrAbortChunk(String)
ErrShutdownNonEstablished
ErrAssociationClosedBeforeConn
ErrAssociationInitFailed
ErrAssociationHandshakeClosed
ErrSilentlyDiscard
ErrInitNotStoredToSend
ErrCookieEchoNotStoredToSend
ErrSctpPacketSourcePortZero
ErrSctpPacketDestinationPortZero
ErrInitChunkBundled
ErrInitChunkVerifyTagNotZero
ErrHandleInitState
ErrInitAckNoCookie
ErrStreamAlreadyExist
ErrStreamCreateFailed
ErrInflightQueueTsnPop
ErrTsnRequestNotExist
ErrResetPacketInStateNotExist
ErrParameterType
ErrPayloadDataStateNotExist
ErrChunkTypeUnhandled
ErrHandshakeInitAck
ErrHandshakeCookieEcho
ErrOutboundPacketTooLarge
ErrStreamClosed
ErrStreamNotExisted
ErrAssociationNotExisted
ErrTransportNoExisted
ErrEof
ErrInvalidSystemTime
ErrNetConnRead
ErrMaxDataChannelID
UnexpectedEndOfBuffer
InvalidMessageType(u8)
InvalidChannelType(u8)
InvalidPayloadProtocolIdentifier(u8)
UnknownProtocol
ErrNilStream
ErrIncompleteFrameHeader
ErrIncompleteFrameData
ErrIncompleteFileHeader
ErrSignatureMismatch
ErrUnknownIVFVersion
ErrFileNotOpened
ErrInvalidNilPacket
ErrBadIDPageSignature
ErrBadIDPageType
ErrBadIDPageLength
ErrBadIDPagePayloadSignature
ErrShortPageHeader
ErrDataIsNotH264Stream
ErrDataIsNotH265Stream
ErrIoEOF
ErrConnectionClosed
ErrConnectionClosed indicates an operation executed after connection has already been closed.
ErrDataChannelClosed
ErrDataChannelClosed indicates an operation executed when the data channel is not (yet) open or closed.
ErrDataChannelNotExisted
ErrDataChannelNonExist indicates an operation executed when the data channel not existed.
ErrCertificateExpired
ErrCertificateExpired indicates that an x509 certificate has expired.
ErrNoTurnCredentials
ErrNoTurnCredentials indicates that a TURN server URL was provided without required credentials.
ErrTurnCredentials
ErrTurnCredentials indicates that provided TURN credentials are partial or malformed.
ErrExistingTrack
ErrExistingTrack indicates that a track already exists.
ErrTrackNotExisted
ErrExistingTrack indicates that a track already exists.
ErrPrivateKeyType
ErrPrivateKeyType indicates that a particular private key encryption chosen to generate a certificate is not supported.
ErrModifyingPeerIdentity
ErrModifyingPeerIdentity indicates that an attempt to modify PeerIdentity was made after PeerConnection has been initialized.
ErrModifyingCertificates
ErrModifyingCertificates indicates that an attempt to modify Certificates was made after PeerConnection has been initialized.
ErrNonCertificate
ErrNonCertificate indicates that there is no certificate
ErrModifyingBundlePolicy
ErrModifyingBundlePolicy indicates that an attempt to modify BundlePolicy was made after PeerConnection has been initialized.
ErrModifyingRTCPMuxPolicy
ErrModifyingRTCPMuxPolicy indicates that an attempt to modify RTCPMuxPolicy was made after PeerConnection has been initialized.
ErrModifyingICECandidatePoolSize
ErrModifyingICECandidatePoolSize indicates that an attempt to modify ICECandidatePoolSize was made after PeerConnection has been initialized.
ErrStringSizeLimit
ErrStringSizeLimit indicates that the character size limit of string is exceeded. The limit is hardcoded to 65535 according to specifications.
ErrNegotiatedWithoutID
ErrNegotiatedWithoutID indicates that an attempt to create a data channel was made while setting the negotiated option to true without providing the negotiated channel ID.
ErrRetransmitsOrPacketLifeTime
ErrRetransmitsOrPacketLifeTime indicates that an attempt to create a data channel was made with both options max_packet_life_time and max_retransmits set together. Such configuration is not supported by the specification and is mutually exclusive.
ErrCodecNotFound
ErrCodecNotFound is returned when a codec search to the Media Engine fails
ErrNoRemoteDescription
ErrNoRemoteDescription indicates that an operation was rejected because the remote description is not set
ErrIncorrectSDPSemantics
ErrIncorrectSDPSemantics indicates that the PeerConnection was configured to generate SDP Answers with different SDP Semantics than the received Offer
ErrIncorrectSignalingState
ErrIncorrectSignalingState indicates that the signaling state of PeerConnection is not correct
ErrProtocolTooLarge
ErrProtocolTooLarge indicates that value given for a DataChannelInit protocol is longer then 65535 bytes
ErrSenderNotCreatedByConnection
ErrSenderNotCreatedByConnection indicates remove_track was called with a RtpSender not created by this PeerConnection
ErrSenderInitialTrackIdAlreadySet
ErrSenderInitialTrackIdAlreadySet indicates a second call to RtpSender::set_initial_track_id which is not allowed.
ErrSessionDescriptionNoFingerprint
ErrSessionDescriptionNoFingerprint indicates set_remote_description was called with a SessionDescription that has no fingerprint
ErrSessionDescriptionInvalidFingerprint
ErrSessionDescriptionInvalidFingerprint indicates set_remote_description was called with a SessionDescription that has an invalid fingerprint
ErrSessionDescriptionConflictingFingerprints
ErrSessionDescriptionConflictingFingerprints indicates set_remote_description was called with a SessionDescription that has an conflicting fingerprints
ErrSessionDescriptionMissingIceUfrag
ErrSessionDescriptionMissingIceUfrag indicates set_remote_description was called with a SessionDescription that is missing an ice-ufrag value
ErrSessionDescriptionMissingIcePwd
ErrSessionDescriptionMissingIcePwd indicates set_remote_description was called with a SessionDescription that is missing an ice-pwd value
ErrSessionDescriptionConflictingIceUfrag
ErrSessionDescriptionConflictingIceUfrag indicates set_remote_description was called with a SessionDescription that contains multiple conflicting ice-ufrag values
ErrSessionDescriptionConflictingIcePwd
ErrSessionDescriptionConflictingIcePwd indicates set_remote_description was called with a SessionDescription that contains multiple conflicting ice-pwd values
ErrNoSRTPProtectionProfile
ErrNoSRTPProtectionProfile indicates that the DTLS handshake completed and no SRTP Protection Profile was chosen
ErrFailedToGenerateCertificateFingerprint
ErrFailedToGenerateCertificateFingerprint indicates that we failed to generate the fingerprint used for comparing certificates
ErrNoCodecsAvailable
ErrNoCodecsAvailable indicates that operation isn’t possible because the MediaEngine has no codecs available
ErrUnsupportedCodec
ErrUnsupportedCodec indicates the remote peer doesn’t support the requested codec
InvalidStateError
InvalidModificationError
RangeError(String)
ErrSenderWithNoCodecs
ErrSenderWithNoCodecs indicates that a RTPSender was created without any codecs. To send media the MediaEngine needs at least one configured codec.
ErrSenderWithNoSSRCs
ErrSenderWithNoSSRCs indicates that a RTPSender was created without any SSRRs. To send media the Sender needs at least one configured ssrc.
ErrRTPSenderNewTrackHasIncorrectKind
ErrRTPSenderNewTrackHasIncorrectKind indicates that the new track is of a different kind than the previous/original
ErrRTPSenderNewTrackHasIncorrectEnvelope
ErrRTPSenderDataSent
ErrRTPSenderDataSent indicates that the sequence number transformer tries to be enabled after the data sending began
ErrRTPSenderSeqTransEnabled
ErrRTPSenderSeqTransEnabled indicates that the sequence number transformer has been already enabled
ErrUnbindFailed
ErrUnbindFailed indicates that a TrackLocal was not able to be unbind
ErrNoPayloaderForCodec
ErrNoPayloaderForCodec indicates that the requested codec does not have a payloader
ErrRegisterHeaderExtensionInvalidDirection
ErrRegisterHeaderExtensionInvalidDirection indicates that a extension was registered with different directions for two different calls.
ErrInvalidDirection
ErrRegisterHeaderExtensionNoFreeID
ErrRegisterHeaderExtensionNoFreeID indicates that there was no extension ID available which in turn means that all 15 available id(1 through 14) have been used.
ErrSimulcastProbeOverflow
ErrSimulcastProbeOverflow indicates that too many Simulcast probe streams are in flight and the requested SSRC was ignored
ErrDetachNotEnabled
ErrDetachBeforeOpened
ErrDtlsTransportNotStarted
ErrDtlsKeyExtractionFailed
ErrFailedToStartSRTP
ErrFailedToStartSRTCP
ErrInvalidDTLSStart
ErrNoRemoteCertificate
ErrIdentityProviderNotImplemented
ErrNoMatchingCertificateFingerprint
ErrUnsupportedFingerprintAlgorithm
ErrICEConnectionNotStarted
ErrICECandidateTypeUnknown
ErrICEInvalidConvertCandidateType
ErrICEAgentNotExist
ErrICECandidatesConversionFailed
ErrICERoleUnknown
ErrICEProtocolUnknown
ErrICEGathererNotStarted
ErrNetworkTypeUnknown
ErrSDPDoesNotMatchOffer
ErrSDPDoesNotMatchAnswer
ErrPeerConnSDPTypeInvalidValue
ErrPeerConnStateChangeInvalid
ErrPeerConnStateChangeUnhandled
ErrPeerConnSDPTypeInvalidValueSetLocalDescription
ErrPeerConnRemoteDescriptionWithoutMidValue
ErrPeerConnRemoteDescriptionNil
ErrPeerConnLocalDescriptionNil
ErrPeerConnSingleMediaSectionHasExplicitSSRC
ErrPeerConnRemoteSSRCAddTransceiver
ErrPeerConnSimulcastMidRTPExtensionRequired
ErrPeerConnSimulcastStreamIDRTPExtensionRequired
ErrPeerConnSimulcastIncomingSSRCFailed
ErrPeerConnStatsCollectionFailed
ErrPeerConnAddTransceiverFromKindOnlyAcceptsOne
ErrPeerConnAddTransceiverFromTrackOnlyAcceptsOne
ErrPeerConnAddTransceiverFromKindSupport
ErrPeerConnAddTransceiverFromTrackSupport
ErrPeerConnSetIdentityProviderNotImplemented
ErrPeerConnWriteRTCPOpenWriteStream
ErrPeerConnTransceiverMidNil
ErrRTPReceiverDTLSTransportNil
ErrRTPReceiverReceiveAlreadyCalled
ErrRTPReceiverWithSSRCTrackStreamNotFound
ErrRTPReceiverForSSRCTrackStreamNotFound
ErrRTPReceiverForRIDTrackStreamNotFound
ErrRTPReceiverStateChangeInvalid
ErrRTPSenderTrackNil
ErrRTPSenderNotExisted
ErrRTPSenderRidNil
ErrRTPSenderNoBaseEncoding
ErrRTPSenderBaseEncodingMismatch
ErrRTPSenderRIDCollision
ErrRTPSenderNoTrackForRID
ErrRTPReceiverNotExisted
ErrRTPSenderDTLSTransportNil
ErrRTPSenderSendAlreadyCalled
ErrRTPTransceiverCannotChangeMid
ErrRTPTransceiverSetSendingInvalidState
ErrRTPTransceiverCodecUnsupported
ErrSCTPTransportDTLS
ErrSDPZeroTransceivers
ErrSDPMediaSectionMediaDataChanInvalid
ErrSDPMediaSectionTrackInvalid
ErrSettingEngineSetAnsweringDTLSRole
ErrSignalingStateCannotRollback
ErrSignalingStateProposedTransitionInvalid(String)
ErrStatsICECandidateStateInvalid
ErrICETransportNotInNew
ErrCertificatePEMFormatError
ErrSCTPNotEstablished
ErrClosedPipe
ErrInterceptorNotBind
ErrExcessiveRetries
ErrRTPTooShort
SimulcastRidParseErrorSyntaxIdDirSplit
SyntaxIdDirSplit indicates rid-syntax could not be parsed.
SimulcastRidParseErrorUnknownDirection
UnknownDirection indicates rid-dir was not parsed. Should be “send” or “recv”.