libp2p/protocols/pubsub/pubsubpeer

    Dark Mode
Search:
Group by:
  Source   Edit

Types

DropConn = proc (peer: PubSubPeer) {....gcsafe, raises: [].}
  Source   Edit
GetConn = proc (): Future[Connection] {....gcsafe, raises: [].}
  Source   Edit
OnEvent = proc (peer: PubSubPeer; event: PubSubPeerEvent) {....gcsafe, raises: [].}
  Source   Edit
PeerRateLimitError = object of CatchableError
  Source   Edit
PubSubObserver = ref object
  onRecv*: proc (peer: PubSubPeer; msgs: var RPCMsg) {....gcsafe, raises: [].}
  onSend*: proc (peer: PubSubPeer; msgs: var RPCMsg) {....gcsafe, raises: [].}
  Source   Edit
PubSubPeer = ref object of RootObj
  getConn*: GetConn
  onEvent*: OnEvent
  codec*: string
  sendConn*: Connection
  connectedFut: Future[void]
  address*: Option[MultiAddress]
  peerId*: PeerId
  handler*: RPCHandler
  observers*: ref seq[PubSubObserver]
  score*: float64
  sentIHaves*: Deque[HashSet[MessageId]]
  heDontWants*: Deque[HashSet[MessageId]]
  iHaveBudget*: int
  pingBudget*: int
  maxMessageSize: int
  appScore*: float64
  behaviourPenalty*: float64
  overheadRateLimitOpt*: Opt[TokenBucket]
  rpcmessagequeue: RpcMessageQueue
  Source   Edit
PubSubPeerEventKind {.pure.} = enum
  Connected, Disconnected
  Source   Edit
RPCHandler = proc (peer: PubSubPeer; data: seq[byte]): Future[void] {....gcsafe,
    raises: [].}
  Source   Edit
RpcMessageQueue = ref object
  priorityQueue: AsyncQueue[seq[byte]]
  nonPriorityQueue: AsyncQueue[seq[byte]]
  queueProcessingTask: Future[void]
  isProcessing: bool
  Source   Edit

Procs

func `==`(a, b: PubSubPeer): bool {....raises: [], tags: [].}
  Source   Edit
proc canAskIWant(p: PubSubPeer; msgId: MessageId): bool {....raises: [], tags: [].}
  Source   Edit
proc connect(p: PubSubPeer) {....raises: [], tags: [RootEffect].}
  Source   Edit
proc connected(p: PubSubPeer): bool {....raises: [], tags: [].}
  Source   Edit
proc getAgent(peer: PubSubPeer): string {....raises: [], tags: [].}
  Source   Edit
proc handle(p: PubSubPeer; conn: Connection): Future[void] {.stackTrace: false,
    ...gcsafe, raises: [], raises: [], raises: [], tags: [RootEffect].}
  Source   Edit
func hash(p: PubSubPeer): Hash {....raises: [], tags: [].}
  Source   Edit
proc hasObservers(p: PubSubPeer): bool {....raises: [], tags: [].}
  Source   Edit
proc hasSendConn(p: PubSubPeer): bool {....raises: [], tags: [].}
  Source   Edit
proc new(T: typedesc[PubSubPeer]; peerId: PeerId; getConn: GetConn;
         onEvent: OnEvent; codec: string; maxMessageSize: int;
         overheadRateLimitOpt: Opt[TokenBucket] = Opt.none(TokenBucket)): T:type {.
    ...raises: [].}
  Source   Edit
func outbound(p: PubSubPeer): bool {....raises: [], tags: [].}
  Source   Edit
proc recvObservers(p: PubSubPeer; msg: var RPCMsg) {....raises: [],
    tags: [RootEffect].}
  Source   Edit
proc send(p: PubSubPeer; msg: RPCMsg; anonymize: bool;
          isHighPriority: bool = false): Future[void] {.stackTrace: false,
    ...gcsafe, raises: [], raises: [], raises: [], tags: [RootEffect].}
  Source   Edit
proc sendEncoded(p: PubSubPeer; msg: seq[byte]; isHighPriority: bool = false): Future[
    void] {.stackTrace: false, ...gcsafe, raises: [], raises: [], raises: [],
            tags: [RootEffect].}
  Source   Edit
func shortLog(p: PubSubPeer): string {....raises: [], tags: [].}
  Source   Edit
proc stopProcessingMessages(p: PubSubPeer) {....raises: [],
    tags: [WriteIOEffect, TimeEffect, RootEffect].}
  Source   Edit

Templates

template formatItIMPL(it: PubSubPeer): auto
  Source   Edit

Exports

formatItIMPL, hash, shortLog, random, $, write, PeerId, ==, getField, <=, capLen, init, validate, init, match, <, getBytes, maxInlineKeyLength, write, withValue, safeConvert, shortLog, >=, withValue, public, shortLog, compilesOr, toBytes, match, valueOr, init, init, init, toOpt, init, hasPublicKey, >, hex, len, exceptionToAssert, cmp, extractPublicKey, newLPStreamWriteError, DNS_OR_IP, ProtoHeader, shortLog, init, random, UDP_DNS, $, <=, MaError, ephemeral, decode, MaPatternOp, ==, WS_DNS, initVBuffer, getProtoHeader, MaxSizeError, ProtoFlags, getLen, ECDHEScheme, shortLog, init, init, closed, [], macOpenArray, random, init, VBuffer, Secret, peekVarint, random, $, validate, mapOr, bytes, maxInlineKeyLength, TranscoderDNS, QUIC, [], key, ephemeral, withValue, getRequiredField, getField, writeLp, WS_IP, isEnough, public, MAKind, getBytes, write, DNSANY, checkFieldNumber, valueOr, getRepeatedField, matchPartial, libp2p_pki_schemes, getBytes, len, readVarint, readLp, HTTP, initVBuffer, mac, atEof, LPStreamTrackerName, peekSeq, toOpt, fullAddrs, payloadType, getProtoHeader, LPStreamError, IP, protoAddress, newRng, DefaultConnectionTimeout, ==, checkValid, getPublicKey, exceptionToAssert, decodeProposal, len, CircuitRelay, extractPublicKey, mapAnd, new, verify, UDP_IP, new, newLPStreamEOFError, init, write, ==, DNSADDR, AddressMapper, write, PeerId, WSS, LPStream, TCP_IP, close, hash, writePacked, init, closeImpl, readSeq, toBytes, TCP_DNS, shortLog, encode, len, capLen, protoName, toRawBytes, TranscoderIP6Zone, $, initProtoBuffer, newLPStreamReadError, init, WSS_DNS, match, writeLPVarint, CryptoResult, WebSockets_DNS, ProtoResult, WebRTCDirect, init, init, UDP, TranscoderOnion, StreamTracker, write, init, LPStreamResetError, isEmpty, writeArray, LPStreamReadError, decode, LPStreamIncompleteError, [], LPStreamEOFError, IP6, shortLog, initVBuffer, decode, PKScheme, payload, init, init, Connection, write, init, TCP, PrivateKey, getBytes, write, &=, PeerInfoError, newLPStreamClosedError, random, compilesOr, TranscoderIP4, init, initProtoBuffer, toException, DNS, UTP, goffset, readVarint, >, KeyPair, init, init, high, toString, cmp, init, SupportedWireTypes, formatItIMPL, formatItIMPL, formatItIMPL, Signature, contains, hash, formatItIMPL, toBytes, DigestSheme, init, IPFS, readOnce, init, isEmpty, ProtoScalar, shortLog, data, LPStreamIncorrectDefect, hex, protocols, update, HTTPS, tryAndWarn, WebSockets, LPError, getPtr, write, TLS_WS, sign, finish, encode, MaResult, ProtoField, init, toBytes, writeSeq, init, &, DNS6, IpTransportProtocol, toOpenArray, init, allFuturesThrowing, IP4, TranscoderPort, write, newLPStreamIncorrectDefect, getField, init, createExchange, >=, init, payloadDomain, $, MaPattern, withValue, getRawBytes, init, LPStreamLimitError, TranscoderOnion3, SignedPayload, toBytes, protoArgument, newLPStreamLimitError, keyOpenArray, match, createProposal, parseFullAddress, $, isEmpty, supported, getRequiredRepeatedField, init, newLPStreamIncompleteError, newLPStreamReadError, initProtoBuffer, MAProtocol, newLPStreamResetError, getPackedRepeatedField, initStream, init, getField, shortLog, DNS4, getWrapped, readArray, selectBest, safeConvert, P2PPattern, Envelope, hasPublicKey, toException, init, isEnough, init, Reliable, addrs, hex, ProtoBuffer, closeImpl, write, WS, stretchKeys, encode, init, init, getField, getField, match, getField, <, iv, readLine, Eof, CryptoError, getField, hash, append, vsizeof, init, parseFullAddress, WSS_IP, LPStreamConnDownError, peekArray, UNIX, PeerRecord, init, SupportedSchemes, getRepeatedField, LPStreamWriteError, getField, Unreliable, SupportedSchemesInt, random, checkFutures, shuffle, init, validate, $, protoCode, mapEq, Onion3, write, TcpOnion3, concat, TranscoderP2P, PeerInfo, AddressInfo, ConnectionTrackerName, TranscoderIP6, write, EnvelopeError, encode, newLPStreamRemoteClosedError, MaPatResult, Direction, InvalidVarintError, shortLog, items, ==, init, write, getBytes, write, init, PublicKey, WebSockets_IP, writeLp, writePBVarint, ProtoFieldKind, readExactly, protoArgument, getRepeatedField, ProtoError, newLPStreamConnDownError, write, initStream, getField, MultiAddress, finish, ivOpenArray, closeWithEOF, TimeoutHandler, orError, decodeExchange, getField, LPStreamRemoteClosedError, setupStreamTracker, MaInvalidAddress, LPStreamClosedError, RsaDefaultKeySize, write, getOrder, TranscoderUnix, SignedPeerRecord, join, writeVarint