From 17f6962a0be5d16bff964f34f627f94f46ff9f42 Mon Sep 17 00:00:00 2001 From: "aegir[bot]" Date: Fri, 13 Sep 2024 17:18:15 +0000 Subject: [PATCH] docs: update documentation [skip ci] --- classes/_libp2p_floodsub.FloodSub.html | 18 ++--- classes/_libp2p_interface.AbortError.html | 4 +- ..._libp2p_interface.AlreadyStartedError.html | 4 +- ...ibp2p_interface.ConnectionClosedError.html | 4 +- ...bp2p_interface.ConnectionClosingError.html | 4 +- ...ibp2p_interface.ConnectionFailedError.html | 4 +- classes/_libp2p_interface.DialError.html | 4 +- .../_libp2p_interface.InvalidCIDError.html | 4 +- ..._interface.InvalidCryptoExchangeError.html | 4 +- ..._libp2p_interface.InvalidMessageError.html | 4 +- ...ibp2p_interface.InvalidMultiaddrError.html | 4 +- ...ibp2p_interface.InvalidMultihashError.html | 4 +- ...bp2p_interface.InvalidParametersError.html | 4 +- .../_libp2p_interface.InvalidPeerIdError.html | 4 +- ...bp2p_interface.InvalidPrivateKeyError.html | 4 +- ...ibp2p_interface.InvalidPublicKeyError.html | 4 +- ...bp2p_interface.LimitedConnectionError.html | 4 +- classes/_libp2p_interface.ListenError.html | 4 +- .../_libp2p_interface.MuxerClosedError.html | 4 +- classes/_libp2p_interface.NotFoundError.html | 4 +- .../_libp2p_interface.NotStartedError.html | 4 +- classes/_libp2p_interface.ProtocolError.html | 4 +- .../_libp2p_interface.StreamResetError.html | 4 +- .../_libp2p_interface.StreamStateError.html | 4 +- classes/_libp2p_interface.TimeoutError.html | 4 +- ...ce.TooManyInboundProtocolStreamsError.html | 4 +- ...e.TooManyOutboundProtocolStreamsError.html | 4 +- .../_libp2p_interface.TypedEventEmitter.html | 6 +- ..._libp2p_interface.UnexpectedPeerError.html | 4 +- ...p2p_interface.UnsupportedKeyTypeError.html | 4 +- ...p_interface.UnsupportedOperationError.html | 4 +- ...2p_interface.UnsupportedProtocolError.html | 4 +- .../_libp2p_peer_collections.PeerFilter.html | 4 +- .../_libp2p_peer_collections.PeerList.html | 4 +- classes/_libp2p_peer_collections.PeerMap.html | 4 +- classes/_libp2p_peer_collections.PeerSet.html | 4 +- classes/_libp2p_peer_record.PeerRecord.html | 10 +-- .../_libp2p_peer_record.RecordEnvelope.html | 16 ++--- ...libp2p_peer_store.PersistentPeerStore.html | 22 +++--- ...ibp2p_pubsub.index.PubSubBaseProtocol.html | 72 +++++++++---------- ...ibp2p_pubsub.peer_streams.PeerStreams.html | 26 +++---- classes/_libp2p_record.Libp2pRecord.html | 10 +-- classes/_libp2p_upnp_nat.NatAPI.html | 4 +- ..._utils.abstract_stream.AbstractStream.html | 52 +++++++------- ...tils.adaptive_timeout.AdaptiveTimeout.html | 4 +- .../_libp2p_utils.filters.BloomFilter.html | 10 +-- .../_libp2p_utils.filters.CuckooFilter.html | 4 +- ...2p_utils.filters.ScalableCuckooFilter.html | 4 +- ...2p_utils.moving_average.MovingAverage.html | 4 +- .../_libp2p_utils.peer_queue.PeerQueue.html | 26 +++---- ...2p_utils.priority_queue.PriorityQueue.html | 24 +++---- classes/_libp2p_utils.queue.Queue.html | 26 +++---- ...libp2p_utils.rate_limiter.RateLimiter.html | 6 +- enums/_libp2p_interface.FaultTolerance.html | 6 +- ...libp2p_interface.TopicValidatorResult.html | 8 +-- enums/_libp2p_kad_dht.EventTypes.html | 4 +- enums/_libp2p_kad_dht.MessageType-1.html | 4 +- functions/_libp2p_autonat.autoNAT.html | 2 +- functions/_libp2p_bootstrap.bootstrap.html | 2 +- ...p_circuit_relay_v2.circuitRelayServer.html | 2 +- ...ircuit_relay_v2.circuitRelayTransport.html | 2 +- functions/_libp2p_crypto.hmac.create.html | 2 +- functions/_libp2p_crypto.index.pbkdf2.html | 2 +- .../_libp2p_crypto.index.randomBytes.html | 2 +- ..._crypto.keys.generateEphemeralKeyPair.html | 2 +- .../_libp2p_crypto.keys.generateKeyPair.html | 2 +- ...p_crypto.keys.generateKeyPairFromSeed.html | 2 +- .../_libp2p_crypto.keys.keyStretcher.html | 2 +- ...2p_crypto.keys.privateKeyFromProtobuf.html | 2 +- ..._libp2p_crypto.keys.privateKeyFromRaw.html | 2 +- ...bp2p_crypto.keys.privateKeyToProtobuf.html | 2 +- ...2p_crypto.keys.publicKeyFromMultihash.html | 2 +- ...p2p_crypto.keys.publicKeyFromProtobuf.html | 2 +- .../_libp2p_crypto.keys.publicKeyFromRaw.html | 2 +- ...ibp2p_crypto.keys.publicKeyToProtobuf.html | 2 +- functions/_libp2p_dcutr.dcutr.html | 2 +- ...bp2p_devtools_metrics.devToolsMetrics.html | 2 +- functions/_libp2p_echo.echo-1.html | 2 +- functions/_libp2p_fetch.fetch-1.html | 2 +- functions/_libp2p_floodsub.floodsub-1.html | 2 +- functions/_libp2p_identify.identify-1.html | 2 +- .../_libp2p_identify.identifyPush-1.html | 2 +- functions/_libp2p_interface.isConnection.html | 2 +- functions/_libp2p_interface.isPeerId.html | 2 +- functions/_libp2p_interface.isPrivateKey.html | 2 +- functions/_libp2p_interface.isPublicKey.html | 2 +- functions/_libp2p_interface.isStartable.html | 2 +- functions/_libp2p_interface.isTransport.html | 2 +- .../_libp2p_interface.setMaxListeners.html | 2 +- functions/_libp2p_interface.start.html | 2 +- functions/_libp2p_interface.stop.html | 2 +- ...e_compliance_tests.connection.default.html | 2 +- ...e_tests.connection_encryption.default.html | 2 +- ...iance_tests.is_valid_tick.isValidTick.html | 2 +- ...pliance_tests.matchers.matchMultiaddr.html | 2 +- ...compliance_tests.matchers.matchPeerId.html | 2 +- ...compliance_tests.mocks.connectionPair.html | 2 +- ...compliance_tests.mocks.mockConnection.html | 2 +- ...iance_tests.mocks.mockConnectionGater.html | 2 +- ...nce_tests.mocks.mockConnectionManager.html | 2 +- ...ace_compliance_tests.mocks.mockDuplex.html | 2 +- ...ce_compliance_tests.mocks.mockMetrics.html | 2 +- ...nce_tests.mocks.mockMultiaddrConnPair.html | 2 +- ...e_tests.mocks.mockMultiaddrConnection.html | 2 +- ...face_compliance_tests.mocks.mockMuxer.html | 2 +- ..._compliance_tests.mocks.mockRegistrar.html | 2 +- ...ace_compliance_tests.mocks.mockStream.html | 2 +- ...e_compliance_tests.mocks.mockUpgrader.html | 2 +- ...ace_compliance_tests.mocks.streamPair.html | 2 +- ...mpliance_tests.peer_discovery.default.html | 2 +- ...rface_compliance_tests.pubsub.default.html | 2 +- ...compliance_tests.stream_muxer.default.html | 2 +- ...ce_compliance_tests.transport.default.html | 2 +- .../_libp2p_kad_dht.MessageType.codec.html | 2 +- functions/_libp2p_kad_dht.kadDHT-1.html | 2 +- .../_libp2p_kad_dht.passthroughMapper.html | 2 +- ..._kad_dht.removePrivateAddressesMapper.html | 2 +- ...p_kad_dht.removePublicAddressesMapper.html | 2 +- functions/_libp2p_keychain.keychain-1.html | 2 +- functions/_libp2p_logger.defaultLogger.html | 2 +- functions/_libp2p_logger.disable.html | 2 +- functions/_libp2p_logger.enable.html | 2 +- functions/_libp2p_logger.enabled.html | 2 +- functions/_libp2p_logger.logger-1.html | 2 +- functions/_libp2p_logger.peerLogger.html | 2 +- functions/_libp2p_logger.prefixLogger.html | 2 +- functions/_libp2p_mdns.mdns.html | 2 +- functions/_libp2p_mplex.mplex.html | 2 +- .../_libp2p_multistream_select.handle.html | 2 +- .../_libp2p_multistream_select.select.html | 2 +- ..._libp2p_peer_collections.peerFilter-1.html | 2 +- .../_libp2p_peer_collections.peerList-1.html | 2 +- .../_libp2p_peer_collections.peerMap-1.html | 2 +- .../_libp2p_peer_collections.peerSet-1.html | 2 +- ...bp2p_peer_collections.trackedPeerList.html | 2 +- ...ibp2p_peer_collections.trackedPeerMap.html | 2 +- ...ibp2p_peer_collections.trackedPeerSet.html | 2 +- functions/_libp2p_peer_id.peerIdFromCID.html | 2 +- .../_libp2p_peer_id.peerIdFromMultihash.html | 2 +- .../_libp2p_peer_id.peerIdFromPrivateKey.html | 2 +- .../_libp2p_peer_id.peerIdFromPublicKey.html | 2 +- .../_libp2p_peer_id.peerIdFromString.html | 2 +- functions/_libp2p_perf.perf-1.html | 2 +- functions/_libp2p_ping.ping.html | 2 +- functions/_libp2p_plaintext.plaintext.html | 2 +- functions/_libp2p_pnet.generateKey.html | 2 +- functions/_libp2p_pnet.preSharedKey.html | 2 +- ..._prometheus_metrics.prometheusMetrics.html | 2 +- functions/_libp2p_pubsub.utils.anyMatch.html | 2 +- .../_libp2p_pubsub.utils.bigIntFromBytes.html | 2 +- .../_libp2p_pubsub.utils.bigIntToBytes.html | 2 +- .../_libp2p_pubsub.utils.ensureArray.html | 2 +- functions/_libp2p_pubsub.utils.msgId.html | 2 +- .../_libp2p_pubsub.utils.noSignMsgId.html | 2 +- .../_libp2p_pubsub.utils.randomSeqno.html | 2 +- functions/_libp2p_pubsub.utils.toMessage.html | 2 +- .../_libp2p_pubsub.utils.toRpcMessage.html | 2 +- .../_libp2p_simple_metrics.simpleMetrics.html | 2 +- functions/_libp2p_tcp.tcp.html | 2 +- functions/_libp2p_tls.tls.html | 2 +- functions/_libp2p_upnp_nat.uPnPNAT-1.html | 2 +- ...ls.abort_options.createTimeoutOptions.html | 2 +- ....address_sort.certifiedAddressesFirst.html | 2 +- ...ddress_sort.circuitRelayAddressesLast.html | 2 +- ...utils.address_sort.defaultAddressSort.html | 2 +- ...ils.address_sort.publicAddressesFirst.html | 2 +- ...libp2p_utils.array_equals.arrayEquals.html | 2 +- ...s.close.safelyCloseConnectionIfUnused.html | 2 +- ..._libp2p_utils.close.safelyCloseStream.html | 2 +- ...libp2p_utils.close_source.closeSource.html | 2 +- ...ibp2p_utils.filters.createBloomFilter.html | 2 +- ...bp2p_utils.filters.createCuckooFilter.html | 2 +- ...ls.filters.createScalableCuckooFilter.html | 2 +- ...p_port_to_multiaddr.ipPortToMultiaddr.html | 2 +- .../_libp2p_utils.is_promise.isPromise.html | 2 +- ...tils.multiaddr_is_loopback.isLoopback.html | 2 +- ..._utils.multiaddr_is_private.isPrivate.html | 2 +- .../_libp2p_utils.private_ip.isPrivateIp.html | 2 +- ...tream_to_ma_conn.streamToMaConnection.html | 2 +- ...libp2p_utils.tracked_list.trackedList.html | 2 +- .../_libp2p_utils.tracked_map.trackedMap.html | 2 +- functions/_libp2p_webrtc.webRTC.html | 2 +- functions/_libp2p_webrtc.webRTCDirect.html | 2 +- functions/_libp2p_websockets.filters.all.html | 2 +- ..._libp2p_websockets.filters.dnsWsOrWss.html | 2 +- .../_libp2p_websockets.filters.dnsWss.html | 2 +- functions/_libp2p_websockets.filters.wss.html | 2 +- .../_libp2p_websockets.index.webSockets.html | 2 +- .../_libp2p_webtransport.webTransport.html | 2 +- functions/libp2p.index.createLibp2p.html | 2 +- .../_libp2p_autonat.AutoNATComponents.html | 4 +- .../_libp2p_autonat.AutoNATServiceInit.html | 14 ++-- ..._libp2p_bootstrap.BootstrapComponents.html | 4 +- .../_libp2p_bootstrap.BootstrapInit.html | 12 ++-- ..._circuit_relay_v2.CircuitRelayService.html | 4 +- ...it_relay_v2.CircuitRelayServiceEvents.html | 4 +- ...p2p_circuit_relay_v2.RelayReservation.html | 4 +- interfaces/_libp2p_crypto.hmac.HMAC.html | 4 +- .../_libp2p_dcutr.DCUtRServiceComponents.html | 4 +- .../_libp2p_dcutr.DCUtRServiceInit.html | 10 +-- .../_libp2p_devtools_metrics.Address.html | 8 +-- ...vtools_metrics.CopyToClipboardMessage.html | 4 +- ...ibp2p_devtools_metrics.DevToolsEvents.html | 8 +-- ...ols_metrics.DevToolsMetricsComponents.html | 4 +- ..._devtools_metrics.DevToolsMetricsInit.html | 4 +- .../_libp2p_devtools_metrics.DevToolsRPC.html | 4 +- .../_libp2p_devtools_metrics.MetricsRPC.html | 14 ++-- .../_libp2p_devtools_metrics.NodeAddress.html | 4 +- .../_libp2p_devtools_metrics.NodeStatus.html | 4 +- ...2p_devtools_metrics.PageLoadedMessage.html | 4 +- interfaces/_libp2p_devtools_metrics.Peer.html | 12 ++-- .../_libp2p_devtools_metrics.PeerAddress.html | 4 +- ...tools_metrics.PermissionsErrorMessage.html | 4 +- .../_libp2p_devtools_metrics.RPCMessage.html | 4 +- interfaces/_libp2p_echo.Echo.html | 4 +- interfaces/_libp2p_echo.EchoComponents.html | 4 +- interfaces/_libp2p_echo.EchoInit.html | 4 +- interfaces/_libp2p_fetch.Fetch.html | 8 +-- interfaces/_libp2p_fetch.FetchComponents.html | 4 +- interfaces/_libp2p_fetch.FetchInit.html | 6 +- interfaces/_libp2p_fetch.LookupFunction.html | 2 +- .../_libp2p_floodsub.FloodSubComponents.html | 2 +- interfaces/_libp2p_floodsub.FloodSubInit.html | 4 +- interfaces/_libp2p_identify.Identify.html | 4 +- .../_libp2p_identify.IdentifyComponents.html | 4 +- interfaces/_libp2p_identify.IdentifyInit.html | 20 +++--- interfaces/_libp2p_identify.IdentifyPush.html | 4 +- ...ibp2p_identify.IdentifyPushComponents.html | 4 +- .../_libp2p_identify.IdentifyPushInit.html | 22 +++--- .../_libp2p_interface.AbortOptions.html | 4 +- interfaces/_libp2p_interface.Address.html | 6 +- .../_libp2p_interface.AddressSorter.html | 2 +- ...p2p_interface.CalculatedMetricOptions.html | 8 +-- .../_libp2p_interface.ComponentLogger.html | 4 +- interfaces/_libp2p_interface.Connection.html | 34 ++++----- ..._libp2p_interface.ConnectionEncrypter.html | 8 +-- .../_libp2p_interface.ConnectionGater.html | 26 +++---- .../_libp2p_interface.ConnectionHandler.html | 2 +- .../_libp2p_interface.ConnectionLimits.html | 6 +- ..._libp2p_interface.ConnectionProtector.html | 4 +- .../_libp2p_interface.ConnectionTimeline.html | 8 +-- .../_libp2p_interface.ContentRouting.html | 10 +-- ...bp2p_interface.ContentRoutingProvider.html | 4 +- interfaces/_libp2p_interface.Counter.html | 6 +- .../_libp2p_interface.CounterGroup.html | 6 +- ...ibp2p_interface.CreateListenerOptions.html | 4 +- interfaces/_libp2p_interface.DialOptions.html | 4 +- ..._libp2p_interface.DialProtocolOptions.html | 8 +-- ...libp2p_interface.DialTransportOptions.html | 4 +- .../_libp2p_interface.Ed25519PeerId.html | 12 ++-- .../_libp2p_interface.Ed25519PrivateKey.html | 12 ++-- .../_libp2p_interface.Ed25519PublicKey.html | 16 ++--- interfaces/_libp2p_interface.Envelope.html | 4 +- .../_libp2p_interface.EventCallback.html | 2 +- interfaces/_libp2p_interface.EventObject.html | 4 +- .../_libp2p_interface.IdentifyResult.html | 20 +++--- .../_libp2p_interface.IncomingStreamData.html | 4 +- .../_libp2p_interface.IsDialableOptions.html | 4 +- interfaces/_libp2p_interface.Libp2p.html | 58 +++++++-------- .../_libp2p_interface.Libp2pEvents.html | 28 ++++---- interfaces/_libp2p_interface.Listener.html | 10 +-- .../_libp2p_interface.ListenerEvents.html | 4 +- interfaces/_libp2p_interface.Logger.html | 4 +- .../_libp2p_interface.LoggerOptions.html | 4 +- interfaces/_libp2p_interface.Metric.html | 12 ++-- interfaces/_libp2p_interface.MetricGroup.html | 12 ++-- .../_libp2p_interface.MetricOptions.html | 6 +- interfaces/_libp2p_interface.Metrics.html | 14 ++-- ..._libp2p_interface.MultiaddrConnection.html | 12 ++-- ...interface.MultiaddrConnectionTimeline.html | 8 +-- .../_libp2p_interface.MultiaddrFilter.html | 2 +- .../_libp2p_interface.NewStreamOptions.html | 8 +-- interfaces/_libp2p_interface.NodeInfo.html | 6 +- interfaces/_libp2p_interface.Peer.html | 14 ++-- interfaces/_libp2p_interface.PeerData.html | 16 ++--- .../_libp2p_interface.PeerDiscovery.html | 6 +- ..._libp2p_interface.PeerDiscoveryEvents.html | 4 +- ...ibp2p_interface.PeerDiscoveryProvider.html | 4 +- interfaces/_libp2p_interface.PeerInfo.html | 6 +- interfaces/_libp2p_interface.PeerQuery.html | 4 +- .../_libp2p_interface.PeerQueryFilter.html | 2 +- .../_libp2p_interface.PeerQueryOrder.html | 2 +- interfaces/_libp2p_interface.PeerRouting.html | 6 +- ..._libp2p_interface.PeerRoutingProvider.html | 4 +- interfaces/_libp2p_interface.PeerStore.html | 20 +++--- .../_libp2p_interface.PeerStreamEvents.html | 4 +- interfaces/_libp2p_interface.PeerStreams.html | 6 +- interfaces/_libp2p_interface.PeerUpdate.html | 4 +- interfaces/_libp2p_interface.PendingDial.html | 10 +-- interfaces/_libp2p_interface.PubSub.html | 20 +++--- .../_libp2p_interface.PubSubEvents.html | 4 +- interfaces/_libp2p_interface.PubSubInit.html | 14 ++-- interfaces/_libp2p_interface.PubSubRPC.html | 4 +- .../_libp2p_interface.PubSubRPCMessage.html | 4 +- ...ibp2p_interface.PubSubRPCSubscription.html | 4 +- .../_libp2p_interface.PublishResult.html | 4 +- interfaces/_libp2p_interface.RSAPeerId.html | 12 ++-- .../_libp2p_interface.RSAPrivateKey.html | 12 ++-- .../_libp2p_interface.RSAPublicKey.html | 16 ++--- interfaces/_libp2p_interface.Record.html | 10 +-- .../_libp2p_interface.RoutingOptions.html | 8 +-- .../_libp2p_interface.Secp256k1PeerId.html | 12 ++-- ..._libp2p_interface.Secp256k1PrivateKey.html | 12 ++-- .../_libp2p_interface.Secp256k1PublicKey.html | 16 ++--- ...p2p_interface.SecureConnectionOptions.html | 4 +- .../_libp2p_interface.SecuredConnection.html | 4 +- .../_libp2p_interface.SignedMessage.html | 4 +- .../_libp2p_interface.SignedPeerRecord.html | 4 +- interfaces/_libp2p_interface.Startable.html | 14 ++-- interfaces/_libp2p_interface.StopTimer.html | 2 +- interfaces/_libp2p_interface.Stream.html | 28 ++++---- .../_libp2p_interface.StreamHandler.html | 2 +- ...libp2p_interface.StreamHandlerOptions.html | 8 +-- ..._libp2p_interface.StreamHandlerRecord.html | 4 +- interfaces/_libp2p_interface.StreamMuxer.html | 12 ++-- .../_libp2p_interface.StreamMuxerFactory.html | 6 +- .../_libp2p_interface.StreamMuxerInit.html | 8 +-- .../_libp2p_interface.StreamTimeline.html | 14 ++-- ...bp2p_interface.SubscriptionChangeData.html | 4 +- interfaces/_libp2p_interface.Tag.html | 4 +- interfaces/_libp2p_interface.TagOptions.html | 6 +- .../_libp2p_interface.TopicValidatorFn.html | 2 +- interfaces/_libp2p_interface.Topology.html | 10 +-- .../_libp2p_interface.TopologyFilter.html | 4 +- interfaces/_libp2p_interface.Transport.html | 14 ++-- .../_libp2p_interface.TypedEventTarget.html | 6 +- interfaces/_libp2p_interface.URLPeerId.html | 12 ++-- .../_libp2p_interface.UnsignedMessage.html | 4 +- interfaces/_libp2p_interface.Upgrader.html | 6 +- .../_libp2p_interface.UpgraderOptions.html | 4 +- ...cryption.ConnectionEncrypterSetupArgs.html | 4 +- ...face_compliance_tests.index.TestSetup.html | 4 +- ...nce_tests.mocks.MockNetworkComponents.html | 4 +- ...mpliance_tests.mocks.MockUpgraderInit.html | 4 +- ...ce_compliance_tests.pubsub.PubSubArgs.html | 4 +- ...pliance_tests.pubsub.PubSubComponents.html | 4 +- ..._compliance_tests.transport.Connector.html | 4 +- ...tests.transport.TransportTestFixtures.html | 4 +- ...p2p_interface_internal.AddressManager.html | 16 ++--- ..._interface_internal.ConnectionManager.html | 18 ++--- .../_libp2p_interface_internal.Envelope.html | 4 +- ...interface_internal.IncomingStreamData.html | 6 +- ...erface_internal.OpenConnectionOptions.html | 6 +- ..._libp2p_interface_internal.RandomWalk.html | 4 +- .../_libp2p_interface_internal.Record.html | 10 +-- .../_libp2p_interface_internal.Registrar.html | 16 ++--- ...bp2p_interface_internal.StreamHandler.html | 2 +- ...terface_internal.StreamHandlerOptions.html | 8 +-- ...nterface_internal.StreamHandlerRecord.html | 6 +- ...p_interface_internal.TransportManager.html | 22 +++--- ..._internal.TransportManagerDialOptions.html | 2 +- interfaces/_libp2p_kad_dht.AddPeerEvent.html | 4 +- interfaces/_libp2p_kad_dht.DHTRecord.html | 4 +- interfaces/_libp2p_kad_dht.DialPeerEvent.html | 4 +- .../_libp2p_kad_dht.FinalPeerEvent.html | 4 +- interfaces/_libp2p_kad_dht.KadDHT.html | 20 +++--- .../_libp2p_kad_dht.KadDHTComponents.html | 4 +- interfaces/_libp2p_kad_dht.KadDHTInit.html | 38 +++++----- .../_libp2p_kad_dht.PeerInfoMapper.html | 2 +- .../_libp2p_kad_dht.PeerResponseEvent.html | 4 +- interfaces/_libp2p_kad_dht.ProviderEvent.html | 4 +- .../_libp2p_kad_dht.QueryErrorEvent.html | 4 +- interfaces/_libp2p_kad_dht.RoutingTable.html | 4 +- interfaces/_libp2p_kad_dht.SelectFn.html | 2 +- .../_libp2p_kad_dht.SendQueryEvent.html | 4 +- interfaces/_libp2p_kad_dht.SingleKadDHT.html | 22 +++--- interfaces/_libp2p_kad_dht.ValidateFn.html | 2 +- interfaces/_libp2p_kad_dht.ValueEvent.html | 4 +- interfaces/_libp2p_keychain.DEKConfig.html | 4 +- interfaces/_libp2p_keychain.KeyInfo.html | 6 +- interfaces/_libp2p_keychain.Keychain.html | 18 ++--- .../_libp2p_keychain.KeychainComponents.html | 4 +- interfaces/_libp2p_keychain.KeychainInit.html | 4 +- .../_libp2p_logger.ComponentLogger.html | 4 +- interfaces/_libp2p_logger.Logger.html | 4 +- .../_libp2p_logger.PeerLoggerOptions.html | 4 +- interfaces/_libp2p_mplex.MplexInit.html | 14 ++-- ...tistream_select.MultistreamSelectInit.html | 4 +- ...p2p_multistream_select.ProtocolStream.html | 4 +- .../_libp2p_peer_record.PeerRecordInit.html | 6 +- ...libp2p_peer_record.RecordEnvelopeInit.html | 4 +- .../_libp2p_peer_store.AddressFilter.html | 2 +- ...r_store.PersistentPeerStoreComponents.html | 4 +- ...2p_peer_store.PersistentPeerStoreInit.html | 4 +- interfaces/_libp2p_perf.Perf.html | 4 +- interfaces/_libp2p_perf.PerfComponents.html | 4 +- interfaces/_libp2p_perf.PerfInit.html | 6 +- interfaces/_libp2p_perf.PerfOptions.html | 4 +- interfaces/_libp2p_perf.PerfOutput.html | 4 +- interfaces/_libp2p_ping.PingService.html | 4 +- .../_libp2p_ping.PingServiceComponents.html | 4 +- interfaces/_libp2p_ping.PingServiceInit.html | 6 +- ..._libp2p_plaintext.PlaintextComponents.html | 4 +- .../_libp2p_pnet.ProtectorComponents.html | 4 +- interfaces/_libp2p_pnet.ProtectorInit.html | 6 +- ...ics.PrometheusCalculatedMetricOptions.html | 4 +- ...s_metrics.PrometheusMetricsComponents.html | 4 +- ...metheus_metrics.PrometheusMetricsInit.html | 10 +-- ..._libp2p_pubsub.index.PubSubComponents.html | 4 +- ...ub.peer_streams.PeerStreamsComponents.html | 4 +- ...p_pubsub.peer_streams.PeerStreamsInit.html | 4 +- .../_libp2p_simple_metrics.OnMetrics.html | 2 +- ...bp2p_simple_metrics.SimpleMetricsInit.html | 6 +- interfaces/_libp2p_tcp.TCPComponents.html | 4 +- .../_libp2p_tcp.TCPCreateListenerOptions.html | 10 +-- interfaces/_libp2p_tcp.TCPDialOptions.html | 10 +-- interfaces/_libp2p_tcp.TCPMetrics.html | 4 +- interfaces/_libp2p_tcp.TCPOptions.html | 18 ++--- interfaces/_libp2p_tcp.TCPSocketOptions.html | 10 +-- interfaces/_libp2p_tls.TLSComponents.html | 4 +- .../_libp2p_upnp_nat.MapPortOptions.html | 4 +- interfaces/_libp2p_upnp_nat.PMPOptions.html | 4 +- interfaces/_libp2p_upnp_nat.UPnPNAT.html | 4 +- .../_libp2p_upnp_nat.UPnPNATComponents.html | 4 +- interfaces/_libp2p_upnp_nat.UPnPNATInit.html | 14 ++-- ...ls.abstract_stream.AbstractStreamInit.html | 24 +++---- ....adaptive_timeout.AdaptiveTimeoutInit.html | 4 +- ...daptive_timeout.AdaptiveTimeoutSignal.html | 4 +- ...ptive_timeout.GetTimeoutSignalOptions.html | 4 +- ...ls.close.SafelyCloseConnectionOptions.html | 4 +- ...bp2p_utils.filters.BloomFilterOptions.html | 4 +- ...libp2p_utils.filters.CuckooFilterInit.html | 12 ++-- interfaces/_libp2p_utils.filters.Filter.html | 4 +- ...tils.filters.ScalableCuckooFilterInit.html | 14 ++-- ..._utils.peer_queue.PeerQueueJobOptions.html | 4 +- ...riority_queue.PriorityQueueJobOptions.html | 4 +- .../_libp2p_utils.queue.Comparator.html | 2 +- .../_libp2p_utils.queue.JobMatcher.html | 2 +- .../_libp2p_utils.queue.QueueEvents.html | 20 +++--- interfaces/_libp2p_utils.queue.QueueInit.html | 10 +-- .../_libp2p_utils.queue.QueueJobFailure.html | 4 +- .../_libp2p_utils.queue.QueueJobSuccess.html | 4 +- .../_libp2p_utils.queue.RunFunction.html | 2 +- ...rate_limiter.GetKeySecDurationOptions.html | 4 +- ...2p_utils.rate_limiter.RateLimiterInit.html | 14 ++-- ..._utils.rate_limiter.RateLimiterResult.html | 4 +- ..._libp2p_utils.rate_limiter.RateRecord.html | 4 +- ...ls.stream_to_ma_conn.StreamProperties.html | 8 +-- ...ls.tracked_list.CreateTrackedListInit.html | 6 +- ...tils.tracked_map.CreateTrackedMapInit.html | 6 +- ...bp2p_utils.tracked_map.TrackedMapInit.html | 4 +- .../_libp2p_webrtc.DataChannelOptions.html | 14 ++-- ...websockets.index.WebSocketsComponents.html | 4 +- ...ibp2p_websockets.index.WebSocketsInit.html | 4 +- ...2p_websockets.index.WebSocketsMetrics.html | 4 +- ..._webtransport.WebTransportCertificate.html | 4 +- ...p_webtransport.WebTransportComponents.html | 4 +- ..._libp2p_webtransport.WebTransportInit.html | 4 +- ...bp2p_webtransport.WebTransportMetrics.html | 4 +- interfaces/libp2p.index.Libp2pInit.html | 42 +++++------ modules/_libp2p_crypto.hmac.html | 2 +- modules/_libp2p_crypto.index.html | 2 +- modules/_libp2p_crypto.keys.html | 2 +- ...interface_compliance_tests.connection.html | 2 +- ...ompliance_tests.connection_encryption.html | 2 +- ...bp2p_interface_compliance_tests.index.html | 2 +- ...erface_compliance_tests.is_valid_tick.html | 2 +- ...p_interface_compliance_tests.matchers.html | 2 +- ...bp2p_interface_compliance_tests.mocks.html | 2 +- ...rface_compliance_tests.peer_discovery.html | 2 +- ...p2p_interface_compliance_tests.pubsub.html | 2 +- ...terface_compliance_tests.stream_muxer.html | 2 +- ..._interface_compliance_tests.transport.html | 2 +- modules/_libp2p_kad_dht.MessageType.html | 2 +- modules/_libp2p_pubsub.index.html | 2 +- modules/_libp2p_pubsub.peer_streams.html | 2 +- modules/_libp2p_pubsub.utils.html | 2 +- modules/_libp2p_utils.abort_options.html | 2 +- modules/_libp2p_utils.abstract_stream.html | 2 +- modules/_libp2p_utils.adaptive_timeout.html | 2 +- modules/_libp2p_utils.address_sort.html | 2 +- modules/_libp2p_utils.array_equals.html | 2 +- modules/_libp2p_utils.close.html | 2 +- modules/_libp2p_utils.close_source.html | 2 +- modules/_libp2p_utils.filters.html | 2 +- modules/_libp2p_utils.index.html | 2 +- .../_libp2p_utils.ip_port_to_multiaddr.html | 2 +- modules/_libp2p_utils.is_promise.html | 2 +- modules/_libp2p_utils.moving_average.html | 2 +- .../_libp2p_utils.multiaddr_is_loopback.html | 2 +- .../_libp2p_utils.multiaddr_is_private.html | 2 +- modules/_libp2p_utils.peer_queue.html | 2 +- modules/_libp2p_utils.priority_queue.html | 2 +- modules/_libp2p_utils.private_ip.html | 2 +- modules/_libp2p_utils.queue.html | 2 +- modules/_libp2p_utils.rate_limiter.html | 2 +- modules/_libp2p_utils.stream_to_ma_conn.html | 2 +- modules/_libp2p_utils.tracked_list.html | 2 +- modules/_libp2p_utils.tracked_map.html | 2 +- modules/_libp2p_websockets.filters.html | 2 +- modules/_libp2p_websockets.index.html | 2 +- modules/libp2p.index.html | 2 +- modules/libp2p.version.html | 2 +- ...p_devtools_metrics.ApplicationMessage.html | 2 +- ...bp2p_devtools_metrics.DevToolsMessage.html | 2 +- ...libp2p_devtools_metrics.WorkerMessage.html | 2 +- types/_libp2p_interface.CalculateMetric.html | 2 +- types/_libp2p_interface.ConnectionStatus.html | 2 +- types/_libp2p_interface.Direction.html | 2 +- types/_libp2p_interface.EventHandler.html | 2 +- ...erface.InboundConnectionUpgradeEvents.html | 2 +- types/_libp2p_interface.KeyType.html | 2 +- types/_libp2p_interface.Libp2pStatus.html | 2 +- types/_libp2p_interface.Message.html | 2 +- ...nterface.OpenConnectionProgressEvents.html | 2 +- ...rface.OutboundConnectionUpgradeEvents.html | 2 +- types/_libp2p_interface.PeerId.html | 2 +- types/_libp2p_interface.PeerIdType.html | 2 +- .../_libp2p_interface.PendingDialStatus.html | 2 +- types/_libp2p_interface.PrivateKey.html | 2 +- types/_libp2p_interface.PublicKey.html | 2 +- types/_libp2p_interface.ReadStatus.html | 2 +- types/_libp2p_interface.ServiceMap.html | 2 +- types/_libp2p_interface.SignaturePolicy.html | 2 +- types/_libp2p_interface.StreamStatus.html | 2 +- ...ce.TransportManagerDialProgressEvents.html | 2 +- types/_libp2p_interface.WriteStatus.html | 2 +- types/_libp2p_kad_dht.DHTProgressEvents.html | 2 +- types/_libp2p_kad_dht.MessageName.html | 2 +- types/_libp2p_kad_dht.QueryEvent.html | 2 +- types/_libp2p_kad_dht.Selectors.html | 2 +- types/_libp2p_kad_dht.Validators.html | 2 +- types/_libp2p_tcp.TCPDialEvents.html | 2 +- types/_libp2p_utils.queue.JobStatus.html | 2 +- ...websockets.index.WebSocketsDialEvents.html | 2 +- ...p_webtransport.WebTransportDialEvents.html | 2 +- types/libp2p.index.Libp2pOptions.html | 2 +- types/libp2p.index.ServiceFactoryMap.html | 2 +- ...p_circuit_relay_v2.RELAY_V2_HOP_CODEC.html | 2 +- ..._circuit_relay_v2.RELAY_V2_STOP_CODEC.html | 2 +- variables/_libp2p_dcutr.multicodec.html | 2 +- ...s_metrics.LIBP2P_DEVTOOLS_METRICS_KEY.html | 2 +- ...evtools_metrics.SOURCE_CONTENT_SCRIPT.html | 2 +- ...bp2p_devtools_metrics.SOURCE_DEVTOOLS.html | 2 +- ...ibp2p_devtools_metrics.SOURCE_METRICS.html | 2 +- ...evtools_metrics.SOURCE_SERVICE_WORKER.html | 2 +- .../_libp2p_devtools_metrics.valueCodecs.html | 2 +- variables/_libp2p_floodsub.multicodec.html | 2 +- variables/_libp2p_interface.KEEP_ALIVE.html | 2 +- variables/_libp2p_interface.StrictNoSign.html | 2 +- variables/_libp2p_interface.StrictSign.html | 2 +- .../_libp2p_interface.connectionSymbol.html | 2 +- ...libp2p_interface.contentRoutingSymbol.html | 2 +- ..._libp2p_interface.peerDiscoverySymbol.html | 2 +- variables/_libp2p_interface.peerIdSymbol.html | 2 +- .../_libp2p_interface.peerRoutingSymbol.html | 2 +- ..._libp2p_interface.serviceCapabilities.html | 2 +- ..._libp2p_interface.serviceDependencies.html | 2 +- .../_libp2p_interface.transportSymbol.html | 2 +- ...ce_compliance_tests.mocks.mockNetwork.html | 2 +- ...libp2p_multistream_select.PROTOCOL_ID.html | 2 +- variables/_libp2p_ping.PING_PROTOCOL.html | 2 +- variables/_libp2p_tls.PROTOCOL.html | 2 +- ...ve_timeout.DEFAULT_FAILURE_MULTIPLIER.html | 2 +- ....adaptive_timeout.DEFAULT_MIN_TIMEOUT.html | 2 +- ...ve_timeout.DEFAULT_TIMEOUT_MULTIPLIER.html | 2 +- variables/libp2p.version.name.html | 2 +- variables/libp2p.version.version.html | 2 +- 558 files changed, 1457 insertions(+), 1457 deletions(-) diff --git a/classes/_libp2p_floodsub.FloodSub.html b/classes/_libp2p_floodsub.FloodSub.html index 522abab035..3dffaec767 100644 --- a/classes/_libp2p_floodsub.FloodSub.html +++ b/classes/_libp2p_floodsub.FloodSub.html @@ -1,7 +1,7 @@ FloodSub | libp2p

FloodSub (aka dumbsub is an implementation of pubsub focused on delivering an API for Publish/Subscribe, but with no CastTree Forming (it just floods the network).

-

Hierarchy (view full)

Constructors

Hierarchy (view full)

Constructors

Properties

#private: any
[serviceDependencies]: string[] = ...
[toStringTag]: "@libp2p/floodsub" = '@libp2p/floodsub'
canRelayMessage: boolean

If router can relay received messages, even if not subscribed

+

Constructors

Properties

#private: any
[serviceDependencies]: string[] = ...
[toStringTag]: "@libp2p/floodsub" = '@libp2p/floodsub'
canRelayMessage: boolean

If router can relay received messages, even if not subscribed

components: PubSubComponents
emitSelf: boolean

if publish should emit to self, if subscribed

enabled: boolean
globalSignaturePolicy: "StrictSign" | "StrictNoSign"

The signature policy to follow by default

log: Logger
multicodecs: string[]

A list of multicodecs that contain the pubsub protocol name.

Map of peer streams

-
seenCache: SimpleTimeCache<boolean>
started: boolean
subscriptions: Set<string>

List of our subscriptions

+
seenCache: SimpleTimeCache<boolean>
started: boolean
subscriptions: Set<string>

List of our subscriptions

topicValidators: Map<string, TopicValidatorFn>

Topic validator map

Keyed by topic Topic validators are functions with the following input:

@@ -72,24 +72,24 @@

Parameters

Returns boolean

  • Normalizes the message and signs it, if signing is enabled. Should be used by the routers to create the message to send.

    -

    Parameters

    • message: {
          data: Uint8Array;
          from: PeerId;
          sequenceNumber: bigint;
          topic: string;
      }

    Returns Promise<Message>

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    +

    Parameters

    • message: {
          data: Uint8Array;
          from: PeerId;
          sequenceNumber: bigint;
          topic: string;
      }

    Returns Promise<Message>

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    MDN Reference

    Parameters

    Returns boolean

  • Get a list of the peer-ids that are subscribed to one topic.

    Parameters

    • topic: string

    Returns PeerId[]

  • Get the list of topics which the peer is subscribed to.

    Returns string[]

  • Parameters

    • type: string

    Returns number

  • Send an rpc object to a peer

    Parameters

    • peer: PeerId
    • data: {
          messages?: Message[];
          subscribe?: boolean;
          subscriptions?: string[];
      }
      • Optional messages?: Message[]
      • Optional subscribe?: boolean
      • Optional subscriptions?: string[]

    Returns void

  • Unregister the pubsub protocol and the streams with other peers will be closed.

    diff --git a/classes/_libp2p_interface.AbortError.html b/classes/_libp2p_interface.AbortError.html index d13753f6b7..a9b8aa6ef3 100644 --- a/classes/_libp2p_interface.AbortError.html +++ b/classes/_libp2p_interface.AbortError.html @@ -1,7 +1,7 @@ AbortError | libp2p

    When this error is thrown it means an operation was aborted, usually in response to the abort event being emitted by an AbortSignal.

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'AbortError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'AbortError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.AlreadyStartedError.html b/classes/_libp2p_interface.AlreadyStartedError.html index ede55aafad..5eb1fb6810 100644 --- a/classes/_libp2p_interface.AlreadyStartedError.html +++ b/classes/_libp2p_interface.AlreadyStartedError.html @@ -1,5 +1,5 @@ AlreadyStartedError | libp2p

    Thrown when a component is started that has already been started

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'AlreadyStartedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'AlreadyStartedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.ConnectionClosedError.html b/classes/_libp2p_interface.ConnectionClosedError.html index b3d842117a..9646a7e177 100644 --- a/classes/_libp2p_interface.ConnectionClosedError.html +++ b/classes/_libp2p_interface.ConnectionClosedError.html @@ -1,5 +1,5 @@ ConnectionClosedError | libp2p

    Thrown when a connection is closed

    -

    Hierarchy

    • Error
      • ConnectionClosedError

    Constructors

    Hierarchy

    • Error
      • ConnectionClosedError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionClosedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionClosedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.ConnectionClosingError.html b/classes/_libp2p_interface.ConnectionClosingError.html index 7d8022794c..7f26302820 100644 --- a/classes/_libp2p_interface.ConnectionClosingError.html +++ b/classes/_libp2p_interface.ConnectionClosingError.html @@ -1,5 +1,5 @@ ConnectionClosingError | libp2p

    Thrown when a connection is closing

    -

    Hierarchy

    • Error
      • ConnectionClosingError

    Constructors

    Hierarchy

    • Error
      • ConnectionClosingError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionClosingError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionClosingError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.ConnectionFailedError.html b/classes/_libp2p_interface.ConnectionFailedError.html index 6718eb1308..1d31ec3435 100644 --- a/classes/_libp2p_interface.ConnectionFailedError.html +++ b/classes/_libp2p_interface.ConnectionFailedError.html @@ -1,5 +1,5 @@ ConnectionFailedError | libp2p

    Thrown when a connection fails

    -

    Hierarchy

    • Error
      • ConnectionFailedError

    Constructors

    Hierarchy

    • Error
      • ConnectionFailedError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionFailedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ConnectionFailedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.DialError.html b/classes/_libp2p_interface.DialError.html index d251b8838d..d0f13ccd85 100644 --- a/classes/_libp2p_interface.DialError.html +++ b/classes/_libp2p_interface.DialError.html @@ -1,5 +1,5 @@ DialError | libp2p

    Thrown when dialing an address failed

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'DialError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'DialError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidCIDError.html b/classes/_libp2p_interface.InvalidCIDError.html index 597fba168e..5f9d2038c5 100644 --- a/classes/_libp2p_interface.InvalidCIDError.html +++ b/classes/_libp2p_interface.InvalidCIDError.html @@ -1,5 +1,5 @@ InvalidCIDError | libp2p

    Thrown when an invalid CID is encountered

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidCIDError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidCIDError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidCryptoExchangeError.html b/classes/_libp2p_interface.InvalidCryptoExchangeError.html index 22c25981fc..a182e9ea9f 100644 --- a/classes/_libp2p_interface.InvalidCryptoExchangeError.html +++ b/classes/_libp2p_interface.InvalidCryptoExchangeError.html @@ -1,5 +1,5 @@ InvalidCryptoExchangeError | libp2p

    Thrown when a crypto exchange fails

    -

    Hierarchy

    • Error
      • InvalidCryptoExchangeError

    Constructors

    Hierarchy

    • Error
      • InvalidCryptoExchangeError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidCryptoExchangeError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidCryptoExchangeError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidMessageError.html b/classes/_libp2p_interface.InvalidMessageError.html index d00ef4ee23..cb005a2149 100644 --- a/classes/_libp2p_interface.InvalidMessageError.html +++ b/classes/_libp2p_interface.InvalidMessageError.html @@ -1,5 +1,5 @@ InvalidMessageError | libp2p

    An invalid or malformed message was encountered during a protocol exchange

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMessageError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMessageError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidMultiaddrError.html b/classes/_libp2p_interface.InvalidMultiaddrError.html index 3a12d6439b..1b443d52c0 100644 --- a/classes/_libp2p_interface.InvalidMultiaddrError.html +++ b/classes/_libp2p_interface.InvalidMultiaddrError.html @@ -1,5 +1,5 @@ InvalidMultiaddrError | libp2p

    Thrown when an invalid multiaddr is encountered

    -

    Hierarchy

    • Error
      • InvalidMultiaddrError

    Constructors

    Hierarchy

    • Error
      • InvalidMultiaddrError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMultiaddrError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMultiaddrError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidMultihashError.html b/classes/_libp2p_interface.InvalidMultihashError.html index e436d1aa26..728657ff84 100644 --- a/classes/_libp2p_interface.InvalidMultihashError.html +++ b/classes/_libp2p_interface.InvalidMultihashError.html @@ -1,5 +1,5 @@ InvalidMultihashError | libp2p

    Thrown when an invalid multihash is encountered

    -

    Hierarchy

    • Error
      • InvalidMultihashError

    Constructors

    Hierarchy

    • Error
      • InvalidMultihashError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMultihashError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidMultihashError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidParametersError.html b/classes/_libp2p_interface.InvalidParametersError.html index 99c9616bcf..98e0ac2b08 100644 --- a/classes/_libp2p_interface.InvalidParametersError.html +++ b/classes/_libp2p_interface.InvalidParametersError.html @@ -1,5 +1,5 @@ InvalidParametersError | libp2p

    Thrown when invalid parameters are passed to a function or method call

    -

    Hierarchy

    • Error
      • InvalidParametersError

    Constructors

    Hierarchy

    • Error
      • InvalidParametersError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidParametersError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidParametersError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidPeerIdError.html b/classes/_libp2p_interface.InvalidPeerIdError.html index c540e3a8c1..fb129070ab 100644 --- a/classes/_libp2p_interface.InvalidPeerIdError.html +++ b/classes/_libp2p_interface.InvalidPeerIdError.html @@ -1,5 +1,5 @@ InvalidPeerIdError | libp2p

    Thrown when an invalid peer ID is encountered

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPeerIdError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPeerIdError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidPrivateKeyError.html b/classes/_libp2p_interface.InvalidPrivateKeyError.html index 9040fcebff..55842eed10 100644 --- a/classes/_libp2p_interface.InvalidPrivateKeyError.html +++ b/classes/_libp2p_interface.InvalidPrivateKeyError.html @@ -1,5 +1,5 @@ InvalidPrivateKeyError | libp2p

    Thrown when a private key is invalid

    -

    Hierarchy

    • Error
      • InvalidPrivateKeyError

    Constructors

    Hierarchy

    • Error
      • InvalidPrivateKeyError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPrivateKeyError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPrivateKeyError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.InvalidPublicKeyError.html b/classes/_libp2p_interface.InvalidPublicKeyError.html index 24b3dffd7e..597a15bac0 100644 --- a/classes/_libp2p_interface.InvalidPublicKeyError.html +++ b/classes/_libp2p_interface.InvalidPublicKeyError.html @@ -1,5 +1,5 @@ InvalidPublicKeyError | libp2p

    Thrown when a public key is invalid

    -

    Hierarchy

    • Error
      • InvalidPublicKeyError

    Constructors

    Hierarchy

    • Error
      • InvalidPublicKeyError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPublicKeyError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'InvalidPublicKeyError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.LimitedConnectionError.html b/classes/_libp2p_interface.LimitedConnectionError.html index 6e3c9da4e3..cb3a74058e 100644 --- a/classes/_libp2p_interface.LimitedConnectionError.html +++ b/classes/_libp2p_interface.LimitedConnectionError.html @@ -1,7 +1,7 @@ LimitedConnectionError | libp2p

    This error is thrown when a limited connection is encountered, i.e. if the user tried to open a stream on a connection for a protocol that is not configured to run over limited connections.

    -

    Hierarchy

    • Error
      • LimitedConnectionError

    Constructors

    Hierarchy

    • Error
      • LimitedConnectionError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'LimitedConnectionError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'LimitedConnectionError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.ListenError.html b/classes/_libp2p_interface.ListenError.html index ddc054107b..b5f2b33581 100644 --- a/classes/_libp2p_interface.ListenError.html +++ b/classes/_libp2p_interface.ListenError.html @@ -1,5 +1,5 @@ ListenError | libp2p

    Thrown when listening on an address failed

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ListenError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ListenError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.MuxerClosedError.html b/classes/_libp2p_interface.MuxerClosedError.html index e45d0f0750..6644cc891b 100644 --- a/classes/_libp2p_interface.MuxerClosedError.html +++ b/classes/_libp2p_interface.MuxerClosedError.html @@ -1,5 +1,5 @@ MuxerClosedError | libp2p

    Thrown when the muxer is closed and an attempt to open a stream occurs

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'MuxerClosedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'MuxerClosedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.NotFoundError.html b/classes/_libp2p_interface.NotFoundError.html index 177f294649..6d9c2523a9 100644 --- a/classes/_libp2p_interface.NotFoundError.html +++ b/classes/_libp2p_interface.NotFoundError.html @@ -1,5 +1,5 @@ NotFoundError | libp2p

    Thrown when a value could not be found

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'NotFoundError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'NotFoundError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.NotStartedError.html b/classes/_libp2p_interface.NotStartedError.html index b21b5e4049..e2a59efde2 100644 --- a/classes/_libp2p_interface.NotStartedError.html +++ b/classes/_libp2p_interface.NotStartedError.html @@ -1,6 +1,6 @@ NotStartedError | libp2p

    Thrown when a startable component is interacted with but it has not been started yet

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'NotStartedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'NotStartedError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.ProtocolError.html b/classes/_libp2p_interface.ProtocolError.html index d70d776b3d..061c4725c5 100644 --- a/classes/_libp2p_interface.ProtocolError.html +++ b/classes/_libp2p_interface.ProtocolError.html @@ -1,6 +1,6 @@ ProtocolError | libp2p

    Thrown when a remote peer sends a structurally valid message that does not comply with the protocol

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ProtocolError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'ProtocolError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.StreamResetError.html b/classes/_libp2p_interface.StreamResetError.html index aecb83dd35..0d2152e877 100644 --- a/classes/_libp2p_interface.StreamResetError.html +++ b/classes/_libp2p_interface.StreamResetError.html @@ -1,5 +1,5 @@ StreamResetError | libp2p

    Thrown when a protocol stream is reset by the remote muxer

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'StreamResetError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'StreamResetError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.StreamStateError.html b/classes/_libp2p_interface.StreamStateError.html index 19254d1927..b8b9b152b0 100644 --- a/classes/_libp2p_interface.StreamStateError.html +++ b/classes/_libp2p_interface.StreamStateError.html @@ -1,5 +1,5 @@ StreamStateError | libp2p

    Thrown when a stream is in an invalid state

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'StreamStateError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'StreamStateError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.TimeoutError.html b/classes/_libp2p_interface.TimeoutError.html index e030bfa822..68853c4701 100644 --- a/classes/_libp2p_interface.TimeoutError.html +++ b/classes/_libp2p_interface.TimeoutError.html @@ -1,5 +1,5 @@ TimeoutError | libp2p

    Throw when an operation times out

    -

    Hierarchy

    Constructors

    Hierarchy

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TimeoutError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TimeoutError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.TooManyInboundProtocolStreamsError.html b/classes/_libp2p_interface.TooManyInboundProtocolStreamsError.html index ab3dcf1ddc..cc3f78057e 100644 --- a/classes/_libp2p_interface.TooManyInboundProtocolStreamsError.html +++ b/classes/_libp2p_interface.TooManyInboundProtocolStreamsError.html @@ -1,5 +1,5 @@ TooManyInboundProtocolStreamsError | libp2p

    Class TooManyInboundProtocolStreamsError

    This error is thrown where there are too many inbound protocols streams open

    -

    Hierarchy

    • Error
      • TooManyInboundProtocolStreamsError

    Constructors

    Hierarchy

    • Error
      • TooManyInboundProtocolStreamsError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TooManyInboundProtocolStreamsError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TooManyInboundProtocolStreamsError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.TooManyOutboundProtocolStreamsError.html b/classes/_libp2p_interface.TooManyOutboundProtocolStreamsError.html index 3c5da9e464..28859aaec3 100644 --- a/classes/_libp2p_interface.TooManyOutboundProtocolStreamsError.html +++ b/classes/_libp2p_interface.TooManyOutboundProtocolStreamsError.html @@ -1,5 +1,5 @@ TooManyOutboundProtocolStreamsError | libp2p

    Class TooManyOutboundProtocolStreamsError

    This error is thrown where there are too many outbound protocols streams open

    -

    Hierarchy

    • Error
      • TooManyOutboundProtocolStreamsError

    Constructors

    Hierarchy

    • Error
      • TooManyOutboundProtocolStreamsError

    Constructors

    Properties

    Methods

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TooManyOutboundProtocolStreamsError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    +

    Constructors

    Properties

    cause?: unknown
    message: string
    name: string
    stack?: string
    name: string = 'TooManyOutboundProtocolStreamsError'
    prepareStackTrace?: ((err, stackTraces) => any)

    Optional override for formatting stack traces

    Type declaration

      • (err, stackTraces): any
      • Parameters

        Returns any

    stackTraceLimit: number

    Methods

    • Create .stack property on a target object

      Parameters

      • targetObject: object
      • Optional constructorOpt: Function

      Returns void

    \ No newline at end of file diff --git a/classes/_libp2p_interface.TypedEventEmitter.html b/classes/_libp2p_interface.TypedEventEmitter.html index 475c2084ea..76f8ce2f58 100644 --- a/classes/_libp2p_interface.TypedEventEmitter.html +++ b/classes/_libp2p_interface.TypedEventEmitter.html @@ -1,12 +1,12 @@ TypedEventEmitter | libp2p

    Class TypedEventEmitter<EventMap>

    An implementation of a typed event target etc

    -

    Type Parameters

    • EventMap extends Record<string, any>

    Hierarchy

    Implements

    Constructors

    Type Parameters

    • EventMap extends Record<string, any>

    Hierarchy

    Implements

    Constructors

    Properties

    #listeners: Map<any, Listener[]> = ...

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      +

    Constructors

    Properties

    #listeners: Map<any, Listener[]> = ...

    Methods

    \ No newline at end of file +

    Parameters

    Returns boolean

\ No newline at end of file diff --git a/classes/_libp2p_interface.UnexpectedPeerError.html b/classes/_libp2p_interface.UnexpectedPeerError.html index 159f82d8c2..143ca80691 100644 --- a/classes/_libp2p_interface.UnexpectedPeerError.html +++ b/classes/_libp2p_interface.UnexpectedPeerError.html @@ -1,5 +1,5 @@ UnexpectedPeerError | libp2p

Thrown when a remote Peer ID does not match the expected one

-

Hierarchy

Constructors

Hierarchy

Constructors

Properties

Methods

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnexpectedPeerError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

+

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnexpectedPeerError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

Type declaration

    • (err, stackTraces): any
    • Parameters

      Returns any

stackTraceLimit: number

Methods

  • Create .stack property on a target object

    Parameters

    • targetObject: object
    • Optional constructorOpt: Function

    Returns void

\ No newline at end of file diff --git a/classes/_libp2p_interface.UnsupportedKeyTypeError.html b/classes/_libp2p_interface.UnsupportedKeyTypeError.html index fa4d50e6fc..cf96b2281e 100644 --- a/classes/_libp2p_interface.UnsupportedKeyTypeError.html +++ b/classes/_libp2p_interface.UnsupportedKeyTypeError.html @@ -1,5 +1,5 @@ UnsupportedKeyTypeError | libp2p

Thrown when and attempt to operate on an unsupported key was made

-

Hierarchy

  • Error
    • UnsupportedKeyTypeError

Constructors

Hierarchy

  • Error
    • UnsupportedKeyTypeError

Constructors

Properties

Methods

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedKeyTypeError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

+

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedKeyTypeError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

Type declaration

    • (err, stackTraces): any
    • Parameters

      Returns any

stackTraceLimit: number

Methods

  • Create .stack property on a target object

    Parameters

    • targetObject: object
    • Optional constructorOpt: Function

    Returns void

\ No newline at end of file diff --git a/classes/_libp2p_interface.UnsupportedOperationError.html b/classes/_libp2p_interface.UnsupportedOperationError.html index 14b26679c8..8cb5036b6f 100644 --- a/classes/_libp2p_interface.UnsupportedOperationError.html +++ b/classes/_libp2p_interface.UnsupportedOperationError.html @@ -1,5 +1,5 @@ UnsupportedOperationError | libp2p

Thrown when a operation is unsupported

-

Hierarchy

  • Error
    • UnsupportedOperationError

Constructors

Hierarchy

  • Error
    • UnsupportedOperationError

Constructors

Properties

Methods

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedOperationError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

+

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedOperationError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

Type declaration

    • (err, stackTraces): any
    • Parameters

      Returns any

stackTraceLimit: number

Methods

  • Create .stack property on a target object

    Parameters

    • targetObject: object
    • Optional constructorOpt: Function

    Returns void

\ No newline at end of file diff --git a/classes/_libp2p_interface.UnsupportedProtocolError.html b/classes/_libp2p_interface.UnsupportedProtocolError.html index cb54064d14..d46dffb11a 100644 --- a/classes/_libp2p_interface.UnsupportedProtocolError.html +++ b/classes/_libp2p_interface.UnsupportedProtocolError.html @@ -1,5 +1,5 @@ UnsupportedProtocolError | libp2p

Thrown when a protocol is not supported

-

Hierarchy

  • Error
    • UnsupportedProtocolError

Constructors

Hierarchy

  • Error
    • UnsupportedProtocolError

Constructors

Properties

Methods

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedProtocolError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

+

Constructors

Properties

cause?: unknown
message: string
name: string
stack?: string
name: string = 'UnsupportedProtocolError'
prepareStackTrace?: ((err, stackTraces) => any)

Optional override for formatting stack traces

Type declaration

    • (err, stackTraces): any
    • Parameters

      Returns any

stackTraceLimit: number

Methods

  • Create .stack property on a target object

    Parameters

    • targetObject: object
    • Optional constructorOpt: Function

    Returns void

\ No newline at end of file diff --git a/classes/_libp2p_peer_collections.PeerFilter.html b/classes/_libp2p_peer_collections.PeerFilter.html index 5184150a91..9095509663 100644 --- a/classes/_libp2p_peer_collections.PeerFilter.html +++ b/classes/_libp2p_peer_collections.PeerFilter.html @@ -1,8 +1,8 @@ PeerFilter | libp2p

Uses a Cuckoo filter to implement a mechanism for deduplicating PeerIds in a way that uses a smaller amount of memory than a PeerSet.

-

Constructors

Constructors

Properties

Methods

Constructors

Properties

filter: Filter

Methods

\ No newline at end of file +

Constructors

Properties

filter: Filter

Methods

\ No newline at end of file diff --git a/classes/_libp2p_peer_collections.PeerList.html b/classes/_libp2p_peer_collections.PeerList.html index 0f82dae33e..bcecd5990c 100644 --- a/classes/_libp2p_peer_collections.PeerList.html +++ b/classes/_libp2p_peer_collections.PeerList.html @@ -5,7 +5,7 @@ should be a cheap operation.

Example

import { peerList } from '@libp2p/peer-collections'

const list = peerList()
list.push(peerId)
-

Constructors

Constructors

Properties

Accessors

Methods

[iterator] @@ -23,4 +23,4 @@ push shift unshift -

Constructors

Properties

list: PeerId[]

Accessors

  • get length(): number
  • Returns number

Methods

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns boolean

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns PeerList

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns undefined | PeerId

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns number

  • Parameters

    • predicate: ((peerId, index, arr) => void)
        • (peerId, index, arr): void
        • Parameters

          Returns void

    Returns void

  • Parameters

    Returns boolean

  • Parameters

    Returns void

  • Parameters

    Returns number

\ No newline at end of file +

Constructors

Properties

list: PeerId[]

Accessors

  • get length(): number
  • Returns number

Methods

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns boolean

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns PeerList

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns undefined | PeerId

  • Parameters

    • predicate: ((peerId, index, arr) => boolean)
        • (peerId, index, arr): boolean
        • Parameters

          Returns boolean

    Returns number

  • Parameters

    • predicate: ((peerId, index, arr) => void)
        • (peerId, index, arr): void
        • Parameters

          Returns void

    Returns void

  • Parameters

    Returns boolean

  • Parameters

    Returns void

  • Parameters

    Returns number

\ No newline at end of file diff --git a/classes/_libp2p_peer_collections.PeerMap.html b/classes/_libp2p_peer_collections.PeerMap.html index de02fd8a04..f61dd71598 100644 --- a/classes/_libp2p_peer_collections.PeerMap.html +++ b/classes/_libp2p_peer_collections.PeerMap.html @@ -5,7 +5,7 @@ should be a cheap operation.

Example

import { peerMap } from '@libp2p/peer-collections'

const map = peerMap<string>()
map.set(peerId, 'value')
-

Type Parameters

Constructors

Type Parameters

  • T

Constructors

Properties

Accessors

Methods

[iterator] @@ -18,4 +18,4 @@ keys set values -

Constructors

Properties

map: Map<string, {
    key: PeerId;
    value: T;
}>

Type declaration

Accessors

  • get size(): number
  • Returns number

Methods

  • Returns void

  • Parameters

    Returns boolean

  • Parameters

    • fn: ((value, key, map) => void)
        • (value, key, map): void
        • Parameters

          Returns void

    Returns void

  • Parameters

    Returns undefined | T

  • Parameters

    Returns boolean

  • Parameters

    Returns void

  • Returns IterableIterator<T>

\ No newline at end of file +

Constructors

Properties

map: Map<string, {
    key: PeerId;
    value: T;
}>

Type declaration

Accessors

  • get size(): number
  • Returns number

Methods

  • Returns void

  • Parameters

    Returns boolean

  • Parameters

    • fn: ((value, key, map) => void)
        • (value, key, map): void
        • Parameters

          Returns void

    Returns void

  • Parameters

    Returns undefined | T

  • Parameters

    Returns boolean

  • Parameters

    Returns void

  • Returns IterableIterator<T>

\ No newline at end of file diff --git a/classes/_libp2p_peer_collections.PeerSet.html b/classes/_libp2p_peer_collections.PeerSet.html index a50e7e2253..f1d8d9f68b 100644 --- a/classes/_libp2p_peer_collections.PeerSet.html +++ b/classes/_libp2p_peer_collections.PeerSet.html @@ -5,7 +5,7 @@ should be a cheap operation.

Example

import { peerSet } from '@libp2p/peer-collections'

const set = peerSet()
set.add(peerId)
-

Constructors

Constructors

Properties

Accessors

Methods

[iterator] @@ -19,4 +19,4 @@ intersection union values -

Constructors

Properties

set: Set<string>

Accessors

  • get size(): number
  • Returns number

Methods

  • Returns void

  • Parameters

    • predicate: ((peerId, index, set) => void)

    Returns void

  • Parameters

    Returns boolean

\ No newline at end of file +

Constructors

Properties

set: Set<string>

Accessors

  • get size(): number
  • Returns number

Methods

  • Returns void

  • Parameters

    • predicate: ((peerId, index, set) => void)

    Returns void

  • Parameters

    Returns boolean

\ No newline at end of file diff --git a/classes/_libp2p_peer_record.PeerRecord.html b/classes/_libp2p_peer_record.PeerRecord.html index d05893c795..8c22d03c7a 100644 --- a/classes/_libp2p_peer_record.PeerRecord.html +++ b/classes/_libp2p_peer_record.PeerRecord.html @@ -1,6 +1,6 @@ PeerRecord | libp2p

The PeerRecord is used for distributing peer routing records across the network. It contains the peer's reachable listen addresses.

-

Constructors

Constructors

Properties

codec domain marshaled? @@ -12,7 +12,7 @@

Methods

Constructors

Properties

codec: Uint8Array = PeerRecord.CODEC
domain: string = PeerRecord.DOMAIN
marshaled?: Uint8Array
multiaddrs: Multiaddr[]
peerId: PeerId
seqNumber: bigint
CODEC: Uint8Array = ENVELOPE_PAYLOAD_TYPE_PEER_RECORD
DOMAIN: string = ENVELOPE_DOMAIN_PEER_RECORD

Methods

  • Returns true if this record equals the other

    -

    Parameters

    • other: unknown

    Returns boolean

\ No newline at end of file +

Constructors

Properties

codec: Uint8Array = PeerRecord.CODEC
domain: string = PeerRecord.DOMAIN
marshaled?: Uint8Array
multiaddrs: Multiaddr[]
peerId: PeerId
seqNumber: bigint
CODEC: Uint8Array = ENVELOPE_PAYLOAD_TYPE_PEER_RECORD
DOMAIN: string = ENVELOPE_DOMAIN_PEER_RECORD

Methods

  • Returns true if this record equals the other

    +

    Parameters

    • other: unknown

    Returns boolean

\ No newline at end of file diff --git a/classes/_libp2p_peer_record.RecordEnvelope.html b/classes/_libp2p_peer_record.RecordEnvelope.html index 8b71ca58ad..b44bfd0693 100644 --- a/classes/_libp2p_peer_record.RecordEnvelope.html +++ b/classes/_libp2p_peer_record.RecordEnvelope.html @@ -1,4 +1,4 @@ -RecordEnvelope | libp2p

Implements

Constructors

constructor +RecordEnvelope | libp2p

Implements

Constructors

Properties

marshaled? payload payloadType @@ -12,12 +12,12 @@ seal

Constructors

Properties

marshaled?: Uint8Array
payload: Uint8Array
payloadType: Uint8Array
publicKey: PublicKey
signature: Uint8Array

Methods

Properties

marshaled?: Uint8Array
payload: Uint8Array
payloadType: Uint8Array
publicKey: PublicKey
signature: Uint8Array

Methods

\ No newline at end of file +

Parameters

Returns Promise<RecordEnvelope>

\ No newline at end of file diff --git a/classes/_libp2p_peer_store.PersistentPeerStore.html b/classes/_libp2p_peer_store.PersistentPeerStore.html index c07d73c067..a8965eeab9 100644 --- a/classes/_libp2p_peer_store.PersistentPeerStore.html +++ b/classes/_libp2p_peer_store.PersistentPeerStore.html @@ -1,5 +1,5 @@ PersistentPeerStore | libp2p

An implementation of PeerStore that stores data in a Datastore

-

Implements

Constructors

Implements

Constructors

Properties

[toStringTag] events log @@ -15,38 +15,38 @@ merge patch save -

Constructors

Properties

[toStringTag]: "@libp2p/peer-store" = '@libp2p/peer-store'
log: Logger
peerId: PeerId

Methods

  • Returns all peers in the peer store.

    +

Constructors

Properties

[toStringTag]: "@libp2p/peer-store" = '@libp2p/peer-store'
log: Logger
peerId: PeerId

Methods

  • Unmarshal and verify a signed peer record, extract the multiaddrs and +

  • Unmarshal and verify a signed peer record, extract the multiaddrs and overwrite the stored addresses for the peer.

    Optionally pass an expected PeerId to verify that the peer record was signed by that peer.

    Parameters

    Returns Promise<boolean>

    Example

    await peerStore.consumePeerRecord(buf, expectedPeer)
     
    -
  • Delete all data stored for the passed peer

    Parameters

    Returns Promise<void>

    Example

    await peerStore.addressBook.set(peerId, multiaddrs)
    await peerStore.addressBook.get(peerId)
    // multiaddrs[]

    await peerStore.delete(peerId)

    await peerStore.addressBook.get(peerId)
    // []
    -
  • Loop over every peer - the looping is async because we read from a datastore but the peer operation is sync, this is to prevent long-lived peer operations causing deadlocks over the datastore which can happen if they try to access the peer store during the loop

    Parameters

    • fn: ((peer) => void)
        • (peer): void
        • Parameters

          Returns void

    • Optional query: PeerQuery

    Returns Promise<void>

    Example

    await peerStore.forEach(peer => {
    // ...
    })
    -
  • Returns true if the passed PeerId is in the peer store

    Parameters

    Returns Promise<boolean>

    Example

    await peerStore.has(peerId)
    // false
    await peerStore.addressBook.add(peerId, multiaddrs)
    await peerStore.has(peerId)
    // true
    -
\ No newline at end of file +
\ No newline at end of file diff --git a/classes/_libp2p_pubsub.index.PubSubBaseProtocol.html b/classes/_libp2p_pubsub.index.PubSubBaseProtocol.html index 65a76e59e9..e70a39b476 100644 --- a/classes/_libp2p_pubsub.index.PubSubBaseProtocol.html +++ b/classes/_libp2p_pubsub.index.PubSubBaseProtocol.html @@ -1,6 +1,6 @@ PubSubBaseProtocol | libp2p

Class PubSubBaseProtocol<Events>Abstract

PubSubBaseProtocol handles the peers and connections logic for pubsub routers and specifies the API that pubsub routers should have.

-

Type Parameters

Hierarchy (view full)

Implements

Constructors

Type Parameters

Hierarchy (view full)

Implements

Constructors

Properties

#private: any
_registrarTopologyIds: undefined | string[]
canRelayMessage: boolean

If router can relay received messages, even if not subscribed

-
components: PubSubComponents
emitSelf: boolean

if publish should emit to self, if subscribed

-
enabled: boolean
globalSignaturePolicy: "StrictSign" | "StrictNoSign"

The signature policy to follow by default

-
log: Logger
maxInboundStreams: number
maxOutboundStreams: number
multicodecs: string[]

A list of multicodecs that contain the pubsub protocol name.

-

Map of peer streams

-
started: boolean
subscriptions: Set<string>

List of our subscriptions

-
topicValidators: Map<string, TopicValidatorFn>

Topic validator map

+

Constructors

Properties

#private: any
_registrarTopologyIds: undefined | string[]
canRelayMessage: boolean

If router can relay received messages, even if not subscribed

+
components: PubSubComponents
emitSelf: boolean

if publish should emit to self, if subscribed

+
enabled: boolean
globalSignaturePolicy: "StrictSign" | "StrictNoSign"

The signature policy to follow by default

+
log: Logger
maxInboundStreams: number
maxOutboundStreams: number
multicodecs: string[]

A list of multicodecs that contain the pubsub protocol name.

+

Map of peer streams

+
started: boolean
subscriptions: Set<string>

List of our subscriptions

+
topicValidators: Map<string, TopicValidatorFn>

Topic validator map

Keyed by topic Topic validators are functions with the following input:

-
topics: Map<string, PeerSet>

Map of topics to which peers are subscribed to

-

Methods

  • Registrar notifies a closing connection with pubsub protocol

    -

    Parameters

    Returns void

topics: Map<string, PeerSet>

Map of topics to which peers are subscribed to

+

Methods

  • Registrar notifies a closing connection with pubsub protocol

    +

    Parameters

    Returns void

  • Whether to accept a message from a peer Override to create a graylist

    -

    Parameters

    Returns boolean

  • Normalizes the message and signs it, if signing is enabled. Should be used by the routers to create the message to send.

    -

    Parameters

    • message: {
          data: Uint8Array;
          from: PeerId;
          sequenceNumber: bigint;
          topic: string;
      }

    Returns Promise<Message>

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    +

    Parameters

    Returns PubSubRPC

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    MDN Reference

    Parameters

    Returns boolean

  • Overriding the implementation of publish should handle the appropriate algorithms for the publish/subscriber implementation. For example, a Floodsub implementation might simply publish each message to each topic for every peer.

    sender might be this peer, or we might be forwarding a message on behalf of another peer, in which case sender is the peer we received the message from, which may not be the peer the message was created by.

    -

    Parameters

    Returns Promise<PublishResult>

  • Send an rpc object to a peer

    -

    Parameters

    • peer: PeerId
    • data: {
          messages?: Message[];
          subscribe?: boolean;
          subscriptions?: string[];
      }
      • Optional messages?: Message[]
      • Optional subscribe?: boolean
      • Optional subscriptions?: string[]

    Returns void

  • Send an rpc object to a peer

    +

    Parameters

    • peer: PeerId
    • data: {
          messages?: Message[];
          subscribe?: boolean;
          subscriptions?: string[];
      }
      • Optional messages?: Message[]
      • Optional subscribe?: boolean
      • Optional subscriptions?: string[]

    Returns void

\ No newline at end of file +

Parameters

Returns Promise<void>

\ No newline at end of file diff --git a/classes/_libp2p_pubsub.peer_streams.PeerStreams.html b/classes/_libp2p_pubsub.peer_streams.PeerStreams.html index 1fdc4d8c8e..e7cc38ae51 100644 --- a/classes/_libp2p_pubsub.peer_streams.PeerStreams.html +++ b/classes/_libp2p_pubsub.peer_streams.PeerStreams.html @@ -1,5 +1,5 @@ PeerStreams | libp2p

Thin wrapper around a peer's inbound / outbound pubsub streams

-

Hierarchy (view full)

Constructors

Hierarchy (view full)

Constructors

Properties

#private: any
_inboundAbortController: AbortController

An AbortController for controlled shutdown of the inbound stream

-
_rawInboundStream?: Stream

The raw inbound stream, as retrieved from the callback from libp2p.handle

-
_rawOutboundStream?: Stream

The raw outbound stream, as retrieved from conn.newStream

-
closed: boolean
id: PeerId
inboundStream?: AsyncIterable<Uint8ArrayList>

Read stream

-
log: Logger
outboundStream?: Pushable<Uint8ArrayList, void, unknown>

Write stream - it's preferable to use the write method

-
protocol: string

Accessors

Methods

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    +

Constructors

Properties

#private: any
_inboundAbortController: AbortController

An AbortController for controlled shutdown of the inbound stream

+
_rawInboundStream?: Stream

The raw inbound stream, as retrieved from the callback from libp2p.handle

+
_rawOutboundStream?: Stream

The raw outbound stream, as retrieved from conn.newStream

+
closed: boolean
id: PeerId
inboundStream?: AsyncIterable<Uint8ArrayList>

Read stream

+
log: Logger
outboundStream?: Pushable<Uint8ArrayList, void, unknown>

Write stream - it's preferable to use the write method

+
protocol: string

Accessors

Methods

  • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

    MDN Reference

    Parameters

    Returns boolean

  • Parameters

    • type: string

    Returns number

\ No newline at end of file +

Parameters

Returns void

\ No newline at end of file diff --git a/classes/_libp2p_record.Libp2pRecord.html b/classes/_libp2p_record.Libp2pRecord.html index 3fb1200afd..36fe57136d 100644 --- a/classes/_libp2p_record.Libp2pRecord.html +++ b/classes/_libp2p_record.Libp2pRecord.html @@ -1,4 +1,4 @@ -Libp2pRecord | libp2p

Constructors

constructor +Libp2pRecord | libp2p

Constructors

Properties

Constructors

Properties

timeReceived: Date
value: Uint8Array

Methods

  • Return the object format ready to be given to the protobuf library.

    -

    Returns Record

\ No newline at end of file +

Constructors

Properties

timeReceived: Date
value: Uint8Array

Methods

  • Return the object format ready to be given to the protobuf library.

    +

    Returns Record

\ No newline at end of file diff --git a/classes/_libp2p_upnp_nat.NatAPI.html b/classes/_libp2p_upnp_nat.NatAPI.html index 0c648bab3b..36b00a3ee4 100644 --- a/classes/_libp2p_upnp_nat.NatAPI.html +++ b/classes/_libp2p_upnp_nat.NatAPI.html @@ -1,4 +1,4 @@ -NatAPI | libp2p

Constructors

constructor +NatAPI | libp2p

Constructors

Properties

Constructors

  • Parameters

    Returns NatAPI

Properties

client: any
description: any
destroyed: any
gateway?: any
keepAlive: any
keepAliveInterval: any
openPorts: MapPortOptions[]
ttl: any
updateIntervals: any

Methods

  • Returns Promise<void>

  • Returns Promise<string>

  • Parameters

    Returns Promise<void>

\ No newline at end of file +

Constructors

  • Parameters

    Returns NatAPI

Properties

client: any
description: any
destroyed: any
gateway?: any
keepAlive: any
keepAliveInterval: any
openPorts: MapPortOptions[]
ttl: any
updateIntervals: any

Methods

  • Returns Promise<void>

  • Returns Promise<string>

  • Parameters

    Returns Promise<void>

\ No newline at end of file diff --git a/classes/_libp2p_utils.abstract_stream.AbstractStream.html b/classes/_libp2p_utils.abstract_stream.AbstractStream.html index c3e83aa2bc..e02fad141b 100644 --- a/classes/_libp2p_utils.abstract_stream.AbstractStream.html +++ b/classes/_libp2p_utils.abstract_stream.AbstractStream.html @@ -2,7 +2,7 @@ can be written to and read from at both ends.

It may be encrypted and multiplexed depending on the configuration of the nodes.

-

Implements

Constructors

Implements

Constructors

Properties

Constructors

Properties

closed: DeferredPromise<void>
direction: Direction

Outbound streams are opened by the local node, inbound streams are opened by the remote

-
endErr: undefined | Error
id: string

Unique identifier for a stream. Identifiers are not unique across muxers.

-
log: Logger

The stream logger

-
metadata: Record<string, unknown>

User defined stream metadata

-
onAbort?: ((err) => void)

Type declaration

    • (err): void
    • Parameters

      Returns void

onCloseRead?: (() => void)

Type declaration

    • (): void
    • Returns void

onCloseWrite?: (() => void)

Type declaration

    • (): void
    • Returns void

onEnd?: ((err?) => void)

Type declaration

    • (err?): void
    • Parameters

      Returns void

onReset?: (() => void)

Type declaration

    • (): void
    • Returns void

protocol?: string

The protocol negotiated for this stream

-
readStatus: ReadStatus

The current status of the readable end of the stream

-
sendCloseWriteTimeout: number
sendingData?: DeferredPromise<void>
sinkController: AbortController
sinkEnd: DeferredPromise<void>
source: AsyncGenerator<Uint8ArrayList, void, unknown>
status: StreamStatus

The current status of the stream

-
streamSource: Pushable<Uint8ArrayList, void, unknown>
timeline: StreamTimeline

Lifecycle times for the stream

-
writeStatus: WriteStatus

The current status of the writable end of the stream

-

Methods

  • Close immediately for reading and writing and send a reset message (local +

Constructors

Properties

closed: DeferredPromise<void>
direction: Direction

Outbound streams are opened by the local node, inbound streams are opened by the remote

+
endErr: undefined | Error
id: string

Unique identifier for a stream. Identifiers are not unique across muxers.

+
log: Logger

The stream logger

+
metadata: Record<string, unknown>

User defined stream metadata

+
onAbort?: ((err) => void)

Type declaration

    • (err): void
    • Parameters

      Returns void

onCloseRead?: (() => void)

Type declaration

    • (): void
    • Returns void

onCloseWrite?: (() => void)

Type declaration

    • (): void
    • Returns void

onEnd?: ((err?) => void)

Type declaration

    • (err?): void
    • Parameters

      Returns void

onReset?: (() => void)

Type declaration

    • (): void
    • Returns void

protocol?: string

The protocol negotiated for this stream

+
readStatus: ReadStatus

The current status of the readable end of the stream

+
sendCloseWriteTimeout: number
sendingData?: DeferredPromise<void>
sinkController: AbortController
sinkEnd: DeferredPromise<void>
source: AsyncGenerator<Uint8ArrayList, void, unknown>
status: StreamStatus

The current status of the stream

+
streamSource: Pushable<Uint8ArrayList, void, unknown>
timeline: StreamTimeline

Lifecycle times for the stream

+
writeStatus: WriteStatus

The current status of the writable end of the stream

+

Methods

  • Closes the stream for reading and writing.

    Any buffered data in the source can still be consumed and the stream will end normally.

    This will cause a CLOSE message to be sent to the remote, unless the sink has already ended.

    The sink and the source will return normally.

    -

    Parameters

    Returns Promise<void>

  • Closes the stream for reading. If iterating over the source of this stream in a for await of loop, it will return (exit the loop) after any buffered data has been consumed.

    This function is called automatically by the muxer when it receives a CLOSE message from the remote.

    The source will return normally, the sink will continue to consume.

    -

    Parameters

    Returns Promise<void>

  • Closes the stream for writing. If iterating over the source of this stream in a for await of loop, it will return (exit the loop) after any buffered data has been consumed.

    The source will return normally, the sink will continue to consume.

    -

    Parameters

    Returns Promise<void>

  • Returns the amount of unread data - can be used to prevent large amounts of data building up when the stream consumer is too slow.

    -

    Returns number

\ No newline at end of file +

Returns number

\ No newline at end of file diff --git a/classes/_libp2p_utils.adaptive_timeout.AdaptiveTimeout.html b/classes/_libp2p_utils.adaptive_timeout.AdaptiveTimeout.html index 466d959632..5ca785e5cc 100644 --- a/classes/_libp2p_utils.adaptive_timeout.AdaptiveTimeout.html +++ b/classes/_libp2p_utils.adaptive_timeout.AdaptiveTimeout.html @@ -1,4 +1,4 @@ -AdaptiveTimeout | libp2p

Constructors

constructor +AdaptiveTimeout | libp2p

Constructors

Properties

failure: MovingAverage
failureMultiplier: number
metric?: MetricGroup<any>
minTimeout: number
success: MovingAverage
timeoutMultiplier: number

Methods

\ No newline at end of file +

Constructors

Properties

failure: MovingAverage
failureMultiplier: number
metric?: MetricGroup<any>
minTimeout: number
success: MovingAverage
timeoutMultiplier: number

Methods

\ No newline at end of file diff --git a/classes/_libp2p_utils.filters.BloomFilter.html b/classes/_libp2p_utils.filters.BloomFilter.html index 3cc0c1a179..641285b515 100644 --- a/classes/_libp2p_utils.filters.BloomFilter.html +++ b/classes/_libp2p_utils.filters.BloomFilter.html @@ -1,4 +1,4 @@ -BloomFilter | libp2p

Implements

Constructors

constructor +BloomFilter | libp2p

Implements

Constructors

Properties

bits buffer seeds @@ -7,9 +7,9 @@ getbit has setbit -

Constructors

Properties

bits: number
buffer: Uint8Array
seeds: number[]

Methods

  • Test if the filter has an item. If it returns false it definitely does not +

Constructors

Properties

bits: number
buffer: Uint8Array
seeds: number[]

Methods

  • Test if the filter has an item. If it returns false it definitely does not have the item. If it returns true, it probably has the item but there's an errorRate chance it doesn't.

    -

    Parameters

    Returns boolean

\ No newline at end of file +

Parameters

Returns boolean

\ No newline at end of file diff --git a/classes/_libp2p_utils.filters.CuckooFilter.html b/classes/_libp2p_utils.filters.CuckooFilter.html index 795ade6916..3b13a0a922 100644 --- a/classes/_libp2p_utils.filters.CuckooFilter.html +++ b/classes/_libp2p_utils.filters.CuckooFilter.html @@ -1,4 +1,4 @@ -CuckooFilter | libp2p

Implements

Constructors

constructor +CuckooFilter | libp2p

Implements

Constructors

Properties

bucketSize buckets count @@ -10,4 +10,4 @@

Methods

Constructors

Properties

bucketSize: number
buckets: Bucket[]
count: number
filterSize: number
fingerprintSize: number
hash: Hash
seed: number

Accessors

Methods

\ No newline at end of file +

Constructors

Properties

bucketSize: number
buckets: Bucket[]
count: number
filterSize: number
fingerprintSize: number
hash: Hash
seed: number

Accessors

Methods

\ No newline at end of file diff --git a/classes/_libp2p_utils.filters.ScalableCuckooFilter.html b/classes/_libp2p_utils.filters.ScalableCuckooFilter.html index 9f37036f31..67423e8f22 100644 --- a/classes/_libp2p_utils.filters.ScalableCuckooFilter.html +++ b/classes/_libp2p_utils.filters.ScalableCuckooFilter.html @@ -1,4 +1,4 @@ -ScalableCuckooFilter | libp2p

Implements

Constructors

constructor +ScalableCuckooFilter | libp2p

Implements

Constructors

Properties

Methods

Constructors

Properties

bucketSize: number
filterSeries: CuckooFilter[]
filterSize: number
fingerprintSize: number
hash: Hash
scale: number
seed: number

Accessors

Methods

\ No newline at end of file +

Constructors

Properties

bucketSize: number
filterSeries: CuckooFilter[]
filterSize: number
fingerprintSize: number
hash: Hash
scale: number
seed: number

Accessors

Methods

\ No newline at end of file diff --git a/classes/_libp2p_utils.moving_average.MovingAverage.html b/classes/_libp2p_utils.moving_average.MovingAverage.html index aa75a1d3ee..a7e904d7fa 100644 --- a/classes/_libp2p_utils.moving_average.MovingAverage.html +++ b/classes/_libp2p_utils.moving_average.MovingAverage.html @@ -3,7 +3,7 @@
  • https://en.wikipedia.org/wiki/Moving_average#Exponential_moving_average
  • https://www.npmjs.com/package/moving-average
  • -

    Constructors

    Constructors

    Properties

    Methods

    Constructors

    Properties

    deviation: number
    forecast: number
    movingAverage: number
    previousTime?: number
    timespan: number
    variance: number

    Methods

    \ No newline at end of file +

    Constructors

    Properties

    deviation: number
    forecast: number
    movingAverage: number
    previousTime?: number
    timespan: number
    variance: number

    Methods

    \ No newline at end of file diff --git a/classes/_libp2p_utils.peer_queue.PeerQueue.html b/classes/_libp2p_utils.peer_queue.PeerQueue.html index 444916c743..12896af06f 100644 --- a/classes/_libp2p_utils.peer_queue.PeerQueue.html +++ b/classes/_libp2p_utils.peer_queue.PeerQueue.html @@ -1,5 +1,5 @@ PeerQueue | libp2p

    Class PeerQueue<JobReturnType, JobOptions>

    Extends Queue to add support for querying queued jobs by peer id

    -

    Type Parameters

    Hierarchy (view full)

    Constructors

    Type Parameters

    Hierarchy (view full)

    Constructors

    Properties

    #private: any
    concurrency: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      +

    Constructors

    Properties

    #private: any
    concurrency: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      MDN Reference

      -

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    • Can be called multiple times. Useful if you for example add additional items at a later time.

      +

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    • The difference with .onEmpty is that .onIdle guarantees that all work from the queue has finished. .onEmpty merely signals that the queue is empty, but it could mean that some promises haven't completed yet.

      Parameters

      Returns Promise<void>

      A promise that settles when the queue becomes empty, and all promises have completed; queue.size === 0 && queue.pending === 0.

      -
    • Parameters

      Returns Promise<void>

      A promise that settles when the queue size is less than the given limit: queue.size < limit.

      If you want to avoid having the queue grow beyond a certain size you can await queue.onSizeLessThan() before adding a new item.

      Note that this only limits the number of items waiting to start. There could still be up to concurrency jobs already running that this call does not include in its calculation.

      -
    \ No newline at end of file +

    Parameters

    Returns AsyncGenerator<JobReturnType, void, unknown>

    \ No newline at end of file diff --git a/classes/_libp2p_utils.priority_queue.PriorityQueue.html b/classes/_libp2p_utils.priority_queue.PriorityQueue.html index 6d0bf937f6..8f37a8655e 100644 --- a/classes/_libp2p_utils.priority_queue.PriorityQueue.html +++ b/classes/_libp2p_utils.priority_queue.PriorityQueue.html @@ -3,7 +3,7 @@
  • Items remain at the head of the queue while they are running so queue.size includes queue.pending items - this is so interested parties can join the results of a queue item while it is running
  • The options for a job are stored separately to the job in order for them to be modified while they are still in the queue
  • -

    Type Parameters

    Hierarchy (view full)

    Constructors

    Type Parameters

    Hierarchy (view full)

    Constructors

    Properties

    #private: any
    concurrency: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      +

    Constructors

    Properties

    #private: any
    concurrency: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      MDN Reference

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    • The difference with .onEmpty is that .onIdle guarantees that all work from the queue has finished. .onEmpty merely signals that the queue is empty, but it could mean that some promises haven't completed yet.

      Parameters

      Returns Promise<void>

      A promise that settles when the queue becomes empty, and all promises have completed; queue.size === 0 && queue.pending === 0.

      -
    • Parameters

      Returns Promise<void>

      A promise that settles when the queue size is less than the given limit: queue.size < limit.

      If you want to avoid having the queue grow beyond a certain size you can await queue.onSizeLessThan() before adding a new item.

      Note that this only limits the number of items waiting to start. There could still be up to concurrency jobs already running that this call does not include in its calculation.

      -
    \ No newline at end of file +

    Parameters

    Returns AsyncGenerator<JobReturnType, void, unknown>

    \ No newline at end of file diff --git a/classes/_libp2p_utils.queue.Queue.html b/classes/_libp2p_utils.queue.Queue.html index 9ee2f6da18..fe5ee1786e 100644 --- a/classes/_libp2p_utils.queue.Queue.html +++ b/classes/_libp2p_utils.queue.Queue.html @@ -3,7 +3,7 @@
  • Items remain at the head of the queue while they are running so queue.size includes queue.pending items - this is so interested parties can join the results of a queue item while it is running
  • The options for a job are stored separately to the job in order for them to be modified while they are still in the queue
  • -

    Type Parameters

    Hierarchy (view full)

    Constructors

    Type Parameters

    Hierarchy (view full)

    Constructors

    Properties

    #private: any
    concurrency: number
    pending: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      +

    Constructors

    Properties

    #private: any
    concurrency: number
    pending: number

    Accessors

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      MDN Reference

      -

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    • Can be called multiple times. Useful if you for example add additional items at a later time.

      +

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    • The difference with .onEmpty is that .onIdle guarantees that all work from the queue has finished. .onEmpty merely signals that the queue is empty, but it could mean that some promises haven't completed yet.

      Parameters

      Returns Promise<void>

      A promise that settles when the queue becomes empty, and all promises have completed; queue.size === 0 && queue.pending === 0.

      -
    • Parameters

      Returns Promise<void>

      A promise that settles when the queue size is less than the given limit: queue.size < limit.

      If you want to avoid having the queue grow beyond a certain size you can await queue.onSizeLessThan() before adding a new item.

      Note that this only limits the number of items waiting to start. There could still be up to concurrency jobs already running that this call does not include in its calculation.

      -
    • Returns an async generator that makes it easy to iterate over the results of jobs added to the queue.

      The generator will end when the queue becomes idle, that is there are no jobs running and no jobs that have yet to run.

      If you need to keep the queue open indefinitely, consider using it-pushable instead.

      -

      Parameters

      Returns AsyncGenerator<JobReturnType, void, unknown>

    \ No newline at end of file +

    Parameters

    Returns AsyncGenerator<JobReturnType, void, unknown>

    \ No newline at end of file diff --git a/classes/_libp2p_utils.rate_limiter.RateLimiter.html b/classes/_libp2p_utils.rate_limiter.RateLimiter.html index 997ef1f142..40cd216326 100644 --- a/classes/_libp2p_utils.rate_limiter.RateLimiter.html +++ b/classes/_libp2p_utils.rate_limiter.RateLimiter.html @@ -1,4 +1,4 @@ -RateLimiter | libp2p

    Constructors

    constructor +RateLimiter | libp2p

    Constructors

    Properties

    Constructors

    Properties

    blockDuration: number
    duration: number
    execEvenly: boolean
    execEvenlyMinDelayMs: number
    keyPrefix: string
    memoryStorage: MemoryStorage
    points: number

    Methods

    \ No newline at end of file +

    Constructors

    Properties

    blockDuration: number
    duration: number
    execEvenly: boolean
    execEvenlyMinDelayMs: number
    keyPrefix: string
    memoryStorage: MemoryStorage
    points: number

    Methods

    \ No newline at end of file diff --git a/enums/_libp2p_interface.FaultTolerance.html b/enums/_libp2p_interface.FaultTolerance.html index c4f93ac602..255815b6e4 100644 --- a/enums/_libp2p_interface.FaultTolerance.html +++ b/enums/_libp2p_interface.FaultTolerance.html @@ -1,6 +1,6 @@ FaultTolerance | libp2p

    Enumeration FaultTolerance

    Enum Transport Manager Fault Tolerance values

    -

    Enumeration Members

    Enumeration Members

    Enumeration Members

    FATAL_ALL: 0

    should be used for failing in any listen circumstance

    -
    NO_FATAL: 1

    should be used for not failing when not listening

    -
    \ No newline at end of file +
    NO_FATAL: 1

    should be used for not failing when not listening

    +
    \ No newline at end of file diff --git a/enums/_libp2p_interface.TopicValidatorResult.html b/enums/_libp2p_interface.TopicValidatorResult.html index ce1ce13071..5b6fc715d5 100644 --- a/enums/_libp2p_interface.TopicValidatorResult.html +++ b/enums/_libp2p_interface.TopicValidatorResult.html @@ -1,7 +1,7 @@ -TopicValidatorResult | libp2p

    Enumeration TopicValidatorResult

    Enumeration Members

    Accept +TopicValidatorResult | libp2p

    Enumeration TopicValidatorResult

    Enumeration Members

    Enumeration Members

    Accept: "accept"

    The message is considered valid, and it should be delivered and forwarded to the network

    -
    Ignore: "ignore"

    The message is neither delivered nor forwarded to the network

    -
    Reject: "reject"

    The message is considered invalid, and it should be rejected

    -
    \ No newline at end of file +
    Ignore: "ignore"

    The message is neither delivered nor forwarded to the network

    +
    Reject: "reject"

    The message is considered invalid, and it should be rejected

    +
    \ No newline at end of file diff --git a/enums/_libp2p_kad_dht.EventTypes.html b/enums/_libp2p_kad_dht.EventTypes.html index 1b5c355455..0373e4c443 100644 --- a/enums/_libp2p_kad_dht.EventTypes.html +++ b/enums/_libp2p_kad_dht.EventTypes.html @@ -1,5 +1,5 @@ EventTypes | libp2p

    Enumeration EventTypes

    The types of events emitted during DHT queries

    -

    Enumeration Members

    Enumeration Members

    ADD_PEER: 6
    DIAL_PEER: 7
    FINAL_PEER: 2
    PEER_RESPONSE: 1
    PROVIDER: 4
    QUERY_ERROR: 3
    SEND_QUERY: 0
    VALUE: 5
    \ No newline at end of file +

    Enumeration Members

    ADD_PEER: 6
    DIAL_PEER: 7
    FINAL_PEER: 2
    PEER_RESPONSE: 1
    PROVIDER: 4
    QUERY_ERROR: 3
    SEND_QUERY: 0
    VALUE: 5
    \ No newline at end of file diff --git a/enums/_libp2p_kad_dht.MessageType-1.html b/enums/_libp2p_kad_dht.MessageType-1.html index 90402dac04..39115b25f5 100644 --- a/enums/_libp2p_kad_dht.MessageType-1.html +++ b/enums/_libp2p_kad_dht.MessageType-1.html @@ -1,7 +1,7 @@ -MessageType | libp2p

    Enumeration MessageType

    Enumeration Members

    ADD_PROVIDER +MessageType | libp2p

    Enumeration MessageType

    Enumeration Members

    ADD_PROVIDER: "ADD_PROVIDER"
    FIND_NODE: "FIND_NODE"
    GET_PROVIDERS: "GET_PROVIDERS"
    GET_VALUE: "GET_VALUE"
    PING: "PING"
    PUT_VALUE: "PUT_VALUE"
    \ No newline at end of file +

    Enumeration Members

    ADD_PROVIDER: "ADD_PROVIDER"
    FIND_NODE: "FIND_NODE"
    GET_PROVIDERS: "GET_PROVIDERS"
    GET_VALUE: "GET_VALUE"
    PING: "PING"
    PUT_VALUE: "PUT_VALUE"
    \ No newline at end of file diff --git a/functions/_libp2p_autonat.autoNAT.html b/functions/_libp2p_autonat.autoNAT.html index b38603c839..0efeb77b1a 100644 --- a/functions/_libp2p_autonat.autoNAT.html +++ b/functions/_libp2p_autonat.autoNAT.html @@ -1 +1 @@ -autoNAT | libp2p
    \ No newline at end of file +autoNAT | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_bootstrap.bootstrap.html b/functions/_libp2p_bootstrap.bootstrap.html index 521dfb2ffa..9a0b59ea69 100644 --- a/functions/_libp2p_bootstrap.bootstrap.html +++ b/functions/_libp2p_bootstrap.bootstrap.html @@ -1 +1 @@ -bootstrap | libp2p
    \ No newline at end of file +bootstrap | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_circuit_relay_v2.circuitRelayServer.html b/functions/_libp2p_circuit_relay_v2.circuitRelayServer.html index ee8898bbbd..1ecca2dddf 100644 --- a/functions/_libp2p_circuit_relay_v2.circuitRelayServer.html +++ b/functions/_libp2p_circuit_relay_v2.circuitRelayServer.html @@ -1 +1 @@ -circuitRelayServer | libp2p
    \ No newline at end of file +circuitRelayServer | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_circuit_relay_v2.circuitRelayTransport.html b/functions/_libp2p_circuit_relay_v2.circuitRelayTransport.html index 08bf6573f6..5d598b619f 100644 --- a/functions/_libp2p_circuit_relay_v2.circuitRelayTransport.html +++ b/functions/_libp2p_circuit_relay_v2.circuitRelayTransport.html @@ -1 +1 @@ -circuitRelayTransport | libp2p
    \ No newline at end of file +circuitRelayTransport | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_crypto.hmac.create.html b/functions/_libp2p_crypto.hmac.create.html index 2943c9074e..c91ebe4bd9 100644 --- a/functions/_libp2p_crypto.hmac.create.html +++ b/functions/_libp2p_crypto.hmac.create.html @@ -1 +1 @@ -create | libp2p
    \ No newline at end of file +create | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_crypto.index.pbkdf2.html b/functions/_libp2p_crypto.index.pbkdf2.html index 53044003ee..2a1e3bc82b 100644 --- a/functions/_libp2p_crypto.index.pbkdf2.html +++ b/functions/_libp2p_crypto.index.pbkdf2.html @@ -1,2 +1,2 @@ pbkdf2 | libp2p
    • Computes the Password-Based Key Derivation Function 2.

      -

      Parameters

      • password: string
      • salt: string | Uint8Array
      • iterations: number
      • keySize: number
      • hash: string

      Returns string

    \ No newline at end of file +

    Parameters

    Returns string

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.index.randomBytes.html b/functions/_libp2p_crypto.index.randomBytes.html index 0ae3742551..ac5421b59a 100644 --- a/functions/_libp2p_crypto.index.randomBytes.html +++ b/functions/_libp2p_crypto.index.randomBytes.html @@ -1,2 +1,2 @@ randomBytes | libp2p
    \ No newline at end of file +

    Parameters

    Returns Uint8Array

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.generateEphemeralKeyPair.html b/functions/_libp2p_crypto.keys.generateEphemeralKeyPair.html index a1a9b02642..de90dd2630 100644 --- a/functions/_libp2p_crypto.keys.generateEphemeralKeyPair.html +++ b/functions/_libp2p_crypto.keys.generateEphemeralKeyPair.html @@ -1,3 +1,3 @@ generateEphemeralKeyPair | libp2p

    Function generateEphemeralKeyPair

    • Generates an ephemeral public key and returns a function that will compute the shared secret key.

      Focuses only on ECDH now, but can be made more general in the future.

      -

      Parameters

      Returns Promise<ECDHKey>

    \ No newline at end of file +

    Parameters

    Returns Promise<ECDHKey>

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.generateKeyPair.html b/functions/_libp2p_crypto.keys.generateKeyPair.html index 6189638ac4..11a6061b7b 100644 --- a/functions/_libp2p_crypto.keys.generateKeyPair.html +++ b/functions/_libp2p_crypto.keys.generateKeyPair.html @@ -1,2 +1,2 @@ generateKeyPair | libp2p
    \ No newline at end of file +

    Parameters

    Returns Promise<Ed25519PrivateKey>

  • Parameters

    • type: "secp256k1"

    Returns Promise<Secp256k1PrivateKey>

  • Parameters

    • type: "RSA"
    • Optional bits: number

    Returns Promise<RSAPrivateKey>

  • Parameters

    Returns Promise<PrivateKey>

  • \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.generateKeyPairFromSeed.html b/functions/_libp2p_crypto.keys.generateKeyPairFromSeed.html index a6cb5d526c..66f5a8653e 100644 --- a/functions/_libp2p_crypto.keys.generateKeyPairFromSeed.html +++ b/functions/_libp2p_crypto.keys.generateKeyPairFromSeed.html @@ -1,4 +1,4 @@ generateKeyPairFromSeed | libp2p

    Function generateKeyPairFromSeed

    \ No newline at end of file +

    Parameters

    Returns Promise<Ed25519PrivateKey>

  • Type Parameters

    Parameters

    Returns Promise<never>

  • \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.keyStretcher.html b/functions/_libp2p_crypto.keys.keyStretcher.html index 3c1838f3fb..890fbe181c 100644 --- a/functions/_libp2p_crypto.keys.keyStretcher.html +++ b/functions/_libp2p_crypto.keys.keyStretcher.html @@ -1,3 +1,3 @@ keyStretcher | libp2p
    \ No newline at end of file +

    Parameters

    Returns Promise<EnhancedKeyPair>

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.privateKeyFromProtobuf.html b/functions/_libp2p_crypto.keys.privateKeyFromProtobuf.html index 36a587ff50..e1003f0cb9 100644 --- a/functions/_libp2p_crypto.keys.privateKeyFromProtobuf.html +++ b/functions/_libp2p_crypto.keys.privateKeyFromProtobuf.html @@ -1,2 +1,2 @@ privateKeyFromProtobuf | libp2p

    Function privateKeyFromProtobuf

    \ No newline at end of file +

    Parameters

    Returns Ed25519PrivateKey | Secp256k1PrivateKey | RSAPrivateKey

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.privateKeyFromRaw.html b/functions/_libp2p_crypto.keys.privateKeyFromRaw.html index caa93f55ac..d2883d386a 100644 --- a/functions/_libp2p_crypto.keys.privateKeyFromRaw.html +++ b/functions/_libp2p_crypto.keys.privateKeyFromRaw.html @@ -1,4 +1,4 @@ privateKeyFromRaw | libp2p
    • Creates a private key from the raw key bytes. For Ed25519 keys this requires the public key to be appended to the private key otherwise we can't differentiate between Ed25519 and secp256k1 keys as they are the same length.

      -

      Parameters

      Returns PrivateKey

    \ No newline at end of file +

    Parameters

    Returns PrivateKey

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.privateKeyToProtobuf.html b/functions/_libp2p_crypto.keys.privateKeyToProtobuf.html index fb36e0cc68..50b516edae 100644 --- a/functions/_libp2p_crypto.keys.privateKeyToProtobuf.html +++ b/functions/_libp2p_crypto.keys.privateKeyToProtobuf.html @@ -1,2 +1,2 @@ privateKeyToProtobuf | libp2p
    \ No newline at end of file +

    Parameters

    Returns Uint8Array

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.publicKeyFromMultihash.html b/functions/_libp2p_crypto.keys.publicKeyFromMultihash.html index 1f8342367b..b94b23b7fc 100644 --- a/functions/_libp2p_crypto.keys.publicKeyFromMultihash.html +++ b/functions/_libp2p_crypto.keys.publicKeyFromMultihash.html @@ -2,4 +2,4 @@ encoded Ed25519 or secp256k1 public key.

    RSA keys are not supported as in practice we they are not stored in identity multihashes since the hash would be very large.

    -

    Parameters

    Returns Ed25519PublicKey | Secp256k1PublicKey

    \ No newline at end of file +

    Parameters

    Returns Ed25519PublicKey | Secp256k1PublicKey

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.publicKeyFromProtobuf.html b/functions/_libp2p_crypto.keys.publicKeyFromProtobuf.html index 63e186b241..e59c312153 100644 --- a/functions/_libp2p_crypto.keys.publicKeyFromProtobuf.html +++ b/functions/_libp2p_crypto.keys.publicKeyFromProtobuf.html @@ -1,2 +1,2 @@ publicKeyFromProtobuf | libp2p

    Function publicKeyFromProtobuf

    \ No newline at end of file +

    Parameters

    Returns PublicKey

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.publicKeyFromRaw.html b/functions/_libp2p_crypto.keys.publicKeyFromRaw.html index 7322c21e95..278138633c 100644 --- a/functions/_libp2p_crypto.keys.publicKeyFromRaw.html +++ b/functions/_libp2p_crypto.keys.publicKeyFromRaw.html @@ -1,2 +1,2 @@ publicKeyFromRaw | libp2p
    \ No newline at end of file +

    Parameters

    Returns PublicKey

    \ No newline at end of file diff --git a/functions/_libp2p_crypto.keys.publicKeyToProtobuf.html b/functions/_libp2p_crypto.keys.publicKeyToProtobuf.html index e9e4ffe683..3ed76c08ea 100644 --- a/functions/_libp2p_crypto.keys.publicKeyToProtobuf.html +++ b/functions/_libp2p_crypto.keys.publicKeyToProtobuf.html @@ -1,2 +1,2 @@ publicKeyToProtobuf | libp2p
    \ No newline at end of file +

    Parameters

    Returns Uint8Array

    \ No newline at end of file diff --git a/functions/_libp2p_dcutr.dcutr.html b/functions/_libp2p_dcutr.dcutr.html index 72f3198dc7..5a712e2124 100644 --- a/functions/_libp2p_dcutr.dcutr.html +++ b/functions/_libp2p_dcutr.dcutr.html @@ -1 +1 @@ -dcutr | libp2p
    \ No newline at end of file +dcutr | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_devtools_metrics.devToolsMetrics.html b/functions/_libp2p_devtools_metrics.devToolsMetrics.html index c51ba7cee0..a85bebabad 100644 --- a/functions/_libp2p_devtools_metrics.devToolsMetrics.html +++ b/functions/_libp2p_devtools_metrics.devToolsMetrics.html @@ -1 +1 @@ -devToolsMetrics | libp2p
    \ No newline at end of file +devToolsMetrics | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_echo.echo-1.html b/functions/_libp2p_echo.echo-1.html index 4230ddc1b2..eb903fd31a 100644 --- a/functions/_libp2p_echo.echo-1.html +++ b/functions/_libp2p_echo.echo-1.html @@ -1 +1 @@ -echo | libp2p
    \ No newline at end of file +echo | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_fetch.fetch-1.html b/functions/_libp2p_fetch.fetch-1.html index 622a1efc53..45ce390d8c 100644 --- a/functions/_libp2p_fetch.fetch-1.html +++ b/functions/_libp2p_fetch.fetch-1.html @@ -1 +1 @@ -fetch | libp2p
    \ No newline at end of file +fetch | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_floodsub.floodsub-1.html b/functions/_libp2p_floodsub.floodsub-1.html index 4019a635ff..e8dd087243 100644 --- a/functions/_libp2p_floodsub.floodsub-1.html +++ b/functions/_libp2p_floodsub.floodsub-1.html @@ -1 +1 @@ -floodsub | libp2p
    \ No newline at end of file +floodsub | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_identify.identify-1.html b/functions/_libp2p_identify.identify-1.html index db5c346000..10706831a8 100644 --- a/functions/_libp2p_identify.identify-1.html +++ b/functions/_libp2p_identify.identify-1.html @@ -1 +1 @@ -identify | libp2p
    \ No newline at end of file +identify | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_identify.identifyPush-1.html b/functions/_libp2p_identify.identifyPush-1.html index a42be55015..71121b4806 100644 --- a/functions/_libp2p_identify.identifyPush-1.html +++ b/functions/_libp2p_identify.identifyPush-1.html @@ -1 +1 @@ -identifyPush | libp2p
    \ No newline at end of file +identifyPush | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface.isConnection.html b/functions/_libp2p_interface.isConnection.html index ae4a0d22b3..1dcc29d526 100644 --- a/functions/_libp2p_interface.isConnection.html +++ b/functions/_libp2p_interface.isConnection.html @@ -1 +1 @@ -isConnection | libp2p
    \ No newline at end of file +isConnection | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface.isPeerId.html b/functions/_libp2p_interface.isPeerId.html index a3f728a91a..bad817b10b 100644 --- a/functions/_libp2p_interface.isPeerId.html +++ b/functions/_libp2p_interface.isPeerId.html @@ -1,2 +1,2 @@ isPeerId | libp2p
    \ No newline at end of file +

    Parameters

    Returns other is PeerId

    \ No newline at end of file diff --git a/functions/_libp2p_interface.isPrivateKey.html b/functions/_libp2p_interface.isPrivateKey.html index 23c13d4112..5f58fd8e02 100644 --- a/functions/_libp2p_interface.isPrivateKey.html +++ b/functions/_libp2p_interface.isPrivateKey.html @@ -1,3 +1,3 @@ isPrivateKey | libp2p
    \ No newline at end of file +

    Parameters

    Returns key is PrivateKey

    \ No newline at end of file diff --git a/functions/_libp2p_interface.isPublicKey.html b/functions/_libp2p_interface.isPublicKey.html index a415512918..54ed5cc6d8 100644 --- a/functions/_libp2p_interface.isPublicKey.html +++ b/functions/_libp2p_interface.isPublicKey.html @@ -1,3 +1,3 @@ isPublicKey | libp2p
    \ No newline at end of file +

    Parameters

    Returns key is PublicKey

    \ No newline at end of file diff --git a/functions/_libp2p_interface.isStartable.html b/functions/_libp2p_interface.isStartable.html index c51ccb831e..497061b0f4 100644 --- a/functions/_libp2p_interface.isStartable.html +++ b/functions/_libp2p_interface.isStartable.html @@ -1 +1 @@ -isStartable | libp2p
    \ No newline at end of file +isStartable | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface.isTransport.html b/functions/_libp2p_interface.isTransport.html index ade98cc960..7cd4a66b34 100644 --- a/functions/_libp2p_interface.isTransport.html +++ b/functions/_libp2p_interface.isTransport.html @@ -1 +1 @@ -isTransport | libp2p
    \ No newline at end of file +isTransport | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface.setMaxListeners.html b/functions/_libp2p_interface.setMaxListeners.html index 672080d868..690e875ba4 100644 --- a/functions/_libp2p_interface.setMaxListeners.html +++ b/functions/_libp2p_interface.setMaxListeners.html @@ -2,4 +2,4 @@

    Parameters

    Returns void

    Since

    v15.4.0

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_interface.start.html b/functions/_libp2p_interface.start.html index 555060de49..42e897ed2b 100644 --- a/functions/_libp2p_interface.start.html +++ b/functions/_libp2p_interface.start.html @@ -1 +1 @@ -start | libp2p
    \ No newline at end of file +start | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface.stop.html b/functions/_libp2p_interface.stop.html index 46cb2630fc..ce3cbc744c 100644 --- a/functions/_libp2p_interface.stop.html +++ b/functions/_libp2p_interface.stop.html @@ -1 +1 @@ -stop | libp2p
    \ No newline at end of file +stop | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.connection.default.html b/functions/_libp2p_interface_compliance_tests.connection.default.html index 431590f5c6..97cff0ebf5 100644 --- a/functions/_libp2p_interface_compliance_tests.connection.default.html +++ b/functions/_libp2p_interface_compliance_tests.connection.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.connection_encryption.default.html b/functions/_libp2p_interface_compliance_tests.connection_encryption.default.html index 226578c36f..8295b18ab3 100644 --- a/functions/_libp2p_interface_compliance_tests.connection_encryption.default.html +++ b/functions/_libp2p_interface_compliance_tests.connection_encryption.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.is_valid_tick.isValidTick.html b/functions/_libp2p_interface_compliance_tests.is_valid_tick.isValidTick.html index 20344cd621..10c61cf305 100644 --- a/functions/_libp2p_interface_compliance_tests.is_valid_tick.isValidTick.html +++ b/functions/_libp2p_interface_compliance_tests.is_valid_tick.isValidTick.html @@ -1,3 +1,3 @@ isValidTick | libp2p
    • A tick is considered valid if it happened between now and ms milliseconds ago

      -

      Parameters

      • Optional date: number
      • ms: number = 5000

      Returns boolean

    \ No newline at end of file +

    Parameters

    Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.matchers.matchMultiaddr.html b/functions/_libp2p_interface_compliance_tests.matchers.matchMultiaddr.html index 6b7c43959d..ec9f2df97e 100644 --- a/functions/_libp2p_interface_compliance_tests.matchers.matchMultiaddr.html +++ b/functions/_libp2p_interface_compliance_tests.matchers.matchMultiaddr.html @@ -1 +1 @@ -matchMultiaddr | libp2p
    \ No newline at end of file +matchMultiaddr | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.matchers.matchPeerId.html b/functions/_libp2p_interface_compliance_tests.matchers.matchPeerId.html index 658541f792..8bcabea7d8 100644 --- a/functions/_libp2p_interface_compliance_tests.matchers.matchPeerId.html +++ b/functions/_libp2p_interface_compliance_tests.matchers.matchPeerId.html @@ -1 +1 @@ -matchPeerId | libp2p
    \ No newline at end of file +matchPeerId | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.connectionPair.html b/functions/_libp2p_interface_compliance_tests.mocks.connectionPair.html index caaf969646..e19179137b 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.connectionPair.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.connectionPair.html @@ -1 +1 @@ -connectionPair | libp2p
    \ No newline at end of file +connectionPair | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockConnection.html b/functions/_libp2p_interface_compliance_tests.mocks.mockConnection.html index 2e495bed83..9b3e0cbdcd 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockConnection.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockConnection.html @@ -1 +1 @@ -mockConnection | libp2p
    \ No newline at end of file +mockConnection | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionGater.html b/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionGater.html index a9c53bdb40..7d7da03a2d 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionGater.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionGater.html @@ -1 +1 @@ -mockConnectionGater | libp2p
    \ No newline at end of file +mockConnectionGater | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionManager.html b/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionManager.html index 44888514cc..fa397c15ac 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionManager.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockConnectionManager.html @@ -1 +1 @@ -mockConnectionManager | libp2p
    \ No newline at end of file +mockConnectionManager | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockDuplex.html b/functions/_libp2p_interface_compliance_tests.mocks.mockDuplex.html index 44c4cc0d45..fe6cea2c8c 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockDuplex.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockDuplex.html @@ -1 +1 @@ -mockDuplex | libp2p
    \ No newline at end of file +mockDuplex | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockMetrics.html b/functions/_libp2p_interface_compliance_tests.mocks.mockMetrics.html index 36d93e2a57..beda06146e 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockMetrics.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockMetrics.html @@ -1 +1 @@ -mockMetrics | libp2p
    \ No newline at end of file +mockMetrics | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnPair.html b/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnPair.html index 263d0fe5b4..13ec8c2f4f 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnPair.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnPair.html @@ -1,2 +1,2 @@ mockMultiaddrConnPair | libp2p
    \ No newline at end of file +

    Parameters

    Returns {
        inbound: MultiaddrConnection;
        outbound: MultiaddrConnection;
    }

    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnection.html b/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnection.html index 201696b6ee..c1a0b4a3fb 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnection.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockMultiaddrConnection.html @@ -1 +1 @@ -mockMultiaddrConnection | libp2p
    \ No newline at end of file +mockMultiaddrConnection | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockMuxer.html b/functions/_libp2p_interface_compliance_tests.mocks.mockMuxer.html index 70609b131b..9156795159 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockMuxer.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockMuxer.html @@ -1 +1 @@ -mockMuxer | libp2p
    \ No newline at end of file +mockMuxer | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockRegistrar.html b/functions/_libp2p_interface_compliance_tests.mocks.mockRegistrar.html index ae458c5783..5782dee64f 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockRegistrar.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockRegistrar.html @@ -1 +1 @@ -mockRegistrar | libp2p
    \ No newline at end of file +mockRegistrar | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockStream.html b/functions/_libp2p_interface_compliance_tests.mocks.mockStream.html index 9f4c108e20..73daf33834 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockStream.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockStream.html @@ -1 +1 @@ -mockStream | libp2p
    \ No newline at end of file +mockStream | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.mockUpgrader.html b/functions/_libp2p_interface_compliance_tests.mocks.mockUpgrader.html index 16c7062a17..6816499c39 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.mockUpgrader.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.mockUpgrader.html @@ -1 +1 @@ -mockUpgrader | libp2p
    \ No newline at end of file +mockUpgrader | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.mocks.streamPair.html b/functions/_libp2p_interface_compliance_tests.mocks.streamPair.html index 807c667e4e..035ba9b2f9 100644 --- a/functions/_libp2p_interface_compliance_tests.mocks.streamPair.html +++ b/functions/_libp2p_interface_compliance_tests.mocks.streamPair.html @@ -1 +1 @@ -streamPair | libp2p
    \ No newline at end of file +streamPair | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.peer_discovery.default.html b/functions/_libp2p_interface_compliance_tests.peer_discovery.default.html index 86e1a01c99..91d09fb377 100644 --- a/functions/_libp2p_interface_compliance_tests.peer_discovery.default.html +++ b/functions/_libp2p_interface_compliance_tests.peer_discovery.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.pubsub.default.html b/functions/_libp2p_interface_compliance_tests.pubsub.default.html index bb2b5a4ea9..2f2b602375 100644 --- a/functions/_libp2p_interface_compliance_tests.pubsub.default.html +++ b/functions/_libp2p_interface_compliance_tests.pubsub.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.stream_muxer.default.html b/functions/_libp2p_interface_compliance_tests.stream_muxer.default.html index a5a3ee8d67..a4b389a67a 100644 --- a/functions/_libp2p_interface_compliance_tests.stream_muxer.default.html +++ b/functions/_libp2p_interface_compliance_tests.stream_muxer.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_interface_compliance_tests.transport.default.html b/functions/_libp2p_interface_compliance_tests.transport.default.html index 482d342aeb..b44a7d28a1 100644 --- a/functions/_libp2p_interface_compliance_tests.transport.default.html +++ b/functions/_libp2p_interface_compliance_tests.transport.default.html @@ -1 +1 @@ -default | libp2p
    \ No newline at end of file +default | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_kad_dht.MessageType.codec.html b/functions/_libp2p_kad_dht.MessageType.codec.html index f474bf9a32..8266e7a36e 100644 --- a/functions/_libp2p_kad_dht.MessageType.codec.html +++ b/functions/_libp2p_kad_dht.MessageType.codec.html @@ -1 +1 @@ -codec | libp2p
    \ No newline at end of file +codec | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_kad_dht.kadDHT-1.html b/functions/_libp2p_kad_dht.kadDHT-1.html index 05cf8988d7..3fa5586fc7 100644 --- a/functions/_libp2p_kad_dht.kadDHT-1.html +++ b/functions/_libp2p_kad_dht.kadDHT-1.html @@ -1,3 +1,3 @@ kadDHT | libp2p
    \ No newline at end of file +

    Parameters

    Returns ((components) => KadDHT)

    \ No newline at end of file diff --git a/functions/_libp2p_kad_dht.passthroughMapper.html b/functions/_libp2p_kad_dht.passthroughMapper.html index 77778d3b4c..80f0aa2f41 100644 --- a/functions/_libp2p_kad_dht.passthroughMapper.html +++ b/functions/_libp2p_kad_dht.passthroughMapper.html @@ -1 +1 @@ -passthroughMapper | libp2p

    Function passthroughMapper

    \ No newline at end of file +passthroughMapper | libp2p

    Function passthroughMapper

    \ No newline at end of file diff --git a/functions/_libp2p_kad_dht.removePrivateAddressesMapper.html b/functions/_libp2p_kad_dht.removePrivateAddressesMapper.html index c65e373dac..a79d82daf3 100644 --- a/functions/_libp2p_kad_dht.removePrivateAddressesMapper.html +++ b/functions/_libp2p_kad_dht.removePrivateAddressesMapper.html @@ -1 +1 @@ -removePrivateAddressesMapper | libp2p

    Function removePrivateAddressesMapper

    \ No newline at end of file +removePrivateAddressesMapper | libp2p

    Function removePrivateAddressesMapper

    \ No newline at end of file diff --git a/functions/_libp2p_kad_dht.removePublicAddressesMapper.html b/functions/_libp2p_kad_dht.removePublicAddressesMapper.html index 36670c9699..37f3650d77 100644 --- a/functions/_libp2p_kad_dht.removePublicAddressesMapper.html +++ b/functions/_libp2p_kad_dht.removePublicAddressesMapper.html @@ -1 +1 @@ -removePublicAddressesMapper | libp2p

    Function removePublicAddressesMapper

    \ No newline at end of file +removePublicAddressesMapper | libp2p

    Function removePublicAddressesMapper

    \ No newline at end of file diff --git a/functions/_libp2p_keychain.keychain-1.html b/functions/_libp2p_keychain.keychain-1.html index 1a6ae9910c..3545c48176 100644 --- a/functions/_libp2p_keychain.keychain-1.html +++ b/functions/_libp2p_keychain.keychain-1.html @@ -1 +1 @@ -keychain | libp2p
    \ No newline at end of file +keychain | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_logger.defaultLogger.html b/functions/_libp2p_logger.defaultLogger.html index 7d7f202b10..8da3d35992 100644 --- a/functions/_libp2p_logger.defaultLogger.html +++ b/functions/_libp2p_logger.defaultLogger.html @@ -1,4 +1,4 @@ defaultLogger | libp2p

    Function defaultLogger

    • Create a component logger

      Returns ComponentLogger

      Example

      import { defaultLogger } from '@libp2p/logger'
      import { peerIdFromString } from '@libp2p/peer-id'

      const logger = defaultLogger()

      const log = logger.forComponent('my-component')
      log.info('hello world')
      // logs "my-component hello world"
      -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_logger.disable.html b/functions/_libp2p_logger.disable.html index 5e79f10332..7d5b5804cc 100644 --- a/functions/_libp2p_logger.disable.html +++ b/functions/_libp2p_logger.disable.html @@ -1 +1 @@ -disable | libp2p
    \ No newline at end of file +disable | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_logger.enable.html b/functions/_libp2p_logger.enable.html index 9c3be4ea39..2d0837310c 100644 --- a/functions/_libp2p_logger.enable.html +++ b/functions/_libp2p_logger.enable.html @@ -1 +1 @@ -enable | libp2p
    • Parameters

      • namespaces: string

      Returns void

    \ No newline at end of file +enable | libp2p
    • Parameters

      • namespaces: string

      Returns void

    \ No newline at end of file diff --git a/functions/_libp2p_logger.enabled.html b/functions/_libp2p_logger.enabled.html index 5545f8281e..036e6d609c 100644 --- a/functions/_libp2p_logger.enabled.html +++ b/functions/_libp2p_logger.enabled.html @@ -1 +1 @@ -enabled | libp2p
    • Parameters

      • namespaces: string

      Returns boolean

    \ No newline at end of file +enabled | libp2p
    • Parameters

      • namespaces: string

      Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_logger.logger-1.html b/functions/_libp2p_logger.logger-1.html index 6a137ec12b..d0b79dd92d 100644 --- a/functions/_libp2p_logger.logger-1.html +++ b/functions/_libp2p_logger.logger-1.html @@ -1,4 +1,4 @@ logger | libp2p
    • Creates a logger for the passed component name.

      Parameters

      • name: string

      Returns Logger

      Example

      import { logger } from '@libp2p/logger'

      const log = logger('my-component')
      log.info('hello world')
      // logs "my-component hello world"
      -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_logger.peerLogger.html b/functions/_libp2p_logger.peerLogger.html index e7570ee0f0..12eb052099 100644 --- a/functions/_libp2p_logger.peerLogger.html +++ b/functions/_libp2p_logger.peerLogger.html @@ -2,4 +2,4 @@ peer id.

    Parameters

    Returns ComponentLogger

    Example

    import { peerLogger } from '@libp2p/logger'
    import { peerIdFromString } from '@libp2p/peer-id'

    const peerId = peerIdFromString('12D3FooBar')
    const logger = peerLogger(peerId)

    const log = logger.forComponent('my-component')
    log.info('hello world')
    // logs "12…oBar:my-component hello world"
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_logger.prefixLogger.html b/functions/_libp2p_logger.prefixLogger.html index 74da0a8324..8ddc8660b2 100644 --- a/functions/_libp2p_logger.prefixLogger.html +++ b/functions/_libp2p_logger.prefixLogger.html @@ -2,4 +2,4 @@ string.

    Parameters

    Returns ComponentLogger

    Example

    import { prefixLogger } from '@libp2p/logger'

    const logger = prefixLogger('my-node')

    const log = logger.forComponent('my-component')
    log.info('hello world')
    // logs "my-node:my-component hello world"
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_mdns.mdns.html b/functions/_libp2p_mdns.mdns.html index 718049aa5c..196e23f063 100644 --- a/functions/_libp2p_mdns.mdns.html +++ b/functions/_libp2p_mdns.mdns.html @@ -1 +1 @@ -mdns | libp2p
    \ No newline at end of file +mdns | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_mplex.mplex.html b/functions/_libp2p_mplex.mplex.html index 531afae0f7..1700b71948 100644 --- a/functions/_libp2p_mplex.mplex.html +++ b/functions/_libp2p_mplex.mplex.html @@ -1,2 +1,2 @@ mplex | libp2p
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_multistream_select.handle.html b/functions/_libp2p_multistream_select.handle.html index 4533372162..a9fb15afc2 100644 --- a/functions/_libp2p_multistream_select.handle.html +++ b/functions/_libp2p_multistream_select.handle.html @@ -6,4 +6,4 @@

    Returns Promise<ProtocolStream<Stream>>

    A stream for the selected protocol and the protocol that was selected from the list of protocols provided to select

    Example

    import { pipe } from 'it-pipe'
    import * as mss from '@libp2p/multistream-select'
    import { Mplex } from '@libp2p/mplex'

    const muxer = new Mplex({
    async onStream (muxedStream) {
    // mss.handle(handledProtocols)
    // Returns selected stream and protocol
    const { stream, protocol } = await mss.handle(muxedStream, [
    '/ipfs-dht/1.0.0',
    '/ipfs-bitswap/1.0.0'
    ])

    // Typically here we'd call the handler function that was registered in
    // libp2p for the given protocol:
    // e.g. handlers[protocol].handler(stream)
    //
    // If protocol was /ipfs-dht/1.0.0 it might do something like this:
    // try {
    // await pipe(
    // dhtStream,
    // source => (async function * () {
    // for await (const chunk of source)
    // // Incoming DHT data -> process and yield to respond
    // })(),
    // dhtStream
    // )
    // } catch (err) {
    // // Error in stream
    // }
    }
    })
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_multistream_select.select.html b/functions/_libp2p_multistream_select.select.html index 3f658e7a8c..fc99d6bd61 100644 --- a/functions/_libp2p_multistream_select.select.html +++ b/functions/_libp2p_multistream_select.select.html @@ -5,4 +5,4 @@

    Returns Promise<ProtocolStream<Stream>>

    A stream for the selected protocol and the protocol that was selected from the list of protocols provided to select.

    Example

    import { pipe } from 'it-pipe'
    import * as mss from '@libp2p/multistream-select'
    import { Mplex } from '@libp2p/mplex'

    const muxer = new Mplex()
    const muxedStream = muxer.newStream()

    // mss.select(protocol(s))
    // Select from one of the passed protocols (in priority order)
    // Returns selected stream and protocol
    const { stream: dhtStream, protocol } = await mss.select(muxedStream, [
    // This might just be different versions of DHT, but could be different impls
    '/ipfs-dht/2.0.0', // Most of the time this will probably just be one item.
    '/ipfs-dht/1.0.0'
    ])

    // Typically this stream will be passed back to the caller of libp2p.dialProtocol
    //
    // ...it might then do something like this:
    // try {
    // await pipe(
    // [uint8ArrayFromString('Some DHT data')]
    // dhtStream,
    // async source => {
    // for await (const chunk of source)
    // // DHT response data
    // }
    // )
    // } catch (err) {
    // // Error in stream
    // }
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.peerFilter-1.html b/functions/_libp2p_peer_collections.peerFilter-1.html index afbfab847d..c8e0399bff 100644 --- a/functions/_libp2p_peer_collections.peerFilter-1.html +++ b/functions/_libp2p_peer_collections.peerFilter-1.html @@ -1,4 +1,4 @@ peerFilter | libp2p
    • Create and return a PeerFilter

      Parameters

      • size: number

        The maximum number of peers expected to be added to the filter

      • errorRate: number = 0.001

        The acceptable error rate

        -

      Returns PeerFilter

    \ No newline at end of file +

    Returns PeerFilter

    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.peerList-1.html b/functions/_libp2p_peer_collections.peerList-1.html index 33d3899a81..565863953a 100644 --- a/functions/_libp2p_peer_collections.peerList-1.html +++ b/functions/_libp2p_peer_collections.peerList-1.html @@ -1 +1 @@ -peerList | libp2p
    \ No newline at end of file +peerList | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.peerMap-1.html b/functions/_libp2p_peer_collections.peerMap-1.html index 437521f2fa..224d8f7c65 100644 --- a/functions/_libp2p_peer_collections.peerMap-1.html +++ b/functions/_libp2p_peer_collections.peerMap-1.html @@ -1 +1 @@ -peerMap | libp2p
    \ No newline at end of file +peerMap | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.peerSet-1.html b/functions/_libp2p_peer_collections.peerSet-1.html index 8c7e85d76e..a193d986ca 100644 --- a/functions/_libp2p_peer_collections.peerSet-1.html +++ b/functions/_libp2p_peer_collections.peerSet-1.html @@ -1 +1 @@ -peerSet | libp2p
    \ No newline at end of file +peerSet | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.trackedPeerList.html b/functions/_libp2p_peer_collections.trackedPeerList.html index 8d5ee7762b..ee10dbf37c 100644 --- a/functions/_libp2p_peer_collections.trackedPeerList.html +++ b/functions/_libp2p_peer_collections.trackedPeerList.html @@ -10,4 +10,4 @@

    const list = trackedPeerList({ name: 'my_metric_name', metrics: libp2p.metrics }) list.push(peerId) ```

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.trackedPeerMap.html b/functions/_libp2p_peer_collections.trackedPeerMap.html index 736c71126a..91202f1db4 100644 --- a/functions/_libp2p_peer_collections.trackedPeerMap.html +++ b/functions/_libp2p_peer_collections.trackedPeerMap.html @@ -10,4 +10,4 @@

    const list = trackedPeerMap({ name: 'my_metric_name', metrics: libp2p.metrics }) map.set(peerId, 'value') ```

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_peer_collections.trackedPeerSet.html b/functions/_libp2p_peer_collections.trackedPeerSet.html index 9786ce6c07..d384741f53 100644 --- a/functions/_libp2p_peer_collections.trackedPeerSet.html +++ b/functions/_libp2p_peer_collections.trackedPeerSet.html @@ -10,4 +10,4 @@

    const list = trackedPeerSet({ name: 'my_metric_name', metrics: libp2p.metrics }) map.add(peerId) ```

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/functions/_libp2p_peer_id.peerIdFromCID.html b/functions/_libp2p_peer_id.peerIdFromCID.html index 0efb928e0c..15dc5f2e51 100644 --- a/functions/_libp2p_peer_id.peerIdFromCID.html +++ b/functions/_libp2p_peer_id.peerIdFromCID.html @@ -1 +1 @@ -peerIdFromCID | libp2p
    \ No newline at end of file +peerIdFromCID | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_peer_id.peerIdFromMultihash.html b/functions/_libp2p_peer_id.peerIdFromMultihash.html index d109b362cf..971d509119 100644 --- a/functions/_libp2p_peer_id.peerIdFromMultihash.html +++ b/functions/_libp2p_peer_id.peerIdFromMultihash.html @@ -1 +1 @@ -peerIdFromMultihash | libp2p

    Function peerIdFromMultihash

    \ No newline at end of file +peerIdFromMultihash | libp2p

    Function peerIdFromMultihash

    \ No newline at end of file diff --git a/functions/_libp2p_peer_id.peerIdFromPrivateKey.html b/functions/_libp2p_peer_id.peerIdFromPrivateKey.html index f009e6086c..07c4ca2c28 100644 --- a/functions/_libp2p_peer_id.peerIdFromPrivateKey.html +++ b/functions/_libp2p_peer_id.peerIdFromPrivateKey.html @@ -1 +1 @@ -peerIdFromPrivateKey | libp2p

    Function peerIdFromPrivateKey

    \ No newline at end of file +peerIdFromPrivateKey | libp2p

    Function peerIdFromPrivateKey

    \ No newline at end of file diff --git a/functions/_libp2p_peer_id.peerIdFromPublicKey.html b/functions/_libp2p_peer_id.peerIdFromPublicKey.html index 149d700628..86ce8be40e 100644 --- a/functions/_libp2p_peer_id.peerIdFromPublicKey.html +++ b/functions/_libp2p_peer_id.peerIdFromPublicKey.html @@ -1 +1 @@ -peerIdFromPublicKey | libp2p

    Function peerIdFromPublicKey

    \ No newline at end of file +peerIdFromPublicKey | libp2p

    Function peerIdFromPublicKey

    \ No newline at end of file diff --git a/functions/_libp2p_peer_id.peerIdFromString.html b/functions/_libp2p_peer_id.peerIdFromString.html index 7721dc7484..76ea6053fd 100644 --- a/functions/_libp2p_peer_id.peerIdFromString.html +++ b/functions/_libp2p_peer_id.peerIdFromString.html @@ -1 +1 @@ -peerIdFromString | libp2p

    Function peerIdFromString

    \ No newline at end of file +peerIdFromString | libp2p

    Function peerIdFromString

    \ No newline at end of file diff --git a/functions/_libp2p_perf.perf-1.html b/functions/_libp2p_perf.perf-1.html index 72898f0294..9db4a77b63 100644 --- a/functions/_libp2p_perf.perf-1.html +++ b/functions/_libp2p_perf.perf-1.html @@ -1 +1 @@ -perf | libp2p
    \ No newline at end of file +perf | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_ping.ping.html b/functions/_libp2p_ping.ping.html index 86aac6fd90..9d24b8b6a0 100644 --- a/functions/_libp2p_ping.ping.html +++ b/functions/_libp2p_ping.ping.html @@ -1 +1 @@ -ping | libp2p
    \ No newline at end of file +ping | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_plaintext.plaintext.html b/functions/_libp2p_plaintext.plaintext.html index 8e119c7611..f044bf2ef7 100644 --- a/functions/_libp2p_plaintext.plaintext.html +++ b/functions/_libp2p_plaintext.plaintext.html @@ -1 +1 @@ -plaintext | libp2p
    \ No newline at end of file +plaintext | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_pnet.generateKey.html b/functions/_libp2p_pnet.generateKey.html index 7fadcf1c41..b89b4bccf1 100644 --- a/functions/_libp2p_pnet.generateKey.html +++ b/functions/_libp2p_pnet.generateKey.html @@ -1,3 +1,3 @@ generateKey | libp2p

    Function generateKey

    • Generates a PSK that can be used in a libp2p-pnet private network

      Parameters

      Returns void

    \ No newline at end of file +

    Returns void

    \ No newline at end of file diff --git a/functions/_libp2p_pnet.preSharedKey.html b/functions/_libp2p_pnet.preSharedKey.html index 4515ae26ba..d2d1f675d5 100644 --- a/functions/_libp2p_pnet.preSharedKey.html +++ b/functions/_libp2p_pnet.preSharedKey.html @@ -1 +1 @@ -preSharedKey | libp2p

    Function preSharedKey

    \ No newline at end of file +preSharedKey | libp2p

    Function preSharedKey

    \ No newline at end of file diff --git a/functions/_libp2p_prometheus_metrics.prometheusMetrics.html b/functions/_libp2p_prometheus_metrics.prometheusMetrics.html index c12f8042eb..8bab7836bb 100644 --- a/functions/_libp2p_prometheus_metrics.prometheusMetrics.html +++ b/functions/_libp2p_prometheus_metrics.prometheusMetrics.html @@ -1 +1 @@ -prometheusMetrics | libp2p
    \ No newline at end of file +prometheusMetrics | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.anyMatch.html b/functions/_libp2p_pubsub.utils.anyMatch.html index e1f38f3e76..798785b66f 100644 --- a/functions/_libp2p_pubsub.utils.anyMatch.html +++ b/functions/_libp2p_pubsub.utils.anyMatch.html @@ -1,3 +1,3 @@ anyMatch | libp2p
    • Check if any member of the first set is also a member of the second set

      -

      Parameters

      • a: Set<number> | number[]
      • b: Set<number> | number[]

      Returns boolean

    \ No newline at end of file +

    Parameters

    Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.bigIntFromBytes.html b/functions/_libp2p_pubsub.utils.bigIntFromBytes.html index 7463cf3c1b..a29bbe9ff7 100644 --- a/functions/_libp2p_pubsub.utils.bigIntFromBytes.html +++ b/functions/_libp2p_pubsub.utils.bigIntFromBytes.html @@ -1 +1 @@ -bigIntFromBytes | libp2p
    \ No newline at end of file +bigIntFromBytes | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.bigIntToBytes.html b/functions/_libp2p_pubsub.utils.bigIntToBytes.html index 8518e4aa4c..9dbbda7759 100644 --- a/functions/_libp2p_pubsub.utils.bigIntToBytes.html +++ b/functions/_libp2p_pubsub.utils.bigIntToBytes.html @@ -1 +1 @@ -bigIntToBytes | libp2p
    \ No newline at end of file +bigIntToBytes | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.ensureArray.html b/functions/_libp2p_pubsub.utils.ensureArray.html index b235ecc1fd..24255cd8bb 100644 --- a/functions/_libp2p_pubsub.utils.ensureArray.html +++ b/functions/_libp2p_pubsub.utils.ensureArray.html @@ -1,2 +1,2 @@ ensureArray | libp2p
    • Make everything an array

      -

      Type Parameters

      • T

      Parameters

      • maybeArray: T | T[]

      Returns T[]

    \ No newline at end of file +

    Type Parameters

    Parameters

    Returns T[]

    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.msgId.html b/functions/_libp2p_pubsub.utils.msgId.html index 1e3bf982b6..00cdceedf8 100644 --- a/functions/_libp2p_pubsub.utils.msgId.html +++ b/functions/_libp2p_pubsub.utils.msgId.html @@ -1,2 +1,2 @@ msgId | libp2p
    \ No newline at end of file +

    Parameters

    Returns Uint8Array

    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.noSignMsgId.html b/functions/_libp2p_pubsub.utils.noSignMsgId.html index 8c74cb41b2..8fd34e94d1 100644 --- a/functions/_libp2p_pubsub.utils.noSignMsgId.html +++ b/functions/_libp2p_pubsub.utils.noSignMsgId.html @@ -1,2 +1,2 @@ noSignMsgId | libp2p
    \ No newline at end of file +

    Parameters

    Returns Uint8Array | Promise<Uint8Array>

    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.randomSeqno.html b/functions/_libp2p_pubsub.utils.randomSeqno.html index 7badc84517..cb13dec48f 100644 --- a/functions/_libp2p_pubsub.utils.randomSeqno.html +++ b/functions/_libp2p_pubsub.utils.randomSeqno.html @@ -1,2 +1,2 @@ randomSeqno | libp2p
    \ No newline at end of file +

    Returns bigint

    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.toMessage.html b/functions/_libp2p_pubsub.utils.toMessage.html index 4423ef66e2..03baad90d0 100644 --- a/functions/_libp2p_pubsub.utils.toMessage.html +++ b/functions/_libp2p_pubsub.utils.toMessage.html @@ -1 +1 @@ -toMessage | libp2p
    \ No newline at end of file +toMessage | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_pubsub.utils.toRpcMessage.html b/functions/_libp2p_pubsub.utils.toRpcMessage.html index 7ebf174dad..cfa6864fb6 100644 --- a/functions/_libp2p_pubsub.utils.toRpcMessage.html +++ b/functions/_libp2p_pubsub.utils.toRpcMessage.html @@ -1 +1 @@ -toRpcMessage | libp2p
    \ No newline at end of file +toRpcMessage | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_simple_metrics.simpleMetrics.html b/functions/_libp2p_simple_metrics.simpleMetrics.html index 26cdeac5cb..03644cf0fb 100644 --- a/functions/_libp2p_simple_metrics.simpleMetrics.html +++ b/functions/_libp2p_simple_metrics.simpleMetrics.html @@ -1 +1 @@ -simpleMetrics | libp2p
    \ No newline at end of file +simpleMetrics | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_tcp.tcp.html b/functions/_libp2p_tcp.tcp.html index 3b910a6321..2d24e20905 100644 --- a/functions/_libp2p_tcp.tcp.html +++ b/functions/_libp2p_tcp.tcp.html @@ -1 +1 @@ -tcp | libp2p
    \ No newline at end of file +tcp | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_tls.tls.html b/functions/_libp2p_tls.tls.html index 87958e3e61..acbff57968 100644 --- a/functions/_libp2p_tls.tls.html +++ b/functions/_libp2p_tls.tls.html @@ -1 +1 @@ -tls | libp2p
    \ No newline at end of file +tls | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_upnp_nat.uPnPNAT-1.html b/functions/_libp2p_upnp_nat.uPnPNAT-1.html index 837328797a..e9d2577f4f 100644 --- a/functions/_libp2p_upnp_nat.uPnPNAT-1.html +++ b/functions/_libp2p_upnp_nat.uPnPNAT-1.html @@ -1 +1 @@ -uPnPNAT | libp2p
    \ No newline at end of file +uPnPNAT | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.abort_options.createTimeoutOptions.html b/functions/_libp2p_utils.abort_options.createTimeoutOptions.html index 7d0c02df06..c2b8e2e3e5 100644 --- a/functions/_libp2p_utils.abort_options.createTimeoutOptions.html +++ b/functions/_libp2p_utils.abort_options.createTimeoutOptions.html @@ -1 +1 @@ -createTimeoutOptions | libp2p
    \ No newline at end of file +createTimeoutOptions | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.address_sort.certifiedAddressesFirst.html b/functions/_libp2p_utils.address_sort.certifiedAddressesFirst.html index 6dc3e1068e..c23429a2fe 100644 --- a/functions/_libp2p_utils.address_sort.certifiedAddressesFirst.html +++ b/functions/_libp2p_utils.address_sort.certifiedAddressesFirst.html @@ -1,3 +1,3 @@ certifiedAddressesFirst | libp2p
    \ No newline at end of file +

    Parameters

    Returns -1 | 0 | 1

    \ No newline at end of file diff --git a/functions/_libp2p_utils.address_sort.circuitRelayAddressesLast.html b/functions/_libp2p_utils.address_sort.circuitRelayAddressesLast.html index b509ed9d3c..f652478e92 100644 --- a/functions/_libp2p_utils.address_sort.circuitRelayAddressesLast.html +++ b/functions/_libp2p_utils.address_sort.circuitRelayAddressesLast.html @@ -1,3 +1,3 @@ circuitRelayAddressesLast | libp2p
    \ No newline at end of file +

    Parameters

    Returns -1 | 0 | 1

    \ No newline at end of file diff --git a/functions/_libp2p_utils.address_sort.defaultAddressSort.html b/functions/_libp2p_utils.address_sort.defaultAddressSort.html index acddef0753..6892462d62 100644 --- a/functions/_libp2p_utils.address_sort.defaultAddressSort.html +++ b/functions/_libp2p_utils.address_sort.defaultAddressSort.html @@ -1 +1 @@ -defaultAddressSort | libp2p
    \ No newline at end of file +defaultAddressSort | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.address_sort.publicAddressesFirst.html b/functions/_libp2p_utils.address_sort.publicAddressesFirst.html index ad250cc0d9..1df4484c3d 100644 --- a/functions/_libp2p_utils.address_sort.publicAddressesFirst.html +++ b/functions/_libp2p_utils.address_sort.publicAddressesFirst.html @@ -1,3 +1,3 @@ publicAddressesFirst | libp2p
    \ No newline at end of file +

    Parameters

    Returns -1 | 0 | 1

    \ No newline at end of file diff --git a/functions/_libp2p_utils.array_equals.arrayEquals.html b/functions/_libp2p_utils.array_equals.arrayEquals.html index a46cb814e6..6df40e31ef 100644 --- a/functions/_libp2p_utils.array_equals.arrayEquals.html +++ b/functions/_libp2p_utils.array_equals.arrayEquals.html @@ -1,3 +1,3 @@ arrayEquals | libp2p
    • Verify if two arrays of non primitive types with the "equals" function are equal. Compatible with multiaddr, peer-id and others.

      -

      Parameters

      • a: any[]
      • b: any[]

      Returns boolean

    \ No newline at end of file +

    Parameters

    Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_utils.close.safelyCloseConnectionIfUnused.html b/functions/_libp2p_utils.close.safelyCloseConnectionIfUnused.html index 1755510ca7..cc8d50f247 100644 --- a/functions/_libp2p_utils.close.safelyCloseConnectionIfUnused.html +++ b/functions/_libp2p_utils.close.safelyCloseConnectionIfUnused.html @@ -1,3 +1,3 @@ safelyCloseConnectionIfUnused | libp2p

    Function safelyCloseConnectionIfUnused

    \ No newline at end of file +

    Parameters

    Returns Promise<void>

    \ No newline at end of file diff --git a/functions/_libp2p_utils.close.safelyCloseStream.html b/functions/_libp2p_utils.close.safelyCloseStream.html index 6b1e1fdf88..15625a7268 100644 --- a/functions/_libp2p_utils.close.safelyCloseStream.html +++ b/functions/_libp2p_utils.close.safelyCloseStream.html @@ -1,3 +1,3 @@ safelyCloseStream | libp2p
    \ No newline at end of file +

    Parameters

    Returns Promise<void>

    \ No newline at end of file diff --git a/functions/_libp2p_utils.close_source.closeSource.html b/functions/_libp2p_utils.close_source.closeSource.html index 58c767bd56..f13efba83c 100644 --- a/functions/_libp2p_utils.close_source.closeSource.html +++ b/functions/_libp2p_utils.close_source.closeSource.html @@ -1 +1 @@ -closeSource | libp2p
    \ No newline at end of file +closeSource | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.filters.createBloomFilter.html b/functions/_libp2p_utils.filters.createBloomFilter.html index a4f1093184..feeda32a62 100644 --- a/functions/_libp2p_utils.filters.createBloomFilter.html +++ b/functions/_libp2p_utils.filters.createBloomFilter.html @@ -1,3 +1,3 @@ createBloomFilter | libp2p
    \ No newline at end of file +

    Parameters

    Returns Filter

    \ No newline at end of file diff --git a/functions/_libp2p_utils.filters.createCuckooFilter.html b/functions/_libp2p_utils.filters.createCuckooFilter.html index 3fa3c16bc3..2b4a807a82 100644 --- a/functions/_libp2p_utils.filters.createCuckooFilter.html +++ b/functions/_libp2p_utils.filters.createCuckooFilter.html @@ -1 +1 @@ -createCuckooFilter | libp2p
    \ No newline at end of file +createCuckooFilter | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.filters.createScalableCuckooFilter.html b/functions/_libp2p_utils.filters.createScalableCuckooFilter.html index 8985ef65ca..04c01d97cd 100644 --- a/functions/_libp2p_utils.filters.createScalableCuckooFilter.html +++ b/functions/_libp2p_utils.filters.createScalableCuckooFilter.html @@ -1 +1 @@ -createScalableCuckooFilter | libp2p

    Function createScalableCuckooFilter

    \ No newline at end of file +createScalableCuckooFilter | libp2p

    Function createScalableCuckooFilter

    \ No newline at end of file diff --git a/functions/_libp2p_utils.ip_port_to_multiaddr.ipPortToMultiaddr.html b/functions/_libp2p_utils.ip_port_to_multiaddr.ipPortToMultiaddr.html index dc14634002..7b31e9790e 100644 --- a/functions/_libp2p_utils.ip_port_to_multiaddr.ipPortToMultiaddr.html +++ b/functions/_libp2p_utils.ip_port_to_multiaddr.ipPortToMultiaddr.html @@ -1,2 +1,2 @@ ipPortToMultiaddr | libp2p
    \ No newline at end of file +

    Parameters

    Returns Multiaddr

    \ No newline at end of file diff --git a/functions/_libp2p_utils.is_promise.isPromise.html b/functions/_libp2p_utils.is_promise.isPromise.html index ac27b061ed..1e985255eb 100644 --- a/functions/_libp2p_utils.is_promise.isPromise.html +++ b/functions/_libp2p_utils.is_promise.isPromise.html @@ -1 +1 @@ -isPromise | libp2p
    \ No newline at end of file +isPromise | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.multiaddr_is_loopback.isLoopback.html b/functions/_libp2p_utils.multiaddr_is_loopback.isLoopback.html index 7131e23d4b..f69715d017 100644 --- a/functions/_libp2p_utils.multiaddr_is_loopback.isLoopback.html +++ b/functions/_libp2p_utils.multiaddr_is_loopback.isLoopback.html @@ -1,2 +1,2 @@ isLoopback | libp2p
    \ No newline at end of file +

    Parameters

    Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_utils.multiaddr_is_private.isPrivate.html b/functions/_libp2p_utils.multiaddr_is_private.isPrivate.html index 7e67867a3f..3f243e09b5 100644 --- a/functions/_libp2p_utils.multiaddr_is_private.isPrivate.html +++ b/functions/_libp2p_utils.multiaddr_is_private.isPrivate.html @@ -1,2 +1,2 @@ isPrivate | libp2p
    \ No newline at end of file +

    Parameters

    Returns boolean

    \ No newline at end of file diff --git a/functions/_libp2p_utils.private_ip.isPrivateIp.html b/functions/_libp2p_utils.private_ip.isPrivateIp.html index a1fee96c9b..a424f114f7 100644 --- a/functions/_libp2p_utils.private_ip.isPrivateIp.html +++ b/functions/_libp2p_utils.private_ip.isPrivateIp.html @@ -1 +1 @@ -isPrivateIp | libp2p
    \ No newline at end of file +isPrivateIp | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.stream_to_ma_conn.streamToMaConnection.html b/functions/_libp2p_utils.stream_to_ma_conn.streamToMaConnection.html index da5a00b791..f417e53dcf 100644 --- a/functions/_libp2p_utils.stream_to_ma_conn.streamToMaConnection.html +++ b/functions/_libp2p_utils.stream_to_ma_conn.streamToMaConnection.html @@ -1,3 +1,3 @@ streamToMaConnection | libp2p
    \ No newline at end of file +

    Parameters

    Returns MultiaddrConnection

    \ No newline at end of file diff --git a/functions/_libp2p_utils.tracked_list.trackedList.html b/functions/_libp2p_utils.tracked_list.trackedList.html index 87a50456a0..6c8b4e1731 100644 --- a/functions/_libp2p_utils.tracked_list.trackedList.html +++ b/functions/_libp2p_utils.tracked_list.trackedList.html @@ -1 +1 @@ -trackedList | libp2p
    \ No newline at end of file +trackedList | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_utils.tracked_map.trackedMap.html b/functions/_libp2p_utils.tracked_map.trackedMap.html index 60a32b936d..d394436fb9 100644 --- a/functions/_libp2p_utils.tracked_map.trackedMap.html +++ b/functions/_libp2p_utils.tracked_map.trackedMap.html @@ -1 +1 @@ -trackedMap | libp2p
    \ No newline at end of file +trackedMap | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_webrtc.webRTC.html b/functions/_libp2p_webrtc.webRTC.html index 09ceb0662c..fd62ceca6b 100644 --- a/functions/_libp2p_webrtc.webRTC.html +++ b/functions/_libp2p_webrtc.webRTC.html @@ -1,2 +1,2 @@ webRTC | libp2p
    \ No newline at end of file +

    Returns ((components) => Transport)

    \ No newline at end of file diff --git a/functions/_libp2p_webrtc.webRTCDirect.html b/functions/_libp2p_webrtc.webRTCDirect.html index 2f4d860bd6..c7879132dd 100644 --- a/functions/_libp2p_webrtc.webRTCDirect.html +++ b/functions/_libp2p_webrtc.webRTCDirect.html @@ -1,2 +1,2 @@ webRTCDirect | libp2p
    \ No newline at end of file +

    Returns ((components) => Transport)

    \ No newline at end of file diff --git a/functions/_libp2p_websockets.filters.all.html b/functions/_libp2p_websockets.filters.all.html index b804d83864..d909b3db63 100644 --- a/functions/_libp2p_websockets.filters.all.html +++ b/functions/_libp2p_websockets.filters.all.html @@ -1 +1 @@ -all | libp2p
    \ No newline at end of file +all | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_websockets.filters.dnsWsOrWss.html b/functions/_libp2p_websockets.filters.dnsWsOrWss.html index 6c5441640e..02c163d7f4 100644 --- a/functions/_libp2p_websockets.filters.dnsWsOrWss.html +++ b/functions/_libp2p_websockets.filters.dnsWsOrWss.html @@ -1 +1 @@ -dnsWsOrWss | libp2p
    \ No newline at end of file +dnsWsOrWss | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_websockets.filters.dnsWss.html b/functions/_libp2p_websockets.filters.dnsWss.html index 25a616ce48..751a974a54 100644 --- a/functions/_libp2p_websockets.filters.dnsWss.html +++ b/functions/_libp2p_websockets.filters.dnsWss.html @@ -1 +1 @@ -dnsWss | libp2p
    \ No newline at end of file +dnsWss | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_websockets.filters.wss.html b/functions/_libp2p_websockets.filters.wss.html index 3cb1e7fa27..f8c49d3975 100644 --- a/functions/_libp2p_websockets.filters.wss.html +++ b/functions/_libp2p_websockets.filters.wss.html @@ -1 +1 @@ -wss | libp2p
    \ No newline at end of file +wss | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_websockets.index.webSockets.html b/functions/_libp2p_websockets.index.webSockets.html index 1f0f89d5b7..b3dc8ed7a5 100644 --- a/functions/_libp2p_websockets.index.webSockets.html +++ b/functions/_libp2p_websockets.index.webSockets.html @@ -1 +1 @@ -webSockets | libp2p
    \ No newline at end of file +webSockets | libp2p
    \ No newline at end of file diff --git a/functions/_libp2p_webtransport.webTransport.html b/functions/_libp2p_webtransport.webTransport.html index c4ad693132..afc0af7c1b 100644 --- a/functions/_libp2p_webtransport.webTransport.html +++ b/functions/_libp2p_webtransport.webTransport.html @@ -1 +1 @@ -webTransport | libp2p
    \ No newline at end of file +webTransport | libp2p
    \ No newline at end of file diff --git a/functions/libp2p.index.createLibp2p.html b/functions/libp2p.index.createLibp2p.html index 7265a68f0a..d24c7c62e0 100644 --- a/functions/libp2p.index.createLibp2p.html +++ b/functions/libp2p.index.createLibp2p.html @@ -3,4 +3,4 @@

    The node will be started unless start: false is passed as an option.

    Type Parameters

    Parameters

    Returns Promise<Libp2p<T>>

    Example

    import { createLibp2p } from 'libp2p'
    import { tcp } from '@libp2p/tcp'
    import { mplex } from '@libp2p/mplex'
    import { noise } from '@chainsafe/libp2p-noise'
    import { yamux } from '@chainsafe/libp2p-yamux'

    // specify options
    const options = {
    transports: [tcp()],
    streamMuxers: [yamux(), mplex()],
    connectionEncrypters: [noise()]
    }

    // create libp2p
    const libp2p = await createLibp2p(options)
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_autonat.AutoNATComponents.html b/interfaces/_libp2p_autonat.AutoNATComponents.html index 6104188298..495715c81d 100644 --- a/interfaces/_libp2p_autonat.AutoNATComponents.html +++ b/interfaces/_libp2p_autonat.AutoNATComponents.html @@ -1,8 +1,8 @@ -AutoNATComponents | libp2p

    Interface AutoNATComponents

    interface AutoNATComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerId: PeerId;
        randomWalk: RandomWalk;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager +AutoNATComponents | libp2p

    Interface AutoNATComponents

    interface AutoNATComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerId: PeerId;
        randomWalk: RandomWalk;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    peerId: PeerId
    randomWalk: RandomWalk
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file +

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    peerId: PeerId
    randomWalk: RandomWalk
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file diff --git a/interfaces/_libp2p_autonat.AutoNATServiceInit.html b/interfaces/_libp2p_autonat.AutoNATServiceInit.html index 3ae68ecc45..b9dec67489 100644 --- a/interfaces/_libp2p_autonat.AutoNATServiceInit.html +++ b/interfaces/_libp2p_autonat.AutoNATServiceInit.html @@ -1,13 +1,13 @@ -AutoNATServiceInit | libp2p

    Interface AutoNATServiceInit

    interface AutoNATServiceInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        refreshInterval?: number;
        startupDelay?: number;
        timeout?: number;
    }

    Properties

    maxInboundStreams? +AutoNATServiceInit | libp2p

    Interface AutoNATServiceInit

    interface AutoNATServiceInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        refreshInterval?: number;
        startupDelay?: number;
        timeout?: number;
    }

    Properties

    maxInboundStreams?: number

    How many parallel inbound autoNAT streams we allow per-connection

    -
    maxOutboundStreams?: number

    How many parallel outbound autoNAT streams we allow per-connection

    -
    protocolPrefix?: string

    Allows overriding the protocol prefix used

    -
    refreshInterval?: number

    Verify our external addresses this often

    -
    startupDelay?: number

    How long to wait after startup before trying to verify our external address

    -
    timeout?: number

    How long we should wait for a remote peer to verify our external address

    -
    \ No newline at end of file +
    maxOutboundStreams?: number

    How many parallel outbound autoNAT streams we allow per-connection

    +
    protocolPrefix?: string

    Allows overriding the protocol prefix used

    +
    refreshInterval?: number

    Verify our external addresses this often

    +
    startupDelay?: number

    How long to wait after startup before trying to verify our external address

    +
    timeout?: number

    How long we should wait for a remote peer to verify our external address

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_bootstrap.BootstrapComponents.html b/interfaces/_libp2p_bootstrap.BootstrapComponents.html index dde6390ad2..9e7d288bfd 100644 --- a/interfaces/_libp2p_bootstrap.BootstrapComponents.html +++ b/interfaces/_libp2p_bootstrap.BootstrapComponents.html @@ -1,4 +1,4 @@ -BootstrapComponents | libp2p

    Interface BootstrapComponents

    interface BootstrapComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerStore: PeerStore;
    }

    Properties

    connectionManager +BootstrapComponents | libp2p

    Interface BootstrapComponents

    interface BootstrapComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerStore: PeerStore;
    }

    Properties

    connectionManager: ConnectionManager
    peerStore: PeerStore
    \ No newline at end of file +

    Properties

    connectionManager: ConnectionManager
    peerStore: PeerStore
    \ No newline at end of file diff --git a/interfaces/_libp2p_bootstrap.BootstrapInit.html b/interfaces/_libp2p_bootstrap.BootstrapInit.html index 60cd8366f0..6b9cf9827f 100644 --- a/interfaces/_libp2p_bootstrap.BootstrapInit.html +++ b/interfaces/_libp2p_bootstrap.BootstrapInit.html @@ -1,13 +1,13 @@ -BootstrapInit | libp2p
    interface BootstrapInit {
        list: string[];
        tagName?: string;
        tagTTL?: number;
        tagValue?: number;
        timeout?: number;
    }

    Properties

    list +BootstrapInit | libp2p
    interface BootstrapInit {
        list: string[];
        tagName?: string;
        tagTTL?: number;
        tagValue?: number;
        timeout?: number;
    }

    Properties

    list: string[]

    The list of peer addresses in multi-address format

    -
    tagName?: string

    Tag a bootstrap peer with this name before "discovering" it

    +
    tagName?: string

    Tag a bootstrap peer with this name before "discovering" it

    Default

    'bootstrap'
     
    -
    tagTTL?: number

    Cause the bootstrap peer tag to be removed after this number of ms

    -
    tagValue?: number

    The bootstrap peer tag will have this value (default: 50)

    -
    timeout?: number

    How long to wait before discovering bootstrap nodes

    -
    \ No newline at end of file +
    tagTTL?: number

    Cause the bootstrap peer tag to be removed after this number of ms

    +
    tagValue?: number

    The bootstrap peer tag will have this value (default: 50)

    +
    timeout?: number

    How long to wait before discovering bootstrap nodes

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_circuit_relay_v2.CircuitRelayService.html b/interfaces/_libp2p_circuit_relay_v2.CircuitRelayService.html index 8da8a363b8..a5211c8271 100644 --- a/interfaces/_libp2p_circuit_relay_v2.CircuitRelayService.html +++ b/interfaces/_libp2p_circuit_relay_v2.CircuitRelayService.html @@ -1,12 +1,12 @@ CircuitRelayService | libp2p

    An implementation of a typed event target etc

    -
    interface CircuitRelayService {
        #private: any;
        reservations: PeerMap<RelayReservation>;
        addEventListener<K>(type, listener, options?): void;
        dispatchEvent(event): boolean;
        listenerCount(type): number;
        removeEventListener<K>(type, listener?, options?): void;
        safeDispatchEvent<Detail>(type, detail?): boolean;
    }

    Hierarchy (view full)

    Properties

    interface CircuitRelayService {
        #private: any;
        reservations: PeerMap<RelayReservation>;
        addEventListener<K>(type, listener, options?): void;
        dispatchEvent(event): boolean;
        listenerCount(type): number;
        removeEventListener<K>(type, listener?, options?): void;
        safeDispatchEvent<Detail>(type, detail?): boolean;
    }

    Hierarchy (view full)

    Properties

    #private: any
    reservations: PeerMap<RelayReservation>

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      +

    Properties

    #private: any
    reservations: PeerMap<RelayReservation>

    Methods

    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

      MDN Reference

      Parameters

      Returns boolean

    • Parameters

      • type: string

      Returns number

    \ No newline at end of file diff --git a/interfaces/_libp2p_circuit_relay_v2.CircuitRelayServiceEvents.html b/interfaces/_libp2p_circuit_relay_v2.CircuitRelayServiceEvents.html index 31b1d94ec1..6717169ce2 100644 --- a/interfaces/_libp2p_circuit_relay_v2.CircuitRelayServiceEvents.html +++ b/interfaces/_libp2p_circuit_relay_v2.CircuitRelayServiceEvents.html @@ -1,4 +1,4 @@ -CircuitRelayServiceEvents | libp2p
    interface CircuitRelayServiceEvents {
        relay:advert:error: CustomEvent<Error>;
        relay:advert:success: CustomEvent<unknown>;
        relay:reservation: CustomEvent<RelayReservation>;
    }

    Properties

    relay:advert:error +CircuitRelayServiceEvents | libp2p
    interface CircuitRelayServiceEvents {
        relay:advert:error: CustomEvent<Error>;
        relay:advert:success: CustomEvent<unknown>;
        relay:reservation: CustomEvent<RelayReservation>;
    }

    Properties

    relay:advert:error: CustomEvent<Error>
    relay:advert:success: CustomEvent<unknown>
    relay:reservation: CustomEvent<RelayReservation>
    \ No newline at end of file +

    Properties

    relay:advert:error: CustomEvent<Error>
    relay:advert:success: CustomEvent<unknown>
    relay:reservation: CustomEvent<RelayReservation>
    \ No newline at end of file diff --git a/interfaces/_libp2p_circuit_relay_v2.RelayReservation.html b/interfaces/_libp2p_circuit_relay_v2.RelayReservation.html index 98d6105215..95a1dbb099 100644 --- a/interfaces/_libp2p_circuit_relay_v2.RelayReservation.html +++ b/interfaces/_libp2p_circuit_relay_v2.RelayReservation.html @@ -1,4 +1,4 @@ -RelayReservation | libp2p
    interface RelayReservation {
        addr: Multiaddr;
        expire: Date;
        limit?: Limit;
    }

    Properties

    addr +RelayReservation | libp2p
    interface RelayReservation {
        addr: Multiaddr;
        expire: Date;
        limit?: Limit;
    }

    Properties

    Properties

    addr: Multiaddr
    expire: Date
    limit?: Limit
    \ No newline at end of file +

    Properties

    addr: Multiaddr
    expire: Date
    limit?: Limit
    \ No newline at end of file diff --git a/interfaces/_libp2p_crypto.hmac.HMAC.html b/interfaces/_libp2p_crypto.hmac.HMAC.html index f6fa5e851e..a35d3ecec4 100644 --- a/interfaces/_libp2p_crypto.hmac.HMAC.html +++ b/interfaces/_libp2p_crypto.hmac.HMAC.html @@ -1,3 +1,3 @@ -HMAC | libp2p
    interface HMAC {
        length: number;
        digest(data): Promise<Uint8Array>;
    }

    Properties

    length +HMAC | libp2p
    interface HMAC {
        length: number;
        digest(data): Promise<Uint8Array>;
    }

    Properties

    Methods

    Properties

    length: number

    Methods

    \ No newline at end of file +

    Properties

    length: number

    Methods

    \ No newline at end of file diff --git a/interfaces/_libp2p_dcutr.DCUtRServiceComponents.html b/interfaces/_libp2p_dcutr.DCUtRServiceComponents.html index 0e509c46c9..819564428d 100644 --- a/interfaces/_libp2p_dcutr.DCUtRServiceComponents.html +++ b/interfaces/_libp2p_dcutr.DCUtRServiceComponents.html @@ -1,7 +1,7 @@ -DCUtRServiceComponents | libp2p

    Interface DCUtRServiceComponents

    interface DCUtRServiceComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerStore: PeerStore;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager +DCUtRServiceComponents | libp2p

    Interface DCUtRServiceComponents

    interface DCUtRServiceComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        peerStore: PeerStore;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    peerStore: PeerStore
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file +

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    peerStore: PeerStore
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file diff --git a/interfaces/_libp2p_dcutr.DCUtRServiceInit.html b/interfaces/_libp2p_dcutr.DCUtRServiceInit.html index dd6a6a5dea..769744994f 100644 --- a/interfaces/_libp2p_dcutr.DCUtRServiceInit.html +++ b/interfaces/_libp2p_dcutr.DCUtRServiceInit.html @@ -1,11 +1,11 @@ -DCUtRServiceInit | libp2p

    Interface DCUtRServiceInit

    interface DCUtRServiceInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        retries?: number;
        timeout?: number;
    }

    Properties

    maxInboundStreams? +DCUtRServiceInit | libp2p

    Interface DCUtRServiceInit

    interface DCUtRServiceInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        retries?: number;
        timeout?: number;
    }

    Properties

    maxInboundStreams?: number

    How many simultaneous inbound DCUtR protocol streams to allow on each connection (default: 1)

    -
    maxOutboundStreams?: number

    How many simultaneous outbound DCUtR protocol streams to allow on each +

    maxOutboundStreams?: number

    How many simultaneous outbound DCUtR protocol streams to allow on each connection (default: 1)

    -
    retries?: number

    How many times to retry the connection upgrade (default: 3)

    -
    timeout?: number

    How long we should wait for the connection upgrade to complete (default: 5s)

    -
    \ No newline at end of file +
    retries?: number

    How many times to retry the connection upgrade (default: 3)

    +
    timeout?: number

    How long we should wait for the connection upgrade to complete (default: 5s)

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.Address.html b/interfaces/_libp2p_devtools_metrics.Address.html index 61311dc1a3..46819689f0 100644 --- a/interfaces/_libp2p_devtools_metrics.Address.html +++ b/interfaces/_libp2p_devtools_metrics.Address.html @@ -1,8 +1,8 @@ -Address | libp2p
    interface Address {
        isCertified?: boolean;
        isConnected?: boolean;
        multiaddr: string;
    }

    Properties

    isCertified? +Address | libp2p
    interface Address {
        isCertified?: boolean;
        isConnected?: boolean;
        multiaddr: string;
    }

    Properties

    isCertified?: boolean

    If true, this multiaddr came from a signed peer record

    -
    isConnected?: boolean

    If true, the current node has an active connection to this peer via this +

    isConnected?: boolean

    If true, the current node has an active connection to this peer via this address

    -
    multiaddr: string

    The multiaddr this address represents

    -
    \ No newline at end of file +
    multiaddr: string

    The multiaddr this address represents

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.CopyToClipboardMessage.html b/interfaces/_libp2p_devtools_metrics.CopyToClipboardMessage.html index c768842b13..214c11ece4 100644 --- a/interfaces/_libp2p_devtools_metrics.CopyToClipboardMessage.html +++ b/interfaces/_libp2p_devtools_metrics.CopyToClipboardMessage.html @@ -1,7 +1,7 @@ CopyToClipboardMessage | libp2p

    This event is intercepted by the service worker which injects a content script into the current page which copies the passed value to the clipboard.

    -
    interface CopyToClipboardMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "copy-to-clipboard";
        value: string;
    }

    Properties

    interface CopyToClipboardMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "copy-to-clipboard";
        value: string;
    }

    Properties

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "copy-to-clipboard"
    value: string
    \ No newline at end of file +

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "copy-to-clipboard"
    value: string
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.DevToolsEvents.html b/interfaces/_libp2p_devtools_metrics.DevToolsEvents.html index add8333aa8..eb5075bbbb 100644 --- a/interfaces/_libp2p_devtools_metrics.DevToolsEvents.html +++ b/interfaces/_libp2p_devtools_metrics.DevToolsEvents.html @@ -1,7 +1,7 @@ -DevToolsEvents | libp2p
    interface DevToolsEvents {
        metrics: CustomEvent<Record<string, any>>;
        peers: CustomEvent<Peer[]>;
        self: CustomEvent<Peer>;
    }

    Properties

    metrics +DevToolsEvents | libp2p
    interface DevToolsEvents {
        metrics: CustomEvent<Record<string, any>>;
        peers: CustomEvent<Peer[]>;
        self: CustomEvent<Peer>;
    }

    Properties

    Properties

    metrics: CustomEvent<Record<string, any>>

    Node metrics have been updated

    -
    peers: CustomEvent<Peer[]>

    The node's connected peers have changed

    -

    The node's status has changed - new addresses and/or protocols, etc

    -
    \ No newline at end of file +
    peers: CustomEvent<Peer[]>

    The node's connected peers have changed

    +

    The node's status has changed - new addresses and/or protocols, etc

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.DevToolsMetricsComponents.html b/interfaces/_libp2p_devtools_metrics.DevToolsMetricsComponents.html index 918cc9677a..49929a7c56 100644 --- a/interfaces/_libp2p_devtools_metrics.DevToolsMetricsComponents.html +++ b/interfaces/_libp2p_devtools_metrics.DevToolsMetricsComponents.html @@ -1,4 +1,4 @@ -DevToolsMetricsComponents | libp2p
    interface DevToolsMetricsComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        contentRouting: ContentRouting;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        peerId: PeerId;
        peerRouting: PeerRouting;
        peerStore: PeerStore;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager +DevToolsMetricsComponents | libp2p
    interface DevToolsMetricsComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        contentRouting: ContentRouting;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        peerId: PeerId;
        peerRouting: PeerRouting;
        peerStore: PeerStore;
        registrar: Registrar;
        transportManager: TransportManager;
    }

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    contentRouting: ContentRouting
    peerId: PeerId
    peerRouting: PeerRouting
    peerStore: PeerStore
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file +

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    contentRouting: ContentRouting
    peerId: PeerId
    peerRouting: PeerRouting
    peerStore: PeerStore
    registrar: Registrar
    transportManager: TransportManager
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.DevToolsMetricsInit.html b/interfaces/_libp2p_devtools_metrics.DevToolsMetricsInit.html index d61df61f4d..884eb2e137 100644 --- a/interfaces/_libp2p_devtools_metrics.DevToolsMetricsInit.html +++ b/interfaces/_libp2p_devtools_metrics.DevToolsMetricsInit.html @@ -1,3 +1,3 @@ -DevToolsMetricsInit | libp2p
    interface DevToolsMetricsInit {
        intervalMs?: number;
    }

    Properties

    intervalMs? +DevToolsMetricsInit | libp2p
    interface DevToolsMetricsInit {
        intervalMs?: number;
    }

    Properties

    Properties

    intervalMs?: number

    How often to pass metrics to the DevTools panel

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.DevToolsRPC.html b/interfaces/_libp2p_devtools_metrics.DevToolsRPC.html index 0c546d4e26..7c45a8d5de 100644 --- a/interfaces/_libp2p_devtools_metrics.DevToolsRPC.html +++ b/interfaces/_libp2p_devtools_metrics.DevToolsRPC.html @@ -1,3 +1,3 @@ DevToolsRPC | libp2p

    RPC operations exposed by the DevTools

    -
    interface DevToolsRPC {
        safeDispatchEvent<Detail>(type, detail?): Promise<void>;
    }

    Methods

    \ No newline at end of file +
    interface DevToolsRPC {
        safeDispatchEvent<Detail>(type, detail?): Promise<void>;
    }

    Methods

    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.MetricsRPC.html b/interfaces/_libp2p_devtools_metrics.MetricsRPC.html index 5b3700f77c..643d824506 100644 --- a/interfaces/_libp2p_devtools_metrics.MetricsRPC.html +++ b/interfaces/_libp2p_devtools_metrics.MetricsRPC.html @@ -1,14 +1,14 @@ MetricsRPC | libp2p

    RPC operations exposed by the metrics

    -
    interface MetricsRPC {
        contentRouting: ContentRouting;
        peerRouting: PeerRouting;
        closeConnection(peerId, options?): Promise<void>;
        init(options?): Promise<{
            debug: string;
            peers: Peer[];
            self: Peer;
        }>;
        openConnection(peerIdOrMultiaddr, options?): Promise<void>;
        setDebug(namespace?): Promise<void>;
    }

    Properties

    interface MetricsRPC {
        contentRouting: ContentRouting;
        peerRouting: PeerRouting;
        closeConnection(peerId, options?): Promise<void>;
        init(options?): Promise<{
            debug: string;
            peers: Peer[];
            self: Peer;
        }>;
        openConnection(peerIdOrMultiaddr, options?): Promise<void>;
        setDebug(namespace?): Promise<void>;
    }

    Properties

    contentRouting: ContentRouting

    Make content routing queries

    -
    peerRouting: PeerRouting

    Make peer routing queries

    -

    Methods

    • Called by DevTools on initial connect

      -

      Parameters

      Returns Promise<{
          debug: string;
          peers: Peer[];
          self: Peer;
      }>

    • Update the currently active debugging namespaces

      -

      Parameters

      • Optional namespace: string

      Returns Promise<void>

    \ No newline at end of file +
    peerRouting: PeerRouting

    Make peer routing queries

    +

    Methods

    • Called by DevTools on initial connect

      +

      Parameters

      Returns Promise<{
          debug: string;
          peers: Peer[];
          self: Peer;
      }>

    • Update the currently active debugging namespaces

      +

      Parameters

      • Optional namespace: string

      Returns Promise<void>

    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.NodeAddress.html b/interfaces/_libp2p_devtools_metrics.NodeAddress.html index 0609d3c48f..d7c92625b2 100644 --- a/interfaces/_libp2p_devtools_metrics.NodeAddress.html +++ b/interfaces/_libp2p_devtools_metrics.NodeAddress.html @@ -1,6 +1,6 @@ -NodeAddress | libp2p
    interface NodeAddress {
        announce?: boolean;
        default?: boolean;
        listen?: boolean;
        multiaddr: Multiaddr;
        observed?: boolean;
    }

    Properties

    announce? +NodeAddress | libp2p
    interface NodeAddress {
        announce?: boolean;
        default?: boolean;
        listen?: boolean;
        multiaddr: Multiaddr;
        observed?: boolean;
    }

    Properties

    announce?: boolean
    default?: boolean
    listen?: boolean
    multiaddr: Multiaddr
    observed?: boolean
    \ No newline at end of file +

    Properties

    announce?: boolean
    default?: boolean
    listen?: boolean
    multiaddr: Multiaddr
    observed?: boolean
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.NodeStatus.html b/interfaces/_libp2p_devtools_metrics.NodeStatus.html index df0b626fcc..207077a072 100644 --- a/interfaces/_libp2p_devtools_metrics.NodeStatus.html +++ b/interfaces/_libp2p_devtools_metrics.NodeStatus.html @@ -1,5 +1,5 @@ -NodeStatus | libp2p
    interface NodeStatus {
        addresses: NodeAddress[];
        agent?: string;
        peerId: PeerId;
        protocols: string[];
    }

    Properties

    addresses +NodeStatus | libp2p
    interface NodeStatus {
        addresses: NodeAddress[];
        agent?: string;
        peerId: PeerId;
        protocols: string[];
    }

    Properties

    addresses: NodeAddress[]
    agent?: string
    peerId: PeerId
    protocols: string[]
    \ No newline at end of file +

    Properties

    addresses: NodeAddress[]
    agent?: string
    peerId: PeerId
    protocols: string[]
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.PageLoadedMessage.html b/interfaces/_libp2p_devtools_metrics.PageLoadedMessage.html index ee7adcc66b..67dfe22d75 100644 --- a/interfaces/_libp2p_devtools_metrics.PageLoadedMessage.html +++ b/interfaces/_libp2p_devtools_metrics.PageLoadedMessage.html @@ -1,6 +1,6 @@ PageLoadedMessage | libp2p

    Sent by the DevTools service worker to the DevTools panel when the inspected page has finished (re)loading

    -
    interface PageLoadedMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "page-loaded";
    }

    Properties

    interface PageLoadedMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "page-loaded";
    }

    Properties

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "page-loaded"
    \ No newline at end of file +

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "page-loaded"
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.Peer.html b/interfaces/_libp2p_devtools_metrics.Peer.html index 72b2a70a8c..89436ad691 100644 --- a/interfaces/_libp2p_devtools_metrics.Peer.html +++ b/interfaces/_libp2p_devtools_metrics.Peer.html @@ -1,11 +1,11 @@ -Peer | libp2p
    interface Peer {
        addresses: PeerAddress[];
        id: PeerId;
        metadata: Record<string, string>;
        protocols: string[];
        tags: Record<string, number>;
    }

    Properties

    addresses +Peer | libp2p
    interface Peer {
        addresses: PeerAddress[];
        id: PeerId;
        metadata: Record<string, string>;
        protocols: string[];
        tags: Record<string, number>;
    }

    Properties

    addresses: PeerAddress[]

    The list of addresses the peer has that we know about

    -
    id: PeerId

    The identifier of the remote peer

    -
    metadata: Record<string, string>

    Any peer store metadata the peer has

    -
    protocols: string[]

    The protocols the peer supports, if known

    -
    tags: Record<string, number>

    Any peer store tags the peer has

    -
    \ No newline at end of file +
    id: PeerId

    The identifier of the remote peer

    +
    metadata: Record<string, string>

    Any peer store metadata the peer has

    +
    protocols: string[]

    The protocols the peer supports, if known

    +
    tags: Record<string, number>

    Any peer store tags the peer has

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.PeerAddress.html b/interfaces/_libp2p_devtools_metrics.PeerAddress.html index 96e3cebffe..69391f1265 100644 --- a/interfaces/_libp2p_devtools_metrics.PeerAddress.html +++ b/interfaces/_libp2p_devtools_metrics.PeerAddress.html @@ -1,4 +1,4 @@ -PeerAddress | libp2p
    interface PeerAddress {
        isCertified?: boolean;
        isConnected?: boolean;
        multiaddr: Multiaddr;
    }

    Properties

    isCertified? +PeerAddress | libp2p
    interface PeerAddress {
        isCertified?: boolean;
        isConnected?: boolean;
        multiaddr: Multiaddr;
    }

    Properties

    isCertified?: boolean
    isConnected?: boolean
    multiaddr: Multiaddr
    \ No newline at end of file +

    Properties

    isCertified?: boolean
    isConnected?: boolean
    multiaddr: Multiaddr
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.PermissionsErrorMessage.html b/interfaces/_libp2p_devtools_metrics.PermissionsErrorMessage.html index 439af83fc2..d73e819c65 100644 --- a/interfaces/_libp2p_devtools_metrics.PermissionsErrorMessage.html +++ b/interfaces/_libp2p_devtools_metrics.PermissionsErrorMessage.html @@ -2,7 +2,7 @@ to send a message to the inspected page as there is no receiving end present.

    This normally means the content script has not been loaded due to the user not having granted permission for the script to run.

    -
    interface PermissionsErrorMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "permissions-error";
    }

    Properties

    interface PermissionsErrorMessage {
        source: "@libp2p/devtools-metrics:devtools";
        tabId: number;
        type: "permissions-error";
    }

    Properties

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "permissions-error"
    \ No newline at end of file +

    Properties

    source: "@libp2p/devtools-metrics:devtools"
    tabId: number
    type: "permissions-error"
    \ No newline at end of file diff --git a/interfaces/_libp2p_devtools_metrics.RPCMessage.html b/interfaces/_libp2p_devtools_metrics.RPCMessage.html index d34a89dd1a..8258ea1b90 100644 --- a/interfaces/_libp2p_devtools_metrics.RPCMessage.html +++ b/interfaces/_libp2p_devtools_metrics.RPCMessage.html @@ -1,7 +1,7 @@ RPCMessage | libp2p

    Invoke a method on the libp2p object

    -
    interface RPCMessage {
        message: string;
        source: "@libp2p/devtools-metrics:devtools" | "@libp2p/devtools-metrics:metrics";
        tabId: number;
        type: "libp2p-rpc";
    }

    Properties

    interface RPCMessage {
        message: string;
        source: "@libp2p/devtools-metrics:devtools" | "@libp2p/devtools-metrics:metrics";
        tabId: number;
        type: "libp2p-rpc";
    }

    Properties

    message: string

    The RPC message encoded as a multibase string

    -
    source: "@libp2p/devtools-metrics:devtools" | "@libp2p/devtools-metrics:metrics"
    tabId: number
    type: "libp2p-rpc"
    \ No newline at end of file +
    source: "@libp2p/devtools-metrics:devtools" | "@libp2p/devtools-metrics:metrics"
    tabId: number
    type: "libp2p-rpc"
    \ No newline at end of file diff --git a/interfaces/_libp2p_echo.Echo.html b/interfaces/_libp2p_echo.Echo.html index 271fca28c6..af184fbfbf 100644 --- a/interfaces/_libp2p_echo.Echo.html +++ b/interfaces/_libp2p_echo.Echo.html @@ -1,2 +1,2 @@ -Echo | libp2p
    interface Echo {
        protocol: string;
    }

    Properties

    Properties

    protocol: string
    \ No newline at end of file +Echo | libp2p
    interface Echo {
        protocol: string;
    }

    Properties

    Properties

    protocol: string
    \ No newline at end of file diff --git a/interfaces/_libp2p_echo.EchoComponents.html b/interfaces/_libp2p_echo.EchoComponents.html index 7a9fb2a855..2021643278 100644 --- a/interfaces/_libp2p_echo.EchoComponents.html +++ b/interfaces/_libp2p_echo.EchoComponents.html @@ -1,4 +1,4 @@ -EchoComponents | libp2p

    Interface EchoComponents

    interface EchoComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        registrar: Registrar;
    }

    Properties

    connectionManager +EchoComponents | libp2p

    Interface EchoComponents

    interface EchoComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        registrar: Registrar;
    }

    Properties

    connectionManager: ConnectionManager
    registrar: Registrar
    \ No newline at end of file +

    Properties

    connectionManager: ConnectionManager
    registrar: Registrar
    \ No newline at end of file diff --git a/interfaces/_libp2p_echo.EchoInit.html b/interfaces/_libp2p_echo.EchoInit.html index 2e163b2f1f..30c630bbb3 100644 --- a/interfaces/_libp2p_echo.EchoInit.html +++ b/interfaces/_libp2p_echo.EchoInit.html @@ -1,4 +1,4 @@ -EchoInit | libp2p

    Interface EchoInit

    interface EchoInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
    }

    Properties

    maxInboundStreams? +EchoInit | libp2p

    Interface EchoInit

    interface EchoInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
    }

    Properties

    maxInboundStreams?: number
    maxOutboundStreams?: number
    protocolPrefix?: string
    \ No newline at end of file +

    Properties

    maxInboundStreams?: number
    maxOutboundStreams?: number
    protocolPrefix?: string
    \ No newline at end of file diff --git a/interfaces/_libp2p_fetch.Fetch.html b/interfaces/_libp2p_fetch.Fetch.html index 6c67252d8f..9e8e7e7b39 100644 --- a/interfaces/_libp2p_fetch.Fetch.html +++ b/interfaces/_libp2p_fetch.Fetch.html @@ -1,13 +1,13 @@ -Fetch | libp2p
    interface Fetch {
        fetch(peer, key, options?): Promise<undefined | Uint8Array>;
        registerLookupFunction(prefix, lookup): void;
        unregisterLookupFunction(prefix, lookup?): void;
    }

    Methods

    fetch +Fetch | libp2p
    interface Fetch {
        fetch(peer, key, options?): Promise<undefined | Uint8Array>;
        registerLookupFunction(prefix, lookup): void;
        unregisterLookupFunction(prefix, lookup?): void;
    }

    Methods

    • Registers a new lookup callback that can map keys to values, for a given set of keys that +

      Parameters

      Returns Promise<undefined | Uint8Array>

    • Registers a new lookup callback that can map keys to values, for a given set of keys that share the same prefix

      Parameters

      Returns void

      Example

      // ...
      libp2p.services.fetch.registerLookupFunction('/prefix', (key) => { ... })
      -
    • Registers a new lookup callback that can map keys to values, for a given set of keys that +

    • Registers a new lookup callback that can map keys to values, for a given set of keys that share the same prefix.

      Parameters

      Returns void

      Example

      // ...
      libp2p.services.fetch.unregisterLookupFunction('/prefix')
      -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_fetch.FetchComponents.html b/interfaces/_libp2p_fetch.FetchComponents.html index 27aa9309d5..a073fa8831 100644 --- a/interfaces/_libp2p_fetch.FetchComponents.html +++ b/interfaces/_libp2p_fetch.FetchComponents.html @@ -1,4 +1,4 @@ -FetchComponents | libp2p

    Interface FetchComponents

    interface FetchComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        registrar: Registrar;
    }

    Properties

    connectionManager +FetchComponents | libp2p

    Interface FetchComponents

    interface FetchComponents {
        connectionManager: ConnectionManager;
        logger: ComponentLogger;
        registrar: Registrar;
    }

    Properties

    connectionManager: ConnectionManager
    registrar: Registrar
    \ No newline at end of file +

    Properties

    connectionManager: ConnectionManager
    registrar: Registrar
    \ No newline at end of file diff --git a/interfaces/_libp2p_fetch.FetchInit.html b/interfaces/_libp2p_fetch.FetchInit.html index 6109f5bb3d..f9cf5a50cb 100644 --- a/interfaces/_libp2p_fetch.FetchInit.html +++ b/interfaces/_libp2p_fetch.FetchInit.html @@ -1,6 +1,6 @@ -FetchInit | libp2p

    Interface FetchInit

    interface FetchInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        timeout?: number;
    }

    Properties

    maxInboundStreams? +FetchInit | libp2p

    Interface FetchInit

    interface FetchInit {
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        timeout?: number;
    }

    Properties

    maxInboundStreams?: number
    maxOutboundStreams?: number
    protocolPrefix?: string
    timeout?: number

    How long we should wait for a remote peer to send any data

    -
    \ No newline at end of file +

    Properties

    maxInboundStreams?: number
    maxOutboundStreams?: number
    protocolPrefix?: string
    timeout?: number

    How long we should wait for a remote peer to send any data

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_fetch.LookupFunction.html b/interfaces/_libp2p_fetch.LookupFunction.html index fa69b03564..64938e6e60 100644 --- a/interfaces/_libp2p_fetch.LookupFunction.html +++ b/interfaces/_libp2p_fetch.LookupFunction.html @@ -1 +1 @@ -LookupFunction | libp2p

    Interface LookupFunction

    interface LookupFunction ((key) => Promise<undefined | Uint8Array>)
    \ No newline at end of file +LookupFunction | libp2p

    Interface LookupFunction

    interface LookupFunction ((key) => Promise<undefined | Uint8Array>)
    \ No newline at end of file diff --git a/interfaces/_libp2p_floodsub.FloodSubComponents.html b/interfaces/_libp2p_floodsub.FloodSubComponents.html index aac34e8ec8..5c65c42656 100644 --- a/interfaces/_libp2p_floodsub.FloodSubComponents.html +++ b/interfaces/_libp2p_floodsub.FloodSubComponents.html @@ -1,4 +1,4 @@ -FloodSubComponents | libp2p

    Interface FloodSubComponents

    interface FloodSubComponents {
        logger: ComponentLogger;
        peerId: PeerId;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    logger +FloodSubComponents | libp2p

    Interface FloodSubComponents

    interface FloodSubComponents {
        logger: ComponentLogger;
        peerId: PeerId;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    logger peerId privateKey registrar diff --git a/interfaces/_libp2p_floodsub.FloodSubInit.html b/interfaces/_libp2p_floodsub.FloodSubInit.html index 9ca2f9adf0..5afcdbfb1a 100644 --- a/interfaces/_libp2p_floodsub.FloodSubInit.html +++ b/interfaces/_libp2p_floodsub.FloodSubInit.html @@ -1,4 +1,4 @@ -FloodSubInit | libp2p
    interface FloodSubInit {
        canRelayMessage?: boolean;
        emitSelf?: boolean;
        enabled?: boolean;
        globalSignaturePolicy?: SignaturePolicy;
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        messageProcessingConcurrency?: number;
        multicodecs?: string[];
        seenTTL?: number;
    }

    Hierarchy (view full)

    Properties

    canRelayMessage? +FloodSubInit | libp2p
    interface FloodSubInit {
        canRelayMessage?: boolean;
        emitSelf?: boolean;
        enabled?: boolean;
        globalSignaturePolicy?: SignaturePolicy;
        maxInboundStreams?: number;
        maxOutboundStreams?: number;
        messageProcessingConcurrency?: number;
        multicodecs?: string[];
        seenTTL?: number;
    }

    Hierarchy (view full)

    Properties

    maxInboundStreams?: number

    How many parallel incoming streams to allow on the pubsub protocol per-connection

    maxOutboundStreams?: number

    How many parallel outgoing streams to allow on the pubsub protocol per-connection

    messageProcessingConcurrency?: number

    handle this many incoming pubsub messages concurrently

    -
    multicodecs?: string[]
    seenTTL?: number
    \ No newline at end of file +
    multicodecs?: string[]
    seenTTL?: number
    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.Identify.html b/interfaces/_libp2p_identify.Identify.html index 8d1f7e5780..d1f2a3f7f7 100644 --- a/interfaces/_libp2p_identify.Identify.html +++ b/interfaces/_libp2p_identify.Identify.html @@ -1,7 +1,7 @@ -Identify | libp2p
    interface Identify {
        identify(connection, options?): Promise<IdentifyResult>;
    }

    Methods

    identify +Identify | libp2p
    interface Identify {
        identify(connection, options?): Promise<IdentifyResult>;
    }

    Methods

    Methods

    • due to the default limits on inbound/outbound streams for this protocol, invoking this method when runOnConnectionOpen is true can lead to unpredictable results as streams may be closed by the local or the remote node. Please use with caution. If you find yourself needing to call this method to discover other peers that support your protocol, you may be better off configuring a topology to be notified instead.

      -

      Parameters

      Returns Promise<IdentifyResult>

    \ No newline at end of file +

    Parameters

    Returns Promise<IdentifyResult>

    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.IdentifyComponents.html b/interfaces/_libp2p_identify.IdentifyComponents.html index 53a72400c0..3ae5ec0239 100644 --- a/interfaces/_libp2p_identify.IdentifyComponents.html +++ b/interfaces/_libp2p_identify.IdentifyComponents.html @@ -1,4 +1,4 @@ -IdentifyComponents | libp2p

    Interface IdentifyComponents

    interface IdentifyComponents {
        addressManager: AddressManager;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        nodeInfo: NodeInfo;
        peerId: PeerId;
        peerStore: PeerStore;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    addressManager +IdentifyComponents | libp2p

    Interface IdentifyComponents

    interface IdentifyComponents {
        addressManager: AddressManager;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        nodeInfo: NodeInfo;
        peerId: PeerId;
        peerStore: PeerStore;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    addressManager: AddressManager
    nodeInfo: NodeInfo
    peerId: PeerId
    peerStore: PeerStore
    privateKey: PrivateKey
    registrar: Registrar
    \ No newline at end of file +

    Properties

    addressManager: AddressManager
    nodeInfo: NodeInfo
    peerId: PeerId
    peerStore: PeerStore
    privateKey: PrivateKey
    registrar: Registrar
    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.IdentifyInit.html b/interfaces/_libp2p_identify.IdentifyInit.html index 276070a74e..0f9dda6026 100644 --- a/interfaces/_libp2p_identify.IdentifyInit.html +++ b/interfaces/_libp2p_identify.IdentifyInit.html @@ -1,4 +1,4 @@ -IdentifyInit | libp2p
    interface IdentifyInit {
        agentVersion?: string;
        maxInboundStreams?: number;
        maxMessageSize?: number;
        maxObservedAddresses?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        runOnConnectionOpen?: boolean;
        runOnLimitedConnection?: boolean;
        timeout?: number;
    }

    Properties

    agentVersion? +IdentifyInit | libp2p
    interface IdentifyInit {
        agentVersion?: string;
        maxInboundStreams?: number;
        maxMessageSize?: number;
        maxObservedAddresses?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        runOnConnectionOpen?: boolean;
        runOnLimitedConnection?: boolean;
        timeout?: number;
    }

    Properties

    agentVersion?: string

    What details we should send as part of an identify message

    -
    maxInboundStreams?: number

    The maximum number of inbound streams that may be open on a single +

    maxInboundStreams?: number

    The maximum number of inbound streams that may be open on a single connection for this protocol

    Default

    1
     
    -
    maxMessageSize?: number

    Identify responses larger than this in bytes will be rejected

    +
    maxMessageSize?: number

    Identify responses larger than this in bytes will be rejected

    Default

    8192
     
    -
    maxObservedAddresses?: number

    The maximum number of observed addresses to send in an Identify message

    -
    maxOutboundStreams?: number

    The maximum number of outbound streams that may be open on a single +

    maxObservedAddresses?: number

    The maximum number of observed addresses to send in an Identify message

    +
    maxOutboundStreams?: number

    The maximum number of outbound streams that may be open on a single connection for this protocol

    Default

    1
     
    -
    protocolPrefix?: string

    The prefix to use for the protocol

    +
    protocolPrefix?: string

    The prefix to use for the protocol

    Default

    'ipfs'
     
    -
    runOnConnectionOpen?: boolean

    Whether to automatically run identify on newly opened connections

    +
    runOnConnectionOpen?: boolean

    Whether to automatically run identify on newly opened connections

    Default

    true
     
    -
    runOnLimitedConnection?: boolean

    Whether to run on connections with data or duration limits

    +
    runOnLimitedConnection?: boolean

    Whether to run on connections with data or duration limits

    Default

    true
     
    -
    timeout?: number

    How long we should wait for a remote peer to send their identify response

    +
    timeout?: number

    How long we should wait for a remote peer to send their identify response

    Default

    5000
     
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.IdentifyPush.html b/interfaces/_libp2p_identify.IdentifyPush.html index 3fd6277d8f..7e884e18f2 100644 --- a/interfaces/_libp2p_identify.IdentifyPush.html +++ b/interfaces/_libp2p_identify.IdentifyPush.html @@ -1,2 +1,2 @@ -IdentifyPush | libp2p
    interface IdentifyPush {
        push(): Promise<void>;
    }

    Methods

    Methods

    \ No newline at end of file +IdentifyPush | libp2p
    interface IdentifyPush {
        push(): Promise<void>;
    }

    Methods

    Methods

    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.IdentifyPushComponents.html b/interfaces/_libp2p_identify.IdentifyPushComponents.html index 44c56e6524..2fff577fe8 100644 --- a/interfaces/_libp2p_identify.IdentifyPushComponents.html +++ b/interfaces/_libp2p_identify.IdentifyPushComponents.html @@ -1,4 +1,4 @@ -IdentifyPushComponents | libp2p

    Interface IdentifyPushComponents

    interface IdentifyPushComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        nodeInfo: NodeInfo;
        peerId: PeerId;
        peerStore: PeerStore;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    addressManager +IdentifyPushComponents | libp2p

    Interface IdentifyPushComponents

    interface IdentifyPushComponents {
        addressManager: AddressManager;
        connectionManager: ConnectionManager;
        events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
        logger: ComponentLogger;
        nodeInfo: NodeInfo;
        peerId: PeerId;
        peerStore: PeerStore;
        privateKey: PrivateKey;
        registrar: Registrar;
    }

    Hierarchy (view full)

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    nodeInfo: NodeInfo
    peerId: PeerId
    peerStore: PeerStore
    privateKey: PrivateKey
    registrar: Registrar
    \ No newline at end of file +

    Properties

    addressManager: AddressManager
    connectionManager: ConnectionManager
    nodeInfo: NodeInfo
    peerId: PeerId
    peerStore: PeerStore
    privateKey: PrivateKey
    registrar: Registrar
    \ No newline at end of file diff --git a/interfaces/_libp2p_identify.IdentifyPushInit.html b/interfaces/_libp2p_identify.IdentifyPushInit.html index 9c60cece97..d04dfee820 100644 --- a/interfaces/_libp2p_identify.IdentifyPushInit.html +++ b/interfaces/_libp2p_identify.IdentifyPushInit.html @@ -1,4 +1,4 @@ -IdentifyPushInit | libp2p

    Interface IdentifyPushInit

    interface IdentifyPushInit {
        agentVersion?: string;
        concurrency?: number;
        maxInboundStreams?: number;
        maxMessageSize?: number;
        maxObservedAddresses?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        runOnLimitedConnection?: boolean;
        runOnSelfUpdate?: boolean;
        timeout?: number;
    }

    Hierarchy

    Properties

    agentVersion? +IdentifyPushInit | libp2p

    Interface IdentifyPushInit

    interface IdentifyPushInit {
        agentVersion?: string;
        concurrency?: number;
        maxInboundStreams?: number;
        maxMessageSize?: number;
        maxObservedAddresses?: number;
        maxOutboundStreams?: number;
        protocolPrefix?: string;
        runOnLimitedConnection?: boolean;
        runOnSelfUpdate?: boolean;
        timeout?: number;
    }

    Hierarchy

    Properties

    agentVersion?: string

    What details we should send as part of an identify message

    -
    concurrency?: number

    Push to this many connections in parallel

    +
    concurrency?: number

    Push to this many connections in parallel

    Default

    32
     
    -
    maxInboundStreams?: number

    The maximum number of inbound streams that may be open on a single +

    maxInboundStreams?: number

    The maximum number of inbound streams that may be open on a single connection for this protocol

    Default

    1
     
    -
    maxMessageSize?: number

    Identify responses larger than this in bytes will be rejected

    +
    maxMessageSize?: number

    Identify responses larger than this in bytes will be rejected

    Default

    8192
     
    -
    maxObservedAddresses?: number

    The maximum number of observed addresses to send in an Identify message

    -
    maxOutboundStreams?: number

    The maximum number of outbound streams that may be open on a single +

    maxObservedAddresses?: number

    The maximum number of observed addresses to send in an Identify message

    +
    maxOutboundStreams?: number

    The maximum number of outbound streams that may be open on a single connection for this protocol

    Default

    1
     
    -
    protocolPrefix?: string

    The prefix to use for the protocol

    +
    protocolPrefix?: string

    The prefix to use for the protocol

    Default

    'ipfs'
     
    -
    runOnLimitedConnection?: boolean

    Whether to run on connections with data or duration limits

    +
    runOnLimitedConnection?: boolean

    Whether to run on connections with data or duration limits

    Default

    true
     
    -
    runOnSelfUpdate?: boolean

    Whether to automatically dial identify-push on self updates

    +
    runOnSelfUpdate?: boolean

    Whether to automatically dial identify-push on self updates

    Default

    true
     
    -
    timeout?: number

    How long we should wait for a remote peer to send their identify response

    +
    timeout?: number

    How long we should wait for a remote peer to send their identify response

    Default

    5000
     
    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.AbortOptions.html b/interfaces/_libp2p_interface.AbortOptions.html index ed3bbcb7b1..5a488944a8 100644 --- a/interfaces/_libp2p_interface.AbortOptions.html +++ b/interfaces/_libp2p_interface.AbortOptions.html @@ -2,5 +2,5 @@ the optional signal property.

    Example

    const controller = new AbortController()

    aLongRunningOperation({
    signal: controller.signal
    })

    // later

    controller.abort()
    -
    interface AbortOptions {
        signal?: AbortSignal;
    }

    Hierarchy (view full)

    Properties

    Properties

    signal?: AbortSignal
    \ No newline at end of file +
    interface AbortOptions {
        signal?: AbortSignal;
    }

    Hierarchy (view full)

    Properties

    Properties

    signal?: AbortSignal
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Address.html b/interfaces/_libp2p_interface.Address.html index 8a6e9ab4d4..e391c380d8 100644 --- a/interfaces/_libp2p_interface.Address.html +++ b/interfaces/_libp2p_interface.Address.html @@ -1,6 +1,6 @@ Address | libp2p

    A multiaddr with an optional flag that indicates if its trustworthy

    -
    interface Address {
        isCertified: boolean;
        multiaddr: Multiaddr;
    }

    Properties

    interface Address {
        isCertified: boolean;
        multiaddr: Multiaddr;
    }

    Properties

    isCertified: boolean

    Obtained from a signed peer record

    -
    multiaddr: Multiaddr

    Peer multiaddr

    -
    \ No newline at end of file +
    multiaddr: Multiaddr

    Peer multiaddr

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.AddressSorter.html b/interfaces/_libp2p_interface.AddressSorter.html index d0f42d1a49..8217a76e51 100644 --- a/interfaces/_libp2p_interface.AddressSorter.html +++ b/interfaces/_libp2p_interface.AddressSorter.html @@ -1,2 +1,2 @@ AddressSorter | libp2p

    Used by the connection manager to sort addresses into order before dialling

    -
    interface AddressSorter ((a, b) => -1 | 0 | 1)
    \ No newline at end of file +
    interface AddressSorter ((a, b) => -1 | 0 | 1)
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.CalculatedMetricOptions.html b/interfaces/_libp2p_interface.CalculatedMetricOptions.html index 20ffd5b129..ed37634857 100644 --- a/interfaces/_libp2p_interface.CalculatedMetricOptions.html +++ b/interfaces/_libp2p_interface.CalculatedMetricOptions.html @@ -1,10 +1,10 @@ CalculatedMetricOptions | libp2p

    Interface CalculatedMetricOptions<T>

    Create tracked metrics that are expensive to calculate by passing a function that is only invoked when metrics are being scraped

    -
    interface CalculatedMetricOptions<T> {
        calculate: CalculateMetric<T>;
        help?: string;
        label?: string;
    }

    Type Parameters

    • T = number

    Hierarchy (view full)

    Properties

    interface CalculatedMetricOptions<T> {
        calculate: CalculateMetric<T>;
        help?: string;
        label?: string;
    }

    Type Parameters

    • T = number

    Hierarchy (view full)

    Properties

    calculate: CalculateMetric<T>

    An optional function invoked to calculate the component metric instead of using .update, .increment, and .decrement

    -
    help?: string

    Optional help for the metric

    -
    label?: string

    Optional label for the metric

    -
    \ No newline at end of file +
    help?: string

    Optional help for the metric

    +
    label?: string

    Optional label for the metric

    +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ComponentLogger.html b/interfaces/_libp2p_interface.ComponentLogger.html index f1b4d0daf1..8543f3f369 100644 --- a/interfaces/_libp2p_interface.ComponentLogger.html +++ b/interfaces/_libp2p_interface.ComponentLogger.html @@ -1,3 +1,3 @@ ComponentLogger | libp2p

    Peer logger component for libp2p

    -
    interface ComponentLogger {
        forComponent(name): Logger;
    }

    Methods

    Methods

    \ No newline at end of file +
    interface ComponentLogger {
        forComponent(name): Logger;
    }

    Methods

    Methods

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Connection.html b/interfaces/_libp2p_interface.Connection.html index d7198a0a3f..c3cc88a7ed 100644 --- a/interfaces/_libp2p_interface.Connection.html +++ b/interfaces/_libp2p_interface.Connection.html @@ -2,7 +2,7 @@ to a remote peer that may have been secured by encryption and multiplexed, depending on the configuration of the nodes between which the connection is made.

    -
    interface Connection {
        direction: Direction;
        encryption?: string;
        id: string;
        limits?: ConnectionLimits;
        log: Logger;
        multiplexer?: string;
        remoteAddr: Multiaddr;
        remotePeer: PeerId;
        rtt?: number;
        status: ConnectionStatus;
        streams: Stream[];
        tags: string[];
        timeline: ConnectionTimeline;
        abort(err): void;
        close(options?): Promise<void>;
        newStream(protocols, options?): Promise<Stream>;
    }

    Properties

    interface Connection {
        direction: Direction;
        encryption?: string;
        id: string;
        limits?: ConnectionLimits;
        log: Logger;
        multiplexer?: string;
        remoteAddr: Multiaddr;
        remotePeer: PeerId;
        rtt?: number;
        status: ConnectionStatus;
        streams: Stream[];
        tags: string[];
        timeline: ConnectionTimeline;
        abort(err): void;
        close(options?): Promise<void>;
        newStream(protocols, options?): Promise<Stream>;
    }

    Properties

    Properties

    direction: Direction

    Outbound conections are opened by the local node, inbound streams are opened by the remote

    -
    encryption?: string

    The encryption protocol negotiated for this connection

    -
    id: string

    The unique identifier for this connection

    -

    If present, this connection has limits applied to it, perhaps by an +

    encryption?: string

    The encryption protocol negotiated for this connection

    +
    id: string

    The unique identifier for this connection

    +

    If present, this connection has limits applied to it, perhaps by an intermediate relay. Once the limits have been reached the connection will be closed by the relay.

    -
    log: Logger

    The connection logger

    -
    multiplexer?: string

    The multiplexer negotiated for this connection

    -
    remoteAddr: Multiaddr

    The address of the remote end of the connection

    -
    remotePeer: PeerId

    The id of the peer at the remote end of the connection

    -
    rtt?: number

    The time in milliseconds it takes to make a round trip to the remote peer.

    +
    log: Logger

    The connection logger

    +
    multiplexer?: string

    The multiplexer negotiated for this connection

    +
    remoteAddr: Multiaddr

    The address of the remote end of the connection

    +
    remotePeer: PeerId

    The id of the peer at the remote end of the connection

    +
    rtt?: number

    The time in milliseconds it takes to make a round trip to the remote peer.

    This is updated periodically by the connection monitor.

    -

    The current status of the connection

    -
    streams: Stream[]

    A list of open streams on this connection

    -
    tags: string[]

    A list of tags applied to this connection

    -

    Lifecycle times for the connection

    -

    Methods

    The current status of the connection

    +
    streams: Stream[]

    A list of open streams on this connection

    +
    tags: string[]

    A list of tags applied to this connection

    +

    Lifecycle times for the connection

    +

    Methods

    \ No newline at end of file +

    Parameters

    Returns Promise<void>

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionEncrypter.html b/interfaces/_libp2p_interface.ConnectionEncrypter.html index f88b8bb288..481e23e920 100644 --- a/interfaces/_libp2p_interface.ConnectionEncrypter.html +++ b/interfaces/_libp2p_interface.ConnectionEncrypter.html @@ -1,12 +1,12 @@ ConnectionEncrypter | libp2p

    Interface ConnectionEncrypter<Extension>

    A libp2p connection encrypter module must be compliant to this interface to ensure all exchanged data between two peers is encrypted.

    -
    interface ConnectionEncrypter<Extension> {
        protocol: string;
        secureInbound<Stream>(connection, options?): Promise<SecuredConnection<Stream, Extension>>;
        secureOutbound<Stream>(connection, options?): Promise<SecuredConnection<Stream, Extension>>;
    }

    Type Parameters

    • Extension = unknown

    Properties

    interface ConnectionEncrypter<Extension> {
        protocol: string;
        secureInbound<Stream>(connection, options?): Promise<SecuredConnection<Stream, Extension>>;
        secureOutbound<Stream>(connection, options?): Promise<SecuredConnection<Stream, Extension>>;
    }

    Type Parameters

    • Extension = unknown

    Properties

    protocol: string

    Methods

    Properties

    protocol: string

    Methods

    \ No newline at end of file +

    Type Parameters

    Parameters

    Returns Promise<SecuredConnection<Stream, Extension>>

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionGater.html b/interfaces/_libp2p_interface.ConnectionGater.html index 27e09c3ee5..eea60c7212 100644 --- a/interfaces/_libp2p_interface.ConnectionGater.html +++ b/interfaces/_libp2p_interface.ConnectionGater.html @@ -1,4 +1,4 @@ -ConnectionGater | libp2p
    interface ConnectionGater {
        denyDialMultiaddr?(multiaddr): boolean | Promise<boolean>;
        denyDialPeer?(peerId): boolean | Promise<boolean>;
        denyInboundConnection?(maConn): boolean | Promise<boolean>;
        denyInboundEncryptedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyInboundRelayReservation?(source): boolean | Promise<boolean>;
        denyInboundRelayedConnection?(relay, remotePeer): boolean | Promise<boolean>;
        denyInboundUpgradedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundEncryptedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundRelayedConnection?(source, destination): boolean | Promise<boolean>;
        denyOutboundUpgradedConnection?(peerId, maConn): boolean | Promise<boolean>;
        filterMultiaddrForPeer?(peer, multiaddr): boolean | Promise<boolean>;
    }

    Methods

    denyDialMultiaddr? +ConnectionGater | libp2p
    interface ConnectionGater {
        denyDialMultiaddr?(multiaddr): boolean | Promise<boolean>;
        denyDialPeer?(peerId): boolean | Promise<boolean>;
        denyInboundConnection?(maConn): boolean | Promise<boolean>;
        denyInboundEncryptedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyInboundRelayReservation?(source): boolean | Promise<boolean>;
        denyInboundRelayedConnection?(relay, remotePeer): boolean | Promise<boolean>;
        denyInboundUpgradedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundEncryptedConnection?(peerId, maConn): boolean | Promise<boolean>;
        denyOutboundRelayedConnection?(source, destination): boolean | Promise<boolean>;
        denyOutboundUpgradedConnection?(peerId, maConn): boolean | Promise<boolean>;
        filterMultiaddrForPeer?(peer, multiaddr): boolean | Promise<boolean>;
    }

    Methods

    denyDialMultiaddr? denyDialPeer? denyInboundConnection? denyInboundEncryptedConnection? @@ -15,52 +15,52 @@

    This is called by the connection manager - if the peer id of the remote node is known it will be present in the multiaddr.

    Return true to prevent dialing the passed peer on the passed multiaddr.

    -

    Parameters

    Returns boolean | Promise<boolean>

    • denyDialPeer tests whether we're permitted to Dial the specified peer.

      This is called by the dialer.connectToPeer implementation before dialling a peer.

      Return true to prevent dialing the passed peer.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyInboundConnection tests whether an incipient inbound connection is allowed.

      This is called by the upgrader, or by the transport directly (e.g. QUIC, Bluetooth), straight after it has accepted a connection from its socket.

      Return true to deny the incoming passed connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyInboundEncryptedConnection tests whether a given connection, now encrypted, is allowed.

      This is called by the upgrader, after it has performed the security handshake, and before it negotiates the muxer, or by the directly by the transport, at the exact same checkpoint.

      Return true to deny the passed secured connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyInboundRelayedConnection tests whether a remote peer is allowed to open a relayed connection to this node.

      This is invoked on the relay client when a remote relay has received an instruction to relay a connection to the client.

      Return true to deny the relayed connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyInboundUpgradedConnection tests whether a fully capable connection is allowed.

      This is called after encryption has been negotiated and the connection has been multiplexed, if a multiplexer is configured.

      Return true to deny the passed upgraded connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyOutboundConnection tests whether an incipient outbound connection is allowed.

      This is called by the upgrader, or by the transport directly (e.g. QUIC, Bluetooth), straight after it has created a connection with its socket.

      Return true to deny the incoming passed connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyOutboundEncryptedConnection tests whether a given connection, now encrypted, is allowed.

      This is called by the upgrader, after it has performed the security handshake, and before it negotiates the muxer, or by the directly by the transport, at the exact same checkpoint.

      Return true to deny the passed secured connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyOutboundRelayedConnection tests whether a remote peer is allowed to open a relayed connection to the destination node.

      This is invoked on the relay server when a source client with a reservation instructs the server to relay a connection to a destination peer.

      Return true to deny the relayed connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    • denyOutboundUpgradedConnection tests whether a fully capable connection is allowed.

      This is called after encryption has been negotiated and the connection has been multiplexed, if a multiplexer is configured.

      Return true to deny the passed upgraded connection.

      -

      Parameters

      Returns boolean | Promise<boolean>

    \ No newline at end of file +

    Parameters

    Returns boolean | Promise<boolean>

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionHandler.html b/interfaces/_libp2p_interface.ConnectionHandler.html index a13e276536..7754051952 100644 --- a/interfaces/_libp2p_interface.ConnectionHandler.html +++ b/interfaces/_libp2p_interface.ConnectionHandler.html @@ -1 +1 @@ -ConnectionHandler | libp2p

    Interface ConnectionHandler

    interface ConnectionHandler ((connection) => void)
    \ No newline at end of file +ConnectionHandler | libp2p

    Interface ConnectionHandler

    interface ConnectionHandler ((connection) => void)
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionLimits.html b/interfaces/_libp2p_interface.ConnectionLimits.html index c1b5305346..ee6a01d70e 100644 --- a/interfaces/_libp2p_interface.ConnectionLimits.html +++ b/interfaces/_libp2p_interface.ConnectionLimits.html @@ -4,10 +4,10 @@

    These limits are applied by Circuit Relay v2 servers, for example and the connection will normally be closed abruptly if the limits are exceeded.

    -
    interface ConnectionLimits {
        bytes?: bigint;
        seconds?: number;
    }

    Properties

    interface ConnectionLimits {
        bytes?: bigint;
        seconds?: number;
    }

    Properties

    Properties

    bytes?: bigint

    If present this is the number of bytes remaining that may be transferred over this connection

    -
    seconds?: number

    If present this is the number of seconds that this connection will +

    seconds?: number

    If present this is the number of seconds that this connection will remain open for

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionProtector.html b/interfaces/_libp2p_interface.ConnectionProtector.html index 4edc79c4eb..950f6a4575 100644 --- a/interfaces/_libp2p_interface.ConnectionProtector.html +++ b/interfaces/_libp2p_interface.ConnectionProtector.html @@ -1,5 +1,5 @@ -ConnectionProtector | libp2p

    Interface ConnectionProtector

    interface ConnectionProtector {
        protect(connection): Promise<MultiaddrConnection>;
    }

    Methods

    protect +ConnectionProtector | libp2p

    Interface ConnectionProtector

    interface ConnectionProtector {
        protect(connection): Promise<MultiaddrConnection>;
    }

    Methods

    Methods

    \ No newline at end of file +

    Parameters

    Returns Promise<MultiaddrConnection>

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ConnectionTimeline.html b/interfaces/_libp2p_interface.ConnectionTimeline.html index d8e486b7c7..7033f60397 100644 --- a/interfaces/_libp2p_interface.ConnectionTimeline.html +++ b/interfaces/_libp2p_interface.ConnectionTimeline.html @@ -1,8 +1,8 @@ -ConnectionTimeline | libp2p

    Interface ConnectionTimeline

    interface ConnectionTimeline {
        close?: number;
        open: number;
        upgraded?: number;
    }

    Properties

    close? +ConnectionTimeline | libp2p

    Interface ConnectionTimeline

    interface ConnectionTimeline {
        close?: number;
        open: number;
        upgraded?: number;
    }

    Properties

    Properties

    close?: number

    When the connection was closed.

    -
    open: number

    When the connection was opened

    -
    upgraded?: number

    When the MultiaddrConnection was upgraded to a Connection - e.g. the type +

    open: number

    When the connection was opened

    +
    upgraded?: number

    When the MultiaddrConnection was upgraded to a Connection - e.g. the type of connection encryption and multiplexing was negotiated.

    -
    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ContentRouting.html b/interfaces/_libp2p_interface.ContentRouting.html index 9b761cebc6..6d26359947 100644 --- a/interfaces/_libp2p_interface.ContentRouting.html +++ b/interfaces/_libp2p_interface.ContentRouting.html @@ -1,19 +1,19 @@ -ContentRouting | libp2p
    interface ContentRouting {
        findProviders(cid, options?): AsyncIterable<PeerInfo>;
        get(key, options?): Promise<Uint8Array>;
        provide(cid, options?): Promise<void>;
        put(key, value, options?): Promise<void>;
    }

    Methods

    findProviders +ContentRouting | libp2p
    interface ContentRouting {
        findProviders(cid, options?): AsyncIterable<PeerInfo>;
        get(key, options?): Promise<Uint8Array>;
        provide(cid, options?): Promise<void>;
        put(key, value, options?): Promise<void>;
    }

    Methods

    \ No newline at end of file +
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ContentRoutingProvider.html b/interfaces/_libp2p_interface.ContentRoutingProvider.html index f0043e3f80..e4bdba5c6d 100644 --- a/interfaces/_libp2p_interface.ContentRoutingProvider.html +++ b/interfaces/_libp2p_interface.ContentRoutingProvider.html @@ -1,4 +1,4 @@ ContentRoutingProvider | libp2p

    Interface ContentRoutingProvider

    Implementers of this interface can provide a ContentRouting implementation to interested callers.

    -
    interface ContentRoutingProvider {
        [contentRoutingSymbol]: ContentRouting;
    }

    Properties

    [contentRoutingSymbol]: ContentRouting
    \ No newline at end of file +
    interface ContentRoutingProvider {
        [contentRoutingSymbol]: ContentRouting;
    }

    Properties

    [contentRoutingSymbol]: ContentRouting
    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Counter.html b/interfaces/_libp2p_interface.Counter.html index 0ed0e2057e..50bc3a3cab 100644 --- a/interfaces/_libp2p_interface.Counter.html +++ b/interfaces/_libp2p_interface.Counter.html @@ -1,7 +1,7 @@ Counter | libp2p

    A tracked counter loosely based on the Counter interface exposed by the prom-client module - counters are metrics that only go up

    -
    interface Counter {
        increment(value?): void;
        reset(): void;
    }

    Methods

    interface Counter {
        increment(value?): void;
        reset(): void;
    }

    Methods

    \ No newline at end of file +

    Parameters

    Returns void

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.CounterGroup.html b/interfaces/_libp2p_interface.CounterGroup.html index e102c41ed3..5673049680 100644 --- a/interfaces/_libp2p_interface.CounterGroup.html +++ b/interfaces/_libp2p_interface.CounterGroup.html @@ -1,10 +1,10 @@ CounterGroup | libp2p

    Interface CounterGroup<T>

    A group of tracked counters loosely based on the Counter interface exposed by the prom-client module - counters are metrics that only go up

    -
    interface CounterGroup<T> {
        increment(values): void;
        reset(): void;
    }

    Type Parameters

    • T extends string = any

    Methods

    interface CounterGroup<T> {
        increment(values): void;
        reset(): void;
    }

    Type Parameters

    • T extends string = any

    Methods

    \ No newline at end of file +

    Returns void

    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.CreateListenerOptions.html b/interfaces/_libp2p_interface.CreateListenerOptions.html index 3b9349f9ab..81cf913ed4 100644 --- a/interfaces/_libp2p_interface.CreateListenerOptions.html +++ b/interfaces/_libp2p_interface.CreateListenerOptions.html @@ -1,3 +1,3 @@ -CreateListenerOptions | libp2p

    Interface CreateListenerOptions

    interface CreateListenerOptions {
        handler?: ConnectionHandler;
        upgrader: Upgrader;
    }

    Hierarchy

    • CreateListenerOptions

      Properties

      handler? +CreateListenerOptions | libp2p

      Interface CreateListenerOptions

      interface CreateListenerOptions {
          handler?: ConnectionHandler;
          upgrader: Upgrader;
      }

      Hierarchy

      • CreateListenerOptions

        Properties

        Properties

        upgrader: Upgrader
        \ No newline at end of file +

        Properties

        upgrader: Upgrader
        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.DialOptions.html b/interfaces/_libp2p_interface.DialOptions.html index 1a4d81b75c..1929648940 100644 --- a/interfaces/_libp2p_interface.DialOptions.html +++ b/interfaces/_libp2p_interface.DialOptions.html @@ -2,8 +2,8 @@ the optional signal property.

        Example

        const controller = new AbortController()

        aLongRunningOperation({
        signal: controller.signal
        })

        // later

        controller.abort()
        -
        interface DialOptions {
            force?: boolean;
            onProgress?: ((evt) => void);
            signal?: AbortSignal;
        }

        Hierarchy (view full)

        Properties

        interface DialOptions {
            force?: boolean;
            onProgress?: ((evt) => void);
            signal?: AbortSignal;
        }

        Hierarchy (view full)

        Properties

        force?: boolean

        If true, open a new connection to the remote even if one already exists

        -
        onProgress?: ((evt) => void)

        Type declaration

          • (evt): void
          • Parameters

            • evt: any

            Returns void

        signal?: AbortSignal
        \ No newline at end of file +
        onProgress?: ((evt) => void)

        Type declaration

          • (evt): void
          • Parameters

            • evt: any

            Returns void

        signal?: AbortSignal
        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.DialProtocolOptions.html b/interfaces/_libp2p_interface.DialProtocolOptions.html index bb6c7d4462..33474c1392 100644 --- a/interfaces/_libp2p_interface.DialProtocolOptions.html +++ b/interfaces/_libp2p_interface.DialProtocolOptions.html @@ -2,14 +2,14 @@ the optional signal property.

        Example

        const controller = new AbortController()

        aLongRunningOperation({
        signal: controller.signal
        })

        // later

        controller.abort()
        -
        interface DialProtocolOptions {
            maxOutboundStreams?: number;
            negotiateFully?: boolean;
            runOnLimitedConnection?: boolean;
            signal?: AbortSignal;
        }

        Hierarchy (view full)

        Properties

        interface DialProtocolOptions {
            maxOutboundStreams?: number;
            negotiateFully?: boolean;
            runOnLimitedConnection?: boolean;
            signal?: AbortSignal;
        }

        Hierarchy (view full)

        Properties

        maxOutboundStreams?: number

        If specified, and no handler has been registered with the registrar for the successfully negotiated protocol, use this as the max outbound stream limit for the protocol

        -
        negotiateFully?: boolean

        By default when negotiating a protocol the dialer writes then protocol name +

        negotiateFully?: boolean

        By default when negotiating a protocol the dialer writes then protocol name then reads the response.

        When a only a single protocol is being negotiated on an outbound stream, and the stream is written to before being read from, we can optimistically @@ -27,11 +27,11 @@ in full before the stream is returned so this option has no effect.

        Default

        true
         
        -
        runOnLimitedConnection?: boolean

        Opt-in to running over a limited connection - one that has restrictions +

        runOnLimitedConnection?: boolean

        Opt-in to running over a limited connection - one that has restrictions on the amount of data that may be transferred or how long it may be open for.

        These limits are typically enforced by a relay server, if the protocol will be transferring a lot of data or the stream will be open for a long time consider upgrading to a direct connection before opening the stream.

        Default

        false
         
        -
        signal?: AbortSignal
        \ No newline at end of file +
        signal?: AbortSignal
        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.DialTransportOptions.html b/interfaces/_libp2p_interface.DialTransportOptions.html index d59b2d93dc..02e7687cf0 100644 --- a/interfaces/_libp2p_interface.DialTransportOptions.html +++ b/interfaces/_libp2p_interface.DialTransportOptions.html @@ -2,7 +2,7 @@ the optional signal property.

        Example

        const controller = new AbortController()

        aLongRunningOperation({
        signal: controller.signal
        })

        // later

        controller.abort()
        -
        interface DialTransportOptions<DialEvents> {
            onProgress?: ((evt) => void);
            signal?: AbortSignal;
            upgrader: Upgrader;
        }

        Type Parameters

        Hierarchy (view full)

        Properties

        interface DialTransportOptions<DialEvents> {
            onProgress?: ((evt) => void);
            signal?: AbortSignal;
            upgrader: Upgrader;
        }

        Type Parameters

        Hierarchy (view full)

        Properties

        onProgress?: ((evt) => void)

        Type declaration

        signal?: AbortSignal
        upgrader: Upgrader
        \ No newline at end of file +

        Properties

        onProgress?: ((evt) => void)

        Type declaration

        signal?: AbortSignal
        upgrader: Upgrader
        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Ed25519PeerId.html b/interfaces/_libp2p_interface.Ed25519PeerId.html index f2f54ddbf8..904c00910f 100644 --- a/interfaces/_libp2p_interface.Ed25519PeerId.html +++ b/interfaces/_libp2p_interface.Ed25519PeerId.html @@ -1,4 +1,4 @@ -Ed25519PeerId | libp2p
        interface Ed25519PeerId {
            publicKey: Ed25519PublicKey;
            type: "Ed25519";
            equals(other?): boolean;
            toCID(): CID<Uint8Array, 114, 0, 1>;
            toMultihash(): MultihashDigest<0>;
            toString(): string;
        }

        Properties

        publicKey +Ed25519PeerId | libp2p
        interface Ed25519PeerId {
            publicKey: Ed25519PublicKey;
            type: "Ed25519";
            equals(other?): boolean;
            toCID(): CID<Uint8Array, 114, 0, 1>;
            toMultihash(): MultihashDigest<0>;
            toString(): string;
        }

        Properties

        Methods

        equals toCID @@ -6,10 +6,10 @@ toString

        Properties

        publicKey: Ed25519PublicKey

        This will always be defined as the public key is embedded in the multihash of this PeerId

        -
        type: "Ed25519"

        Methods

        type: "Ed25519"

        Methods

        \ No newline at end of file +

        Returns MultihashDigest<0>

        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Ed25519PrivateKey.html b/interfaces/_libp2p_interface.Ed25519PrivateKey.html index 2226449a02..39add2bc8b 100644 --- a/interfaces/_libp2p_interface.Ed25519PrivateKey.html +++ b/interfaces/_libp2p_interface.Ed25519PrivateKey.html @@ -1,13 +1,13 @@ -Ed25519PrivateKey | libp2p

        Interface Ed25519PrivateKey

        interface Ed25519PrivateKey {
            publicKey: Ed25519PublicKey;
            raw: Uint8Array;
            type: "Ed25519";
            equals(key?): boolean;
            sign(data): Uint8Array | Promise<Uint8Array>;
        }

        Hierarchy

        Properties

        publicKey +Ed25519PrivateKey | libp2p

        Interface Ed25519PrivateKey

        interface Ed25519PrivateKey {
            publicKey: Ed25519PublicKey;
            raw: Uint8Array;
            type: "Ed25519";
            equals(key?): boolean;
            sign(data): Uint8Array | Promise<Uint8Array>;
        }

        Hierarchy

        Properties

        Methods

        Properties

        publicKey: Ed25519PublicKey

        The public key that corresponds to this private key

        -

        The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 +

        The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

        -
        type: "Ed25519"

        The type of this key

        -

        Methods

        • Returns true if the passed object matches this key

          -

          Parameters

          • Optional key: any

          Returns boolean

        type: "Ed25519"

        The type of this key

        +

        Methods

        • Returns true if the passed object matches this key

          +

          Parameters

          • Optional key: any

          Returns boolean

        \ No newline at end of file +

        Parameters

        Returns Uint8Array | Promise<Uint8Array>

        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Ed25519PublicKey.html b/interfaces/_libp2p_interface.Ed25519PublicKey.html index 8c73765618..9ffec08171 100644 --- a/interfaces/_libp2p_interface.Ed25519PublicKey.html +++ b/interfaces/_libp2p_interface.Ed25519PublicKey.html @@ -1,4 +1,4 @@ -Ed25519PublicKey | libp2p

        Interface Ed25519PublicKey

        interface Ed25519PublicKey {
            raw: Uint8Array;
            type: "Ed25519";
            equals(key?): boolean;
            toCID(): CID<unknown, 114, 0, 1>;
            toMultihash(): MultihashDigest<0>;
            toString(): string;
            verify(data, sig): boolean | Promise<boolean>;
        }

        Hierarchy

        Properties

        raw +Ed25519PublicKey | libp2p

        Interface Ed25519PublicKey

        interface Ed25519PublicKey {
            raw: Uint8Array;
            type: "Ed25519";
            equals(key?): boolean;
            toCID(): CID<unknown, 114, 0, 1>;
            toMultihash(): MultihashDigest<0>;
            toString(): string;
            verify(data, sig): boolean | Promise<boolean>;
        }

        Hierarchy

        Properties

        Methods

        equals toCID @@ -7,17 +7,17 @@ verify

        Properties

        The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

        -
        type: "Ed25519"

        The type of this key

        -

        Methods

        • Returns true if the passed object matches this key

          -

          Parameters

          • Optional key: any

          Returns boolean

        type: "Ed25519"

        The type of this key

        +

        Methods

        • Returns true if the passed object matches this key

          +

          Parameters

          • Optional key: any

          Returns boolean

        • Return this public key as a CID encoded with the libp2p-key codec

          The digest contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

          -

          Returns CID<unknown, 114, 0, 1>

        • Returns this public key as a Multihash digest.

          It contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

          -

          Returns MultihashDigest<0>

        \ No newline at end of file +

        Parameters

        Returns boolean | Promise<boolean>

        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Envelope.html b/interfaces/_libp2p_interface.Envelope.html index 44beb968bc..3388702b06 100644 --- a/interfaces/_libp2p_interface.Envelope.html +++ b/interfaces/_libp2p_interface.Envelope.html @@ -1,8 +1,8 @@ -Envelope | libp2p
        interface Envelope {
            payload: Uint8Array;
            payloadType: Uint8Array | Uint8ArrayList;
            publicKey: PublicKey;
            signature: Uint8Array | Uint8ArrayList;
            equals(other): boolean;
            marshal(): Uint8Array;
            validate(domain): Promise<boolean>;
        }

        Implemented by

          Properties

          payload +Envelope | libp2p
          interface Envelope {
              payload: Uint8Array;
              payloadType: Uint8Array | Uint8ArrayList;
              publicKey: PublicKey;
              signature: Uint8Array | Uint8ArrayList;
              equals(other): boolean;
              marshal(): Uint8Array;
              validate(domain): Promise<boolean>;
          }

          Implemented by

            Properties

            payload: Uint8Array
            payloadType: Uint8Array | Uint8ArrayList
            publicKey: PublicKey

            Methods

            \ No newline at end of file +

            Properties

            payload: Uint8Array
            payloadType: Uint8Array | Uint8ArrayList
            publicKey: PublicKey

            Methods

            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.EventCallback.html b/interfaces/_libp2p_interface.EventCallback.html index 57651a4cee..d0a6e09575 100644 --- a/interfaces/_libp2p_interface.EventCallback.html +++ b/interfaces/_libp2p_interface.EventCallback.html @@ -1 +1 @@ -EventCallback | libp2p

            Interface EventCallback<EventType>

            interface EventCallback<EventType> ((evt) => void)

            Type Parameters

            • EventType
            \ No newline at end of file +EventCallback | libp2p

            Interface EventCallback<EventType>

            interface EventCallback<EventType> ((evt) => void)

            Type Parameters

            • EventType
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.EventObject.html b/interfaces/_libp2p_interface.EventObject.html index e1e1ac516f..90416e58d4 100644 --- a/interfaces/_libp2p_interface.EventObject.html +++ b/interfaces/_libp2p_interface.EventObject.html @@ -1,2 +1,2 @@ -EventObject | libp2p

            Interface EventObject<EventType>

            interface EventObject<EventType> {
                handleEvent: EventCallback<EventType>;
            }

            Type Parameters

            • EventType

            Properties

            Properties

            handleEvent: EventCallback<EventType>
            \ No newline at end of file +EventObject | libp2p

            Interface EventObject<EventType>

            interface EventObject<EventType> {
                handleEvent: EventCallback<EventType>;
            }

            Type Parameters

            • EventType

            Properties

            Properties

            handleEvent: EventCallback<EventType>
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.IdentifyResult.html b/interfaces/_libp2p_interface.IdentifyResult.html index 2cd979955a..30f9e04fd1 100644 --- a/interfaces/_libp2p_interface.IdentifyResult.html +++ b/interfaces/_libp2p_interface.IdentifyResult.html @@ -1,5 +1,5 @@ IdentifyResult | libp2p

            Data returned from a successful identify response

            -
            interface IdentifyResult {
                agentVersion?: string;
                connection: Connection;
                listenAddrs: Multiaddr[];
                observedAddr?: Multiaddr;
                peerId: PeerId;
                protocolVersion?: string;
                protocols: string[];
                publicKey?: Uint8Array;
                signedPeerRecord?: SignedPeerRecord;
            }

            Properties

            interface IdentifyResult {
                agentVersion?: string;
                connection: Connection;
                listenAddrs: Multiaddr[];
                observedAddr?: Multiaddr;
                peerId: PeerId;
                protocolVersion?: string;
                protocols: string[];
                publicKey?: Uint8Array;
                signedPeerRecord?: SignedPeerRecord;
            }

            Properties

            agentVersion?: string

            The remote agent version

            -
            connection: Connection

            The connection that the identify protocol ran over

            -
            listenAddrs: Multiaddr[]

            The unsigned addresses they are listening on. Note - any multiaddrs present +

            connection: Connection

            The connection that the identify protocol ran over

            +
            listenAddrs: Multiaddr[]

            The unsigned addresses they are listening on. Note - any multiaddrs present in the signed peer record should be preferred to the value here.

            -
            observedAddr?: Multiaddr

            If set this is the address that the remote peer saw the identify request +

            observedAddr?: Multiaddr

            If set this is the address that the remote peer saw the identify request originate from

            -
            peerId: PeerId

            The remote Peer's PeerId

            -
            protocolVersion?: string

            The remote protocol version

            -
            protocols: string[]

            The protocols the remote peer supports

            -
            publicKey?: Uint8Array

            The public key part of the remote PeerId - this is only useful for older +

            peerId: PeerId

            The remote Peer's PeerId

            +
            protocolVersion?: string

            The remote protocol version

            +
            protocols: string[]

            The protocols the remote peer supports

            +
            publicKey?: Uint8Array

            The public key part of the remote PeerId - this is only useful for older RSA-based PeerIds, the more modern Ed25519 and secp256k1 types have the public key embedded in them

            -
            signedPeerRecord?: SignedPeerRecord

            If sent by the remote peer this is the deserialized signed peer record

            -
            \ No newline at end of file +
            signedPeerRecord?: SignedPeerRecord

            If sent by the remote peer this is the deserialized signed peer record

            +
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.IncomingStreamData.html b/interfaces/_libp2p_interface.IncomingStreamData.html index 2934e73ce1..021969e6ac 100644 --- a/interfaces/_libp2p_interface.IncomingStreamData.html +++ b/interfaces/_libp2p_interface.IncomingStreamData.html @@ -1,3 +1,3 @@ -IncomingStreamData | libp2p

            Interface IncomingStreamData

            interface IncomingStreamData {
                connection: Connection;
                stream: Stream;
            }

            Properties

            connection +IncomingStreamData | libp2p

            Interface IncomingStreamData

            interface IncomingStreamData {
                connection: Connection;
                stream: Stream;
            }

            Properties

            Properties

            connection: Connection
            stream: Stream
            \ No newline at end of file +

            Properties

            connection: Connection
            stream: Stream
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.IsDialableOptions.html b/interfaces/_libp2p_interface.IsDialableOptions.html index d75ebc6b33..3dc950825b 100644 --- a/interfaces/_libp2p_interface.IsDialableOptions.html +++ b/interfaces/_libp2p_interface.IsDialableOptions.html @@ -2,10 +2,10 @@ the optional signal property.

            Example

            const controller = new AbortController()

            aLongRunningOperation({
            signal: controller.signal
            })

            // later

            controller.abort()
            -
            interface IsDialableOptions {
                runOnLimitedConnection?: boolean;
                signal?: AbortSignal;
            }

            Hierarchy (view full)

            Properties

            interface IsDialableOptions {
                runOnLimitedConnection?: boolean;
                signal?: AbortSignal;
            }

            Hierarchy (view full)

            Properties

            runOnLimitedConnection?: boolean

            If the dial attempt would open a protocol, and the multiaddr being dialed is a circuit relay address, passing true here would cause the test to fail because that protocol would not be allowed to run over a data/time limited connection.

            -
            signal?: AbortSignal
            \ No newline at end of file +
            signal?: AbortSignal
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Libp2p.html b/interfaces/_libp2p_interface.Libp2p.html index 6b6a30e360..b9242ded5a 100644 --- a/interfaces/_libp2p_interface.Libp2p.html +++ b/interfaces/_libp2p_interface.Libp2p.html @@ -1,5 +1,5 @@ Libp2p | libp2p

            Libp2p nodes implement this interface.

            -
            interface Libp2p<T> {
                contentRouting: ContentRouting;
                logger: ComponentLogger;
                metrics?: Metrics;
                peerId: PeerId;
                peerRouting: PeerRouting;
                peerStore: PeerStore;
                services: T;
                status: Libp2pStatus;
                addEventListener<K>(type, listener, options?): void;
                afterStart?(): void | Promise<void>;
                afterStop?(): void | Promise<void>;
                beforeStart?(): void | Promise<void>;
                beforeStop?(): void | Promise<void>;
                dial(peer, options?): Promise<Connection>;
                dialProtocol(peer, protocols, options?): Promise<Stream>;
                dispatchEvent(event): boolean;
                dispatchEvent(event): boolean;
                getConnections(peerId?): Connection[];
                getDialQueue(): PendingDial[];
                getMultiaddrs(): Multiaddr[];
                getPeers(): PeerId[];
                getProtocols(): string[];
                getPublicKey(peer, options?): Promise<Ed25519PublicKey>;
                getPublicKey(peer, options?): Promise<Secp256k1PublicKey>;
                getPublicKey(peer, options?): Promise<RSAPublicKey>;
                getPublicKey(peer, options?): Promise<never>;
                getPublicKey(peer, options?): Promise<PublicKey>;
                handle(protocol, handler, options?): Promise<void>;
                hangUp(peer, options?): Promise<void>;
                isDialable(multiaddr, options?): Promise<boolean>;
                listenerCount(type): number;
                register(protocol, topology): Promise<string>;
                removeEventListener<K>(type, listener?, options?): void;
                removeEventListener(type, listener?, options?): void;
                safeDispatchEvent<Detail>(type, detail): boolean;
                start(): void | Promise<void>;
                stop(): void | Promise<void>;
                unhandle(protocols): Promise<void>;
                unregister(id): void;
            }

            Type Parameters

            Hierarchy (view full)

            Properties

            interface Libp2p<T> {
                contentRouting: ContentRouting;
                logger: ComponentLogger;
                metrics?: Metrics;
                peerId: PeerId;
                peerRouting: PeerRouting;
                peerStore: PeerStore;
                services: T;
                status: Libp2pStatus;
                addEventListener<K>(type, listener, options?): void;
                afterStart?(): void | Promise<void>;
                afterStop?(): void | Promise<void>;
                beforeStart?(): void | Promise<void>;
                beforeStop?(): void | Promise<void>;
                dial(peer, options?): Promise<Connection>;
                dialProtocol(peer, protocols, options?): Promise<Stream>;
                dispatchEvent(event): boolean;
                dispatchEvent(event): boolean;
                getConnections(peerId?): Connection[];
                getDialQueue(): PendingDial[];
                getMultiaddrs(): Multiaddr[];
                getPeers(): PeerId[];
                getProtocols(): string[];
                getPublicKey(peer, options?): Promise<Ed25519PublicKey>;
                getPublicKey(peer, options?): Promise<Secp256k1PublicKey>;
                getPublicKey(peer, options?): Promise<RSAPublicKey>;
                getPublicKey(peer, options?): Promise<never>;
                getPublicKey(peer, options?): Promise<PublicKey>;
                handle(protocol, handler, options?): Promise<void>;
                hangUp(peer, options?): Promise<void>;
                isDialable(multiaddr, options?): Promise<boolean>;
                listenerCount(type): number;
                register(protocol, topology): Promise<string>;
                removeEventListener<K>(type, listener?, options?): void;
                removeEventListener(type, listener?, options?): void;
                safeDispatchEvent<Detail>(type, detail): boolean;
                start(): void | Promise<void>;
                stop(): void | Promise<void>;
                unhandle(protocols): Promise<void>;
                unregister(id): void;
            }

            Type Parameters

            Hierarchy (view full)

            Properties

            contentRouting logger metrics? peerId @@ -37,49 +37,49 @@ the DHT.

            Example

            for await (const peerInfo of libp2p.contentRouting.findProviders(cid)) {
            console.info(peerInfo)
            // { id: PeerId(12D3Foo...), multiaddrs: [] ... }
            }
            -

            The logger used by this libp2p node

            -
            metrics?: Metrics

            The metrics subsystem allows recording values to assess the health/performance +

            The logger used by this libp2p node

            +
            metrics?: Metrics

            The metrics subsystem allows recording values to assess the health/performance of the running node.

            Example

            const metric = libp2p.metrics.registerMetric({
            'my-metric'
            })

            // later
            metric.update(5)
            -
            peerId: PeerId

            The PeerId is a unique identifier for a node on the network.

            +
            peerId: PeerId

            The PeerId is a unique identifier for a node on the network.

            It is the hash of an RSA public key or, for Ed25519 or secp256k1 keys, the key itself.

            Example

            console.info(libp2p.peerId)
            // PeerId(12D3Foo...)
            -
            peerRouting: PeerRouting

            The peer routing subsystem allows the user to find peers on the network +

            peerRouting: PeerRouting

            The peer routing subsystem allows the user to find peers on the network or to find peers close to binary keys.

            Example

            const peerInfo = await libp2p.peerRouting.findPeer(peerId)
            console.info(peerInfo)
            // { id: PeerId(12D3Foo...), multiaddrs: [] ... }

            Example

            for await (const peerInfo of libp2p.peerRouting.getClosestPeers(key)) {
            console.info(peerInfo)
            // { id: PeerId(12D3Foo...), multiaddrs: [] ... }
            }
            -
            peerStore: PeerStore

            The peer store holds information we know about other peers on the network.

            +
            peerStore: PeerStore

            The peer store holds information we know about other peers on the network.

            • multiaddrs, supported protocols, etc.

            Example

            const peer = await libp2p.peerStore.get(peerId)
            console.info(peer)
            // { id: PeerId(12D3Foo...), addresses: [] ... }
            -
            services: T

            A set of user defined services

            -
            status: Libp2pStatus

            The current status of the libp2p node

            -

            Methods

            services: T

            A set of user defined services

            +
            status: Libp2pStatus

            The current status of the libp2p node

            +

            Methods

            • Dials to the provided peer. If successful, the known metadata of the peer will be added to the nodes peerStore.

              If a PeerId is passed as the first argument, the peer will need to have known multiaddrs for it in the PeerStore.

              Parameters

              Returns Promise<Connection>

              Example

              const conn = await libp2p.dial(remotePeerId)

              // create a new stream within the connection
              const stream = await conn.newStream(['/echo/1.1.0', '/echo/1.0.0'])

              // protocol negotiated: 'echo/1.0.0' means that the other party only supports the older version

              // ...
              await conn.close()
              -
            • Dials to the provided peer and tries to handshake with the given protocols in order. If successful, the known metadata of the peer will be added to the nodes peerStore, and the MuxedStream will be returned together with the successful negotiated protocol.

              Parameters

              Returns Promise<Stream>

              Example

              import { pipe } from 'it-pipe'

              const { stream, protocol } = await libp2p.dialProtocol(remotePeerId, protocols)

              // Use this new stream like any other duplex stream
              pipe([1, 2, 3], stream, consume)
              -
            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              +
            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              MDN Reference

              Parameters

              Returns boolean

            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              MDN Reference

              @@ -87,53 +87,53 @@

              Example

              for
               

              Parameters

              Returns Connection[]

              Example

              for (const connection of libp2p.getConnections()) {
              console.log(peerId, connection.remoteAddr.toString())
              // Logs the PeerId string and the observed remote multiaddr of each Connection
              }
              -
            • Get a deduplicated list of peer advertising multiaddrs by concatenating the listen addresses used by transports with any configured announce addresses as well as observed addresses reported by peers.

              If Announce addrs are specified, configured listen addresses will be ignored though observed addresses will still be included.

              Returns Multiaddr[]

              Example

              const listenMa = libp2p.getMultiaddrs()
              // [ <Multiaddr 047f00000106f9ba - /ip4/127.0.0.1/tcp/63930> ]
              -
            • Returns a list of supported protocols

              Returns string[]

              Example

              const protocols = libp2p.getProtocols()
              // [ '/ipfs/ping/1.0.0', '/ipfs/id/1.0.0' ]
              -
            • Sets up multistream-select routing of protocols to their application handlers. Whenever a stream is opened on one of the provided protocols, the handler will be called. handle must be called in order to register a handler and support for a given protocol. This also informs other peers of the protocols you support.

              libp2p.handle(protocols, handler, options)

              In the event of a new handler for the same protocol being added, the first one is discarded.

              Parameters

              Returns Promise<void>

              Example

              const handler = ({ connection, stream, protocol }) => {
              // use stream or connection according to the needs
              }

              libp2p.handle('/echo/1.0.0', handler, {
              maxInboundStreams: 5,
              maxOutboundStreams: 5
              })
              -
            • Attempts to gracefully close an open connection to the given peer. If the connection is not closed in the grace period, it will be forcefully closed.

              An AbortSignal can optionally be passed to control when the connection is forcefully closed.

              Parameters

              Returns Promise<void>

              Example

              await libp2p.hangUp(remotePeerId)
               
              -
            • Given the current node configuration, returns a promise of true or false if the node would attempt to dial the passed multiaddr.

              This means a relevant transport is configured, and the connection gater would not block the dial attempt.

              This may involve resolving DNS addresses so you should pass an AbortSignal.

              -

              Parameters

              Returns Promise<boolean>

            • Register a topology to be informed when peers are encountered that support the specified protocol

              Parameters

              Returns Promise<string>

              Example

              const id = await libp2p.register('/echo/1.0.0', {
              onConnect: (peer, connection) => {
              // handle connect
              },
              onDisconnect: (peer, connection) => {
              // handle disconnect
              }
              })
              -
            • Removes the handler for each protocol. The protocol will no longer be supported on streams.

              Parameters

              • protocols: string | string[]

              Returns Promise<void>

              Example

              libp2p.unhandle(['/echo/1.0.0'])
               
              -
            • Unregister topology to no longer be informed when peers connect or disconnect.

              Parameters

              • id: string

              Returns void

              Example

              const id = await libp2p.register(...)

              libp2p.unregister(id)
              -
            \ No newline at end of file +
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Libp2pEvents.html b/interfaces/_libp2p_interface.Libp2pEvents.html index 7a616aac1b..8a87d45da4 100644 --- a/interfaces/_libp2p_interface.Libp2pEvents.html +++ b/interfaces/_libp2p_interface.Libp2pEvents.html @@ -2,7 +2,7 @@ so that you can be notified of relevant network events.

            Event names are noun:verb so the first part is the name of the object being acted on and the second is the action.

            -
            interface Libp2pEvents<T> {
                connection:close: CustomEvent<Connection>;
                connection:open: CustomEvent<Connection>;
                connection:prune: CustomEvent<Connection[]>;
                peer:connect: CustomEvent<PeerId>;
                peer:disconnect: CustomEvent<PeerId>;
                peer:discovery: CustomEvent<PeerInfo>;
                peer:identify: CustomEvent<IdentifyResult>;
                peer:update: CustomEvent<PeerUpdate>;
                self:peer:update: CustomEvent<PeerUpdate>;
                start: CustomEvent<Libp2p<T>>;
                stop: CustomEvent<Libp2p<T>>;
                transport:close: CustomEvent<Listener>;
                transport:listening: CustomEvent<Listener>;
            }

            Type Parameters

            Properties

            interface Libp2pEvents<T> {
                connection:close: CustomEvent<Connection>;
                connection:open: CustomEvent<Connection>;
                connection:prune: CustomEvent<Connection[]>;
                peer:connect: CustomEvent<PeerId>;
                peer:disconnect: CustomEvent<PeerId>;
                peer:discovery: CustomEvent<PeerInfo>;
                peer:identify: CustomEvent<IdentifyResult>;
                peer:update: CustomEvent<PeerUpdate>;
                self:peer:update: CustomEvent<PeerUpdate>;
                start: CustomEvent<Libp2p<T>>;
                stop: CustomEvent<Libp2p<T>>;
                transport:close: CustomEvent<Listener>;
                transport:listening: CustomEvent<Listener>;
            }

            Type Parameters

            Properties

            connection:close: CustomEvent<Connection>

            This event notifies listeners when incoming or outgoing connections are closed.

            -
            connection:open: CustomEvent<Connection>

            This event notifies listeners when new incoming or outgoing connections +

            connection:open: CustomEvent<Connection>

            This event notifies listeners when new incoming or outgoing connections are opened.

            -
            connection:prune: CustomEvent<Connection[]>

            This event is dispatched when the connection manager has more than the +

            connection:prune: CustomEvent<Connection[]>

            This event is dispatched when the connection manager has more than the configured allowable max connections and has closed some connections to bring the node back under the limit.

            -
            peer:connect: CustomEvent<PeerId>

            This event will be triggered any time a new peer connects.

            +
            peer:connect: CustomEvent<PeerId>

            This event will be triggered any time a new peer connects.

            Example

            libp2p.addEventListener('peer:connect', (event) => {
            const peerId = event.detail
            // ...
            })
            -
            peer:disconnect: CustomEvent<PeerId>

            This event will be triggered any time we are disconnected from another peer, regardless of +

            peer:disconnect: CustomEvent<PeerId>

            This event will be triggered any time we are disconnected from another peer, regardless of the circumstances of that disconnection. If we happen to have multiple connections to a peer, this event will only be triggered when the last connection is closed.

            Example

            libp2p.addEventListener('peer:disconnect', (event) => {
            const peerId = event.detail
            // ...
            })
            -
            peer:discovery: CustomEvent<PeerInfo>

            This event is dispatched when a new network peer is discovered.

            +
            peer:discovery: CustomEvent<PeerInfo>

            This event is dispatched when a new network peer is discovered.

            Example

            libp2p.addEventListener('peer:discovery', (event) => {
            const peerInfo = event.detail
            // ...
            })
            -
            peer:identify: CustomEvent<IdentifyResult>

            This event is dispatched after a remote peer has successfully responded to the identify +

            peer:identify: CustomEvent<IdentifyResult>

            This event is dispatched after a remote peer has successfully responded to the identify protocol. Note that for this to be emitted, both peers must have an identify service configured.

            Example

            libp2p.addEventListener('peer:identify', (event) => {
            const identifyResult = event.detail
            // ...
            })
            -
            peer:update: CustomEvent<PeerUpdate>

            This event is dispatched when the peer store data for a peer has been +

            peer:update: CustomEvent<PeerUpdate>

            This event is dispatched when the peer store data for a peer has been updated - e.g. their multiaddrs, protocols etc have changed.

            If they were previously known to this node, the old peer data will be set in the previous field.

            This may be in response to the identify protocol running, a manual update or some other event.

            -
            self:peer:update: CustomEvent<PeerUpdate>

            This event is dispatched when the current node's peer record changes - +

            self:peer:update: CustomEvent<PeerUpdate>

            This event is dispatched when the current node's peer record changes - for example a transport started listening on a new address or a new protocol handler was registered.

            Example

            libp2p.addEventListener('self:peer:update', (event) => {
            const { peer } = event.detail
            // ...
            })
            -

            This event notifies listeners that the node has started

            +

            This event notifies listeners that the node has started

            libp2p.addEventListener('start', (event) => {
            console.info(libp2p.isStarted()) // true
            })
            -

            This event notifies listeners that the node has stopped

            +

            This event notifies listeners that the node has stopped

            libp2p.addEventListener('stop', (event) => {
            console.info(libp2p.isStarted()) // false
            })
            -
            transport:close: CustomEvent<Listener>

            This event is dispatched when a transport stops listening on an address

            -
            transport:listening: CustomEvent<Listener>

            This event is dispatched when a transport begins listening on a new address

            -
            \ No newline at end of file +
            transport:close: CustomEvent<Listener>

            This event is dispatched when a transport stops listening on an address

            +
            transport:listening: CustomEvent<Listener>

            This event is dispatched when a transport begins listening on a new address

            +
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Listener.html b/interfaces/_libp2p_interface.Listener.html index e68b53ca26..5a46c1e830 100644 --- a/interfaces/_libp2p_interface.Listener.html +++ b/interfaces/_libp2p_interface.Listener.html @@ -3,7 +3,7 @@ https://github.com/microsoft/TypeScript/issues/43477 https://github.com/microsoft/TypeScript/issues/299 etc

            -
            interface Listener {
                addEventListener<K>(type, listener, options?): void;
                close(): Promise<void>;
                dispatchEvent(event): boolean;
                dispatchEvent(event): boolean;
                getAddrs(): Multiaddr[];
                listen(multiaddr): Promise<void>;
                listenerCount(type): number;
                removeEventListener<K>(type, listener?, options?): void;
                removeEventListener(type, listener?, options?): void;
                safeDispatchEvent<Detail>(type, detail): boolean;
            }

            Hierarchy (view full)

            Methods

            interface Listener {
                addEventListener<K>(type, listener, options?): void;
                close(): Promise<void>;
                dispatchEvent(event): boolean;
                dispatchEvent(event): boolean;
                getAddrs(): Multiaddr[];
                listen(multiaddr): Promise<void>;
                listenerCount(type): number;
                removeEventListener<K>(type, listener?, options?): void;
                removeEventListener(type, listener?, options?): void;
                safeDispatchEvent<Detail>(type, detail): boolean;
            }

            Hierarchy (view full)

            Methods

            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              +

            Methods

            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              MDN Reference

              Parameters

              Returns boolean

            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

              MDN Reference

              Parameters

              Returns boolean

            \ No newline at end of file +

            Returns Multiaddr[]

            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.ListenerEvents.html b/interfaces/_libp2p_interface.ListenerEvents.html index ac90ad5fce..2e695e91cb 100644 --- a/interfaces/_libp2p_interface.ListenerEvents.html +++ b/interfaces/_libp2p_interface.ListenerEvents.html @@ -1,5 +1,5 @@ -ListenerEvents | libp2p
            interface ListenerEvents {
                close: CustomEvent<any>;
                connection: CustomEvent<Connection>;
                error: CustomEvent<Error>;
                listening: CustomEvent<any>;
            }

            Properties

            close +ListenerEvents | libp2p
            interface ListenerEvents {
                close: CustomEvent<any>;
                connection: CustomEvent<Connection>;
                error: CustomEvent<Error>;
                listening: CustomEvent<any>;
            }

            Properties

            close: CustomEvent<any>
            connection: CustomEvent<Connection>
            listening: CustomEvent<any>
            \ No newline at end of file +

            Properties

            close: CustomEvent<any>
            connection: CustomEvent<Connection>
            listening: CustomEvent<any>
            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Logger.html b/interfaces/_libp2p_interface.Logger.html index 50303119f2..b86351a18f 100644 --- a/interfaces/_libp2p_interface.Logger.html +++ b/interfaces/_libp2p_interface.Logger.html @@ -1,5 +1,5 @@ Logger | libp2p

            Logger component for libp2p

            -
            interface Logger {
                enabled: boolean;
                error(formatter, ...args): void;
                trace(formatter, ...args): void;
                (formatter, ...args): void;
            }

            Properties

            interface Logger {
                enabled: boolean;
                error(formatter, ...args): void;
                trace(formatter, ...args): void;
                (formatter, ...args): void;
            }

            Properties

            Methods

            Properties

            enabled: boolean

            Methods

            \ No newline at end of file +

            Properties

            enabled: boolean

            Methods

            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.LoggerOptions.html b/interfaces/_libp2p_interface.LoggerOptions.html index 8a0fddc011..aa0c02ed22 100644 --- a/interfaces/_libp2p_interface.LoggerOptions.html +++ b/interfaces/_libp2p_interface.LoggerOptions.html @@ -1,3 +1,3 @@ LoggerOptions | libp2p

            An object that contains a Logger as the log property.

            -
            interface LoggerOptions {
                log: Logger;
            }

            Hierarchy

            • LoggerOptions

              Properties

              log -

              Properties

              log: Logger
              \ No newline at end of file +
              interface LoggerOptions {
                  log: Logger;
              }

              Hierarchy

              • LoggerOptions

                Properties

                log +

                Properties

                log: Logger
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Metric.html b/interfaces/_libp2p_interface.Metric.html index 2126be60b5..e7c57f915d 100644 --- a/interfaces/_libp2p_interface.Metric.html +++ b/interfaces/_libp2p_interface.Metric.html @@ -1,14 +1,14 @@ Metric | libp2p

                A tracked metric loosely based on the interfaces exposed by the prom-client module

                -
                interface Metric {
                    decrement(value?): void;
                    increment(value?): void;
                    reset(): void;
                    timer(): StopTimer;
                    update(value): void;
                }

                Methods

                interface Metric {
                    decrement(value?): void;
                    increment(value?): void;
                    reset(): void;
                    timer(): StopTimer;
                    update(value): void;
                }

                Methods

                \ No newline at end of file +

                Returns StopTimer

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.MetricGroup.html b/interfaces/_libp2p_interface.MetricGroup.html index ab364e58d5..ce7f7d23c8 100644 --- a/interfaces/_libp2p_interface.MetricGroup.html +++ b/interfaces/_libp2p_interface.MetricGroup.html @@ -1,17 +1,17 @@ MetricGroup | libp2p

                Interface MetricGroup<T>

                A group of related metrics loosely based on the interfaces exposed by the prom-client module

                -
                interface MetricGroup<T> {
                    decrement(values): void;
                    increment(values): void;
                    reset(): void;
                    timer(key): StopTimer;
                    update(values): void;
                }

                Type Parameters

                • T extends string = any

                Methods

                interface MetricGroup<T> {
                    decrement(values): void;
                    increment(values): void;
                    reset(): void;
                    timer(key): StopTimer;
                    update(values): void;
                }

                Type Parameters

                • T extends string = any

                Methods

                \ No newline at end of file +

                Parameters

                • key: string

                Returns StopTimer

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.MetricOptions.html b/interfaces/_libp2p_interface.MetricOptions.html index bb52841879..010dc882e0 100644 --- a/interfaces/_libp2p_interface.MetricOptions.html +++ b/interfaces/_libp2p_interface.MetricOptions.html @@ -1,7 +1,7 @@ MetricOptions | libp2p

                Create tracked metrics with these options. Loosely based on the interfaces exposed by the prom-client module

                -
                interface MetricOptions {
                    help?: string;
                    label?: string;
                }

                Hierarchy (view full)

                Properties

                interface MetricOptions {
                    help?: string;
                    label?: string;
                }

                Hierarchy (view full)

                Properties

                Properties

                help?: string

                Optional help for the metric

                -
                label?: string

                Optional label for the metric

                -
                \ No newline at end of file +
                label?: string

                Optional label for the metric

                +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Metrics.html b/interfaces/_libp2p_interface.Metrics.html index 0c6118a649..463331e741 100644 --- a/interfaces/_libp2p_interface.Metrics.html +++ b/interfaces/_libp2p_interface.Metrics.html @@ -16,7 +16,7 @@

                Example: How to track multiaddr connections

                This is something only li

                Example: How to track protocol streams

                This is something only libp2p connections need to do.

                import { Metrics } from '@libp2p/interface/metrics'

                interface MyServiceComponents {
                metrics: Metrics
                }

                class MyService {
                private readonly metrics: Metrics

                constructor (components: MyServiceComponents) {
                this.metrics = components.metrics
                }

                // later
                doSomething () {
                const stream = {} // create a stream
                this.metrics.trackProtocolStream(stream)
                }
                }
                -
                interface Metrics {
                    registerCounter: ((name, options?) => Counter) & ((name, options) => void);
                    registerCounterGroup: ((name, options?) => CounterGroup<any>) & ((name, options) => void);
                    registerMetric: ((name, options?) => Metric) & ((name, options) => void);
                    registerMetricGroup: ((name, options?) => MetricGroup<any>) & ((name, options) => void);
                    trackMultiaddrConnection(maConn): void;
                    trackProtocolStream(stream, connection): void;
                }

                Properties

                interface Metrics {
                    registerCounter: ((name, options?) => Counter) & ((name, options) => void);
                    registerCounterGroup: ((name, options?) => CounterGroup<any>) & ((name, options) => void);
                    registerMetric: ((name, options?) => Metric) & ((name, options) => void);
                    registerMetricGroup: ((name, options?) => MetricGroup<any>) & ((name, options) => void);
                    trackMultiaddrConnection(maConn): void;
                    trackProtocolStream(stream, connection): void;
                }

                Properties

                registerCounter registerCounterGroup registerMetric registerMetricGroup @@ -24,15 +24,15 @@

                Example: How to track protocol streams

                This is something only libp2p trackProtocolStream

                Properties

                registerCounter: ((name, options?) => Counter) & ((name, options) => void)

                Register an arbitrary counter. Call this to set help/labels for counters and increment them by calling methods on the returned counter object

                -

                Type declaration

                Type declaration

                registerCounterGroup: ((name, options?) => CounterGroup<any>) & ((name, options) => void)

                Register a a group of related counters. Call this to set help/labels for +

                Type declaration

                Type declaration

                registerCounterGroup: ((name, options?) => CounterGroup<any>) & ((name, options) => void)

                Register a a group of related counters. Call this to set help/labels for groups of related counters that will be updated with by calling the .increment method on the returned counter group object

                -

                Type declaration

                Type declaration

                registerMetric: ((name, options?) => Metric) & ((name, options) => void)

                Register an arbitrary metric. Call this to set help/labels for metrics +

                Type declaration

                Type declaration

                registerMetric: ((name, options?) => Metric) & ((name, options) => void)

                Register an arbitrary metric. Call this to set help/labels for metrics and update/increment/decrement/etc them by calling methods on the returned metric object

                -

                Type declaration

                Type declaration

                registerMetricGroup: ((name, options?) => MetricGroup<any>) & ((name, options) => void)

                Register a a group of related metrics. Call this to set help/labels for +

                Type declaration

                Type declaration

                registerMetricGroup: ((name, options?) => MetricGroup<any>) & ((name, options) => void)

                Register a a group of related metrics. Call this to set help/labels for groups of related metrics that will be updated with by calling .update, .increment and/or .decrement methods on the returned metric group object

                -

                Type declaration

                Type declaration

                Methods

                \ No newline at end of file +

                Type declaration

                Type declaration

                Methods

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.MultiaddrConnection.html b/interfaces/_libp2p_interface.MultiaddrConnection.html index b7039f54d2..d4747e5a62 100644 --- a/interfaces/_libp2p_interface.MultiaddrConnection.html +++ b/interfaces/_libp2p_interface.MultiaddrConnection.html @@ -1,7 +1,7 @@ MultiaddrConnection | libp2p

                Interface MultiaddrConnection

                A MultiaddrConnection is returned by transports after dialing a peer. It is a low-level primitive and is the raw connection without encryption or stream multiplexing.

                -
                interface MultiaddrConnection {
                    log: Logger;
                    remoteAddr: Multiaddr;
                    sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>;
                    source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>;
                    timeline: MultiaddrConnectionTimeline;
                    abort(err): void;
                    close(options?): Promise<void>;
                }

                Hierarchy

                Properties

                log +
                interface MultiaddrConnection {
                    log: Logger;
                    remoteAddr: Multiaddr;
                    sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>;
                    source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>;
                    timeline: MultiaddrConnectionTimeline;
                    abort(err): void;
                    close(options?): Promise<void>;
                }

                Hierarchy

                Properties

                log remoteAddr sink source @@ -9,9 +9,9 @@

                Methods

                Properties

                log: Logger

                The multiaddr connection logger

                -
                remoteAddr: Multiaddr

                The address of the remote end of the connection

                -
                sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>
                source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>

                When connection lifecycle events occurred

                -

                Methods

                remoteAddr: Multiaddr

                The address of the remote end of the connection

                +
                sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>
                source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>

                When connection lifecycle events occurred

                +

                Methods

                \ No newline at end of file +

                Parameters

                Returns Promise<void>

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.MultiaddrConnectionTimeline.html b/interfaces/_libp2p_interface.MultiaddrConnectionTimeline.html index 83ee382f74..adba253706 100644 --- a/interfaces/_libp2p_interface.MultiaddrConnectionTimeline.html +++ b/interfaces/_libp2p_interface.MultiaddrConnectionTimeline.html @@ -1,8 +1,8 @@ -MultiaddrConnectionTimeline | libp2p

                Interface MultiaddrConnectionTimeline

                interface MultiaddrConnectionTimeline {
                    close?: number;
                    open: number;
                    upgraded?: number;
                }

                Properties

                close? +MultiaddrConnectionTimeline | libp2p

                Interface MultiaddrConnectionTimeline

                interface MultiaddrConnectionTimeline {
                    close?: number;
                    open: number;
                    upgraded?: number;
                }

                Properties

                Properties

                close?: number

                When the connection was closed.

                -
                open: number

                When the connection was opened

                -
                upgraded?: number

                When the MultiaddrConnection was upgraded to a Connection - the type of +

                open: number

                When the connection was opened

                +
                upgraded?: number

                When the MultiaddrConnection was upgraded to a Connection - the type of connection encryption and multiplexing was negotiated.

                -
                \ No newline at end of file +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.MultiaddrFilter.html b/interfaces/_libp2p_interface.MultiaddrFilter.html index ee27c36ef8..0bd6c7dbe3 100644 --- a/interfaces/_libp2p_interface.MultiaddrFilter.html +++ b/interfaces/_libp2p_interface.MultiaddrFilter.html @@ -1 +1 @@ -MultiaddrFilter | libp2p
                interface MultiaddrFilter ((multiaddrs) => Multiaddr[])
                \ No newline at end of file +MultiaddrFilter | libp2p
                interface MultiaddrFilter ((multiaddrs) => Multiaddr[])
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.NewStreamOptions.html b/interfaces/_libp2p_interface.NewStreamOptions.html index 659127c9bd..26dc4564ea 100644 --- a/interfaces/_libp2p_interface.NewStreamOptions.html +++ b/interfaces/_libp2p_interface.NewStreamOptions.html @@ -2,14 +2,14 @@ the optional signal property.

                Example

                const controller = new AbortController()

                aLongRunningOperation({
                signal: controller.signal
                })

                // later

                controller.abort()
                -
                interface NewStreamOptions {
                    maxOutboundStreams?: number;
                    negotiateFully?: boolean;
                    runOnLimitedConnection?: boolean;
                    signal?: AbortSignal;
                }

                Hierarchy (view full)

                Properties

                interface NewStreamOptions {
                    maxOutboundStreams?: number;
                    negotiateFully?: boolean;
                    runOnLimitedConnection?: boolean;
                    signal?: AbortSignal;
                }

                Hierarchy (view full)

                Properties

                maxOutboundStreams?: number

                If specified, and no handler has been registered with the registrar for the successfully negotiated protocol, use this as the max outbound stream limit for the protocol

                -
                negotiateFully?: boolean

                By default when negotiating a protocol the dialer writes then protocol name +

                negotiateFully?: boolean

                By default when negotiating a protocol the dialer writes then protocol name then reads the response.

                When a only a single protocol is being negotiated on an outbound stream, and the stream is written to before being read from, we can optimistically @@ -27,11 +27,11 @@ in full before the stream is returned so this option has no effect.

                Default

                true
                 
                -
                runOnLimitedConnection?: boolean

                Opt-in to running over a limited connection - one that has restrictions +

                runOnLimitedConnection?: boolean

                Opt-in to running over a limited connection - one that has restrictions on the amount of data that may be transferred or how long it may be open for.

                These limits are typically enforced by a relay server, if the protocol will be transferring a lot of data or the stream will be open for a long time consider upgrading to a direct connection before opening the stream.

                Default

                false
                 
                -
                signal?: AbortSignal
                \ No newline at end of file +
                signal?: AbortSignal
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.NodeInfo.html b/interfaces/_libp2p_interface.NodeInfo.html index 106d79d1d5..a32c844ea0 100644 --- a/interfaces/_libp2p_interface.NodeInfo.html +++ b/interfaces/_libp2p_interface.NodeInfo.html @@ -1,6 +1,6 @@ NodeInfo | libp2p

                Metadata about the current node

                -
                interface NodeInfo {
                    name: string;
                    version: string;
                }

                Properties

                interface NodeInfo {
                    name: string;
                    version: string;
                }

                Properties

                Properties

                name: string

                The implementation name

                -
                version: string

                The implementation version

                -
                \ No newline at end of file +
                version: string

                The implementation version

                +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Peer.html b/interfaces/_libp2p_interface.Peer.html index 8bcab161aa..5feb033e5f 100644 --- a/interfaces/_libp2p_interface.Peer.html +++ b/interfaces/_libp2p_interface.Peer.html @@ -1,5 +1,5 @@ Peer | libp2p

                Data stored in the peer store about peers

                -
                interface Peer {
                    addresses: Address[];
                    id: PeerId;
                    metadata: Map<string, Uint8Array>;
                    peerRecordEnvelope?: Uint8Array;
                    protocols: string[];
                    tags: Map<string, Tag>;
                }

                Properties

                interface Peer {
                    addresses: Address[];
                    id: PeerId;
                    metadata: Map<string, Uint8Array>;
                    peerRecordEnvelope?: Uint8Array;
                    protocols: string[];
                    tags: Map<string, Tag>;
                }

                Properties

                Properties

                addresses: Address[]

                Peer's addresses containing a list of multiaddrs and a isCertified field indicating if the address was loaded from a signed peer record or not

                -
                id: PeerId

                Peer's peer-id instance

                -
                metadata: Map<string, Uint8Array>

                Peer's metadata map

                -
                peerRecordEnvelope?: Uint8Array

                The last peer record envelope received

                -
                protocols: string[]

                Peer's supported protocols

                -
                tags: Map<string, Tag>

                Tags a peer has

                -
                \ No newline at end of file +
                id: PeerId

                Peer's peer-id instance

                +
                metadata: Map<string, Uint8Array>

                Peer's metadata map

                +
                peerRecordEnvelope?: Uint8Array

                The last peer record envelope received

                +
                protocols: string[]

                Peer's supported protocols

                +
                tags: Map<string, Tag>

                Tags a peer has

                +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerData.html b/interfaces/_libp2p_interface.PeerData.html index 29dbb1e91a..5d069dc28c 100644 --- a/interfaces/_libp2p_interface.PeerData.html +++ b/interfaces/_libp2p_interface.PeerData.html @@ -1,5 +1,5 @@ PeerData | libp2p

                Peer data used to update the peer store

                -
                interface PeerData {
                    addresses?: Address[];
                    metadata?: Map<string, undefined | Uint8Array> | Record<string, undefined | Uint8Array>;
                    multiaddrs?: Multiaddr[];
                    peerRecordEnvelope?: Uint8Array;
                    protocols?: string[];
                    publicKey?: PublicKey;
                    tags?: Map<string, undefined | TagOptions> | Record<string, undefined | TagOptions>;
                }

                Properties

                interface PeerData {
                    addresses?: Address[];
                    metadata?: Map<string, undefined | Uint8Array> | Record<string, undefined | Uint8Array>;
                    multiaddrs?: Multiaddr[];
                    peerRecordEnvelope?: Uint8Array;
                    protocols?: string[];
                    publicKey?: PublicKey;
                    tags?: Map<string, undefined | TagOptions> | Record<string, undefined | TagOptions>;
                }

                Properties

                addresses? metadata? multiaddrs? peerRecordEnvelope? @@ -11,14 +11,14 @@ set to true.

                If both addresses and multiaddrs are specified they will be merged together with entries in addresses taking precedence.

                -
                metadata?: Map<string, undefined | Uint8Array> | Record<string, undefined | Uint8Array>

                Peer's metadata map. When merging pass undefined as values to remove metadata.

                -
                multiaddrs?: Multiaddr[]

                Peer's multiaddrs - any multiaddrs passed here will be treated as +

                metadata?: Map<string, undefined | Uint8Array> | Record<string, undefined | Uint8Array>

                Peer's metadata map. When merging pass undefined as values to remove metadata.

                +
                multiaddrs?: Multiaddr[]

                Peer's multiaddrs - any multiaddrs passed here will be treated as uncertified.

                If both addresses and multiaddrs are specified they will be merged together with entries in addresses taking precedence.

                -
                peerRecordEnvelope?: Uint8Array

                The last peer record envelope received

                -
                protocols?: string[]

                Peer's supported protocols

                -
                publicKey?: PublicKey

                If this Peer has an RSA key, it's public key can be set with this property.

                +
                peerRecordEnvelope?: Uint8Array

                The last peer record envelope received

                +
                protocols?: string[]

                Peer's supported protocols

                +
                publicKey?: PublicKey

                If this Peer has an RSA key, it's public key can be set with this property.

                The byte array should be the protobuf encoded form of the public key.

                -
                tags?: Map<string, undefined | TagOptions> | Record<string, undefined | TagOptions>

                Peer tags. When merging pass undefined as values to remove tags.

                -
                \ No newline at end of file +
                tags?: Map<string, undefined | TagOptions> | Record<string, undefined | TagOptions>

                Peer tags. When merging pass undefined as values to remove tags.

                +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerDiscovery.html b/interfaces/_libp2p_interface.PeerDiscovery.html index 530d279927..4363e572d1 100644 --- a/interfaces/_libp2p_interface.PeerDiscovery.html +++ b/interfaces/_libp2p_interface.PeerDiscovery.html @@ -3,13 +3,13 @@ https://github.com/microsoft/TypeScript/issues/43477 https://github.com/microsoft/TypeScript/issues/299 etc

                -
                interface PeerDiscovery {
                    addEventListener<K>(type, listener, options?): void;
                    dispatchEvent(event): boolean;
                    dispatchEvent(event): boolean;
                    listenerCount(type): number;
                    removeEventListener<K>(type, listener?, options?): void;
                    removeEventListener(type, listener?, options?): void;
                    safeDispatchEvent<Detail>(type, detail): boolean;
                }

                Hierarchy (view full)

                Methods

                interface PeerDiscovery {
                    addEventListener<K>(type, listener, options?): void;
                    dispatchEvent(event): boolean;
                    dispatchEvent(event): boolean;
                    listenerCount(type): number;
                    removeEventListener<K>(type, listener?, options?): void;
                    removeEventListener(type, listener?, options?): void;
                    safeDispatchEvent<Detail>(type, detail): boolean;
                }

                Hierarchy (view full)

                Methods

                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                  +

                Methods

                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                  MDN Reference

                  Parameters

                  Returns boolean

                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                  MDN Reference

                  -

                  Parameters

                  Returns boolean

                \ No newline at end of file +

                Parameters

                Returns boolean

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerDiscoveryEvents.html b/interfaces/_libp2p_interface.PeerDiscoveryEvents.html index 0d3be69a0d..4cf8c39cff 100644 --- a/interfaces/_libp2p_interface.PeerDiscoveryEvents.html +++ b/interfaces/_libp2p_interface.PeerDiscoveryEvents.html @@ -1,2 +1,2 @@ -PeerDiscoveryEvents | libp2p

                Interface PeerDiscoveryEvents

                interface PeerDiscoveryEvents {
                    peer: CustomEvent<PeerInfo>;
                }

                Properties

                Properties

                \ No newline at end of file +PeerDiscoveryEvents | libp2p

                Interface PeerDiscoveryEvents

                interface PeerDiscoveryEvents {
                    peer: CustomEvent<PeerInfo>;
                }

                Properties

                Properties

                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerDiscoveryProvider.html b/interfaces/_libp2p_interface.PeerDiscoveryProvider.html index f77810961f..e2fe518621 100644 --- a/interfaces/_libp2p_interface.PeerDiscoveryProvider.html +++ b/interfaces/_libp2p_interface.PeerDiscoveryProvider.html @@ -1,4 +1,4 @@ PeerDiscoveryProvider | libp2p

                Interface PeerDiscoveryProvider

                Implementers of this interface can provide a PeerDiscovery implementation to interested callers.

                -
                interface PeerDiscoveryProvider {
                    [peerDiscoverySymbol]: PeerDiscovery;
                }

                Properties

                [peerDiscoverySymbol]: PeerDiscovery
                \ No newline at end of file +
                interface PeerDiscoveryProvider {
                    [peerDiscoverySymbol]: PeerDiscovery;
                }

                Properties

                [peerDiscoverySymbol]: PeerDiscovery
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerInfo.html b/interfaces/_libp2p_interface.PeerInfo.html index 65abd21a4e..80b71c564b 100644 --- a/interfaces/_libp2p_interface.PeerInfo.html +++ b/interfaces/_libp2p_interface.PeerInfo.html @@ -1,8 +1,8 @@ PeerInfo | libp2p

                A PeerInfo is a lightweight object that represents a remote peer, it can be obtained from peer discovery mechanisms, HTTP RPC endpoints, etc.

                interface PeerInfo {
                    id: PeerId;
                    multiaddrs: Multiaddr[];
                }

                Properties

                id +
                interface PeerInfo {
                    id: PeerId;
                    multiaddrs: Multiaddr[];
                }

                Properties

                Properties

                id: PeerId

                The identifier of the remote peer

                -
                multiaddrs: Multiaddr[]

                The multiaddrs a peer is listening on

                -
                \ No newline at end of file +
                multiaddrs: Multiaddr[]

                The multiaddrs a peer is listening on

                +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerQuery.html b/interfaces/_libp2p_interface.PeerQuery.html index 1f2a9ecbf2..73321e0315 100644 --- a/interfaces/_libp2p_interface.PeerQuery.html +++ b/interfaces/_libp2p_interface.PeerQuery.html @@ -1,6 +1,6 @@ PeerQuery | libp2p

                A query for getting lists of peers

                -
                interface PeerQuery {
                    filters?: PeerQueryFilter[];
                    limit?: number;
                    offset?: number;
                    orders?: PeerQueryOrder[];
                }

                Properties

                interface PeerQuery {
                    filters?: PeerQueryFilter[];
                    limit?: number;
                    offset?: number;
                    orders?: PeerQueryOrder[];
                }

                Properties

                filters?: PeerQueryFilter[]
                limit?: number
                offset?: number
                orders?: PeerQueryOrder[]
                \ No newline at end of file +

                Properties

                filters?: PeerQueryFilter[]
                limit?: number
                offset?: number
                orders?: PeerQueryOrder[]
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerQueryFilter.html b/interfaces/_libp2p_interface.PeerQueryFilter.html index 4546052141..ff0be03645 100644 --- a/interfaces/_libp2p_interface.PeerQueryFilter.html +++ b/interfaces/_libp2p_interface.PeerQueryFilter.html @@ -1,2 +1,2 @@ PeerQueryFilter | libp2p

                A predicate by which to filter lists of peers

                -
                interface PeerQueryFilter ((peer) => boolean)
                \ No newline at end of file +
                interface PeerQueryFilter ((peer) => boolean)
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerQueryOrder.html b/interfaces/_libp2p_interface.PeerQueryOrder.html index 8fdb12e705..b27bee8440 100644 --- a/interfaces/_libp2p_interface.PeerQueryOrder.html +++ b/interfaces/_libp2p_interface.PeerQueryOrder.html @@ -1,2 +1,2 @@ PeerQueryOrder | libp2p

                A predicate by which to sort lists of peers

                -
                interface PeerQueryOrder ((a, b) => -1 | 0 | 1)
                \ No newline at end of file +
                interface PeerQueryOrder ((a, b) => -1 | 0 | 1)
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerRouting.html b/interfaces/_libp2p_interface.PeerRouting.html index eba3677a91..6cd9a35d55 100644 --- a/interfaces/_libp2p_interface.PeerRouting.html +++ b/interfaces/_libp2p_interface.PeerRouting.html @@ -1,10 +1,10 @@ -PeerRouting | libp2p
                interface PeerRouting {
                    findPeer(peerId, options?): Promise<PeerInfo>;
                    getClosestPeers(key, options?): AsyncIterable<PeerInfo>;
                }

                Methods

                findPeer +PeerRouting | libp2p
                interface PeerRouting {
                    findPeer(peerId, options?): Promise<PeerInfo>;
                    getClosestPeers(key, options?): AsyncIterable<PeerInfo>;
                }

                Methods

                • Search the network for peers that are closer to the passed key. Peer info should be yielded in ever-increasing closeness to the key.

                  Parameters

                  Returns AsyncIterable<PeerInfo>

                  Example

                  // Iterate over the closest peers found for the given key
                  for await (const peer of peerRouting.getClosestPeers(key)) {
                  console.log(peer.id, peer.multiaddrs)
                  }
                  -
                \ No newline at end of file +
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerRoutingProvider.html b/interfaces/_libp2p_interface.PeerRoutingProvider.html index e6165ff54e..2135d131e6 100644 --- a/interfaces/_libp2p_interface.PeerRoutingProvider.html +++ b/interfaces/_libp2p_interface.PeerRoutingProvider.html @@ -1,4 +1,4 @@ PeerRoutingProvider | libp2p

                Interface PeerRoutingProvider

                Implementers of this interface can provide a PeerRouting implementation to interested callers.

                -
                interface PeerRoutingProvider {
                    [peerRoutingSymbol]: PeerRouting;
                }

                Properties

                [peerRoutingSymbol]: PeerRouting
                \ No newline at end of file +
                interface PeerRoutingProvider {
                    [peerRoutingSymbol]: PeerRouting;
                }

                Properties

                [peerRoutingSymbol]: PeerRouting
                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerStore.html b/interfaces/_libp2p_interface.PeerStore.html index 72137e3054..652886ee45 100644 --- a/interfaces/_libp2p_interface.PeerStore.html +++ b/interfaces/_libp2p_interface.PeerStore.html @@ -1,4 +1,4 @@ -PeerStore | libp2p
                interface PeerStore {
                    all(query?): Promise<Peer[]>;
                    consumePeerRecord(buf, expectedPeer?): Promise<boolean>;
                    delete(peerId): Promise<void>;
                    forEach(fn, query?): Promise<void>;
                    get(peerId): Promise<Peer>;
                    has(peerId): Promise<boolean>;
                    merge(id, data): Promise<Peer>;
                    patch(id, data): Promise<Peer>;
                    save(id, data): Promise<Peer>;
                }

                Implemented by

                  Methods

                  all +PeerStore | libp2p
                  interface PeerStore {
                      all(query?): Promise<Peer[]>;
                      consumePeerRecord(buf, expectedPeer?): Promise<boolean>;
                      delete(peerId): Promise<void>;
                      forEach(fn, query?): Promise<void>;
                      get(peerId): Promise<Peer>;
                      has(peerId): Promise<boolean>;
                      merge(id, data): Promise<Peer>;
                      patch(id, data): Promise<Peer>;
                      save(id, data): Promise<Peer>;
                  }

                  Implemented by

                    Methods

                    all consumePeerRecord delete forEach @@ -10,35 +10,35 @@

                    Methods

                    • Unmarshal and verify a signed peer record, extract the multiaddrs and overwrite the stored addresses for the peer.

                      Optionally pass an expected PeerId to verify that the peer record was signed by that peer.

                      Parameters

                      Returns Promise<boolean>

                      Example

                      await peerStore.consumePeerRecord(buf, expectedPeer)
                       
                      -
                    • Delete all data stored for the passed peer

                      Parameters

                      Returns Promise<void>

                      Example

                      await peerStore.addressBook.set(peerId, multiaddrs)
                      await peerStore.addressBook.get(peerId)
                      // multiaddrs[]

                      await peerStore.delete(peerId)

                      await peerStore.addressBook.get(peerId)
                      // []
                      -
                    • Loop over every peer - the looping is async because we read from a datastore but the peer operation is sync, this is to prevent long-lived peer operations causing deadlocks over the datastore which can happen if they try to access the peer store during the loop

                      Parameters

                      • fn: ((peer) => void)
                          • (peer): void
                          • Parameters

                            Returns void

                      • Optional query: PeerQuery

                      Returns Promise<void>

                      Example

                      await peerStore.forEach(peer => {
                      // ...
                      })
                      -
                    \ No newline at end of file +
                    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerStreamEvents.html b/interfaces/_libp2p_interface.PeerStreamEvents.html index c18b196565..603e5a4010 100644 --- a/interfaces/_libp2p_interface.PeerStreamEvents.html +++ b/interfaces/_libp2p_interface.PeerStreamEvents.html @@ -1,4 +1,4 @@ -PeerStreamEvents | libp2p

                    Interface PeerStreamEvents

                    interface PeerStreamEvents {
                        close: CustomEvent<never>;
                        stream:inbound: CustomEvent<never>;
                        stream:outbound: CustomEvent<never>;
                    }

                    Properties

                    close +PeerStreamEvents | libp2p

                    Interface PeerStreamEvents

                    interface PeerStreamEvents {
                        close: CustomEvent<never>;
                        stream:inbound: CustomEvent<never>;
                        stream:outbound: CustomEvent<never>;
                    }

                    Properties

                    close: CustomEvent<never>
                    stream:inbound: CustomEvent<never>
                    stream:outbound: CustomEvent<never>
                    \ No newline at end of file +

                    Properties

                    close: CustomEvent<never>
                    stream:inbound: CustomEvent<never>
                    stream:outbound: CustomEvent<never>
                    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerStreams.html b/interfaces/_libp2p_interface.PeerStreams.html index 60671f383b..a1f22e73a3 100644 --- a/interfaces/_libp2p_interface.PeerStreams.html +++ b/interfaces/_libp2p_interface.PeerStreams.html @@ -3,7 +3,7 @@ https://github.com/microsoft/TypeScript/issues/43477 https://github.com/microsoft/TypeScript/issues/299 etc

                    -
                    interface PeerStreams {
                        id: PeerId;
                        inboundStream?: AsyncIterable<Uint8ArrayList>;
                        isWritable: boolean;
                        outboundStream?: Pushable<Uint8ArrayList, void, unknown>;
                        protocol: string;
                        addEventListener<K>(type, listener, options?): void;
                        attachInboundStream(stream): AsyncIterable<Uint8ArrayList>;
                        attachOutboundStream(stream): Promise<Pushable<Uint8ArrayList, void, unknown>>;
                        close(): void;
                        dispatchEvent(event): boolean;
                        dispatchEvent(event): boolean;
                        listenerCount(type): number;
                        removeEventListener<K>(type, listener?, options?): void;
                        removeEventListener(type, listener?, options?): void;
                        safeDispatchEvent<Detail>(type, detail): boolean;
                        write(buf): void;
                    }

                    Hierarchy (view full)

                    Properties

                    id +
                    interface PeerStreams {
                        id: PeerId;
                        inboundStream?: AsyncIterable<Uint8ArrayList>;
                        isWritable: boolean;
                        outboundStream?: Pushable<Uint8ArrayList, void, unknown>;
                        protocol: string;
                        addEventListener<K>(type, listener, options?): void;
                        attachInboundStream(stream): AsyncIterable<Uint8ArrayList>;
                        attachOutboundStream(stream): Promise<Pushable<Uint8ArrayList, void, unknown>>;
                        close(): void;
                        dispatchEvent(event): boolean;
                        dispatchEvent(event): boolean;
                        listenerCount(type): number;
                        removeEventListener<K>(type, listener?, options?): void;
                        removeEventListener(type, listener?, options?): void;
                        safeDispatchEvent<Detail>(type, detail): boolean;
                        write(buf): void;
                    }

                    Hierarchy (view full)

                    Properties

                    id: PeerId
                    inboundStream?: AsyncIterable<Uint8ArrayList>
                    isWritable: boolean
                    outboundStream?: Pushable<Uint8ArrayList, void, unknown>
                    protocol: string

                    Methods

                    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                      +

                    Properties

                    id: PeerId
                    inboundStream?: AsyncIterable<Uint8ArrayList>
                    isWritable: boolean
                    outboundStream?: Pushable<Uint8ArrayList, void, unknown>
                    protocol: string

                    Methods

                    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                      MDN Reference

                      Parameters

                      Returns boolean

                    • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                      MDN Reference

                      -

                      Parameters

                      Returns boolean

                    \ No newline at end of file +

                    Parameters

                    Returns boolean

                    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PeerUpdate.html b/interfaces/_libp2p_interface.PeerUpdate.html index a9068af69b..3d56690921 100644 --- a/interfaces/_libp2p_interface.PeerUpdate.html +++ b/interfaces/_libp2p_interface.PeerUpdate.html @@ -1,4 +1,4 @@ PeerUpdate | libp2p

                    Event detail emitted when peer data changes

                    -
                    interface PeerUpdate {
                        peer: Peer;
                        previous?: Peer;
                    }

                    Properties

                    interface PeerUpdate {
                        peer: Peer;
                        previous?: Peer;
                    }

                    Properties

                    Properties

                    peer: Peer
                    previous?: Peer
                    \ No newline at end of file +

                    Properties

                    peer: Peer
                    previous?: Peer
                    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PendingDial.html b/interfaces/_libp2p_interface.PendingDial.html index fdbc7cb94b..b77fb0f772 100644 --- a/interfaces/_libp2p_interface.PendingDial.html +++ b/interfaces/_libp2p_interface.PendingDial.html @@ -1,12 +1,12 @@ PendingDial | libp2p

                    An item in the dial queue

                    -
                    interface PendingDial {
                        id: string;
                        multiaddrs: Multiaddr[];
                        peerId?: PeerId;
                        status: PendingDialStatus;
                    }

                    Properties

                    id +
                    interface PendingDial {
                        id: string;
                        multiaddrs: Multiaddr[];
                        peerId?: PeerId;
                        status: PendingDialStatus;
                    }

                    Properties

                    id: string

                    A unique identifier for this dial

                    -
                    multiaddrs: Multiaddr[]

                    The list of multiaddrs that will be dialled. The returned connection will +

                    multiaddrs: Multiaddr[]

                    The list of multiaddrs that will be dialled. The returned connection will use the first address that succeeds, all other dials part of this pending dial will be cancelled.

                    -
                    peerId?: PeerId

                    If known, this is the peer id that libp2p expects to be dialling

                    -

                    The current status of the dial

                    -
                    \ No newline at end of file +
                    peerId?: PeerId

                    If known, this is the peer id that libp2p expects to be dialling

                    +

                    The current status of the dial

                    +
                    \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSub.html b/interfaces/_libp2p_interface.PubSub.html index 17d7660de4..e996285f1f 100644 --- a/interfaces/_libp2p_interface.PubSub.html +++ b/interfaces/_libp2p_interface.PubSub.html @@ -3,7 +3,7 @@ https://github.com/microsoft/TypeScript/issues/43477 https://github.com/microsoft/TypeScript/issues/299 etc

                    -
                    interface PubSub<Events> {
                        globalSignaturePolicy: "StrictSign" | "StrictNoSign";
                        multicodecs: string[];
                        topicValidators: Map<string, TopicValidatorFn>;
                        addEventListener<K>(type, listener, options?): void;
                        dispatchEvent(event): boolean;
                        dispatchEvent(event): boolean;
                        getPeers(): PeerId[];
                        getSubscribers(topic): PeerId[];
                        getTopics(): string[];
                        listenerCount(type): number;
                        publish(topic, data): Promise<PublishResult>;
                        removeEventListener<K>(type, listener?, options?): void;
                        removeEventListener(type, listener?, options?): void;
                        safeDispatchEvent<Detail>(type, detail): boolean;
                        subscribe(topic): void;
                        unsubscribe(topic): void;
                    }

                    Type Parameters

                    Hierarchy (view full)

                    Implemented by

                      Properties

                      interface PubSub<Events> {
                          globalSignaturePolicy: "StrictSign" | "StrictNoSign";
                          multicodecs: string[];
                          topicValidators: Map<string, TopicValidatorFn>;
                          addEventListener<K>(type, listener, options?): void;
                          dispatchEvent(event): boolean;
                          dispatchEvent(event): boolean;
                          getPeers(): PeerId[];
                          getSubscribers(topic): PeerId[];
                          getTopics(): string[];
                          listenerCount(type): number;
                          publish(topic, data): Promise<PublishResult>;
                          removeEventListener<K>(type, listener?, options?): void;
                          removeEventListener(type, listener?, options?): void;
                          safeDispatchEvent<Detail>(type, detail): boolean;
                          subscribe(topic): void;
                          unsubscribe(topic): void;
                      }

                      Type Parameters

                      Hierarchy (view full)

                      Implemented by

                        Properties

                        Methods

                        addEventListener @@ -21,29 +21,29 @@ signed or unsigned messages.

                        Signed messages prevent spoofing message senders and should be preferred to using unsigned messages.

                        -
                        multicodecs: string[]

                        A list of multicodecs that contain the pubsub protocol name.

                        -
                        topicValidators: Map<string, TopicValidatorFn>

                        Pubsub routers support message validators per topic, which will validate the message +

                        multicodecs: string[]

                        A list of multicodecs that contain the pubsub protocol name.

                        +
                        topicValidators: Map<string, TopicValidatorFn>

                        Pubsub routers support message validators per topic, which will validate the message before its propagations. They are stored in a map where keys are the topic name and values are the validators.

                        Example

                        const topic = 'topic'
                        const validateMessage = (msgTopic, msg) => {
                        const input = uint8ArrayToString(msg.data)
                        const validInputs = ['a', 'b', 'c']

                        if (!validInputs.includes(input)) {
                        throw new Error('no valid input received')
                        }
                        }
                        libp2p.pubsub.topicValidators.set(topic, validateMessage)
                        -

                        Methods

                        • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                          +

                        Methods

                        • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                          MDN Reference

                          Parameters

                          Returns boolean

                        • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                          MDN Reference

                          -

                          Parameters

                          Returns boolean

                        • Gets a list of the PeerIds that are subscribed to one topic.

                          +

                          Parameters

                          Returns boolean

                        • Subscribes to a pubsub topic.

                          Parameters

                          • topic: string

                          Returns void

                          Example

                          const topic = 'topic'
                          const handler = (msg) => {
                          if (msg.topic === topic) {
                          // msg.data - pubsub data received
                          }
                          }

                          libp2p.pubsub.addEventListener('message', handler)
                          libp2p.pubsub.subscribe(topic)
                          -
                        • Unsubscribes from a pubsub topic.

                          Parameters

                          • topic: string

                          Returns void

                          Example

                          const topic = 'topic'
                          const handler = (msg) => {
                          // msg.data - pubsub data received
                          }

                          libp2p.pubsub.removeEventListener(topic handler)
                          libp2p.pubsub.unsubscribe(topic)
                          -
                        \ No newline at end of file +
                        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSubEvents.html b/interfaces/_libp2p_interface.PubSubEvents.html index 22f96a55ca..bf28a16a91 100644 --- a/interfaces/_libp2p_interface.PubSubEvents.html +++ b/interfaces/_libp2p_interface.PubSubEvents.html @@ -1,3 +1,3 @@ -PubSubEvents | libp2p
                        interface PubSubEvents {
                            message: CustomEvent<Message>;
                            subscription-change: CustomEvent<SubscriptionChangeData>;
                        }

                        Properties

                        message +PubSubEvents | libp2p
                        interface PubSubEvents {
                            message: CustomEvent<Message>;
                            subscription-change: CustomEvent<SubscriptionChangeData>;
                        }

                        Properties

                        subscription-change: CustomEvent<SubscriptionChangeData>
                        \ No newline at end of file +

                        Properties

                        subscription-change: CustomEvent<SubscriptionChangeData>
                        \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSubInit.html b/interfaces/_libp2p_interface.PubSubInit.html index 36ab870a07..4ee5b8a363 100644 --- a/interfaces/_libp2p_interface.PubSubInit.html +++ b/interfaces/_libp2p_interface.PubSubInit.html @@ -1,4 +1,4 @@ -PubSubInit | libp2p
                        interface PubSubInit {
                            canRelayMessage?: boolean;
                            emitSelf?: boolean;
                            enabled?: boolean;
                            globalSignaturePolicy?: SignaturePolicy;
                            maxInboundStreams?: number;
                            maxOutboundStreams?: number;
                            messageProcessingConcurrency?: number;
                            multicodecs?: string[];
                        }

                        Hierarchy

                        • PubSubInit

                          Properties

                          canRelayMessage? +PubSubInit | libp2p
                          interface PubSubInit {
                              canRelayMessage?: boolean;
                              emitSelf?: boolean;
                              enabled?: boolean;
                              globalSignaturePolicy?: SignaturePolicy;
                              maxInboundStreams?: number;
                              maxOutboundStreams?: number;
                              messageProcessingConcurrency?: number;
                              multicodecs?: string[];
                          }

                          Hierarchy

                          • PubSubInit

                            Properties

                            canRelayMessage?: boolean

                            if can relay messages not subscribed

                            -
                            emitSelf?: boolean

                            if publish should emit to self, if subscribed

                            -
                            enabled?: boolean
                            globalSignaturePolicy?: SignaturePolicy

                            defines how signatures should be handled

                            -
                            maxInboundStreams?: number

                            How many parallel incoming streams to allow on the pubsub protocol per-connection

                            -
                            maxOutboundStreams?: number

                            How many parallel outgoing streams to allow on the pubsub protocol per-connection

                            -
                            messageProcessingConcurrency?: number

                            handle this many incoming pubsub messages concurrently

                            -
                            multicodecs?: string[]
                            \ No newline at end of file +
                            emitSelf?: boolean

                            if publish should emit to self, if subscribed

                            +
                            enabled?: boolean
                            globalSignaturePolicy?: SignaturePolicy

                            defines how signatures should be handled

                            +
                            maxInboundStreams?: number

                            How many parallel incoming streams to allow on the pubsub protocol per-connection

                            +
                            maxOutboundStreams?: number

                            How many parallel outgoing streams to allow on the pubsub protocol per-connection

                            +
                            messageProcessingConcurrency?: number

                            handle this many incoming pubsub messages concurrently

                            +
                            multicodecs?: string[]
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSubRPC.html b/interfaces/_libp2p_interface.PubSubRPC.html index ce3dcfc39e..173752b703 100644 --- a/interfaces/_libp2p_interface.PubSubRPC.html +++ b/interfaces/_libp2p_interface.PubSubRPC.html @@ -1,3 +1,3 @@ -PubSubRPC | libp2p
                            interface PubSubRPC {
                                messages: PubSubRPCMessage[];
                                subscriptions: PubSubRPCSubscription[];
                            }

                            Properties

                            messages +PubSubRPC | libp2p
                            interface PubSubRPC {
                                messages: PubSubRPCMessage[];
                                subscriptions: PubSubRPCSubscription[];
                            }

                            Properties

                            messages: PubSubRPCMessage[]
                            subscriptions: PubSubRPCSubscription[]
                            \ No newline at end of file +

                            Properties

                            messages: PubSubRPCMessage[]
                            subscriptions: PubSubRPCSubscription[]
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSubRPCMessage.html b/interfaces/_libp2p_interface.PubSubRPCMessage.html index 7b94ccb408..27300a80e4 100644 --- a/interfaces/_libp2p_interface.PubSubRPCMessage.html +++ b/interfaces/_libp2p_interface.PubSubRPCMessage.html @@ -1,7 +1,7 @@ -PubSubRPCMessage | libp2p

                            Interface PubSubRPCMessage

                            interface PubSubRPCMessage {
                                data?: Uint8Array;
                                from?: Uint8Array;
                                key?: Uint8Array;
                                sequenceNumber?: Uint8Array;
                                signature?: Uint8Array;
                                topic?: string;
                            }

                            Properties

                            data? +PubSubRPCMessage | libp2p

                            Interface PubSubRPCMessage

                            interface PubSubRPCMessage {
                                data?: Uint8Array;
                                from?: Uint8Array;
                                key?: Uint8Array;
                                sequenceNumber?: Uint8Array;
                                signature?: Uint8Array;
                                topic?: string;
                            }

                            Properties

                            data?: Uint8Array
                            from?: Uint8Array
                            sequenceNumber?: Uint8Array
                            signature?: Uint8Array
                            topic?: string
                            \ No newline at end of file +

                            Properties

                            data?: Uint8Array
                            from?: Uint8Array
                            sequenceNumber?: Uint8Array
                            signature?: Uint8Array
                            topic?: string
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PubSubRPCSubscription.html b/interfaces/_libp2p_interface.PubSubRPCSubscription.html index 5925eed97f..d235268c64 100644 --- a/interfaces/_libp2p_interface.PubSubRPCSubscription.html +++ b/interfaces/_libp2p_interface.PubSubRPCSubscription.html @@ -1,3 +1,3 @@ -PubSubRPCSubscription | libp2p

                            Interface PubSubRPCSubscription

                            interface PubSubRPCSubscription {
                                subscribe?: boolean;
                                topic?: string;
                            }

                            Properties

                            subscribe? +PubSubRPCSubscription | libp2p

                            Interface PubSubRPCSubscription

                            interface PubSubRPCSubscription {
                                subscribe?: boolean;
                                topic?: string;
                            }

                            Properties

                            Properties

                            subscribe?: boolean
                            topic?: string
                            \ No newline at end of file +

                            Properties

                            subscribe?: boolean
                            topic?: string
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.PublishResult.html b/interfaces/_libp2p_interface.PublishResult.html index 677cf5b6ac..9bc2bb5673 100644 --- a/interfaces/_libp2p_interface.PublishResult.html +++ b/interfaces/_libp2p_interface.PublishResult.html @@ -1,2 +1,2 @@ -PublishResult | libp2p
                            interface PublishResult {
                                recipients: PeerId[];
                            }

                            Properties

                            Properties

                            recipients: PeerId[]
                            \ No newline at end of file +PublishResult | libp2p
                            interface PublishResult {
                                recipients: PeerId[];
                            }

                            Properties

                            Properties

                            recipients: PeerId[]
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.RSAPeerId.html b/interfaces/_libp2p_interface.RSAPeerId.html index 89959c79cd..2d772c342a 100644 --- a/interfaces/_libp2p_interface.RSAPeerId.html +++ b/interfaces/_libp2p_interface.RSAPeerId.html @@ -4,7 +4,7 @@ secp256k1 should be preferred as they can embed their public key in the PeerId itself.

                            Deprecated

                            Ed25519 or secp256k1 keys are preferred to RSA

                            -
                            interface RSAPeerId {
                                publicKey?: RSAPublicKey;
                                type: "RSA";
                                equals(other?): boolean;
                                toCID(): CID<Uint8Array, 114, 18, 1>;
                                toMultihash(): MultihashDigest<18>;
                                toString(): string;
                            }

                            Properties

                            interface RSAPeerId {
                                publicKey?: RSAPublicKey;
                                type: "RSA";
                                equals(other?): boolean;
                                toCID(): CID<Uint8Array, 114, 18, 1>;
                                toMultihash(): MultihashDigest<18>;
                                toString(): string;
                            }

                            Properties

                            Methods

                            equals toCID @@ -14,10 +14,10 @@ refer to peers, so this will only be defined if the public key has previously been found through a routing query or during normal protocol operations

                            -
                            type: "RSA"

                            Methods

                            type: "RSA"

                            Methods

                            \ No newline at end of file +

                            Returns MultihashDigest<18>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.RSAPrivateKey.html b/interfaces/_libp2p_interface.RSAPrivateKey.html index 731e455655..8d296f9a74 100644 --- a/interfaces/_libp2p_interface.RSAPrivateKey.html +++ b/interfaces/_libp2p_interface.RSAPrivateKey.html @@ -1,13 +1,13 @@ -RSAPrivateKey | libp2p
                            interface RSAPrivateKey {
                                publicKey: RSAPublicKey;
                                raw: Uint8Array;
                                type: "RSA";
                                equals(key?): boolean;
                                sign(data): Uint8Array | Promise<Uint8Array>;
                            }

                            Hierarchy

                            Properties

                            publicKey +RSAPrivateKey | libp2p
                            interface RSAPrivateKey {
                                publicKey: RSAPublicKey;
                                raw: Uint8Array;
                                type: "RSA";
                                equals(key?): boolean;
                                sign(data): Uint8Array | Promise<Uint8Array>;
                            }

                            Hierarchy

                            Properties

                            Methods

                            Properties

                            publicKey: RSAPublicKey

                            The public key that corresponds to this private key

                            -

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 +

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

                            -
                            type: "RSA"

                            The type of this key

                            -

                            Methods

                            • Returns true if the passed object matches this key

                              -

                              Parameters

                              • Optional key: any

                              Returns boolean

                            type: "RSA"

                            The type of this key

                            +

                            Methods

                            • Returns true if the passed object matches this key

                              +

                              Parameters

                              • Optional key: any

                              Returns boolean

                            \ No newline at end of file +

                            Parameters

                            Returns Uint8Array | Promise<Uint8Array>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.RSAPublicKey.html b/interfaces/_libp2p_interface.RSAPublicKey.html index 480763b367..34738594d5 100644 --- a/interfaces/_libp2p_interface.RSAPublicKey.html +++ b/interfaces/_libp2p_interface.RSAPublicKey.html @@ -1,4 +1,4 @@ -RSAPublicKey | libp2p
                            interface RSAPublicKey {
                                raw: Uint8Array;
                                type: "RSA";
                                equals(key?): boolean;
                                toCID(): CID<unknown, 114, 18, 1>;
                                toMultihash(): MultihashDigest<18>;
                                toString(): string;
                                verify(data, sig): boolean | Promise<boolean>;
                            }

                            Hierarchy

                            Properties

                            raw +RSAPublicKey | libp2p
                            interface RSAPublicKey {
                                raw: Uint8Array;
                                type: "RSA";
                                equals(key?): boolean;
                                toCID(): CID<unknown, 114, 18, 1>;
                                toMultihash(): MultihashDigest<18>;
                                toString(): string;
                                verify(data, sig): boolean | Promise<boolean>;
                            }

                            Hierarchy

                            Properties

                            Methods

                            equals toCID @@ -7,17 +7,17 @@ verify

                            Properties

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

                            -
                            type: "RSA"

                            The type of this key

                            -

                            Methods

                            • Returns true if the passed object matches this key

                              -

                              Parameters

                              • Optional key: any

                              Returns boolean

                            type: "RSA"

                            The type of this key

                            +

                            Methods

                            • Returns true if the passed object matches this key

                              +

                              Parameters

                              • Optional key: any

                              Returns boolean

                            • Return this public key as a CID encoded with the libp2p-key codec

                              The digest contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

                              -

                              Returns CID<unknown, 114, 18, 1>

                            • Returns this public key as a Multihash digest.

                              It contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

                              -

                              Returns MultihashDigest<18>

                            \ No newline at end of file +

                            Parameters

                            Returns boolean | Promise<boolean>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Record.html b/interfaces/_libp2p_interface.Record.html index fd87ff8949..8e0622ebb7 100644 --- a/interfaces/_libp2p_interface.Record.html +++ b/interfaces/_libp2p_interface.Record.html @@ -1,10 +1,10 @@ Record | libp2p

                            Record is the base implementation of a record that can be used as the payload of a libp2p envelope.

                            -
                            interface Record {
                                codec: Uint8Array;
                                domain: string;
                                equals(other): boolean;
                                marshal(): Uint8Array;
                            }

                            Properties

                            interface Record {
                                codec: Uint8Array;
                                domain: string;
                                equals(other): boolean;
                                marshal(): Uint8Array;
                            }

                            Properties

                            Methods

                            Properties

                            codec: Uint8Array

                            identifier of the type of record

                            -
                            domain: string

                            signature domain.

                            -

                            Methods

                            \ No newline at end of file +
                            domain: string

                            signature domain.

                            +

                            Methods

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.RoutingOptions.html b/interfaces/_libp2p_interface.RoutingOptions.html index 4e3f3f3ffd..1716a597a8 100644 --- a/interfaces/_libp2p_interface.RoutingOptions.html +++ b/interfaces/_libp2p_interface.RoutingOptions.html @@ -2,14 +2,14 @@ controlling where the values are read from. By default libp2p will check local caches but may not use the network if a valid local value is found, these options allow tuning that behaviour.

                            -
                            interface RoutingOptions {
                                onProgress?: ((evt) => void);
                                signal?: AbortSignal;
                                useCache?: boolean;
                                useNetwork?: boolean;
                            }

                            Hierarchy (view full)

                            Properties

                            interface RoutingOptions {
                                onProgress?: ((evt) => void);
                                signal?: AbortSignal;
                                useCache?: boolean;
                                useNetwork?: boolean;
                            }

                            Hierarchy (view full)

                            Properties

                            onProgress?: ((evt) => void)

                            Type declaration

                              • (evt): void
                              • Parameters

                                • evt: any

                                Returns void

                            signal?: AbortSignal
                            useCache?: boolean

                            Pass false to not use cached values

                            +

                            Properties

                            onProgress?: ((evt) => void)

                            Type declaration

                              • (evt): void
                              • Parameters

                                • evt: any

                                Returns void

                            signal?: AbortSignal
                            useCache?: boolean

                            Pass false to not use cached values

                            Default

                            true
                             
                            -
                            useNetwork?: boolean

                            Pass false to not use the network

                            +
                            useNetwork?: boolean

                            Pass false to not use the network

                            Default

                            true
                             
                            -
                            \ No newline at end of file +
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Secp256k1PeerId.html b/interfaces/_libp2p_interface.Secp256k1PeerId.html index 50796fb5fa..324a6c631e 100644 --- a/interfaces/_libp2p_interface.Secp256k1PeerId.html +++ b/interfaces/_libp2p_interface.Secp256k1PeerId.html @@ -1,4 +1,4 @@ -Secp256k1PeerId | libp2p
                            interface Secp256k1PeerId {
                                publicKey: Secp256k1PublicKey;
                                type: "secp256k1";
                                equals(other?): boolean;
                                toCID(): CID<Uint8Array, 114, 0, 1>;
                                toMultihash(): MultihashDigest<0>;
                                toString(): string;
                            }

                            Properties

                            publicKey +Secp256k1PeerId | libp2p
                            interface Secp256k1PeerId {
                                publicKey: Secp256k1PublicKey;
                                type: "secp256k1";
                                equals(other?): boolean;
                                toCID(): CID<Uint8Array, 114, 0, 1>;
                                toMultihash(): MultihashDigest<0>;
                                toString(): string;
                            }

                            Properties

                            Methods

                            equals toCID @@ -6,10 +6,10 @@ toString

                            Properties

                            This will always be defined as the public key is embedded in the multihash of this PeerId

                            -
                            type: "secp256k1"

                            Methods

                            type: "secp256k1"

                            Methods

                            \ No newline at end of file +

                            Returns MultihashDigest<0>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Secp256k1PrivateKey.html b/interfaces/_libp2p_interface.Secp256k1PrivateKey.html index a0b74e7681..b12097b3d1 100644 --- a/interfaces/_libp2p_interface.Secp256k1PrivateKey.html +++ b/interfaces/_libp2p_interface.Secp256k1PrivateKey.html @@ -1,13 +1,13 @@ -Secp256k1PrivateKey | libp2p

                            Interface Secp256k1PrivateKey

                            interface Secp256k1PrivateKey {
                                publicKey: Secp256k1PublicKey;
                                raw: Uint8Array;
                                type: "secp256k1";
                                equals(key?): boolean;
                                sign(data): Uint8Array | Promise<Uint8Array>;
                            }

                            Hierarchy

                            Properties

                            publicKey +Secp256k1PrivateKey | libp2p

                            Interface Secp256k1PrivateKey

                            interface Secp256k1PrivateKey {
                                publicKey: Secp256k1PublicKey;
                                raw: Uint8Array;
                                type: "secp256k1";
                                equals(key?): boolean;
                                sign(data): Uint8Array | Promise<Uint8Array>;
                            }

                            Hierarchy

                            Properties

                            Methods

                            Properties

                            The public key that corresponds to this private key

                            -

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 +

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

                            -
                            type: "secp256k1"

                            The type of this key

                            -

                            Methods

                            • Returns true if the passed object matches this key

                              -

                              Parameters

                              • Optional key: any

                              Returns boolean

                            type: "secp256k1"

                            The type of this key

                            +

                            Methods

                            • Returns true if the passed object matches this key

                              +

                              Parameters

                              • Optional key: any

                              Returns boolean

                            \ No newline at end of file +

                            Parameters

                            Returns Uint8Array | Promise<Uint8Array>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Secp256k1PublicKey.html b/interfaces/_libp2p_interface.Secp256k1PublicKey.html index 73ddb617a7..7267767e68 100644 --- a/interfaces/_libp2p_interface.Secp256k1PublicKey.html +++ b/interfaces/_libp2p_interface.Secp256k1PublicKey.html @@ -1,4 +1,4 @@ -Secp256k1PublicKey | libp2p

                            Interface Secp256k1PublicKey

                            interface Secp256k1PublicKey {
                                raw: Uint8Array;
                                type: "secp256k1";
                                equals(key?): boolean;
                                toCID(): CID<unknown, 114, 0, 1>;
                                toMultihash(): MultihashDigest<0>;
                                toString(): string;
                                verify(data, sig): boolean | Promise<boolean>;
                            }

                            Hierarchy

                            Properties

                            raw +Secp256k1PublicKey | libp2p

                            Interface Secp256k1PublicKey

                            interface Secp256k1PublicKey {
                                raw: Uint8Array;
                                type: "secp256k1";
                                equals(key?): boolean;
                                toCID(): CID<unknown, 114, 0, 1>;
                                toMultihash(): MultihashDigest<0>;
                                toString(): string;
                                verify(data, sig): boolean | Promise<boolean>;
                            }

                            Hierarchy

                            Properties

                            Methods

                            equals toCID @@ -7,17 +7,17 @@ verify

                            Properties

                            The raw public key bytes (for Ed25519 and secp256k1 keys) or PKIX in ASN1 DER format (for RSA keys)

                            -
                            type: "secp256k1"

                            The type of this key

                            -

                            Methods

                            • Returns true if the passed object matches this key

                              -

                              Parameters

                              • Optional key: any

                              Returns boolean

                            type: "secp256k1"

                            The type of this key

                            +

                            Methods

                            • Returns true if the passed object matches this key

                              +

                              Parameters

                              • Optional key: any

                              Returns boolean

                            • Return this public key as a CID encoded with the libp2p-key codec

                              The digest contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

                              -

                              Returns CID<unknown, 114, 0, 1>

                            • Returns this public key as a Multihash digest.

                              It contains either an identity hash containing the protobuf version of the public key (for Ed25519 and secp256k1 keys) or a sha256 hash of the protobuf version of the public key (RSA keys).

                              -

                              Returns MultihashDigest<0>

                            \ No newline at end of file +

                            Parameters

                            Returns boolean | Promise<boolean>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.SecureConnectionOptions.html b/interfaces/_libp2p_interface.SecureConnectionOptions.html index 59195dbb91..8e19956712 100644 --- a/interfaces/_libp2p_interface.SecureConnectionOptions.html +++ b/interfaces/_libp2p_interface.SecureConnectionOptions.html @@ -1,6 +1,6 @@ SecureConnectionOptions | libp2p

                            Interface SecureConnectionOptions

                            If the remote PeerId is known and passed as an option, the securing operation will throw if the remote peer cannot prove it has the private key that corresponds to the public key the remote PeerId is derived from.

                            -
                            interface SecureConnectionOptions {
                                remotePeer?: PeerId;
                                signal?: AbortSignal;
                            }

                            Hierarchy (view full)

                            Properties

                            interface SecureConnectionOptions {
                                remotePeer?: PeerId;
                                signal?: AbortSignal;
                            }

                            Hierarchy (view full)

                            Properties

                            Properties

                            remotePeer?: PeerId
                            signal?: AbortSignal
                            \ No newline at end of file +

                            Properties

                            remotePeer?: PeerId
                            signal?: AbortSignal
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.SecuredConnection.html b/interfaces/_libp2p_interface.SecuredConnection.html index 9ce99bac0c..5ee6085d86 100644 --- a/interfaces/_libp2p_interface.SecuredConnection.html +++ b/interfaces/_libp2p_interface.SecuredConnection.html @@ -1,4 +1,4 @@ -SecuredConnection | libp2p

                            Interface SecuredConnection<Stream, Extension>

                            interface SecuredConnection<Stream, Extension> {
                                conn: Stream;
                                remoteExtensions?: Extension;
                                remotePeer: PeerId;
                            }

                            Type Parameters

                            • Stream = any
                            • Extension = unknown

                            Properties

                            conn +SecuredConnection | libp2p

                            Interface SecuredConnection<Stream, Extension>

                            interface SecuredConnection<Stream, Extension> {
                                conn: Stream;
                                remoteExtensions?: Extension;
                                remotePeer: PeerId;
                            }

                            Type Parameters

                            • Stream = any
                            • Extension = unknown

                            Properties

                            conn: Stream
                            remoteExtensions?: Extension
                            remotePeer: PeerId
                            \ No newline at end of file +

                            Properties

                            conn: Stream
                            remoteExtensions?: Extension
                            remotePeer: PeerId
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.SignedMessage.html b/interfaces/_libp2p_interface.SignedMessage.html index 3f4fcc7a0b..4bdb49417c 100644 --- a/interfaces/_libp2p_interface.SignedMessage.html +++ b/interfaces/_libp2p_interface.SignedMessage.html @@ -1,8 +1,8 @@ -SignedMessage | libp2p
                            interface SignedMessage {
                                data: Uint8Array;
                                from: PeerId;
                                key: PublicKey;
                                sequenceNumber: bigint;
                                signature: Uint8Array;
                                topic: string;
                                type: "signed";
                            }

                            Properties

                            data +SignedMessage | libp2p
                            interface SignedMessage {
                                data: Uint8Array;
                                from: PeerId;
                                key: PublicKey;
                                sequenceNumber: bigint;
                                signature: Uint8Array;
                                topic: string;
                                type: "signed";
                            }

                            Properties

                            from: PeerId
                            sequenceNumber: bigint
                            signature: Uint8Array
                            topic: string
                            type: "signed"
                            \ No newline at end of file +

                            Properties

                            from: PeerId
                            sequenceNumber: bigint
                            signature: Uint8Array
                            topic: string
                            type: "signed"
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.SignedPeerRecord.html b/interfaces/_libp2p_interface.SignedPeerRecord.html index f63c11a85d..17a94cb4f4 100644 --- a/interfaces/_libp2p_interface.SignedPeerRecord.html +++ b/interfaces/_libp2p_interface.SignedPeerRecord.html @@ -1,4 +1,4 @@ SignedPeerRecord | libp2p

                            Interface SignedPeerRecord

                            Peer data signed by the remote Peer's public key

                            -
                            interface SignedPeerRecord {
                                addresses: Multiaddr[];
                                seq: bigint;
                            }

                            Properties

                            interface SignedPeerRecord {
                                addresses: Multiaddr[];
                                seq: bigint;
                            }

                            Properties

                            Properties

                            addresses: Multiaddr[]
                            seq: bigint
                            \ No newline at end of file +

                            Properties

                            addresses: Multiaddr[]
                            seq: bigint
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Startable.html b/interfaces/_libp2p_interface.Startable.html index 20c8d7e01f..96a0f801e8 100644 --- a/interfaces/_libp2p_interface.Startable.html +++ b/interfaces/_libp2p_interface.Startable.html @@ -1,5 +1,5 @@ Startable | libp2p

                            Implemented by components that have a lifecycle

                            -
                            interface Startable {
                                afterStart?(): void | Promise<void>;
                                afterStop?(): void | Promise<void>;
                                beforeStart?(): void | Promise<void>;
                                beforeStop?(): void | Promise<void>;
                                start(): void | Promise<void>;
                                stop(): void | Promise<void>;
                            }

                            Hierarchy (view full)

                            Methods

                            interface Startable {
                                afterStart?(): void | Promise<void>;
                                afterStop?(): void | Promise<void>;
                                beforeStart?(): void | Promise<void>;
                                beforeStop?(): void | Promise<void>;
                                start(): void | Promise<void>;
                                stop(): void | Promise<void>;
                            }

                            Hierarchy (view full)

                            Methods

                            • If implemented, this method will be invoked after the start method.

                              All other components will have had their start method invoked before this method is called.

                              -

                              Returns void | Promise<void>

                            • If implemented, this method will be invoked after the stop method.

                              All other components will have had their stop method invoked before this method is called.

                              -

                              Returns void | Promise<void>

                            \ No newline at end of file +

                            Returns void | Promise<void>

                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StopTimer.html b/interfaces/_libp2p_interface.StopTimer.html index 0d99bc328d..50f324f06c 100644 --- a/interfaces/_libp2p_interface.StopTimer.html +++ b/interfaces/_libp2p_interface.StopTimer.html @@ -1,3 +1,3 @@ StopTimer | libp2p

                            Call this function to stop the timer returned from the .timer method on the metric

                            -
                            interface StopTimer (() => void)
                            \ No newline at end of file +
                            interface StopTimer (() => void)
                            \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Stream.html b/interfaces/_libp2p_interface.Stream.html index 28ce62d432..c4dabab32f 100644 --- a/interfaces/_libp2p_interface.Stream.html +++ b/interfaces/_libp2p_interface.Stream.html @@ -2,7 +2,7 @@ can be written to and read from at both ends.

                            It may be encrypted and multiplexed depending on the configuration of the nodes.

                            -
                            interface Stream {
                                direction: Direction;
                                id: string;
                                log: Logger;
                                metadata: Record<string, any>;
                                protocol?: string;
                                readStatus: ReadStatus;
                                sink: Sink<Source<Uint8Array | Uint8ArrayList>, Promise<void>>;
                                source: AsyncGenerator<Uint8ArrayList, any, unknown>;
                                status: StreamStatus;
                                timeline: StreamTimeline;
                                writeStatus: WriteStatus;
                                abort(err): void;
                                close(options?): Promise<void>;
                                closeRead(options?): Promise<void>;
                                closeWrite(options?): Promise<void>;
                            }

                            Hierarchy

                            Implemented by

                              Properties

                              interface Stream {
                                  direction: Direction;
                                  id: string;
                                  log: Logger;
                                  metadata: Record<string, any>;
                                  protocol?: string;
                                  readStatus: ReadStatus;
                                  sink: Sink<Source<Uint8Array | Uint8ArrayList>, Promise<void>>;
                                  source: AsyncGenerator<Uint8ArrayList, any, unknown>;
                                  status: StreamStatus;
                                  timeline: StreamTimeline;
                                  writeStatus: WriteStatus;
                                  abort(err): void;
                                  close(options?): Promise<void>;
                                  closeRead(options?): Promise<void>;
                                  closeWrite(options?): Promise<void>;
                              }

                              Hierarchy

                              Implemented by

                                Properties

                                Properties

                                direction: Direction

                                Outbound streams are opened by the local node, inbound streams are opened by the remote

                                -
                                id: string

                                Unique identifier for a stream. Identifiers are not unique across muxers.

                                -
                                log: Logger

                                The stream logger

                                -
                                metadata: Record<string, any>

                                User defined stream metadata

                                -
                                protocol?: string

                                The protocol negotiated for this stream

                                -
                                readStatus: ReadStatus

                                The current status of the readable end of the stream

                                -
                                source: AsyncGenerator<Uint8ArrayList, any, unknown>
                                status: StreamStatus

                                The current status of the stream

                                -
                                timeline: StreamTimeline

                                Lifecycle times for the stream

                                -
                                writeStatus: WriteStatus

                                The current status of the writable end of the stream

                                -

                                Methods

                                id: string

                                Unique identifier for a stream. Identifiers are not unique across muxers.

                                +
                                log: Logger

                                The stream logger

                                +
                                metadata: Record<string, any>

                                User defined stream metadata

                                +
                                protocol?: string

                                The protocol negotiated for this stream

                                +
                                readStatus: ReadStatus

                                The current status of the readable end of the stream

                                +
                                source: AsyncGenerator<Uint8ArrayList, any, unknown>
                                status: StreamStatus

                                The current status of the stream

                                +
                                timeline: StreamTimeline

                                Lifecycle times for the stream

                                +
                                writeStatus: WriteStatus

                                The current status of the writable end of the stream

                                +

                                Methods

                                • Closes the stream for reading and writing. This should be called when a local error has occurred.

                                  Note, if called without an error any buffered data in the source can still be consumed and the stream will end normally.

                                  This will cause a RESET message to be sent to the remote, unless the sink has already ended.

                                  The sink will return and the source will throw if an error is passed or return normally if not.

                                  -

                                  Parameters

                                  Returns void

                                • Closes the stream for reading and writing.

                                  Any buffered data in the source can still be consumed and the stream will end normally.

                                  This will cause a CLOSE message to be sent to the remote, unless the sink has already ended.

                                  The sink and the source will return normally.

                                  -

                                  Parameters

                                  Returns Promise<void>

                                • Closes the stream for reading. If iterating over the source of this stream in a for await of loop, it will return (exit the loop) after any buffered data has been consumed.

                                  This function is called automatically by the muxer when it receives a CLOSE message from the remote.

                                  The source will return normally, the sink will continue to consume.

                                  -

                                  Parameters

                                  Returns Promise<void>

                                • Closes the stream for writing. If iterating over the source of this stream in a for await of loop, it will return (exit the loop) after any buffered data has been consumed.

                                  The source will return normally, the sink will continue to consume.

                                  -

                                  Parameters

                                  Returns Promise<void>

                                \ No newline at end of file +

                                Parameters

                                Returns Promise<void>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamHandler.html b/interfaces/_libp2p_interface.StreamHandler.html index e72ed3207b..3228d35757 100644 --- a/interfaces/_libp2p_interface.StreamHandler.html +++ b/interfaces/_libp2p_interface.StreamHandler.html @@ -1 +1 @@ -StreamHandler | libp2p
                                interface StreamHandler ((data) => void)
                                \ No newline at end of file +StreamHandler | libp2p
                                interface StreamHandler ((data) => void)
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamHandlerOptions.html b/interfaces/_libp2p_interface.StreamHandlerOptions.html index 1ee487515b..259872fb51 100644 --- a/interfaces/_libp2p_interface.StreamHandlerOptions.html +++ b/interfaces/_libp2p_interface.StreamHandlerOptions.html @@ -1,8 +1,8 @@ -StreamHandlerOptions | libp2p

                                Interface StreamHandlerOptions

                                interface StreamHandlerOptions {
                                    maxInboundStreams?: number;
                                    maxOutboundStreams?: number;
                                    runOnLimitedConnection?: boolean;
                                }

                                Properties

                                maxInboundStreams? +StreamHandlerOptions | libp2p

                                Interface StreamHandlerOptions

                                interface StreamHandlerOptions {
                                    maxInboundStreams?: number;
                                    maxOutboundStreams?: number;
                                    runOnLimitedConnection?: boolean;
                                }

                                Properties

                                maxInboundStreams?: number

                                How many incoming streams can be open for this protocol at the same time on each connection (default: 32)

                                -
                                maxOutboundStreams?: number

                                How many outgoing streams can be open for this protocol at the same time on each connection (default: 64)

                                -
                                runOnLimitedConnection?: boolean

                                Opt-in to running over connections with limits on how much data can be +

                                maxOutboundStreams?: number

                                How many outgoing streams can be open for this protocol at the same time on each connection (default: 64)

                                +
                                runOnLimitedConnection?: boolean

                                Opt-in to running over connections with limits on how much data can be transferred or how long it can be open for.

                                -
                                \ No newline at end of file +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamHandlerRecord.html b/interfaces/_libp2p_interface.StreamHandlerRecord.html index ea099668c8..febc9b8166 100644 --- a/interfaces/_libp2p_interface.StreamHandlerRecord.html +++ b/interfaces/_libp2p_interface.StreamHandlerRecord.html @@ -1,3 +1,3 @@ -StreamHandlerRecord | libp2p

                                Interface StreamHandlerRecord

                                interface StreamHandlerRecord {
                                    handler: StreamHandler;
                                    options: StreamHandlerOptions;
                                }

                                Properties

                                handler +StreamHandlerRecord | libp2p

                                Interface StreamHandlerRecord

                                interface StreamHandlerRecord {
                                    handler: StreamHandler;
                                    options: StreamHandlerOptions;
                                }

                                Properties

                                Properties

                                handler: StreamHandler
                                \ No newline at end of file +

                                Properties

                                handler: StreamHandler
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamMuxer.html b/interfaces/_libp2p_interface.StreamMuxer.html index 0429a0051d..9f5e3ff03b 100644 --- a/interfaces/_libp2p_interface.StreamMuxer.html +++ b/interfaces/_libp2p_interface.StreamMuxer.html @@ -1,5 +1,5 @@ StreamMuxer | libp2p

                                A libp2p stream muxer

                                -
                                interface StreamMuxer {
                                    protocol: string;
                                    sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>;
                                    source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>;
                                    streams: Stream[];
                                    abort(err): void;
                                    close(options?): Promise<void>;
                                    newStream(name?): Stream | Promise<Stream>;
                                }

                                Hierarchy

                                Properties

                                interface StreamMuxer {
                                    protocol: string;
                                    sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>;
                                    source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>;
                                    streams: Stream[];
                                    abort(err): void;
                                    close(options?): Promise<void>;
                                    newStream(name?): Stream | Promise<Stream>;
                                }

                                Hierarchy

                                Properties

                                Properties

                                protocol: string

                                The protocol used to select this muxer during connection opening

                                -
                                sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>
                                source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>
                                streams: Stream[]

                                A list of streams that are currently open. Closed streams will not be returned.

                                -

                                Methods

                                sink: Sink<AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>, unknown>
                                source: AsyncGenerator<Uint8Array | Uint8ArrayList, any, unknown>
                                streams: Stream[]

                                A list of streams that are currently open. Closed streams will not be returned.

                                +

                                Methods

                                \ No newline at end of file +

                                Parameters

                                • Optional name: string

                                Returns Stream | Promise<Stream>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamMuxerFactory.html b/interfaces/_libp2p_interface.StreamMuxerFactory.html index d0ceb9bb35..0e9e2aca35 100644 --- a/interfaces/_libp2p_interface.StreamMuxerFactory.html +++ b/interfaces/_libp2p_interface.StreamMuxerFactory.html @@ -1,5 +1,5 @@ -StreamMuxerFactory | libp2p

                                Interface StreamMuxerFactory

                                interface StreamMuxerFactory {
                                    protocol: string;
                                    createStreamMuxer(init?): StreamMuxer;
                                }

                                Properties

                                protocol +StreamMuxerFactory | libp2p

                                Interface StreamMuxerFactory

                                interface StreamMuxerFactory {
                                    protocol: string;
                                    createStreamMuxer(init?): StreamMuxer;
                                }

                                Properties

                                Methods

                                Properties

                                protocol: string

                                The protocol used to select this muxer during connection opening

                                -

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamMuxerInit.html b/interfaces/_libp2p_interface.StreamMuxerInit.html index 7aae4cc2b5..1f5b3778df 100644 --- a/interfaces/_libp2p_interface.StreamMuxerInit.html +++ b/interfaces/_libp2p_interface.StreamMuxerInit.html @@ -1,7 +1,7 @@ -StreamMuxerInit | libp2p
                                interface StreamMuxerInit {
                                    direction?: Direction;
                                    onIncomingStream?(stream): void;
                                    onStreamEnd?(stream): void;
                                }

                                Properties

                                direction? +StreamMuxerInit | libp2p
                                interface StreamMuxerInit {
                                    direction?: Direction;
                                    onIncomingStream?(stream): void;
                                    onStreamEnd?(stream): void;
                                }

                                Properties

                                direction?: Direction

                                Outbound stream muxers are opened by the local node, inbound stream muxers are opened by the remote

                                -

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.StreamTimeline.html b/interfaces/_libp2p_interface.StreamTimeline.html index 942151fad2..9b84b27e02 100644 --- a/interfaces/_libp2p_interface.StreamTimeline.html +++ b/interfaces/_libp2p_interface.StreamTimeline.html @@ -1,13 +1,13 @@ -StreamTimeline | libp2p
                                interface StreamTimeline {
                                    abort?: number;
                                    close?: number;
                                    closeRead?: number;
                                    closeWrite?: number;
                                    open: number;
                                    reset?: number;
                                }

                                Properties

                                abort? +StreamTimeline | libp2p
                                interface StreamTimeline {
                                    abort?: number;
                                    close?: number;
                                    closeRead?: number;
                                    closeWrite?: number;
                                    open: number;
                                    reset?: number;
                                }

                                Properties

                                abort?: number

                                A timestamp of when the stream was aborted

                                -
                                close?: number

                                A timestamp of when the stream was closed for both reading and writing

                                -
                                closeRead?: number

                                A timestamp of when the stream was closed for reading

                                -
                                closeWrite?: number

                                A timestamp of when the stream was closed for writing

                                -
                                open: number

                                A timestamp of when the stream was opened

                                -
                                reset?: number

                                A timestamp of when the stream was reset

                                -
                                \ No newline at end of file +
                                close?: number

                                A timestamp of when the stream was closed for both reading and writing

                                +
                                closeRead?: number

                                A timestamp of when the stream was closed for reading

                                +
                                closeWrite?: number

                                A timestamp of when the stream was closed for writing

                                +
                                open: number

                                A timestamp of when the stream was opened

                                +
                                reset?: number

                                A timestamp of when the stream was reset

                                +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.SubscriptionChangeData.html b/interfaces/_libp2p_interface.SubscriptionChangeData.html index a8814270a5..07916f447b 100644 --- a/interfaces/_libp2p_interface.SubscriptionChangeData.html +++ b/interfaces/_libp2p_interface.SubscriptionChangeData.html @@ -1,3 +1,3 @@ -SubscriptionChangeData | libp2p

                                Interface SubscriptionChangeData

                                interface SubscriptionChangeData {
                                    peerId: PeerId;
                                    subscriptions: Subscription[];
                                }

                                Properties

                                peerId +SubscriptionChangeData | libp2p

                                Interface SubscriptionChangeData

                                interface SubscriptionChangeData {
                                    peerId: PeerId;
                                    subscriptions: Subscription[];
                                }

                                Properties

                                Properties

                                peerId: PeerId
                                subscriptions: Subscription[]
                                \ No newline at end of file +

                                Properties

                                peerId: PeerId
                                subscriptions: Subscription[]
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Tag.html b/interfaces/_libp2p_interface.Tag.html index c358c9baf3..8f6aaf31d1 100644 --- a/interfaces/_libp2p_interface.Tag.html +++ b/interfaces/_libp2p_interface.Tag.html @@ -1,3 +1,3 @@ -Tag | libp2p
                                interface Tag {
                                    value: number;
                                }

                                Properties

                                value +Tag | libp2p
                                interface Tag {
                                    value: number;
                                }

                                Properties

                                Properties

                                value: number

                                The tag value

                                -
                                \ No newline at end of file +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.TagOptions.html b/interfaces/_libp2p_interface.TagOptions.html index 0f973ccdea..677478b6d6 100644 --- a/interfaces/_libp2p_interface.TagOptions.html +++ b/interfaces/_libp2p_interface.TagOptions.html @@ -1,5 +1,5 @@ -TagOptions | libp2p
                                interface TagOptions {
                                    ttl?: number;
                                    value?: number;
                                }

                                Properties

                                ttl? +TagOptions | libp2p
                                interface TagOptions {
                                    ttl?: number;
                                    value?: number;
                                }

                                Properties

                                Properties

                                ttl?: number

                                An optional duration in ms after which the tag will expire

                                -
                                value?: number

                                An optional tag value (1-100)

                                -
                                \ No newline at end of file +
                                value?: number

                                An optional tag value (1-100)

                                +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.TopicValidatorFn.html b/interfaces/_libp2p_interface.TopicValidatorFn.html index 7e28793e0a..a7a736b1ac 100644 --- a/interfaces/_libp2p_interface.TopicValidatorFn.html +++ b/interfaces/_libp2p_interface.TopicValidatorFn.html @@ -1 +1 @@ -TopicValidatorFn | libp2p

                                Interface TopicValidatorFn

                                interface TopicValidatorFn ((peer, message) => TopicValidatorResult | Promise<TopicValidatorResult>)
                                \ No newline at end of file +TopicValidatorFn | libp2p

                                Interface TopicValidatorFn

                                interface TopicValidatorFn ((peer, message) => TopicValidatorResult | Promise<TopicValidatorResult>)
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Topology.html b/interfaces/_libp2p_interface.Topology.html index c8deddb55d..bd8f843979 100644 --- a/interfaces/_libp2p_interface.Topology.html +++ b/interfaces/_libp2p_interface.Topology.html @@ -2,19 +2,19 @@ complete network.

                                It is a way to be notified when peers that support a given protocol connect to or disconnect from the current node.

                                -
                                interface Topology {
                                    filter?: TopologyFilter;
                                    notifyOnLimitedConnection?: boolean;
                                    onConnect?(peerId, conn): void;
                                    onDisconnect?(peerId): void;
                                }

                                Properties

                                interface Topology {
                                    filter?: TopologyFilter;
                                    notifyOnLimitedConnection?: boolean;
                                    onConnect?(peerId, conn): void;
                                    onDisconnect?(peerId): void;
                                }

                                Properties

                                An optional filter can prevent duplicate topology notifications for the same peer.

                                -
                                notifyOnLimitedConnection?: boolean

                                If true, invoke onConnect for this topology on limited connections, e.g. +

                                notifyOnLimitedConnection?: boolean

                                If true, invoke onConnect for this topology on limited connections, e.g. ones with limits on how much data can be transferred or how long they can be open for.

                                Default

                                false
                                 
                                -

                                Methods

                                Methods

                                \ No newline at end of file +

                                Parameters

                                Returns void

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.TopologyFilter.html b/interfaces/_libp2p_interface.TopologyFilter.html index 1b4272936a..215ea6c533 100644 --- a/interfaces/_libp2p_interface.TopologyFilter.html +++ b/interfaces/_libp2p_interface.TopologyFilter.html @@ -1,6 +1,6 @@ TopologyFilter | libp2p

                                A topology filter

                                interface TopologyFilter {
                                    add(peerId): void;
                                    has(peerId): boolean;
                                    remove(peerId): void;
                                }

                                Methods

                                add +
                                interface TopologyFilter {
                                    add(peerId): void;
                                    has(peerId): boolean;
                                    remove(peerId): void;
                                }

                                Methods

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Transport.html b/interfaces/_libp2p_interface.Transport.html index 4416de14a9..feceae02ac 100644 --- a/interfaces/_libp2p_interface.Transport.html +++ b/interfaces/_libp2p_interface.Transport.html @@ -1,16 +1,16 @@ Transport | libp2p

                                Interface Transport<DialEvents>

                                A libp2p transport offers dial and listen methods to establish connections.

                                -
                                interface Transport<DialEvents> {
                                    [toStringTag]: string;
                                    [transportSymbol]: true;
                                    dialFilter: MultiaddrFilter;
                                    listenFilter: MultiaddrFilter;
                                    createListener(options): Listener;
                                    dial(ma, options): Promise<Connection>;
                                }

                                Type Parameters

                                Properties

                                interface Transport<DialEvents> {
                                    [toStringTag]: string;
                                    [transportSymbol]: true;
                                    dialFilter: MultiaddrFilter;
                                    listenFilter: MultiaddrFilter;
                                    createListener(options): Listener;
                                    dial(ma, options): Promise<Connection>;
                                }

                                Type Parameters

                                Properties

                                [toStringTag]: string

                                Used to identify the transport

                                -
                                [transportSymbol]: true

                                Used by the isTransport function

                                -
                                dialFilter: MultiaddrFilter

                                Takes a list of Multiaddrs and returns only addresses that are vali for +

                                [transportSymbol]: true

                                Used by the isTransport function

                                +
                                dialFilter: MultiaddrFilter

                                Takes a list of Multiaddrs and returns only addresses that are vali for the transport to dial

                                -
                                listenFilter: MultiaddrFilter

                                Takes a list of Multiaddrs and returns only addresses that are valid for +

                                listenFilter: MultiaddrFilter

                                Takes a list of Multiaddrs and returns only addresses that are valid for the transport to listen on

                                -

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.TypedEventTarget.html b/interfaces/_libp2p_interface.TypedEventTarget.html index f3d135dd91..5ae15f3b4d 100644 --- a/interfaces/_libp2p_interface.TypedEventTarget.html +++ b/interfaces/_libp2p_interface.TypedEventTarget.html @@ -3,13 +3,13 @@ https://github.com/microsoft/TypeScript/issues/43477 https://github.com/microsoft/TypeScript/issues/299 etc

                                -
                                interface TypedEventTarget<EventMap> {
                                    addEventListener<K>(type, listener, options?): void;
                                    dispatchEvent(event): boolean;
                                    dispatchEvent(event): boolean;
                                    listenerCount(type): number;
                                    removeEventListener<K>(type, listener?, options?): void;
                                    removeEventListener(type, listener?, options?): void;
                                    safeDispatchEvent<Detail>(type, detail): boolean;
                                }

                                Type Parameters

                                • EventMap extends Record<string, any>

                                Hierarchy (view full)

                                Implemented by

                                Methods

                                interface TypedEventTarget<EventMap> {
                                    addEventListener<K>(type, listener, options?): void;
                                    dispatchEvent(event): boolean;
                                    dispatchEvent(event): boolean;
                                    listenerCount(type): number;
                                    removeEventListener<K>(type, listener?, options?): void;
                                    removeEventListener(type, listener?, options?): void;
                                    safeDispatchEvent<Detail>(type, detail): boolean;
                                }

                                Type Parameters

                                • EventMap extends Record<string, any>

                                Hierarchy (view full)

                                Implemented by

                                Methods

                                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                  +

                                Methods

                                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                  MDN Reference

                                  Parameters

                                  Returns boolean

                                • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                  MDN Reference

                                  -

                                  Parameters

                                  Returns boolean

                                \ No newline at end of file +

                                Parameters

                                Returns boolean

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.URLPeerId.html b/interfaces/_libp2p_interface.URLPeerId.html index e7b57ab1db..cc244a7ed2 100644 --- a/interfaces/_libp2p_interface.URLPeerId.html +++ b/interfaces/_libp2p_interface.URLPeerId.html @@ -1,14 +1,14 @@ -URLPeerId | libp2p
                                interface URLPeerId {
                                    publicKey: undefined;
                                    type: "url";
                                    equals(other?): boolean;
                                    toCID(): CID<Uint8Array, 2336, 0, 1>;
                                    toMultihash(): MultihashDigest<0>;
                                    toString(): string;
                                }

                                Properties

                                publicKey +URLPeerId | libp2p
                                interface URLPeerId {
                                    publicKey: undefined;
                                    type: "url";
                                    equals(other?): boolean;
                                    toCID(): CID<Uint8Array, 2336, 0, 1>;
                                    toMultihash(): MultihashDigest<0>;
                                    toString(): string;
                                }

                                Properties

                                publicKey: undefined

                                This will always be undefined as URL Peers do not have public keys

                                -
                                type: "url"

                                Methods

                                type: "url"

                                Methods

                                \ No newline at end of file +

                                Returns MultihashDigest<0>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.UnsignedMessage.html b/interfaces/_libp2p_interface.UnsignedMessage.html index 9e2b179824..5ad9dd59af 100644 --- a/interfaces/_libp2p_interface.UnsignedMessage.html +++ b/interfaces/_libp2p_interface.UnsignedMessage.html @@ -1,4 +1,4 @@ -UnsignedMessage | libp2p
                                interface UnsignedMessage {
                                    data: Uint8Array;
                                    topic: string;
                                    type: "unsigned";
                                }

                                Properties

                                data +UnsignedMessage | libp2p
                                interface UnsignedMessage {
                                    data: Uint8Array;
                                    topic: string;
                                    type: "unsigned";
                                }

                                Properties

                                Properties

                                topic: string
                                type: "unsigned"
                                \ No newline at end of file +

                                Properties

                                topic: string
                                type: "unsigned"
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.Upgrader.html b/interfaces/_libp2p_interface.Upgrader.html index 28275fabd4..c603821073 100644 --- a/interfaces/_libp2p_interface.Upgrader.html +++ b/interfaces/_libp2p_interface.Upgrader.html @@ -1,5 +1,5 @@ -Upgrader | libp2p
                                interface Upgrader {
                                    upgradeInbound(maConn, opts?): Promise<Connection>;
                                    upgradeOutbound(maConn, opts?): Promise<Connection>;
                                }

                                Methods

                                upgradeInbound +Upgrader | libp2p
                                interface Upgrader {
                                    upgradeInbound(maConn, opts?): Promise<Connection>;
                                    upgradeOutbound(maConn, opts?): Promise<Connection>;
                                }

                                Methods

                                \ No newline at end of file +

                                Returns Promise<Connection>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface.UpgraderOptions.html b/interfaces/_libp2p_interface.UpgraderOptions.html index 1cf1440af5..b63ab2453d 100644 --- a/interfaces/_libp2p_interface.UpgraderOptions.html +++ b/interfaces/_libp2p_interface.UpgraderOptions.html @@ -2,10 +2,10 @@ the optional signal property.

                                Example

                                const controller = new AbortController()

                                aLongRunningOperation({
                                signal: controller.signal
                                })

                                // later

                                controller.abort()
                                -
                                interface UpgraderOptions<ConnectionUpgradeEvents> {
                                    limits?: ConnectionLimits;
                                    muxerFactory?: StreamMuxerFactory;
                                    onProgress?: ((evt) => void);
                                    signal?: AbortSignal;
                                    skipEncryption?: boolean;
                                    skipProtection?: boolean;
                                }

                                Type Parameters

                                Hierarchy (view full)

                                Properties

                                interface UpgraderOptions<ConnectionUpgradeEvents> {
                                    limits?: ConnectionLimits;
                                    muxerFactory?: StreamMuxerFactory;
                                    onProgress?: ((evt) => void);
                                    signal?: AbortSignal;
                                    skipEncryption?: boolean;
                                    skipProtection?: boolean;
                                }

                                Type Parameters

                                Hierarchy (view full)

                                Properties

                                muxerFactory?: StreamMuxerFactory
                                onProgress?: ((evt) => void)

                                Type declaration

                                signal?: AbortSignal
                                skipEncryption?: boolean
                                skipProtection?: boolean
                                \ No newline at end of file +

                                Properties

                                muxerFactory?: StreamMuxerFactory
                                onProgress?: ((evt) => void)

                                Type declaration

                                signal?: AbortSignal
                                skipEncryption?: boolean
                                skipProtection?: boolean
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.connection_encryption.ConnectionEncrypterSetupArgs.html b/interfaces/_libp2p_interface_compliance_tests.connection_encryption.ConnectionEncrypterSetupArgs.html index 31caba7ed1..4779093766 100644 --- a/interfaces/_libp2p_interface_compliance_tests.connection_encryption.ConnectionEncrypterSetupArgs.html +++ b/interfaces/_libp2p_interface_compliance_tests.connection_encryption.ConnectionEncrypterSetupArgs.html @@ -1,2 +1,2 @@ -ConnectionEncrypterSetupArgs | libp2p
                                interface ConnectionEncrypterSetupArgs {
                                    privateKey: PrivateKey;
                                }

                                Properties

                                Properties

                                privateKey: PrivateKey
                                \ No newline at end of file +ConnectionEncrypterSetupArgs | libp2p
                                interface ConnectionEncrypterSetupArgs {
                                    privateKey: PrivateKey;
                                }

                                Properties

                                Properties

                                privateKey: PrivateKey
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.index.TestSetup.html b/interfaces/_libp2p_interface_compliance_tests.index.TestSetup.html index c9a4c6a291..671577bb5f 100644 --- a/interfaces/_libp2p_interface_compliance_tests.index.TestSetup.html +++ b/interfaces/_libp2p_interface_compliance_tests.index.TestSetup.html @@ -1,3 +1,3 @@ -TestSetup | libp2p
                                interface TestSetup<T, SetupArgs> {
                                    setup(args?): Promise<T>;
                                    teardown(): Promise<void>;
                                }

                                Type Parameters

                                • T
                                • SetupArgs = Record<string, unknown>

                                Methods

                                setup +TestSetup | libp2p
                                interface TestSetup<T, SetupArgs> {
                                    setup(args?): Promise<T>;
                                    teardown(): Promise<void>;
                                }

                                Type Parameters

                                • T
                                • SetupArgs = Record<string, unknown>

                                Methods

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.mocks.MockNetworkComponents.html b/interfaces/_libp2p_interface_compliance_tests.mocks.MockNetworkComponents.html index 7fcbdc22ca..6a4143ca85 100644 --- a/interfaces/_libp2p_interface_compliance_tests.mocks.MockNetworkComponents.html +++ b/interfaces/_libp2p_interface_compliance_tests.mocks.MockNetworkComponents.html @@ -1,8 +1,8 @@ -MockNetworkComponents | libp2p
                                interface MockNetworkComponents {
                                    connectionManager: ConnectionManager;
                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    logger: ComponentLogger;
                                    peerId: PeerId;
                                    privateKey: PrivateKey;
                                    pubsub?: PubSub<PubSubEvents>;
                                    registrar: Registrar;
                                }

                                Properties

                                connectionManager +MockNetworkComponents | libp2p
                                interface MockNetworkComponents {
                                    connectionManager: ConnectionManager;
                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    logger: ComponentLogger;
                                    peerId: PeerId;
                                    privateKey: PrivateKey;
                                    pubsub?: PubSub<PubSubEvents>;
                                    registrar: Registrar;
                                }

                                Properties

                                connectionManager: ConnectionManager
                                peerId: PeerId
                                privateKey: PrivateKey
                                registrar: Registrar
                                \ No newline at end of file +

                                Properties

                                connectionManager: ConnectionManager
                                peerId: PeerId
                                privateKey: PrivateKey
                                registrar: Registrar
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.mocks.MockUpgraderInit.html b/interfaces/_libp2p_interface_compliance_tests.mocks.MockUpgraderInit.html index c896242070..0a5ad39f73 100644 --- a/interfaces/_libp2p_interface_compliance_tests.mocks.MockUpgraderInit.html +++ b/interfaces/_libp2p_interface_compliance_tests.mocks.MockUpgraderInit.html @@ -1,3 +1,3 @@ -MockUpgraderInit | libp2p
                                interface MockUpgraderInit {
                                    events?: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    registrar?: Registrar;
                                }

                                Properties

                                events? +MockUpgraderInit | libp2p
                                interface MockUpgraderInit {
                                    events?: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    registrar?: Registrar;
                                }

                                Properties

                                Properties

                                registrar?: Registrar
                                \ No newline at end of file +

                                Properties

                                registrar?: Registrar
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubArgs.html b/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubArgs.html index b2eaaaaf18..51ff0f5e51 100644 --- a/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubArgs.html +++ b/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubArgs.html @@ -1,3 +1,3 @@ -PubSubArgs | libp2p
                                interface PubSubArgs {
                                    components: PubSubComponents;
                                    init: PubSubInit;
                                }

                                Properties

                                components +PubSubArgs | libp2p
                                interface PubSubArgs {
                                    components: PubSubComponents;
                                    init: PubSubInit;
                                }

                                Properties

                                Properties

                                components: PubSubComponents
                                \ No newline at end of file +

                                Properties

                                components: PubSubComponents
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubComponents.html b/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubComponents.html index f179715da4..a02fc471e0 100644 --- a/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubComponents.html +++ b/interfaces/_libp2p_interface_compliance_tests.pubsub.PubSubComponents.html @@ -1,7 +1,7 @@ -PubSubComponents | libp2p
                                interface PubSubComponents {
                                    connectionManager: ConnectionManager;
                                    logger: ComponentLogger;
                                    peerId: PeerId;
                                    privateKey: PrivateKey;
                                    pubsub?: PubSub<PubSubEvents>;
                                    registrar: Registrar;
                                }

                                Properties

                                connectionManager +PubSubComponents | libp2p
                                interface PubSubComponents {
                                    connectionManager: ConnectionManager;
                                    logger: ComponentLogger;
                                    peerId: PeerId;
                                    privateKey: PrivateKey;
                                    pubsub?: PubSub<PubSubEvents>;
                                    registrar: Registrar;
                                }

                                Properties

                                connectionManager: ConnectionManager
                                peerId: PeerId
                                privateKey: PrivateKey
                                registrar: Registrar
                                \ No newline at end of file +

                                Properties

                                connectionManager: ConnectionManager
                                peerId: PeerId
                                privateKey: PrivateKey
                                registrar: Registrar
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.transport.Connector.html b/interfaces/_libp2p_interface_compliance_tests.transport.Connector.html index bf888af487..3b0dd22c14 100644 --- a/interfaces/_libp2p_interface_compliance_tests.transport.Connector.html +++ b/interfaces/_libp2p_interface_compliance_tests.transport.Connector.html @@ -1,3 +1,3 @@ -Connector | libp2p
                                interface Connector {
                                    delay(ms): void;
                                    restore(): void;
                                }

                                Methods

                                delay +Connector | libp2p
                                interface Connector {
                                    delay(ms): void;
                                    restore(): void;
                                }

                                Methods

                                Methods

                                \ No newline at end of file +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_compliance_tests.transport.TransportTestFixtures.html b/interfaces/_libp2p_interface_compliance_tests.transport.TransportTestFixtures.html index de973fe675..dcefea8434 100644 --- a/interfaces/_libp2p_interface_compliance_tests.transport.TransportTestFixtures.html +++ b/interfaces/_libp2p_interface_compliance_tests.transport.TransportTestFixtures.html @@ -1,6 +1,6 @@ -TransportTestFixtures | libp2p
                                interface TransportTestFixtures {
                                    connector: Connector;
                                    dialAddrs: Multiaddr[];
                                    dialer: Transport<ProgressEvent<any, unknown>>;
                                    listenAddrs: Multiaddr[];
                                    listener: Transport<ProgressEvent<any, unknown>>;
                                }

                                Properties

                                connector +TransportTestFixtures | libp2p
                                interface TransportTestFixtures {
                                    connector: Connector;
                                    dialAddrs: Multiaddr[];
                                    dialer: Transport<ProgressEvent<any, unknown>>;
                                    listenAddrs: Multiaddr[];
                                    listener: Transport<ProgressEvent<any, unknown>>;
                                }

                                Properties

                                connector: Connector
                                dialAddrs: Multiaddr[]
                                dialer: Transport<ProgressEvent<any, unknown>>
                                listenAddrs: Multiaddr[]
                                listener: Transport<ProgressEvent<any, unknown>>
                                \ No newline at end of file +

                                Properties

                                connector: Connector
                                dialAddrs: Multiaddr[]
                                dialer: Transport<ProgressEvent<any, unknown>>
                                listenAddrs: Multiaddr[]
                                listener: Transport<ProgressEvent<any, unknown>>
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.AddressManager.html b/interfaces/_libp2p_interface_internal.AddressManager.html index 4c24500bcb..87218e8b19 100644 --- a/interfaces/_libp2p_interface_internal.AddressManager.html +++ b/interfaces/_libp2p_interface_internal.AddressManager.html @@ -1,4 +1,4 @@ -AddressManager | libp2p
                                interface AddressManager {
                                    addObservedAddr(addr): void;
                                    confirmObservedAddr(addr): void;
                                    getAddresses(): Multiaddr[];
                                    getAnnounceAddrs(): Multiaddr[];
                                    getListenAddrs(): Multiaddr[];
                                    getObservedAddrs(): Multiaddr[];
                                    removeObservedAddr(addr): void;
                                }

                                Methods

                                addObservedAddr +AddressManager | libp2p
                                interface AddressManager {
                                    addObservedAddr(addr): void;
                                    confirmObservedAddr(addr): void;
                                    getAddresses(): Multiaddr[];
                                    getAnnounceAddrs(): Multiaddr[];
                                    getListenAddrs(): Multiaddr[];
                                    getObservedAddrs(): Multiaddr[];
                                    removeObservedAddr(addr): void;
                                }

                                Methods

                                \ No newline at end of file +

                                Parameters

                                Returns void

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.ConnectionManager.html b/interfaces/_libp2p_interface_internal.ConnectionManager.html index bac5c0a931..9e461d2598 100644 --- a/interfaces/_libp2p_interface_internal.ConnectionManager.html +++ b/interfaces/_libp2p_interface_internal.ConnectionManager.html @@ -1,4 +1,4 @@ -ConnectionManager | libp2p
                                interface ConnectionManager {
                                    acceptIncomingConnection(maConn): Promise<boolean>;
                                    afterUpgradeInbound(): void;
                                    closeConnections(peer, options?): Promise<void>;
                                    getConnections(peerId?): Connection[];
                                    getConnectionsMap(): PeerMap<Connection[]>;
                                    getDialQueue(): PendingDial[];
                                    isDialable(multiaddr, options?): Promise<boolean>;
                                    openConnection(peer, options?): Promise<Connection>;
                                }

                                Methods

                                acceptIncomingConnection +ConnectionManager | libp2p
                                interface ConnectionManager {
                                    acceptIncomingConnection(maConn): Promise<boolean>;
                                    afterUpgradeInbound(): void;
                                    closeConnections(peer, options?): Promise<void>;
                                    getConnections(peerId?): Connection[];
                                    getConnectionsMap(): PeerMap<Connection[]>;
                                    getDialQueue(): PendingDial[];
                                    isDialable(multiaddr, options?): Promise<boolean>;
                                    openConnection(peer, options?): Promise<Connection>;
                                }

                                Methods

                                acceptIncomingConnection afterUpgradeInbound closeConnections getConnections @@ -10,23 +10,23 @@ exchanged, this lets the ConnectionManager check we have sufficient resources to accept the connection in which case it will return true, otherwise it will return false.

                                -

                                Parameters

                                Returns Promise<boolean>

                                \ No newline at end of file +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.Envelope.html b/interfaces/_libp2p_interface_internal.Envelope.html index e09e5da541..a0a9597ac0 100644 --- a/interfaces/_libp2p_interface_internal.Envelope.html +++ b/interfaces/_libp2p_interface_internal.Envelope.html @@ -1,8 +1,8 @@ -Envelope | libp2p
                                interface Envelope {
                                    payload: Uint8Array;
                                    payloadType: Uint8Array | Uint8ArrayList;
                                    peerId: PeerId;
                                    signature: Uint8Array | Uint8ArrayList;
                                    equals(other): boolean;
                                    marshal(): Uint8Array;
                                    validate(domain): Promise<boolean>;
                                }

                                Properties

                                payload +Envelope | libp2p
                                interface Envelope {
                                    payload: Uint8Array;
                                    payloadType: Uint8Array | Uint8ArrayList;
                                    peerId: PeerId;
                                    signature: Uint8Array | Uint8ArrayList;
                                    equals(other): boolean;
                                    marshal(): Uint8Array;
                                    validate(domain): Promise<boolean>;
                                }

                                Properties

                                payload: Uint8Array
                                payloadType: Uint8Array | Uint8ArrayList
                                peerId: PeerId

                                Methods

                                \ No newline at end of file +

                                Properties

                                payload: Uint8Array
                                payloadType: Uint8Array | Uint8ArrayList
                                peerId: PeerId

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.IncomingStreamData.html b/interfaces/_libp2p_interface_internal.IncomingStreamData.html index 9655ba7894..f91b615a11 100644 --- a/interfaces/_libp2p_interface_internal.IncomingStreamData.html +++ b/interfaces/_libp2p_interface_internal.IncomingStreamData.html @@ -1,5 +1,5 @@ -IncomingStreamData | libp2p
                                interface IncomingStreamData {
                                    connection: Connection;
                                    stream: Stream;
                                }

                                Properties

                                connection +IncomingStreamData | libp2p
                                interface IncomingStreamData {
                                    connection: Connection;
                                    stream: Stream;
                                }

                                Properties

                                Properties

                                connection: Connection

                                The connection that the stream was opened on

                                -
                                stream: Stream

                                The stream that has been opened

                                -
                                \ No newline at end of file +
                                stream: Stream

                                The stream that has been opened

                                +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.OpenConnectionOptions.html b/interfaces/_libp2p_interface_internal.OpenConnectionOptions.html index 5143cd2039..75669c40dc 100644 --- a/interfaces/_libp2p_interface_internal.OpenConnectionOptions.html +++ b/interfaces/_libp2p_interface_internal.OpenConnectionOptions.html @@ -2,13 +2,13 @@ the optional signal property.

                                Example

                                const controller = new AbortController()

                                aLongRunningOperation({
                                signal: controller.signal
                                })

                                // later

                                controller.abort()
                                -
                                interface OpenConnectionOptions {
                                    force?: boolean;
                                    onProgress?: ((evt) => void);
                                    priority?: number;
                                    signal?: AbortSignal;
                                }

                                Hierarchy (view full)

                                Properties

                                interface OpenConnectionOptions {
                                    force?: boolean;
                                    onProgress?: ((evt) => void);
                                    priority?: number;
                                    signal?: AbortSignal;
                                }

                                Hierarchy (view full)

                                Properties

                                force?: boolean

                                When opening a connection to a remote peer, if a connection already exists it will be returned instead of creating a new connection. Pass true here to override that and dial a new connection anyway. (default: false)

                                -
                                onProgress?: ((evt) => void)

                                Type declaration

                                priority?: number

                                Connection requests with a higher priority will be executed before those +

                                onProgress?: ((evt) => void)

                                Type declaration

                                priority?: number

                                Connection requests with a higher priority will be executed before those with a lower priority. (default: 50)

                                -
                                signal?: AbortSignal
                                \ No newline at end of file +
                                signal?: AbortSignal
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.RandomWalk.html b/interfaces/_libp2p_interface_internal.RandomWalk.html index d8edd9bcc6..8652bc7488 100644 --- a/interfaces/_libp2p_interface_internal.RandomWalk.html +++ b/interfaces/_libp2p_interface_internal.RandomWalk.html @@ -1,6 +1,6 @@ RandomWalk | libp2p

                                RandomWalk finds random peers on the network and dials them. Use this after registering a Topology if you need to discover common network services.

                                -
                                interface RandomWalk {
                                    walk(options?): AsyncGenerator<PeerInfo, any, unknown>;
                                }

                                Methods

                                interface RandomWalk {
                                    walk(options?): AsyncGenerator<PeerInfo, any, unknown>;
                                }

                                Methods

                                Methods

                                \ No newline at end of file +

                                Parameters

                                Returns AsyncGenerator<PeerInfo, any, unknown>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.Record.html b/interfaces/_libp2p_interface_internal.Record.html index 2d709940c3..4be4d0250a 100644 --- a/interfaces/_libp2p_interface_internal.Record.html +++ b/interfaces/_libp2p_interface_internal.Record.html @@ -1,10 +1,10 @@ Record | libp2p

                                Record is the base implementation of a record that can be used as the payload of a libp2p envelope.

                                -
                                interface Record {
                                    codec: Uint8Array;
                                    domain: string;
                                    equals(other): boolean;
                                    marshal(): Uint8Array;
                                }

                                Properties

                                interface Record {
                                    codec: Uint8Array;
                                    domain: string;
                                    equals(other): boolean;
                                    marshal(): Uint8Array;
                                }

                                Properties

                                Methods

                                Properties

                                codec: Uint8Array

                                identifier of the type of record

                                -
                                domain: string

                                signature domain.

                                -

                                Methods

                                \ No newline at end of file +
                                domain: string

                                signature domain.

                                +

                                Methods

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.Registrar.html b/interfaces/_libp2p_interface_internal.Registrar.html index 7465e6116f..fa196b73ba 100644 --- a/interfaces/_libp2p_interface_internal.Registrar.html +++ b/interfaces/_libp2p_interface_internal.Registrar.html @@ -1,4 +1,4 @@ -Registrar | libp2p
                                interface Registrar {
                                    getHandler(protocol): StreamHandlerRecord;
                                    getProtocols(): string[];
                                    getTopologies(protocol): Topology[];
                                    handle(protocol, handler, options?): Promise<void>;
                                    register(protocol, topology): Promise<string>;
                                    unhandle(protocol): Promise<void>;
                                    unregister(id): void;
                                }

                                Methods

                                getHandler +Registrar | libp2p
                                interface Registrar {
                                    getHandler(protocol): StreamHandlerRecord;
                                    getProtocols(): string[];
                                    getTopologies(protocol): Topology[];
                                    handle(protocol, handler, options?): Promise<void>;
                                    register(protocol, topology): Promise<string>;
                                    unhandle(protocol): Promise<void>;
                                    unregister(id): void;
                                }

                                Methods

                                • Register a topology handler for a protocol - the topology will be invoked when peers are discovered on the network that support the passed protocol.

                                  An id will be returned that can later be used to unregister the topology.

                                  -

                                  Parameters

                                  Returns Promise<string>

                                \ No newline at end of file +

                                Parameters

                                Returns Promise<string>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.StreamHandler.html b/interfaces/_libp2p_interface_internal.StreamHandler.html index 3cb6ad95d2..d07d677917 100644 --- a/interfaces/_libp2p_interface_internal.StreamHandler.html +++ b/interfaces/_libp2p_interface_internal.StreamHandler.html @@ -1 +1 @@ -StreamHandler | libp2p
                                interface StreamHandler ((data) => void)
                                \ No newline at end of file +StreamHandler | libp2p
                                interface StreamHandler ((data) => void)
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.StreamHandlerOptions.html b/interfaces/_libp2p_interface_internal.StreamHandlerOptions.html index aebf3d1c6e..c89de8a185 100644 --- a/interfaces/_libp2p_interface_internal.StreamHandlerOptions.html +++ b/interfaces/_libp2p_interface_internal.StreamHandlerOptions.html @@ -1,11 +1,11 @@ -StreamHandlerOptions | libp2p
                                interface StreamHandlerOptions {
                                    maxInboundStreams?: number;
                                    maxOutboundStreams?: number;
                                    runOnLimitedConnection?: boolean;
                                }

                                Properties

                                maxInboundStreams? +StreamHandlerOptions | libp2p
                                interface StreamHandlerOptions {
                                    maxInboundStreams?: number;
                                    maxOutboundStreams?: number;
                                    runOnLimitedConnection?: boolean;
                                }

                                Properties

                                maxInboundStreams?: number

                                How many incoming streams can be open for this protocol at the same time on each connection (default: 32)

                                -
                                maxOutboundStreams?: number

                                How many outgoing streams can be open for this protocol at the same time on each connection (default: 64)

                                -
                                runOnLimitedConnection?: boolean

                                If true, allow this protocol to run on limited connections (e.g. +

                                maxOutboundStreams?: number

                                How many outgoing streams can be open for this protocol at the same time on each connection (default: 64)

                                +
                                runOnLimitedConnection?: boolean

                                If true, allow this protocol to run on limited connections (e.g. connections with data or duration limits such as circuit relay connections)

                                Default

                                false
                                 
                                -
                                \ No newline at end of file +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.StreamHandlerRecord.html b/interfaces/_libp2p_interface_internal.StreamHandlerRecord.html index a0e123ee3a..5c970a4b33 100644 --- a/interfaces/_libp2p_interface_internal.StreamHandlerRecord.html +++ b/interfaces/_libp2p_interface_internal.StreamHandlerRecord.html @@ -1,5 +1,5 @@ -StreamHandlerRecord | libp2p
                                interface StreamHandlerRecord {
                                    handler: StreamHandler;
                                    options: StreamHandlerOptions;
                                }

                                Properties

                                handler +StreamHandlerRecord | libp2p
                                interface StreamHandlerRecord {
                                    handler: StreamHandler;
                                    options: StreamHandlerOptions;
                                }

                                Properties

                                Properties

                                handler: StreamHandler

                                The handler that was registered to handle streams opened on the protocol

                                -

                                The options that were used to register the stream handler

                                -
                                \ No newline at end of file +

                                The options that were used to register the stream handler

                                +
                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.TransportManager.html b/interfaces/_libp2p_interface_internal.TransportManager.html index e86dacd9ee..a90c093196 100644 --- a/interfaces/_libp2p_interface_internal.TransportManager.html +++ b/interfaces/_libp2p_interface_internal.TransportManager.html @@ -1,4 +1,4 @@ -TransportManager | libp2p
                                interface TransportManager {
                                    add(transport): void;
                                    dial(ma, options?): Promise<Connection>;
                                    dialTransportForMultiaddr(ma): undefined | Transport<ProgressEvent<any, unknown>>;
                                    getAddrs(): Multiaddr[];
                                    getListeners(): Listener[];
                                    getTransports(): Transport<ProgressEvent<any, unknown>>[];
                                    listen(addrs): Promise<void>;
                                    listenTransportForMultiaddr(ma): undefined | Transport<ProgressEvent<any, unknown>>;
                                    remove(key): Promise<void>;
                                    removeAll(): Promise<void>;
                                }

                                Methods

                                add +TransportManager | libp2p
                                interface TransportManager {
                                    add(transport): void;
                                    dial(ma, options?): Promise<Connection>;
                                    dialTransportForMultiaddr(ma): undefined | Transport<ProgressEvent<any, unknown>>;
                                    getAddrs(): Multiaddr[];
                                    getListeners(): Listener[];
                                    getTransports(): Transport<ProgressEvent<any, unknown>>[];
                                    listen(addrs): Promise<void>;
                                    listenTransportForMultiaddr(ma): undefined | Transport<ProgressEvent<any, unknown>>;
                                    remove(key): Promise<void>;
                                    removeAll(): Promise<void>;
                                }

                                Methods

                                \ No newline at end of file +

                                Parameters

                                Returns undefined | Transport<ProgressEvent<any, unknown>>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_interface_internal.TransportManagerDialOptions.html b/interfaces/_libp2p_interface_internal.TransportManagerDialOptions.html index 7971ed60af..7ba3e780ff 100644 --- a/interfaces/_libp2p_interface_internal.TransportManagerDialOptions.html +++ b/interfaces/_libp2p_interface_internal.TransportManagerDialOptions.html @@ -2,6 +2,6 @@ the optional signal property.

                                Example

                                const controller = new AbortController()

                                aLongRunningOperation({
                                signal: controller.signal
                                })

                                // later

                                controller.abort()
                                -
                                interface TransportManagerDialOptions {
                                    onProgress?: ((evt) => void);
                                    signal?: AbortSignal;
                                }

                                Hierarchy (view full)

                                Properties

                                interface TransportManagerDialOptions {
                                    onProgress?: ((evt) => void);
                                    signal?: AbortSignal;
                                }

                                Hierarchy (view full)

                                Properties

                                Properties

                                onProgress?: ((evt) => void)

                                Type declaration

                                signal?: AbortSignal
                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.AddPeerEvent.html b/interfaces/_libp2p_kad_dht.AddPeerEvent.html index 1529876097..bcf1c710f1 100644 --- a/interfaces/_libp2p_kad_dht.AddPeerEvent.html +++ b/interfaces/_libp2p_kad_dht.AddPeerEvent.html @@ -1,5 +1,5 @@ AddPeerEvent | libp2p

                                Interface AddPeerEvent

                                Emitted when peers are added to a query

                                -
                                interface AddPeerEvent {
                                    name: "ADD_PEER";
                                    peer: PeerId;
                                    type: ADD_PEER;
                                }

                                Properties

                                interface AddPeerEvent {
                                    name: "ADD_PEER";
                                    peer: PeerId;
                                    type: ADD_PEER;
                                }

                                Properties

                                Properties

                                name: "ADD_PEER"
                                peer: PeerId
                                type: ADD_PEER
                                \ No newline at end of file +

                                Properties

                                name: "ADD_PEER"
                                peer: PeerId
                                type: ADD_PEER
                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.DHTRecord.html b/interfaces/_libp2p_kad_dht.DHTRecord.html index 4a2b018394..eeb86f2b67 100644 --- a/interfaces/_libp2p_kad_dht.DHTRecord.html +++ b/interfaces/_libp2p_kad_dht.DHTRecord.html @@ -1,4 +1,4 @@ -DHTRecord | libp2p
                                interface DHTRecord {
                                    key: Uint8Array;
                                    timeReceived?: Date;
                                    value: Uint8Array;
                                }

                                Properties

                                key +DHTRecord | libp2p
                                interface DHTRecord {
                                    key: Uint8Array;
                                    timeReceived?: Date;
                                    value: Uint8Array;
                                }

                                Properties

                                Properties

                                timeReceived?: Date
                                value: Uint8Array
                                \ No newline at end of file +

                                Properties

                                timeReceived?: Date
                                value: Uint8Array
                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.DialPeerEvent.html b/interfaces/_libp2p_kad_dht.DialPeerEvent.html index ea4f5175d7..1d3a09e9b5 100644 --- a/interfaces/_libp2p_kad_dht.DialPeerEvent.html +++ b/interfaces/_libp2p_kad_dht.DialPeerEvent.html @@ -1,5 +1,5 @@ DialPeerEvent | libp2p

                                Interface DialPeerEvent

                                Emitted when peers are dialled as part of a query

                                -
                                interface DialPeerEvent {
                                    name: "DIAL_PEER";
                                    peer: PeerId;
                                    type: DIAL_PEER;
                                }

                                Properties

                                interface DialPeerEvent {
                                    name: "DIAL_PEER";
                                    peer: PeerId;
                                    type: DIAL_PEER;
                                }

                                Properties

                                Properties

                                name: "DIAL_PEER"
                                peer: PeerId
                                type: DIAL_PEER
                                \ No newline at end of file +

                                Properties

                                name: "DIAL_PEER"
                                peer: PeerId
                                type: DIAL_PEER
                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.FinalPeerEvent.html b/interfaces/_libp2p_kad_dht.FinalPeerEvent.html index c5bd365e0f..b12256a472 100644 --- a/interfaces/_libp2p_kad_dht.FinalPeerEvent.html +++ b/interfaces/_libp2p_kad_dht.FinalPeerEvent.html @@ -1,6 +1,6 @@ FinalPeerEvent | libp2p

                                Interface FinalPeerEvent

                                Emitted at the end of a findPeer query

                                -
                                interface FinalPeerEvent {
                                    from: PeerId;
                                    name: "FINAL_PEER";
                                    peer: PeerInfo;
                                    type: FINAL_PEER;
                                }

                                Properties

                                interface FinalPeerEvent {
                                    from: PeerId;
                                    name: "FINAL_PEER";
                                    peer: PeerInfo;
                                    type: FINAL_PEER;
                                }

                                Properties

                                Properties

                                from: PeerId
                                name: "FINAL_PEER"
                                peer: PeerInfo
                                \ No newline at end of file +

                                Properties

                                from: PeerId
                                name: "FINAL_PEER"
                                peer: PeerInfo
                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.KadDHT.html b/interfaces/_libp2p_kad_dht.KadDHT.html index 29c29bdb1a..9b7f6ea88a 100644 --- a/interfaces/_libp2p_kad_dht.KadDHT.html +++ b/interfaces/_libp2p_kad_dht.KadDHT.html @@ -1,4 +1,4 @@ -KadDHT | libp2p
                                interface KadDHT {
                                    findPeer(id, options?): AsyncIterable<QueryEvent>;
                                    findProviders(key, options?): AsyncIterable<QueryEvent>;
                                    get(key, options?): AsyncIterable<QueryEvent>;
                                    getClosestPeers(key, options?): AsyncIterable<QueryEvent>;
                                    getMode(): "client" | "server";
                                    provide(key, options?): AsyncIterable<QueryEvent>;
                                    put(key, value, options?): AsyncIterable<QueryEvent>;
                                    refreshRoutingTable(): Promise<void>;
                                    setMode(mode): Promise<void>;
                                }

                                Hierarchy (view full)

                                Methods

                                findPeer +KadDHT | libp2p
                                interface KadDHT {
                                    findPeer(id, options?): AsyncIterable<QueryEvent>;
                                    findProviders(key, options?): AsyncIterable<QueryEvent>;
                                    get(key, options?): AsyncIterable<QueryEvent>;
                                    getClosestPeers(key, options?): AsyncIterable<QueryEvent>;
                                    getMode(): "client" | "server";
                                    provide(key, options?): AsyncIterable<QueryEvent>;
                                    put(key, value, options?): AsyncIterable<QueryEvent>;
                                    refreshRoutingTable(): Promise<void>;
                                    setMode(mode): Promise<void>;
                                }

                                Hierarchy (view full)

                                Methods

                                • Returns the mode this node is in

                                  -

                                  Returns "client" | "server"

                                • Returns the mode this node is in

                                  +

                                  Returns "client" | "server"

                                • If 'server' this node will respond to DHT queries, if 'client' this node will not.

                                  -

                                  Parameters

                                  • mode: "client" | "server"

                                  Returns Promise<void>

                                \ No newline at end of file +

                                Parameters

                                • mode: "client" | "server"

                                Returns Promise<void>

                                \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.KadDHTComponents.html b/interfaces/_libp2p_kad_dht.KadDHTComponents.html index fa417019de..907803697c 100644 --- a/interfaces/_libp2p_kad_dht.KadDHTComponents.html +++ b/interfaces/_libp2p_kad_dht.KadDHTComponents.html @@ -1,4 +1,4 @@ -KadDHTComponents | libp2p

                                Interface KadDHTComponents

                                interface KadDHTComponents {
                                    addressManager: AddressManager;
                                    connectionManager: ConnectionManager;
                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    logger: ComponentLogger;
                                    metrics?: Metrics;
                                    peerId: PeerId;
                                    peerStore: PeerStore;
                                    privateKey: PrivateKey;
                                    registrar: Registrar;
                                }

                                Properties

                                addressManager +KadDHTComponents | libp2p

                                Interface KadDHTComponents

                                interface KadDHTComponents {
                                    addressManager: AddressManager;
                                    connectionManager: ConnectionManager;
                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                    logger: ComponentLogger;
                                    metrics?: Metrics;
                                    peerId: PeerId;
                                    peerStore: PeerStore;
                                    privateKey: PrivateKey;
                                    registrar: Registrar;
                                }

                                Properties

                                addressManager: AddressManager
                                connectionManager: ConnectionManager
                                datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                Type declaration

                                  Type declaration

                                    Type declaration

                                      Type declaration

                                        Type declaration

                                          Type declaration

                                            Type declaration

                                              Type declaration

                                                Type declaration

                                                  Type declaration

                                                    metrics?: Metrics
                                                    peerId: PeerId
                                                    peerStore: PeerStore
                                                    privateKey: PrivateKey
                                                    registrar: Registrar
                                                    \ No newline at end of file +

                                                    Properties

                                                    addressManager: AddressManager
                                                    connectionManager: ConnectionManager
                                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                    Type declaration

                                                      Type declaration

                                                        Type declaration

                                                          Type declaration

                                                            Type declaration

                                                              Type declaration

                                                                Type declaration

                                                                  Type declaration

                                                                    Type declaration

                                                                      Type declaration

                                                                        metrics?: Metrics
                                                                        peerId: PeerId
                                                                        peerStore: PeerStore
                                                                        privateKey: PrivateKey
                                                                        registrar: Registrar
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.KadDHTInit.html b/interfaces/_libp2p_kad_dht.KadDHTInit.html index cbf2268214..e00e264387 100644 --- a/interfaces/_libp2p_kad_dht.KadDHTInit.html +++ b/interfaces/_libp2p_kad_dht.KadDHTInit.html @@ -1,4 +1,4 @@ -KadDHTInit | libp2p
                                                                        interface KadDHTInit {
                                                                            allowQueryWithZeroPeers?: boolean;
                                                                            clientMode?: boolean;
                                                                            initialQuerySelfInterval?: number;
                                                                            kBucketSize?: number;
                                                                            kBucketSplitThreshold?: number;
                                                                            logPrefix?: string;
                                                                            maxInboundStreams?: number;
                                                                            maxOutboundStreams?: number;
                                                                            networkDialTimeout?: Omit<AdaptiveTimeoutInit, "metricsName" | "metrics">;
                                                                            pingConcurrency?: number;
                                                                            pingTimeout?: number;
                                                                            prefixLength?: number;
                                                                            protocol?: string;
                                                                            providers?: ProvidersInit;
                                                                            querySelfInterval?: number;
                                                                            selectors?: Selectors;
                                                                            validators?: Validators;
                                                                            peerInfoMapper?(peer): PeerInfo;
                                                                        }

                                                                        Properties

                                                                        allowQueryWithZeroPeers? +KadDHTInit | libp2p
                                                                        interface KadDHTInit {
                                                                            allowQueryWithZeroPeers?: boolean;
                                                                            clientMode?: boolean;
                                                                            initialQuerySelfInterval?: number;
                                                                            kBucketSize?: number;
                                                                            kBucketSplitThreshold?: number;
                                                                            logPrefix?: string;
                                                                            maxInboundStreams?: number;
                                                                            maxOutboundStreams?: number;
                                                                            networkDialTimeout?: Omit<AdaptiveTimeoutInit, "metricsName" | "metrics">;
                                                                            pingConcurrency?: number;
                                                                            pingTimeout?: number;
                                                                            prefixLength?: number;
                                                                            protocol?: string;
                                                                            providers?: ProvidersInit;
                                                                            querySelfInterval?: number;
                                                                            selectors?: Selectors;
                                                                            validators?: Validators;
                                                                            peerInfoMapper?(peer): PeerInfo;
                                                                        }

                                                                        Properties

                                                                        allowQueryWithZeroPeers? clientMode? initialQuerySelfInterval? kBucketSize? @@ -21,49 +21,49 @@

                                                                        Pass true here to disable this behaviour.

                                                                        Default

                                                                        false
                                                                         
                                                                        -
                                                                        clientMode?: boolean

                                                                        If true, only ever be a DHT client. If false, be a DHT client until told +

                                                                        clientMode?: boolean

                                                                        If true, only ever be a DHT client. If false, be a DHT client until told to be a DHT server via setMode.

                                                                        Default

                                                                        false
                                                                         
                                                                        -
                                                                        initialQuerySelfInterval?: number

                                                                        During startup we run the self-query at a shorter interval to ensure +

                                                                        initialQuerySelfInterval?: number

                                                                        During startup we run the self-query at a shorter interval to ensure the containing node can respond to queries quickly. Set this interval here in ms.

                                                                        Default

                                                                        1000
                                                                         
                                                                        -
                                                                        kBucketSize?: number

                                                                        How many peers to store in each kBucket. Once there are more than this +

                                                                        kBucketSize?: number

                                                                        How many peers to store in each kBucket. Once there are more than this number of peers for a given prefix in a kBucket, the node will start to ping existing peers to see if they are still online - if they are offline they will be evicted and the new peer added.

                                                                        Default

                                                                        20
                                                                         
                                                                        -
                                                                        kBucketSplitThreshold?: number

                                                                        The threshold at which a kBucket will be split into two smaller kBuckets.

                                                                        +
                                                                        kBucketSplitThreshold?: number

                                                                        The threshold at which a kBucket will be split into two smaller kBuckets.

                                                                        KBuckets will not be split once the maximum trie depth is reached (controlled by the prefixLength option) so one can replicate go-libp2p's accelerated DHT client by (for example) setting kBucketSize to Infinity and kBucketSplitThreshold to 20.

                                                                        Default

                                                                        kBucketSize
                                                                         
                                                                        -
                                                                        logPrefix?: string

                                                                        The logging prefix to use

                                                                        +
                                                                        logPrefix?: string

                                                                        The logging prefix to use

                                                                        Default

                                                                        "libp2p:kad-dht"
                                                                         
                                                                        -
                                                                        maxInboundStreams?: number

                                                                        How many parallel incoming streams to allow on the DHT protocol per +

                                                                        maxInboundStreams?: number

                                                                        How many parallel incoming streams to allow on the DHT protocol per connection

                                                                        Default

                                                                        32
                                                                         
                                                                        -
                                                                        maxOutboundStreams?: number

                                                                        How many parallel outgoing streams to allow on the DHT protocol per +

                                                                        maxOutboundStreams?: number

                                                                        How many parallel outgoing streams to allow on the DHT protocol per connection

                                                                        Default

                                                                        64
                                                                         
                                                                        -
                                                                        networkDialTimeout?: Omit<AdaptiveTimeoutInit, "metricsName" | "metrics">

                                                                        Dynamic network timeout settings for sending messages to peers

                                                                        -
                                                                        pingConcurrency?: number

                                                                        How many peers to ping in parallel when deciding if they should +

                                                                        networkDialTimeout?: Omit<AdaptiveTimeoutInit, "metricsName" | "metrics">

                                                                        Dynamic network timeout settings for sending messages to peers

                                                                        +
                                                                        pingConcurrency?: number

                                                                        How many peers to ping in parallel when deciding if they should be evicted from the routing table or not

                                                                        Default

                                                                        10
                                                                         
                                                                        -
                                                                        pingTimeout?: number

                                                                        How long to wait in ms when pinging DHT peers to decide if they +

                                                                        pingTimeout?: number

                                                                        How long to wait in ms when pinging DHT peers to decide if they should be evicted from the routing table or not.

                                                                        Default

                                                                        10000
                                                                         
                                                                        -
                                                                        prefixLength?: number

                                                                        How many bits of the KAD-ID of peers to use when creating the routing +

                                                                        prefixLength?: number

                                                                        How many bits of the KAD-ID of peers to use when creating the routing table.

                                                                        The routing table is a binary trie with peers stored in the leaf nodes. The larger this number gets, the taller the trie can grow and the more peers @@ -72,14 +72,14 @@ to locate a certain peer, but also that more memory is consumed.

                                                                        Default

                                                                        32
                                                                         
                                                                        -
                                                                        protocol?: string

                                                                        The network protocol to use

                                                                        +
                                                                        protocol?: string

                                                                        The network protocol to use

                                                                        Default

                                                                        "/ipfs/kad/1.0.0"
                                                                         
                                                                        -
                                                                        providers?: ProvidersInit

                                                                        Initialization options for the Providers component

                                                                        -
                                                                        querySelfInterval?: number

                                                                        How often to query our own PeerId in order to ensure we have a +

                                                                        providers?: ProvidersInit

                                                                        Initialization options for the Providers component

                                                                        +
                                                                        querySelfInterval?: number

                                                                        How often to query our own PeerId in order to ensure we have a good view on the KAD address space local to our PeerId

                                                                        -
                                                                        selectors?: Selectors

                                                                        Record selectors

                                                                        -
                                                                        validators?: Validators

                                                                        Record validators

                                                                        -

                                                                        Methods

                                                                        selectors?: Selectors

                                                                        Record selectors

                                                                        +
                                                                        validators?: Validators

                                                                        Record validators

                                                                        +

                                                                        Methods

                                                                        \ No newline at end of file +

                                                                        Parameters

                                                                        Returns PeerInfo

                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.PeerInfoMapper.html b/interfaces/_libp2p_kad_dht.PeerInfoMapper.html index 86b1bfa0b9..bd2220d2a0 100644 --- a/interfaces/_libp2p_kad_dht.PeerInfoMapper.html +++ b/interfaces/_libp2p_kad_dht.PeerInfoMapper.html @@ -1 +1 @@ -PeerInfoMapper | libp2p

                                                                        Interface PeerInfoMapper

                                                                        interface PeerInfoMapper ((peer) => PeerInfo)
                                                                        \ No newline at end of file +PeerInfoMapper | libp2p

                                                                        Interface PeerInfoMapper

                                                                        interface PeerInfoMapper ((peer) => PeerInfo)
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.PeerResponseEvent.html b/interfaces/_libp2p_kad_dht.PeerResponseEvent.html index ce12c4bc4c..648329357f 100644 --- a/interfaces/_libp2p_kad_dht.PeerResponseEvent.html +++ b/interfaces/_libp2p_kad_dht.PeerResponseEvent.html @@ -1,6 +1,6 @@ PeerResponseEvent | libp2p

                                                                        Interface PeerResponseEvent

                                                                        Emitted when query responses are received form remote peers. Depending on the query these events may be followed by a FinalPeerEvent, a ValueEvent or a ProviderEvent.

                                                                        -
                                                                        interface PeerResponseEvent {
                                                                            closer: PeerInfo[];
                                                                            from: PeerId;
                                                                            messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec";
                                                                            messageType: MessageType;
                                                                            name: "PEER_RESPONSE";
                                                                            providers: PeerInfo[];
                                                                            record?: DHTRecord;
                                                                            type: PEER_RESPONSE;
                                                                        }

                                                                        Properties

                                                                        interface PeerResponseEvent {
                                                                            closer: PeerInfo[];
                                                                            from: PeerId;
                                                                            messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec";
                                                                            messageType: MessageType;
                                                                            name: "PEER_RESPONSE";
                                                                            providers: PeerInfo[];
                                                                            record?: DHTRecord;
                                                                            type: PEER_RESPONSE;
                                                                        }

                                                                        Properties

                                                                        closer: PeerInfo[]
                                                                        from: PeerId
                                                                        messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec"
                                                                        messageType: MessageType
                                                                        name: "PEER_RESPONSE"
                                                                        providers: PeerInfo[]
                                                                        record?: DHTRecord
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        closer: PeerInfo[]
                                                                        from: PeerId
                                                                        messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec"
                                                                        messageType: MessageType
                                                                        name: "PEER_RESPONSE"
                                                                        providers: PeerInfo[]
                                                                        record?: DHTRecord
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.ProviderEvent.html b/interfaces/_libp2p_kad_dht.ProviderEvent.html index ad1ca0d6d1..cf7f598175 100644 --- a/interfaces/_libp2p_kad_dht.ProviderEvent.html +++ b/interfaces/_libp2p_kad_dht.ProviderEvent.html @@ -1,6 +1,6 @@ ProviderEvent | libp2p

                                                                        Interface ProviderEvent

                                                                        Emitted when providers are found

                                                                        -
                                                                        interface ProviderEvent {
                                                                            from: PeerId;
                                                                            name: "PROVIDER";
                                                                            providers: PeerInfo[];
                                                                            type: PROVIDER;
                                                                        }

                                                                        Properties

                                                                        interface ProviderEvent {
                                                                            from: PeerId;
                                                                            name: "PROVIDER";
                                                                            providers: PeerInfo[];
                                                                            type: PROVIDER;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        from: PeerId
                                                                        name: "PROVIDER"
                                                                        providers: PeerInfo[]
                                                                        type: PROVIDER
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        from: PeerId
                                                                        name: "PROVIDER"
                                                                        providers: PeerInfo[]
                                                                        type: PROVIDER
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.QueryErrorEvent.html b/interfaces/_libp2p_kad_dht.QueryErrorEvent.html index bb9476d3aa..99e75d83e9 100644 --- a/interfaces/_libp2p_kad_dht.QueryErrorEvent.html +++ b/interfaces/_libp2p_kad_dht.QueryErrorEvent.html @@ -1,6 +1,6 @@ QueryErrorEvent | libp2p

                                                                        Interface QueryErrorEvent

                                                                        Something went wrong with the query

                                                                        -
                                                                        interface QueryErrorEvent {
                                                                            error: Error;
                                                                            from: PeerId;
                                                                            name: "QUERY_ERROR";
                                                                            type: QUERY_ERROR;
                                                                        }

                                                                        Properties

                                                                        interface QueryErrorEvent {
                                                                            error: Error;
                                                                            from: PeerId;
                                                                            name: "QUERY_ERROR";
                                                                            type: QUERY_ERROR;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        error: Error
                                                                        from: PeerId
                                                                        name: "QUERY_ERROR"
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        error: Error
                                                                        from: PeerId
                                                                        name: "QUERY_ERROR"
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.RoutingTable.html b/interfaces/_libp2p_kad_dht.RoutingTable.html index b231a11a9a..4c306d50a0 100644 --- a/interfaces/_libp2p_kad_dht.RoutingTable.html +++ b/interfaces/_libp2p_kad_dht.RoutingTable.html @@ -1,2 +1,2 @@ -RoutingTable | libp2p

                                                                        Interface RoutingTable

                                                                        interface RoutingTable {
                                                                            size: number;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        size: number
                                                                        \ No newline at end of file +RoutingTable | libp2p

                                                                        Interface RoutingTable

                                                                        interface RoutingTable {
                                                                            size: number;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        size: number
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.SelectFn.html b/interfaces/_libp2p_kad_dht.SelectFn.html index 2deebb1a80..87c54c84bb 100644 --- a/interfaces/_libp2p_kad_dht.SelectFn.html +++ b/interfaces/_libp2p_kad_dht.SelectFn.html @@ -1,3 +1,3 @@ SelectFn | libp2p

                                                                        A selector function takes a DHT key and a list of records and returns the index of the best record in the list

                                                                        -
                                                                        interface SelectFn ((key, records) => number)
                                                                        \ No newline at end of file +
                                                                        interface SelectFn ((key, records) => number)
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.SendQueryEvent.html b/interfaces/_libp2p_kad_dht.SendQueryEvent.html index 625124096a..4a9b1affbb 100644 --- a/interfaces/_libp2p_kad_dht.SendQueryEvent.html +++ b/interfaces/_libp2p_kad_dht.SendQueryEvent.html @@ -1,7 +1,7 @@ SendQueryEvent | libp2p

                                                                        Interface SendQueryEvent

                                                                        Emitted when sending queries to remote peers

                                                                        -
                                                                        interface SendQueryEvent {
                                                                            messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec";
                                                                            messageType: MessageType;
                                                                            name: "SEND_QUERY";
                                                                            to: PeerId;
                                                                            type: SEND_QUERY;
                                                                        }

                                                                        Properties

                                                                        interface SendQueryEvent {
                                                                            messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec";
                                                                            messageType: MessageType;
                                                                            name: "SEND_QUERY";
                                                                            to: PeerId;
                                                                            type: SEND_QUERY;
                                                                        }

                                                                        Properties

                                                                        messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec"
                                                                        messageType: MessageType
                                                                        name: "SEND_QUERY"
                                                                        to: PeerId
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        messageName: "PUT_VALUE" | "GET_VALUE" | "ADD_PROVIDER" | "GET_PROVIDERS" | "FIND_NODE" | "PING" | "codec"
                                                                        messageType: MessageType
                                                                        name: "SEND_QUERY"
                                                                        to: PeerId
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.SingleKadDHT.html b/interfaces/_libp2p_kad_dht.SingleKadDHT.html index e29c701eb8..a429e0ff04 100644 --- a/interfaces/_libp2p_kad_dht.SingleKadDHT.html +++ b/interfaces/_libp2p_kad_dht.SingleKadDHT.html @@ -1,4 +1,4 @@ -SingleKadDHT | libp2p

                                                                        Interface SingleKadDHT

                                                                        interface SingleKadDHT {
                                                                            routingTable: RoutingTable;
                                                                            findPeer(id, options?): AsyncIterable<QueryEvent>;
                                                                            findProviders(key, options?): AsyncIterable<QueryEvent>;
                                                                            get(key, options?): AsyncIterable<QueryEvent>;
                                                                            getClosestPeers(key, options?): AsyncIterable<QueryEvent>;
                                                                            getMode(): "client" | "server";
                                                                            provide(key, options?): AsyncIterable<QueryEvent>;
                                                                            put(key, value, options?): AsyncIterable<QueryEvent>;
                                                                            refreshRoutingTable(): Promise<void>;
                                                                            setMode(mode): Promise<void>;
                                                                        }

                                                                        Hierarchy (view full)

                                                                        Properties

                                                                        routingTable +SingleKadDHT | libp2p

                                                                        Interface SingleKadDHT

                                                                        interface SingleKadDHT {
                                                                            routingTable: RoutingTable;
                                                                            findPeer(id, options?): AsyncIterable<QueryEvent>;
                                                                            findProviders(key, options?): AsyncIterable<QueryEvent>;
                                                                            get(key, options?): AsyncIterable<QueryEvent>;
                                                                            getClosestPeers(key, options?): AsyncIterable<QueryEvent>;
                                                                            getMode(): "client" | "server";
                                                                            provide(key, options?): AsyncIterable<QueryEvent>;
                                                                            put(key, value, options?): AsyncIterable<QueryEvent>;
                                                                            refreshRoutingTable(): Promise<void>;
                                                                            setMode(mode): Promise<void>;
                                                                        }

                                                                        Hierarchy (view full)

                                                                        Properties

                                                                        routingTable: RoutingTable

                                                                        Methods

                                                                        • If 'server' this node will respond to DHT queries, if 'client' this node +

                                                                        Properties

                                                                        routingTable: RoutingTable

                                                                        Methods

                                                                        \ No newline at end of file +

                                                                        Parameters

                                                                        • mode: "client" | "server"

                                                                        Returns Promise<void>

                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.ValidateFn.html b/interfaces/_libp2p_kad_dht.ValidateFn.html index 9bb51f7dbe..44d577dcee 100644 --- a/interfaces/_libp2p_kad_dht.ValidateFn.html +++ b/interfaces/_libp2p_kad_dht.ValidateFn.html @@ -1,3 +1,3 @@ ValidateFn | libp2p

                                                                        A validator function takes a DHT key and the value of the record for that key and throws if the record is invalid

                                                                        -
                                                                        interface ValidateFn ((key, value) => Promise<void>)
                                                                        \ No newline at end of file +
                                                                        interface ValidateFn ((key, value) => Promise<void>)
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_kad_dht.ValueEvent.html b/interfaces/_libp2p_kad_dht.ValueEvent.html index 147762dbad..6b99a401cf 100644 --- a/interfaces/_libp2p_kad_dht.ValueEvent.html +++ b/interfaces/_libp2p_kad_dht.ValueEvent.html @@ -1,6 +1,6 @@ ValueEvent | libp2p

                                                                        Emitted when values are found

                                                                        -
                                                                        interface ValueEvent {
                                                                            from: PeerId;
                                                                            name: "VALUE";
                                                                            type: VALUE;
                                                                            value: Uint8Array;
                                                                        }

                                                                        Properties

                                                                        interface ValueEvent {
                                                                            from: PeerId;
                                                                            name: "VALUE";
                                                                            type: VALUE;
                                                                            value: Uint8Array;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        from: PeerId
                                                                        name: "VALUE"
                                                                        type: VALUE
                                                                        value: Uint8Array
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        from: PeerId
                                                                        name: "VALUE"
                                                                        type: VALUE
                                                                        value: Uint8Array
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_keychain.DEKConfig.html b/interfaces/_libp2p_keychain.DEKConfig.html index e38475ea74..421e2f12a7 100644 --- a/interfaces/_libp2p_keychain.DEKConfig.html +++ b/interfaces/_libp2p_keychain.DEKConfig.html @@ -1,5 +1,5 @@ -DEKConfig | libp2p
                                                                        interface DEKConfig {
                                                                            hash: string;
                                                                            iterationCount: number;
                                                                            keyLength: number;
                                                                            salt: string;
                                                                        }

                                                                        Properties

                                                                        hash +DEKConfig | libp2p
                                                                        interface DEKConfig {
                                                                            hash: string;
                                                                            iterationCount: number;
                                                                            keyLength: number;
                                                                            salt: string;
                                                                        }

                                                                        Properties

                                                                        hash: string
                                                                        iterationCount: number
                                                                        keyLength: number
                                                                        salt: string
                                                                        \ No newline at end of file +

                                                                        Properties

                                                                        hash: string
                                                                        iterationCount: number
                                                                        keyLength: number
                                                                        salt: string
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_keychain.KeyInfo.html b/interfaces/_libp2p_keychain.KeyInfo.html index 7bb7d70dd9..fe960419c2 100644 --- a/interfaces/_libp2p_keychain.KeyInfo.html +++ b/interfaces/_libp2p_keychain.KeyInfo.html @@ -1,5 +1,5 @@ -KeyInfo | libp2p
                                                                        interface KeyInfo {
                                                                            id: string;
                                                                            name: string;
                                                                        }

                                                                        Properties

                                                                        id +KeyInfo | libp2p
                                                                        interface KeyInfo {
                                                                            id: string;
                                                                            name: string;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        id: string

                                                                        The universally unique key id

                                                                        -
                                                                        name: string

                                                                        The local key name

                                                                        -
                                                                        \ No newline at end of file +
                                                                        name: string

                                                                        The local key name

                                                                        +
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_keychain.Keychain.html b/interfaces/_libp2p_keychain.Keychain.html index 9eb238798a..8ee29fe1a0 100644 --- a/interfaces/_libp2p_keychain.Keychain.html +++ b/interfaces/_libp2p_keychain.Keychain.html @@ -1,4 +1,4 @@ -Keychain | libp2p
                                                                        interface Keychain {
                                                                            exportKey(name): Promise<PrivateKey>;
                                                                            findKeyById(id): Promise<KeyInfo>;
                                                                            findKeyByName(name): Promise<KeyInfo>;
                                                                            importKey(name, key): Promise<KeyInfo>;
                                                                            listKeys(): Promise<KeyInfo[]>;
                                                                            removeKey(name): Promise<KeyInfo>;
                                                                            renameKey(oldName, newName): Promise<KeyInfo>;
                                                                            rotateKeychainPass(oldPass, newPass): Promise<void>;
                                                                        }

                                                                        Methods

                                                                        exportKey +Keychain | libp2p
                                                                        interface Keychain {
                                                                            exportKey(name): Promise<PrivateKey>;
                                                                            findKeyById(id): Promise<KeyInfo>;
                                                                            findKeyByName(name): Promise<KeyInfo>;
                                                                            importKey(name, key): Promise<KeyInfo>;
                                                                            listKeys(): Promise<KeyInfo[]>;
                                                                            removeKey(name): Promise<KeyInfo>;
                                                                            renameKey(oldName, newName): Promise<KeyInfo>;
                                                                            rotateKeychainPass(oldPass, newPass): Promise<void>;
                                                                        }

                                                                        Methods

                                                                        Methods

                                                                        • Export an existing private key.

                                                                          Parameters

                                                                          • name: string

                                                                          Returns Promise<PrivateKey>

                                                                          Example

                                                                          import { generateKeyPair } from '@libp2p/crypto/keys'

                                                                          const key = await generateKeyPair('Ed25519')
                                                                          const keyInfo = await libp2p.keychain.importKey('my-key', key)
                                                                          const key = await libp2p.keychain.exportKey(keyInfo.id)
                                                                          -
                                                                        • Find a key by id

                                                                          Parameters

                                                                          • id: string

                                                                          Returns Promise<KeyInfo>

                                                                          Example

                                                                          import { generateKeyPair } from '@libp2p/crypto/keys'

                                                                          const key = await generateKeyPair('Ed25519')
                                                                          const keyInfo = await libp2p.keychain.importKey('my-key', key)
                                                                          const keyInfo2 = await libp2p.keychain.findKeyById(keyInfo.id)
                                                                          -
                                                                        • Find a key by name

                                                                          Parameters

                                                                          • name: string

                                                                          Returns Promise<KeyInfo>

                                                                          Example

                                                                          import { generateKeyPair } from '@libp2p/crypto/keys'

                                                                          const key = await generateKeyPair('Ed25519')
                                                                          const keyInfo = await libp2p.keychain.importKey('my-key', key)
                                                                          const keyInfo2 = await libp2p.keychain.findKeyByName(keyInfo.name)
                                                                          -
                                                                        • Import a new private key.

                                                                          Parameters

                                                                          Returns Promise<KeyInfo>

                                                                          Example

                                                                          import { generateKeyPair } from '@libp2p/crypto/keys'

                                                                          const key = await generateKeyPair('Ed25519')
                                                                          const keyInfo = await libp2p.keychain.importKey('my-key', key)
                                                                          -
                                                                        • Removes a key from the keychain.

                                                                          Parameters

                                                                          • name: string

                                                                          Returns Promise<KeyInfo>

                                                                          Example

                                                                          await libp2p.services.keychain.createKey('keyTest', 'RSA', 4096)
                                                                          const keyInfo = await libp2p.services.keychain.removeKey('keyTest')
                                                                          -
                                                                        • Rename a key in the keychain. This is done in a batch commit with rollback +

                                                                        • Rename a key in the keychain. This is done in a batch commit with rollback so errors thrown during the operation will not cause key loss.

                                                                          Parameters

                                                                          • oldName: string
                                                                          • newName: string

                                                                          Returns Promise<KeyInfo>

                                                                          Example

                                                                          await libp2p.services.keychain.createKey('keyTest', 'RSA', 4096)
                                                                          const keyInfo = await libp2p.services.keychain.renameKey('keyTest', 'keyNewNtest')
                                                                          -
                                                                        • Rotate keychain password and re-encrypt all associated keys

                                                                          +
                                                                        • Rotate keychain password and re-encrypt all associated keys

                                                                          Parameters

                                                                          • oldPass: string
                                                                          • newPass: string

                                                                          Returns Promise<void>

                                                                          Example

                                                                          await libp2p.services.keychain.rotateKeychainPass('oldPassword', 'newPassword')
                                                                           
                                                                          -
                                                                        \ No newline at end of file +
                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_keychain.KeychainComponents.html b/interfaces/_libp2p_keychain.KeychainComponents.html index 718dbe8590..e70e3d0f50 100644 --- a/interfaces/_libp2p_keychain.KeychainComponents.html +++ b/interfaces/_libp2p_keychain.KeychainComponents.html @@ -1,3 +1,3 @@ -KeychainComponents | libp2p

                                                                        Interface KeychainComponents

                                                                        interface KeychainComponents {
                                                                            datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                            logger: ComponentLogger;
                                                                        }

                                                                        Properties

                                                                        datastore +KeychainComponents | libp2p

                                                                        Interface KeychainComponents

                                                                        interface KeychainComponents {
                                                                            datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                            logger: ComponentLogger;
                                                                        }

                                                                        Properties

                                                                        Properties

                                                                        datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                        Type declaration

                                                                          Type declaration

                                                                            Type declaration

                                                                              Type declaration

                                                                                Type declaration

                                                                                  Type declaration

                                                                                    Type declaration

                                                                                      Type declaration

                                                                                        Type declaration

                                                                                          Type declaration

                                                                                            \ No newline at end of file +

                                                                                            Properties

                                                                                            datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                                            Type declaration

                                                                                              Type declaration

                                                                                                Type declaration

                                                                                                  Type declaration

                                                                                                    Type declaration

                                                                                                      Type declaration

                                                                                                        Type declaration

                                                                                                          Type declaration

                                                                                                            Type declaration

                                                                                                              Type declaration

                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_keychain.KeychainInit.html b/interfaces/_libp2p_keychain.KeychainInit.html index 260d40a601..9969472676 100644 --- a/interfaces/_libp2p_keychain.KeychainInit.html +++ b/interfaces/_libp2p_keychain.KeychainInit.html @@ -1,3 +1,3 @@ -KeychainInit | libp2p
                                                                                                                interface KeychainInit {
                                                                                                                    dek?: DEKConfig;
                                                                                                                    pass?: string;
                                                                                                                }

                                                                                                                Properties

                                                                                                                dek? +KeychainInit | libp2p
                                                                                                                interface KeychainInit {
                                                                                                                    dek?: DEKConfig;
                                                                                                                    pass?: string;
                                                                                                                }

                                                                                                                Properties

                                                                                                                Properties

                                                                                                                dek?: DEKConfig
                                                                                                                pass?: string
                                                                                                                \ No newline at end of file +

                                                                                                                Properties

                                                                                                                dek?: DEKConfig
                                                                                                                pass?: string
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_logger.ComponentLogger.html b/interfaces/_libp2p_logger.ComponentLogger.html index 42b9091d2e..d1fa695bd6 100644 --- a/interfaces/_libp2p_logger.ComponentLogger.html +++ b/interfaces/_libp2p_logger.ComponentLogger.html @@ -1,2 +1,2 @@ -ComponentLogger | libp2p

                                                                                                                Interface ComponentLogger

                                                                                                                interface ComponentLogger {
                                                                                                                    forComponent(name): Logger;
                                                                                                                }

                                                                                                                Methods

                                                                                                                Methods

                                                                                                                \ No newline at end of file +ComponentLogger | libp2p

                                                                                                                Interface ComponentLogger

                                                                                                                interface ComponentLogger {
                                                                                                                    forComponent(name): Logger;
                                                                                                                }

                                                                                                                Methods

                                                                                                                Methods

                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_logger.Logger.html b/interfaces/_libp2p_logger.Logger.html index 0d9245cb16..71a5084925 100644 --- a/interfaces/_libp2p_logger.Logger.html +++ b/interfaces/_libp2p_logger.Logger.html @@ -1,4 +1,4 @@ -Logger | libp2p
                                                                                                                interface Logger {
                                                                                                                    enabled: boolean;
                                                                                                                    error(formatter, ...args): void;
                                                                                                                    trace(formatter, ...args): void;
                                                                                                                    (formatter, ...args): void;
                                                                                                                }
                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                Properties

                                                                                                                enabled +Logger | libp2p
                                                                                                                interface Logger {
                                                                                                                    enabled: boolean;
                                                                                                                    error(formatter, ...args): void;
                                                                                                                    trace(formatter, ...args): void;
                                                                                                                    (formatter, ...args): void;
                                                                                                                }
                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                Properties

                                                                                                                Methods

                                                                                                                Properties

                                                                                                                enabled: boolean

                                                                                                                Methods

                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                \ No newline at end of file +

                                                                                                                Properties

                                                                                                                enabled: boolean

                                                                                                                Methods

                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                • Parameters

                                                                                                                  • formatter: any
                                                                                                                  • Rest ...args: any[]

                                                                                                                  Returns void

                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_logger.PeerLoggerOptions.html b/interfaces/_libp2p_logger.PeerLoggerOptions.html index 272fb23b11..6072ec5010 100644 --- a/interfaces/_libp2p_logger.PeerLoggerOptions.html +++ b/interfaces/_libp2p_logger.PeerLoggerOptions.html @@ -1,3 +1,3 @@ -PeerLoggerOptions | libp2p

                                                                                                                Interface PeerLoggerOptions

                                                                                                                interface PeerLoggerOptions {
                                                                                                                    prefixLength: number;
                                                                                                                    suffixLength: number;
                                                                                                                }

                                                                                                                Properties

                                                                                                                prefixLength +PeerLoggerOptions | libp2p

                                                                                                                Interface PeerLoggerOptions

                                                                                                                interface PeerLoggerOptions {
                                                                                                                    prefixLength: number;
                                                                                                                    suffixLength: number;
                                                                                                                }

                                                                                                                Properties

                                                                                                                prefixLength: number
                                                                                                                suffixLength: number
                                                                                                                \ No newline at end of file +

                                                                                                                Properties

                                                                                                                prefixLength: number
                                                                                                                suffixLength: number
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_mplex.MplexInit.html b/interfaces/_libp2p_mplex.MplexInit.html index 5e97739ea6..a8c5e5a235 100644 --- a/interfaces/_libp2p_mplex.MplexInit.html +++ b/interfaces/_libp2p_mplex.MplexInit.html @@ -1,4 +1,4 @@ -MplexInit | libp2p

                                                                                                                Interface MplexInit

                                                                                                                interface MplexInit {
                                                                                                                    disconnectThreshold?: number;
                                                                                                                    maxInboundStreams?: number;
                                                                                                                    maxMsgSize?: number;
                                                                                                                    maxOutboundStreams?: number;
                                                                                                                    maxStreamBufferSize?: number;
                                                                                                                    maxUnprocessedMessageQueueSize?: number;
                                                                                                                }

                                                                                                                Properties

                                                                                                                disconnectThreshold? +MplexInit | libp2p

                                                                                                                Interface MplexInit

                                                                                                                interface MplexInit {
                                                                                                                    disconnectThreshold?: number;
                                                                                                                    maxInboundStreams?: number;
                                                                                                                    maxMsgSize?: number;
                                                                                                                    maxOutboundStreams?: number;
                                                                                                                    maxStreamBufferSize?: number;
                                                                                                                    maxUnprocessedMessageQueueSize?: number;
                                                                                                                }

                                                                                                                Properties

                                                                                                                disconnectThreshold?: number

                                                                                                                When maxInboundStreams is hit, if the remote continues try to open more than this many new multiplexed streams per second the connection will be closed (default: 5)

                                                                                                                -
                                                                                                                maxInboundStreams?: number

                                                                                                                The maximum number of multiplexed streams that can be open at any +

                                                                                                                maxInboundStreams?: number

                                                                                                                The maximum number of multiplexed streams that can be open at any one time. A request to open more than this will have a stream reset message sent immediately as a response for the newly opened stream id (default: 1024)

                                                                                                                -
                                                                                                                maxMsgSize?: number

                                                                                                                The maximum size of message that can be sent in one go in bytes. +

                                                                                                                maxMsgSize?: number

                                                                                                                The maximum size of message that can be sent in one go in bytes. Messages larger than this will be split into multiple smaller messages. If we receive a message larger than this an error will be thrown and the connection closed. (default: 1MB)

                                                                                                                -
                                                                                                                maxOutboundStreams?: number

                                                                                                                The maximum number of multiplexed streams that can be open at any +

                                                                                                                maxOutboundStreams?: number

                                                                                                                The maximum number of multiplexed streams that can be open at any one time. An attempt to open more than this will throw (default: 1024)

                                                                                                                -
                                                                                                                maxStreamBufferSize?: number

                                                                                                                Incoming stream messages are buffered until processed by the stream +

                                                                                                                maxStreamBufferSize?: number

                                                                                                                Incoming stream messages are buffered until processed by the stream handler. If the buffer reaches this size in bytes the stream will be reset (default: 4MB)

                                                                                                                -
                                                                                                                maxUnprocessedMessageQueueSize?: number

                                                                                                                Constrains the size of the unprocessed message queue buffer. +

                                                                                                                maxUnprocessedMessageQueueSize?: number

                                                                                                                Constrains the size of the unprocessed message queue buffer. Before messages are deserialized, the raw bytes are buffered to ensure we have the complete message to deserialized. If the queue gets longer than this value an error will be thrown and the connection closed. (default: 4MB)

                                                                                                                -
                                                                                                                \ No newline at end of file +
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_multistream_select.MultistreamSelectInit.html b/interfaces/_libp2p_multistream_select.MultistreamSelectInit.html index 80f8636c36..e9cf5ecda5 100644 --- a/interfaces/_libp2p_multistream_select.MultistreamSelectInit.html +++ b/interfaces/_libp2p_multistream_select.MultistreamSelectInit.html @@ -2,7 +2,7 @@ the optional signal property.

                                                                                                                Example

                                                                                                                const controller = new AbortController()

                                                                                                                aLongRunningOperation({
                                                                                                                signal: controller.signal
                                                                                                                })

                                                                                                                // later

                                                                                                                controller.abort()
                                                                                                                -
                                                                                                                interface MultistreamSelectInit {
                                                                                                                    log: Logger;
                                                                                                                    maxDataLength?: number;
                                                                                                                    maxLengthLength?: number;
                                                                                                                    negotiateFully?: boolean;
                                                                                                                    signal?: AbortSignal;
                                                                                                                    yieldBytes?: boolean;
                                                                                                                    lengthDecoder?(data): number;
                                                                                                                    lengthEncoder?(value): Uint8Array | Uint8ArrayList;
                                                                                                                }

                                                                                                                Hierarchy (view full)

                                                                                                                Properties

                                                                                                                log +
                                                                                                                interface MultistreamSelectInit {
                                                                                                                    log: Logger;
                                                                                                                    maxDataLength?: number;
                                                                                                                    maxLengthLength?: number;
                                                                                                                    negotiateFully?: boolean;
                                                                                                                    signal?: AbortSignal;
                                                                                                                    yieldBytes?: boolean;
                                                                                                                    lengthDecoder?(data): number;
                                                                                                                    lengthEncoder?(value): Uint8Array | Uint8ArrayList;
                                                                                                                }

                                                                                                                Hierarchy (view full)

                                                                                                                Properties

                                                                                                                log maxDataLength? maxLengthLength? negotiateFully? @@ -15,7 +15,7 @@ initial message, saving a round trip for connection establishment.

                                                                                                                Default

                                                                                                                true
                                                                                                                 
                                                                                                                -
                                                                                                                signal?: AbortSignal
                                                                                                                yieldBytes?: boolean

                                                                                                                After the stream is unwrapped, any bytes that have been read from the +

                                                                                                                signal?: AbortSignal
                                                                                                                yieldBytes?: boolean

                                                                                                                After the stream is unwrapped, any bytes that have been read from the incoming stream will be yielded in-order as Uint8Array(s).

                                                                                                                To yield a single Uint8ArrayList with all unread bytes instead, pass false here.

                                                                                                                diff --git a/interfaces/_libp2p_multistream_select.ProtocolStream.html b/interfaces/_libp2p_multistream_select.ProtocolStream.html index d61befa4cc..8e8873d05b 100644 --- a/interfaces/_libp2p_multistream_select.ProtocolStream.html +++ b/interfaces/_libp2p_multistream_select.ProtocolStream.html @@ -1,3 +1,3 @@ -ProtocolStream | libp2p

                                                                                                                Interface ProtocolStream<Stream>

                                                                                                                interface ProtocolStream<Stream> {
                                                                                                                    protocol: string;
                                                                                                                    stream: Stream;
                                                                                                                }

                                                                                                                Type Parameters

                                                                                                                • Stream

                                                                                                                Properties

                                                                                                                protocol +ProtocolStream | libp2p

                                                                                                                Interface ProtocolStream<Stream>

                                                                                                                interface ProtocolStream<Stream> {
                                                                                                                    protocol: string;
                                                                                                                    stream: Stream;
                                                                                                                }

                                                                                                                Type Parameters

                                                                                                                • Stream

                                                                                                                Properties

                                                                                                                Properties

                                                                                                                protocol: string
                                                                                                                stream: Stream
                                                                                                                \ No newline at end of file +

                                                                                                                Properties

                                                                                                                protocol: string
                                                                                                                stream: Stream
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_peer_record.PeerRecordInit.html b/interfaces/_libp2p_peer_record.PeerRecordInit.html index 69f4de24d7..54b2271f0e 100644 --- a/interfaces/_libp2p_peer_record.PeerRecordInit.html +++ b/interfaces/_libp2p_peer_record.PeerRecordInit.html @@ -1,6 +1,6 @@ -PeerRecordInit | libp2p
                                                                                                                interface PeerRecordInit {
                                                                                                                    multiaddrs?: Multiaddr[];
                                                                                                                    peerId: PeerId;
                                                                                                                    seqNumber?: bigint;
                                                                                                                }

                                                                                                                Properties

                                                                                                                multiaddrs? +PeerRecordInit | libp2p
                                                                                                                interface PeerRecordInit {
                                                                                                                    multiaddrs?: Multiaddr[];
                                                                                                                    peerId: PeerId;
                                                                                                                    seqNumber?: bigint;
                                                                                                                }

                                                                                                                Properties

                                                                                                                multiaddrs?: Multiaddr[]

                                                                                                                Addresses of the associated peer.

                                                                                                                -
                                                                                                                peerId: PeerId
                                                                                                                seqNumber?: bigint

                                                                                                                Monotonically-increasing sequence counter that's used to order PeerRecords in time.

                                                                                                                -
                                                                                                                \ No newline at end of file +
                                                                                                                peerId: PeerId
                                                                                                                seqNumber?: bigint

                                                                                                                Monotonically-increasing sequence counter that's used to order PeerRecords in time.

                                                                                                                +
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_peer_record.RecordEnvelopeInit.html b/interfaces/_libp2p_peer_record.RecordEnvelopeInit.html index 4f5837cf1b..a267b5c1ee 100644 --- a/interfaces/_libp2p_peer_record.RecordEnvelopeInit.html +++ b/interfaces/_libp2p_peer_record.RecordEnvelopeInit.html @@ -1,5 +1,5 @@ -RecordEnvelopeInit | libp2p
                                                                                                                interface RecordEnvelopeInit {
                                                                                                                    payload: Uint8Array;
                                                                                                                    payloadType: Uint8Array;
                                                                                                                    publicKey: PublicKey;
                                                                                                                    signature: Uint8Array;
                                                                                                                }

                                                                                                                Properties

                                                                                                                payload +RecordEnvelopeInit | libp2p
                                                                                                                interface RecordEnvelopeInit {
                                                                                                                    payload: Uint8Array;
                                                                                                                    payloadType: Uint8Array;
                                                                                                                    publicKey: PublicKey;
                                                                                                                    signature: Uint8Array;
                                                                                                                }

                                                                                                                Properties

                                                                                                                payload: Uint8Array
                                                                                                                payloadType: Uint8Array
                                                                                                                publicKey: PublicKey
                                                                                                                signature: Uint8Array
                                                                                                                \ No newline at end of file +

                                                                                                                Properties

                                                                                                                payload: Uint8Array
                                                                                                                payloadType: Uint8Array
                                                                                                                publicKey: PublicKey
                                                                                                                signature: Uint8Array
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_peer_store.AddressFilter.html b/interfaces/_libp2p_peer_store.AddressFilter.html index 08215d1c85..2d218bd47e 100644 --- a/interfaces/_libp2p_peer_store.AddressFilter.html +++ b/interfaces/_libp2p_peer_store.AddressFilter.html @@ -1,2 +1,2 @@ AddressFilter | libp2p

                                                                                                                Return true to allow storing the passed multiaddr for the passed peer

                                                                                                                -
                                                                                                                interface AddressFilter ((peerId, multiaddr) => boolean | Promise<boolean>)
                                                                                                                \ No newline at end of file +
                                                                                                                interface AddressFilter ((peerId, multiaddr) => boolean | Promise<boolean>)
                                                                                                                \ No newline at end of file diff --git a/interfaces/_libp2p_peer_store.PersistentPeerStoreComponents.html b/interfaces/_libp2p_peer_store.PersistentPeerStoreComponents.html index 36112142d3..cf99dbb41f 100644 --- a/interfaces/_libp2p_peer_store.PersistentPeerStoreComponents.html +++ b/interfaces/_libp2p_peer_store.PersistentPeerStoreComponents.html @@ -1,5 +1,5 @@ -PersistentPeerStoreComponents | libp2p

                                                                                                                Interface PersistentPeerStoreComponents

                                                                                                                interface PersistentPeerStoreComponents {
                                                                                                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                                                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                                                                                                    logger: ComponentLogger;
                                                                                                                    peerId: PeerId;
                                                                                                                }

                                                                                                                Properties

                                                                                                                datastore +PersistentPeerStoreComponents | libp2p

                                                                                                                Interface PersistentPeerStoreComponents

                                                                                                                interface PersistentPeerStoreComponents {
                                                                                                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                                                                    events: TypedEventTarget<Libp2pEvents<ServiceMap>>;
                                                                                                                    logger: ComponentLogger;
                                                                                                                    peerId: PeerId;
                                                                                                                }

                                                                                                                Properties

                                                                                                                datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                                                                Type declaration

                                                                                                                  Type declaration

                                                                                                                    Type declaration

                                                                                                                      Type declaration

                                                                                                                        Type declaration

                                                                                                                          Type declaration

                                                                                                                            Type declaration

                                                                                                                              Type declaration

                                                                                                                                Type declaration

                                                                                                                                  Type declaration

                                                                                                                                    peerId: PeerId
                                                                                                                                    \ No newline at end of file +

                                                                                                                                    Properties

                                                                                                                                    datastore: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                                                                                    Type declaration

                                                                                                                                      Type declaration

                                                                                                                                        Type declaration

                                                                                                                                          Type declaration

                                                                                                                                            Type declaration

                                                                                                                                              Type declaration

                                                                                                                                                Type declaration

                                                                                                                                                  Type declaration

                                                                                                                                                    Type declaration

                                                                                                                                                      Type declaration

                                                                                                                                                        peerId: PeerId
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_peer_store.PersistentPeerStoreInit.html b/interfaces/_libp2p_peer_store.PersistentPeerStoreInit.html index 3059644b48..ea8646670b 100644 --- a/interfaces/_libp2p_peer_store.PersistentPeerStoreInit.html +++ b/interfaces/_libp2p_peer_store.PersistentPeerStoreInit.html @@ -1,2 +1,2 @@ -PersistentPeerStoreInit | libp2p

                                                                                                                                                        Interface PersistentPeerStoreInit

                                                                                                                                                        interface PersistentPeerStoreInit {
                                                                                                                                                            addressFilter?: AddressFilter;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        addressFilter?: AddressFilter
                                                                                                                                                        \ No newline at end of file +PersistentPeerStoreInit | libp2p

                                                                                                                                                        Interface PersistentPeerStoreInit

                                                                                                                                                        interface PersistentPeerStoreInit {
                                                                                                                                                            addressFilter?: AddressFilter;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        addressFilter?: AddressFilter
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_perf.Perf.html b/interfaces/_libp2p_perf.Perf.html index a561d5ca35..39c7d9d389 100644 --- a/interfaces/_libp2p_perf.Perf.html +++ b/interfaces/_libp2p_perf.Perf.html @@ -1,2 +1,2 @@ -Perf | libp2p
                                                                                                                                                        interface Perf {
                                                                                                                                                            measurePerformance(multiaddr, sendBytes, recvBytes, options?): AsyncGenerator<PerfOutput, any, unknown>;
                                                                                                                                                        }

                                                                                                                                                        Methods

                                                                                                                                                        \ No newline at end of file +Perf | libp2p
                                                                                                                                                        interface Perf {
                                                                                                                                                            measurePerformance(multiaddr, sendBytes, recvBytes, options?): AsyncGenerator<PerfOutput, any, unknown>;
                                                                                                                                                        }

                                                                                                                                                        Methods

                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_perf.PerfComponents.html b/interfaces/_libp2p_perf.PerfComponents.html index ac9d6a6567..9b0ba1ece0 100644 --- a/interfaces/_libp2p_perf.PerfComponents.html +++ b/interfaces/_libp2p_perf.PerfComponents.html @@ -1,4 +1,4 @@ -PerfComponents | libp2p

                                                                                                                                                        Interface PerfComponents

                                                                                                                                                        interface PerfComponents {
                                                                                                                                                            connectionManager: ConnectionManager;
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            registrar: Registrar;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager +PerfComponents | libp2p

                                                                                                                                                        Interface PerfComponents

                                                                                                                                                        interface PerfComponents {
                                                                                                                                                            connectionManager: ConnectionManager;
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            registrar: Registrar;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager: ConnectionManager
                                                                                                                                                        registrar: Registrar
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager: ConnectionManager
                                                                                                                                                        registrar: Registrar
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_perf.PerfInit.html b/interfaces/_libp2p_perf.PerfInit.html index 9cd0a94cff..f16d7f6ad2 100644 --- a/interfaces/_libp2p_perf.PerfInit.html +++ b/interfaces/_libp2p_perf.PerfInit.html @@ -1,7 +1,7 @@ -PerfInit | libp2p

                                                                                                                                                        Interface PerfInit

                                                                                                                                                        interface PerfInit {
                                                                                                                                                            maxInboundStreams?: number;
                                                                                                                                                            maxOutboundStreams?: number;
                                                                                                                                                            protocolName?: string;
                                                                                                                                                            runOnLimitedConnection?: boolean;
                                                                                                                                                            writeBlockSize?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams? +PerfInit | libp2p

                                                                                                                                                        Interface PerfInit

                                                                                                                                                        interface PerfInit {
                                                                                                                                                            maxInboundStreams?: number;
                                                                                                                                                            maxOutboundStreams?: number;
                                                                                                                                                            protocolName?: string;
                                                                                                                                                            runOnLimitedConnection?: boolean;
                                                                                                                                                            writeBlockSize?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams?: number
                                                                                                                                                        maxOutboundStreams?: number
                                                                                                                                                        protocolName?: string
                                                                                                                                                        runOnLimitedConnection?: boolean
                                                                                                                                                        writeBlockSize?: number

                                                                                                                                                        Data sent/received will be sent in chunks of this size (default: 64KiB)

                                                                                                                                                        -
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams?: number
                                                                                                                                                        maxOutboundStreams?: number
                                                                                                                                                        protocolName?: string
                                                                                                                                                        runOnLimitedConnection?: boolean
                                                                                                                                                        writeBlockSize?: number

                                                                                                                                                        Data sent/received will be sent in chunks of this size (default: 64KiB)

                                                                                                                                                        +
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_perf.PerfOptions.html b/interfaces/_libp2p_perf.PerfOptions.html index 93a4912546..9d2fc219cd 100644 --- a/interfaces/_libp2p_perf.PerfOptions.html +++ b/interfaces/_libp2p_perf.PerfOptions.html @@ -2,10 +2,10 @@ the optional signal property.

                                                                                                                                                        Example

                                                                                                                                                        const controller = new AbortController()

                                                                                                                                                        aLongRunningOperation({
                                                                                                                                                        signal: controller.signal
                                                                                                                                                        })

                                                                                                                                                        // later

                                                                                                                                                        controller.abort()
                                                                                                                                                        -
                                                                                                                                                        interface PerfOptions {
                                                                                                                                                            reuseExistingConnection?: boolean;
                                                                                                                                                            signal?: AbortSignal;
                                                                                                                                                        }

                                                                                                                                                        Hierarchy (view full)

                                                                                                                                                        Properties

                                                                                                                                                        interface PerfOptions {
                                                                                                                                                            reuseExistingConnection?: boolean;
                                                                                                                                                            signal?: AbortSignal;
                                                                                                                                                        }

                                                                                                                                                        Hierarchy (view full)

                                                                                                                                                        Properties

                                                                                                                                                        reuseExistingConnection?: boolean

                                                                                                                                                        By default measuring perf should include the time it takes to establish a connection, so a new connection will be opened for every performance run.

                                                                                                                                                        To override this and re-use an existing connection if one is present, pass true here. (default: false)

                                                                                                                                                        -
                                                                                                                                                        signal?: AbortSignal
                                                                                                                                                        \ No newline at end of file +
                                                                                                                                                        signal?: AbortSignal
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_perf.PerfOutput.html b/interfaces/_libp2p_perf.PerfOutput.html index b4bc6ef010..814435cb57 100644 --- a/interfaces/_libp2p_perf.PerfOutput.html +++ b/interfaces/_libp2p_perf.PerfOutput.html @@ -1,5 +1,5 @@ -PerfOutput | libp2p

                                                                                                                                                        Interface PerfOutput

                                                                                                                                                        interface PerfOutput {
                                                                                                                                                            downloadBytes: number;
                                                                                                                                                            timeSeconds: number;
                                                                                                                                                            type: "stream" | "intermediary" | "connection" | "final";
                                                                                                                                                            uploadBytes: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        downloadBytes +PerfOutput | libp2p

                                                                                                                                                        Interface PerfOutput

                                                                                                                                                        interface PerfOutput {
                                                                                                                                                            downloadBytes: number;
                                                                                                                                                            timeSeconds: number;
                                                                                                                                                            type: "stream" | "intermediary" | "connection" | "final";
                                                                                                                                                            uploadBytes: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        downloadBytes: number
                                                                                                                                                        timeSeconds: number
                                                                                                                                                        type: "stream" | "intermediary" | "connection" | "final"
                                                                                                                                                        uploadBytes: number
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        downloadBytes: number
                                                                                                                                                        timeSeconds: number
                                                                                                                                                        type: "stream" | "intermediary" | "connection" | "final"
                                                                                                                                                        uploadBytes: number
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_ping.PingService.html b/interfaces/_libp2p_ping.PingService.html index 567ccff7d4..ed4b918a8c 100644 --- a/interfaces/_libp2p_ping.PingService.html +++ b/interfaces/_libp2p_ping.PingService.html @@ -1,2 +1,2 @@ -PingService | libp2p

                                                                                                                                                        Interface PingService

                                                                                                                                                        interface PingService {
                                                                                                                                                            ping(peer, options?): Promise<number>;
                                                                                                                                                        }

                                                                                                                                                        Methods

                                                                                                                                                        Methods

                                                                                                                                                        \ No newline at end of file +PingService | libp2p

                                                                                                                                                        Interface PingService

                                                                                                                                                        interface PingService {
                                                                                                                                                            ping(peer, options?): Promise<number>;
                                                                                                                                                        }

                                                                                                                                                        Methods

                                                                                                                                                        Methods

                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_ping.PingServiceComponents.html b/interfaces/_libp2p_ping.PingServiceComponents.html index 7fbf230200..ad9da0e1fe 100644 --- a/interfaces/_libp2p_ping.PingServiceComponents.html +++ b/interfaces/_libp2p_ping.PingServiceComponents.html @@ -1,4 +1,4 @@ -PingServiceComponents | libp2p

                                                                                                                                                        Interface PingServiceComponents

                                                                                                                                                        interface PingServiceComponents {
                                                                                                                                                            connectionManager: ConnectionManager;
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            registrar: Registrar;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager +PingServiceComponents | libp2p

                                                                                                                                                        Interface PingServiceComponents

                                                                                                                                                        interface PingServiceComponents {
                                                                                                                                                            connectionManager: ConnectionManager;
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            registrar: Registrar;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager: ConnectionManager
                                                                                                                                                        registrar: Registrar
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        connectionManager: ConnectionManager
                                                                                                                                                        registrar: Registrar
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_ping.PingServiceInit.html b/interfaces/_libp2p_ping.PingServiceInit.html index e4507c7467..8a8aed281f 100644 --- a/interfaces/_libp2p_ping.PingServiceInit.html +++ b/interfaces/_libp2p_ping.PingServiceInit.html @@ -1,7 +1,7 @@ -PingServiceInit | libp2p

                                                                                                                                                        Interface PingServiceInit

                                                                                                                                                        interface PingServiceInit {
                                                                                                                                                            maxInboundStreams?: number;
                                                                                                                                                            maxOutboundStreams?: number;
                                                                                                                                                            protocolPrefix?: string;
                                                                                                                                                            runOnLimitedConnection?: boolean;
                                                                                                                                                            timeout?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams? +PingServiceInit | libp2p

                                                                                                                                                        Interface PingServiceInit

                                                                                                                                                        interface PingServiceInit {
                                                                                                                                                            maxInboundStreams?: number;
                                                                                                                                                            maxOutboundStreams?: number;
                                                                                                                                                            protocolPrefix?: string;
                                                                                                                                                            runOnLimitedConnection?: boolean;
                                                                                                                                                            timeout?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams?: number
                                                                                                                                                        maxOutboundStreams?: number
                                                                                                                                                        protocolPrefix?: string
                                                                                                                                                        runOnLimitedConnection?: boolean
                                                                                                                                                        timeout?: number

                                                                                                                                                        How long we should wait for a ping response

                                                                                                                                                        -
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        maxInboundStreams?: number
                                                                                                                                                        maxOutboundStreams?: number
                                                                                                                                                        protocolPrefix?: string
                                                                                                                                                        runOnLimitedConnection?: boolean
                                                                                                                                                        timeout?: number

                                                                                                                                                        How long we should wait for a ping response

                                                                                                                                                        +
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_plaintext.PlaintextComponents.html b/interfaces/_libp2p_plaintext.PlaintextComponents.html index 369a944238..7f87ac17f7 100644 --- a/interfaces/_libp2p_plaintext.PlaintextComponents.html +++ b/interfaces/_libp2p_plaintext.PlaintextComponents.html @@ -1,3 +1,3 @@ -PlaintextComponents | libp2p

                                                                                                                                                        Interface PlaintextComponents

                                                                                                                                                        interface PlaintextComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            privateKey: PrivateKey;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        logger +PlaintextComponents | libp2p

                                                                                                                                                        Interface PlaintextComponents

                                                                                                                                                        interface PlaintextComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            privateKey: PrivateKey;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        privateKey: PrivateKey
                                                                                                                                                        \ No newline at end of file +

                                                                                                                                                        Properties

                                                                                                                                                        privateKey: PrivateKey
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_pnet.ProtectorComponents.html b/interfaces/_libp2p_pnet.ProtectorComponents.html index 3c8275e0bc..81c715ac0e 100644 --- a/interfaces/_libp2p_pnet.ProtectorComponents.html +++ b/interfaces/_libp2p_pnet.ProtectorComponents.html @@ -1,2 +1,2 @@ -ProtectorComponents | libp2p

                                                                                                                                                        Interface ProtectorComponents

                                                                                                                                                        interface ProtectorComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        \ No newline at end of file +ProtectorComponents | libp2p

                                                                                                                                                        Interface ProtectorComponents

                                                                                                                                                        interface ProtectorComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_pnet.ProtectorInit.html b/interfaces/_libp2p_pnet.ProtectorInit.html index eb39a9e61f..52798984ae 100644 --- a/interfaces/_libp2p_pnet.ProtectorInit.html +++ b/interfaces/_libp2p_pnet.ProtectorInit.html @@ -1,7 +1,7 @@ -ProtectorInit | libp2p

                                                                                                                                                        Interface ProtectorInit

                                                                                                                                                        interface ProtectorInit {
                                                                                                                                                            psk: Uint8Array;
                                                                                                                                                            timeout?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        psk +ProtectorInit | libp2p

                                                                                                                                                        Interface ProtectorInit

                                                                                                                                                        interface ProtectorInit {
                                                                                                                                                            psk: Uint8Array;
                                                                                                                                                            timeout?: number;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        A pre-shared key. This must be the same byte value for all peers in the swarm in order for them to communicate.

                                                                                                                                                        -
                                                                                                                                                        timeout?: number

                                                                                                                                                        The initial nonce exchange must complete within this many milliseconds +

                                                                                                                                                        timeout?: number

                                                                                                                                                        The initial nonce exchange must complete within this many milliseconds (default: 1000)

                                                                                                                                                        -
                                                                                                                                                        \ No newline at end of file +
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_prometheus_metrics.PrometheusCalculatedMetricOptions.html b/interfaces/_libp2p_prometheus_metrics.PrometheusCalculatedMetricOptions.html index 128c0ff4fb..56753bdd8f 100644 --- a/interfaces/_libp2p_prometheus_metrics.PrometheusCalculatedMetricOptions.html +++ b/interfaces/_libp2p_prometheus_metrics.PrometheusCalculatedMetricOptions.html @@ -1,6 +1,6 @@ PrometheusCalculatedMetricOptions | libp2p

                                                                                                                                                        Interface PrometheusCalculatedMetricOptions<T>

                                                                                                                                                        Create tracked metrics that are expensive to calculate by passing a function that is only invoked when metrics are being scraped

                                                                                                                                                        -
                                                                                                                                                        interface PrometheusCalculatedMetricOptions<T> {
                                                                                                                                                            calculate: CalculateMetric<T>;
                                                                                                                                                            help?: string;
                                                                                                                                                            label?: string;
                                                                                                                                                            registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">;
                                                                                                                                                        }

                                                                                                                                                        Type Parameters

                                                                                                                                                        • T = number

                                                                                                                                                        Hierarchy (view full)

                                                                                                                                                        Properties

                                                                                                                                                        interface PrometheusCalculatedMetricOptions<T> {
                                                                                                                                                            calculate: CalculateMetric<T>;
                                                                                                                                                            help?: string;
                                                                                                                                                            label?: string;
                                                                                                                                                            registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">;
                                                                                                                                                        }

                                                                                                                                                        Type Parameters

                                                                                                                                                        • T = number

                                                                                                                                                        Hierarchy (view full)

                                                                                                                                                        Properties

                                                                                                                                                        calculate help? label? registry? @@ -8,4 +8,4 @@ using .update, .increment, and .decrement

                                                                                                                                                        help?: string

                                                                                                                                                        Optional help for the metric

                                                                                                                                                        label?: string

                                                                                                                                                        Optional label for the metric

                                                                                                                                                        -
                                                                                                                                                        registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">
                                                                                                                                                        \ No newline at end of file +
                                                                                                                                                        registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsComponents.html b/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsComponents.html index a439f70707..9588abe2ec 100644 --- a/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsComponents.html +++ b/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsComponents.html @@ -1,2 +1,2 @@ -PrometheusMetricsComponents | libp2p
                                                                                                                                                        interface PrometheusMetricsComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        \ No newline at end of file +PrometheusMetricsComponents | libp2p
                                                                                                                                                        interface PrometheusMetricsComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        Properties

                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsInit.html b/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsInit.html index b6b14164cb..1050070b8f 100644 --- a/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsInit.html +++ b/interfaces/_libp2p_prometheus_metrics.PrometheusMetricsInit.html @@ -1,13 +1,13 @@ -PrometheusMetricsInit | libp2p
                                                                                                                                                        interface PrometheusMetricsInit {
                                                                                                                                                            collectDefaultMetrics?: boolean;
                                                                                                                                                            defaultMetrics?: DefaultMetricsCollectorConfiguration<RegistryContentType>;
                                                                                                                                                            preserveExistingMetrics?: boolean;
                                                                                                                                                            registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        collectDefaultMetrics? +PrometheusMetricsInit | libp2p
                                                                                                                                                        interface PrometheusMetricsInit {
                                                                                                                                                            collectDefaultMetrics?: boolean;
                                                                                                                                                            defaultMetrics?: DefaultMetricsCollectorConfiguration<RegistryContentType>;
                                                                                                                                                            preserveExistingMetrics?: boolean;
                                                                                                                                                            registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">;
                                                                                                                                                        }

                                                                                                                                                        Properties

                                                                                                                                                        collectDefaultMetrics?: boolean

                                                                                                                                                        By default we collect default metrics - CPU, memory etc, to not do this, pass true here

                                                                                                                                                        -

                                                                                                                                                        prom-client options to pass to the collectDefaultMetrics function

                                                                                                                                                        -
                                                                                                                                                        preserveExistingMetrics?: boolean

                                                                                                                                                        All metrics in prometheus are global so to prevent clashes in naming +

                                                                                                                                                        prom-client options to pass to the collectDefaultMetrics function

                                                                                                                                                        +
                                                                                                                                                        preserveExistingMetrics?: boolean

                                                                                                                                                        All metrics in prometheus are global so to prevent clashes in naming we reset the global metrics registry on creation - to not do this, pass true here

                                                                                                                                                        -
                                                                                                                                                        registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">

                                                                                                                                                        Use a custom registry to register metrics. +

                                                                                                                                                        registry?: Registry<"text/plain; version=0.0.4; charset=utf-8">

                                                                                                                                                        Use a custom registry to register metrics. By default, the global registry is used to register metrics.

                                                                                                                                                        -
                                                                                                                                                        \ No newline at end of file +
                                                                                                                                                        \ No newline at end of file diff --git a/interfaces/_libp2p_pubsub.index.PubSubComponents.html b/interfaces/_libp2p_pubsub.index.PubSubComponents.html index 7d78e055ad..65e989a870 100644 --- a/interfaces/_libp2p_pubsub.index.PubSubComponents.html +++ b/interfaces/_libp2p_pubsub.index.PubSubComponents.html @@ -1,5 +1,5 @@ -PubSubComponents | libp2p
                                                                                                                                                        interface PubSubComponents {
                                                                                                                                                            logger: ComponentLogger;
                                                                                                                                                            peerId: PeerId;
                                                                                                                                                            privateKey: PrivateKey;
                                                                                                                                                            registrar: Registrar;
                                                                                                                                                        }

                                                                                                                                                        Hierarchy

                                                                                                                                                        • PubSubComponents

                                                                                                                                                          Properties

                                                                                                                                                          logger +PubSubComponents | libp2p
                                                                                                                                                          interface PubSubComponents {
                                                                                                                                                              logger: ComponentLogger;
                                                                                                                                                              peerId: PeerId;
                                                                                                                                                              privateKey: PrivateKey;
                                                                                                                                                              registrar: Registrar;
                                                                                                                                                          }

                                                                                                                                                          Hierarchy

                                                                                                                                                          • PubSubComponents

                                                                                                                                                            Properties

                                                                                                                                                            peerId: PeerId
                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            registrar: Registrar
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            peerId: PeerId
                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            registrar: Registrar
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsComponents.html b/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsComponents.html index 59d3308a69..7e39ea9d19 100644 --- a/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsComponents.html +++ b/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsComponents.html @@ -1,2 +1,2 @@ -PeerStreamsComponents | libp2p
                                                                                                                                                            interface PeerStreamsComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            \ No newline at end of file +PeerStreamsComponents | libp2p
                                                                                                                                                            interface PeerStreamsComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsInit.html b/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsInit.html index f9fa6628ee..8c9f4f1930 100644 --- a/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsInit.html +++ b/interfaces/_libp2p_pubsub.peer_streams.PeerStreamsInit.html @@ -1,3 +1,3 @@ -PeerStreamsInit | libp2p
                                                                                                                                                            interface PeerStreamsInit {
                                                                                                                                                                id: PeerId;
                                                                                                                                                                protocol: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            id +PeerStreamsInit | libp2p
                                                                                                                                                            interface PeerStreamsInit {
                                                                                                                                                                id: PeerId;
                                                                                                                                                                protocol: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            id: PeerId
                                                                                                                                                            protocol: string
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            id: PeerId
                                                                                                                                                            protocol: string
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_simple_metrics.OnMetrics.html b/interfaces/_libp2p_simple_metrics.OnMetrics.html index 88df481015..78e3e8d53d 100644 --- a/interfaces/_libp2p_simple_metrics.OnMetrics.html +++ b/interfaces/_libp2p_simple_metrics.OnMetrics.html @@ -1 +1 @@ -OnMetrics | libp2p
                                                                                                                                                            interface OnMetrics ((metrics) => void)
                                                                                                                                                            • Parameters

                                                                                                                                                              Returns void

                                                                                                                                                            \ No newline at end of file +OnMetrics | libp2p
                                                                                                                                                            interface OnMetrics ((metrics) => void)
                                                                                                                                                            • Parameters

                                                                                                                                                              Returns void

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_simple_metrics.SimpleMetricsInit.html b/interfaces/_libp2p_simple_metrics.SimpleMetricsInit.html index 39d4bff10d..ecbc098ac5 100644 --- a/interfaces/_libp2p_simple_metrics.SimpleMetricsInit.html +++ b/interfaces/_libp2p_simple_metrics.SimpleMetricsInit.html @@ -1,5 +1,5 @@ -SimpleMetricsInit | libp2p
                                                                                                                                                            interface SimpleMetricsInit {
                                                                                                                                                                intervalMs?: number;
                                                                                                                                                                onMetrics: OnMetrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            intervalMs? +SimpleMetricsInit | libp2p
                                                                                                                                                            interface SimpleMetricsInit {
                                                                                                                                                                intervalMs?: number;
                                                                                                                                                                onMetrics: OnMetrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            intervalMs?: number

                                                                                                                                                            How often to invoke the onMetrics callback

                                                                                                                                                            -
                                                                                                                                                            onMetrics: OnMetrics

                                                                                                                                                            A callback periodically invoked with collected metrics

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            onMetrics: OnMetrics

                                                                                                                                                            A callback periodically invoked with collected metrics

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPComponents.html b/interfaces/_libp2p_tcp.TCPComponents.html index d5c02e463a..54adad0fd7 100644 --- a/interfaces/_libp2p_tcp.TCPComponents.html +++ b/interfaces/_libp2p_tcp.TCPComponents.html @@ -1,3 +1,3 @@ -TCPComponents | libp2p

                                                                                                                                                            Interface TCPComponents

                                                                                                                                                            interface TCPComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            logger +TCPComponents | libp2p

                                                                                                                                                            Interface TCPComponents

                                                                                                                                                            interface TCPComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPCreateListenerOptions.html b/interfaces/_libp2p_tcp.TCPCreateListenerOptions.html index 96ca89f7ed..f1651ded16 100644 --- a/interfaces/_libp2p_tcp.TCPCreateListenerOptions.html +++ b/interfaces/_libp2p_tcp.TCPCreateListenerOptions.html @@ -1,5 +1,5 @@ TCPCreateListenerOptions | libp2p

                                                                                                                                                            Interface TCPCreateListenerOptions

                                                                                                                                                            Expose a subset of net.connect options

                                                                                                                                                            -
                                                                                                                                                            interface TCPCreateListenerOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                handler?: ConnectionHandler;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                upgrader: Upgrader;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface TCPCreateListenerOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                handler?: ConnectionHandler;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                upgrader: Upgrader;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            allowHalfOpen?: boolean
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            upgrader: Upgrader
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            upgrader: Upgrader
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPDialOptions.html b/interfaces/_libp2p_tcp.TCPDialOptions.html index 5e27ba6ed7..cdecee3160 100644 --- a/interfaces/_libp2p_tcp.TCPDialOptions.html +++ b/interfaces/_libp2p_tcp.TCPDialOptions.html @@ -1,5 +1,5 @@ TCPDialOptions | libp2p

                                                                                                                                                            Interface TCPDialOptions

                                                                                                                                                            Expose a subset of net.connect options

                                                                                                                                                            -
                                                                                                                                                            interface TCPDialOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                onProgress?: ((evt) => void);
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                upgrader: Upgrader;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface TCPDialOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                onProgress?: ((evt) => void);
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                upgrader: Upgrader;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            allowHalfOpen?: boolean
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            onProgress?: ((evt) => void)

                                                                                                                                                            Type declaration

                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            upgrader: Upgrader
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            onProgress?: ((evt) => void)

                                                                                                                                                            Type declaration

                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            upgrader: Upgrader
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPMetrics.html b/interfaces/_libp2p_tcp.TCPMetrics.html index 808fce9aef..eefb437c6f 100644 --- a/interfaces/_libp2p_tcp.TCPMetrics.html +++ b/interfaces/_libp2p_tcp.TCPMetrics.html @@ -1,2 +1,2 @@ -TCPMetrics | libp2p

                                                                                                                                                            Interface TCPMetrics

                                                                                                                                                            interface TCPMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<"error" | "connect" | "abort" | "timeout">;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<"error" | "connect" | "abort" | "timeout">
                                                                                                                                                            \ No newline at end of file +TCPMetrics | libp2p

                                                                                                                                                            Interface TCPMetrics

                                                                                                                                                            interface TCPMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<"error" | "connect" | "abort" | "timeout">;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<"error" | "connect" | "abort" | "timeout">
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPOptions.html b/interfaces/_libp2p_tcp.TCPOptions.html index 49f5626f62..f112308518 100644 --- a/interfaces/_libp2p_tcp.TCPOptions.html +++ b/interfaces/_libp2p_tcp.TCPOptions.html @@ -1,4 +1,4 @@ -TCPOptions | libp2p

                                                                                                                                                            Interface TCPOptions

                                                                                                                                                            interface TCPOptions {
                                                                                                                                                                backlog?: number;
                                                                                                                                                                closeServerOnMaxConnections?: CloseServerOnMaxConnectionsOpts;
                                                                                                                                                                dialOpts?: TCPSocketOptions;
                                                                                                                                                                inboundSocketInactivityTimeout?: number;
                                                                                                                                                                listenOpts?: TCPSocketOptions;
                                                                                                                                                                maxConnections?: number;
                                                                                                                                                                outboundSocketInactivityTimeout?: number;
                                                                                                                                                                socketCloseTimeout?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            backlog? +TCPOptions | libp2p

                                                                                                                                                            Interface TCPOptions

                                                                                                                                                            interface TCPOptions {
                                                                                                                                                                backlog?: number;
                                                                                                                                                                closeServerOnMaxConnections?: CloseServerOnMaxConnectionsOpts;
                                                                                                                                                                dialOpts?: TCPSocketOptions;
                                                                                                                                                                inboundSocketInactivityTimeout?: number;
                                                                                                                                                                listenOpts?: TCPSocketOptions;
                                                                                                                                                                maxConnections?: number;
                                                                                                                                                                outboundSocketInactivityTimeout?: number;
                                                                                                                                                                socketCloseTimeout?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            backlog?: number

                                                                                                                                                            Parameter to specify the maximum length of the queue of pending connections https://nodejs.org/dist/latest-v18.x/docs/api/net.html#serverlisten

                                                                                                                                                            -
                                                                                                                                                            closeServerOnMaxConnections?: CloseServerOnMaxConnectionsOpts

                                                                                                                                                            Close server (stop listening for new connections) if connections exceed a limit. +

                                                                                                                                                            closeServerOnMaxConnections?: CloseServerOnMaxConnectionsOpts

                                                                                                                                                            Close server (stop listening for new connections) if connections exceed a limit. Open server (start listening for new connections) if connections fall below a limit.

                                                                                                                                                            -
                                                                                                                                                            dialOpts?: TCPSocketOptions

                                                                                                                                                            Options passed to net.connect for every opened TCP socket

                                                                                                                                                            -
                                                                                                                                                            inboundSocketInactivityTimeout?: number

                                                                                                                                                            An optional number in ms that is used as an inactivity timeout after which the socket will be closed

                                                                                                                                                            -
                                                                                                                                                            listenOpts?: TCPSocketOptions

                                                                                                                                                            Options passed to every net.createServer for every TCP server

                                                                                                                                                            -
                                                                                                                                                            maxConnections?: number

                                                                                                                                                            Set this property to reject connections when the server's connection count gets high. +

                                                                                                                                                            dialOpts?: TCPSocketOptions

                                                                                                                                                            Options passed to net.connect for every opened TCP socket

                                                                                                                                                            +
                                                                                                                                                            inboundSocketInactivityTimeout?: number

                                                                                                                                                            An optional number in ms that is used as an inactivity timeout after which the socket will be closed

                                                                                                                                                            +
                                                                                                                                                            listenOpts?: TCPSocketOptions

                                                                                                                                                            Options passed to every net.createServer for every TCP server

                                                                                                                                                            +
                                                                                                                                                            maxConnections?: number

                                                                                                                                                            Set this property to reject connections when the server's connection count gets high. https://nodejs.org/api/net.html#servermaxconnections

                                                                                                                                                            -
                                                                                                                                                            outboundSocketInactivityTimeout?: number

                                                                                                                                                            An optional number in ms that is used as an inactivity timeout after which the socket will be closed

                                                                                                                                                            -
                                                                                                                                                            socketCloseTimeout?: number

                                                                                                                                                            When closing a socket, wait this long for it to close gracefully before it is closed more forcibly

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            outboundSocketInactivityTimeout?: number

                                                                                                                                                            An optional number in ms that is used as an inactivity timeout after which the socket will be closed

                                                                                                                                                            +
                                                                                                                                                            socketCloseTimeout?: number

                                                                                                                                                            When closing a socket, wait this long for it to close gracefully before it is closed more forcibly

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tcp.TCPSocketOptions.html b/interfaces/_libp2p_tcp.TCPSocketOptions.html index 44bc095a8b..49d2d8fb14 100644 --- a/interfaces/_libp2p_tcp.TCPSocketOptions.html +++ b/interfaces/_libp2p_tcp.TCPSocketOptions.html @@ -1,11 +1,11 @@ TCPSocketOptions | libp2p

                                                                                                                                                            Interface TCPSocketOptions

                                                                                                                                                            Expose a subset of net.connect options

                                                                                                                                                            -
                                                                                                                                                            interface TCPSocketOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface TCPSocketOptions {
                                                                                                                                                                allowHalfOpen?: boolean;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                keepAliveInitialDelay?: number;
                                                                                                                                                                noDelay?: boolean;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            allowHalfOpen?: boolean
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            keepAlive?: boolean
                                                                                                                                                            keepAliveInitialDelay?: number
                                                                                                                                                            noDelay?: boolean
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_tls.TLSComponents.html b/interfaces/_libp2p_tls.TLSComponents.html index 0377708776..56ddaf3afa 100644 --- a/interfaces/_libp2p_tls.TLSComponents.html +++ b/interfaces/_libp2p_tls.TLSComponents.html @@ -1,3 +1,3 @@ -TLSComponents | libp2p

                                                                                                                                                            Interface TLSComponents

                                                                                                                                                            interface TLSComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                privateKey: PrivateKey;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            logger +TLSComponents | libp2p

                                                                                                                                                            Interface TLSComponents

                                                                                                                                                            interface TLSComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                privateKey: PrivateKey;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_upnp_nat.MapPortOptions.html b/interfaces/_libp2p_upnp_nat.MapPortOptions.html index 55b9cba40b..374b7ade23 100644 --- a/interfaces/_libp2p_upnp_nat.MapPortOptions.html +++ b/interfaces/_libp2p_upnp_nat.MapPortOptions.html @@ -1,8 +1,8 @@ -MapPortOptions | libp2p

                                                                                                                                                            Interface MapPortOptions

                                                                                                                                                            interface MapPortOptions {
                                                                                                                                                                description: string;
                                                                                                                                                                gateway?: string;
                                                                                                                                                                localAddress: string;
                                                                                                                                                                localPort: number;
                                                                                                                                                                protocol: "TCP" | "UDP";
                                                                                                                                                                publicPort: number;
                                                                                                                                                                ttl: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            description +MapPortOptions | libp2p

                                                                                                                                                            Interface MapPortOptions

                                                                                                                                                            interface MapPortOptions {
                                                                                                                                                                description: string;
                                                                                                                                                                gateway?: string;
                                                                                                                                                                localAddress: string;
                                                                                                                                                                localPort: number;
                                                                                                                                                                protocol: "TCP" | "UDP";
                                                                                                                                                                publicPort: number;
                                                                                                                                                                ttl: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            description: string
                                                                                                                                                            gateway?: string
                                                                                                                                                            localAddress: string
                                                                                                                                                            localPort: number
                                                                                                                                                            protocol: "TCP" | "UDP"
                                                                                                                                                            publicPort: number
                                                                                                                                                            ttl: number
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            description: string
                                                                                                                                                            gateway?: string
                                                                                                                                                            localAddress: string
                                                                                                                                                            localPort: number
                                                                                                                                                            protocol: "TCP" | "UDP"
                                                                                                                                                            publicPort: number
                                                                                                                                                            ttl: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_upnp_nat.PMPOptions.html b/interfaces/_libp2p_upnp_nat.PMPOptions.html index 6555a080a9..bffabf4cd6 100644 --- a/interfaces/_libp2p_upnp_nat.PMPOptions.html +++ b/interfaces/_libp2p_upnp_nat.PMPOptions.html @@ -1,3 +1,3 @@ -PMPOptions | libp2p
                                                                                                                                                            interface PMPOptions {
                                                                                                                                                                enabled?: boolean;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            enabled? +PMPOptions | libp2p
                                                                                                                                                            interface PMPOptions {
                                                                                                                                                                enabled?: boolean;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            enabled?: boolean

                                                                                                                                                            Whether to enable PMP as well as UPnP

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_upnp_nat.UPnPNAT.html b/interfaces/_libp2p_upnp_nat.UPnPNAT.html index 8d2ec549aa..7d25b0744a 100644 --- a/interfaces/_libp2p_upnp_nat.UPnPNAT.html +++ b/interfaces/_libp2p_upnp_nat.UPnPNAT.html @@ -1,2 +1,2 @@ -UPnPNAT | libp2p
                                                                                                                                                            interface UPnPNAT {
                                                                                                                                                                client: NatAPI;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            client: NatAPI
                                                                                                                                                            \ No newline at end of file +UPnPNAT | libp2p
                                                                                                                                                            interface UPnPNAT {
                                                                                                                                                                client: NatAPI;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            client: NatAPI
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_upnp_nat.UPnPNATComponents.html b/interfaces/_libp2p_upnp_nat.UPnPNATComponents.html index 16d52dd638..e43ca5124c 100644 --- a/interfaces/_libp2p_upnp_nat.UPnPNATComponents.html +++ b/interfaces/_libp2p_upnp_nat.UPnPNATComponents.html @@ -1,6 +1,6 @@ -UPnPNATComponents | libp2p

                                                                                                                                                            Interface UPnPNATComponents

                                                                                                                                                            interface UPnPNATComponents {
                                                                                                                                                                addressManager: AddressManager;
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                nodeInfo: NodeInfo;
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                transportManager: TransportManager;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            addressManager +UPnPNATComponents | libp2p

                                                                                                                                                            Interface UPnPNATComponents

                                                                                                                                                            interface UPnPNATComponents {
                                                                                                                                                                addressManager: AddressManager;
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                nodeInfo: NodeInfo;
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                transportManager: TransportManager;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            addressManager: AddressManager
                                                                                                                                                            nodeInfo: NodeInfo
                                                                                                                                                            peerId: PeerId
                                                                                                                                                            transportManager: TransportManager
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            addressManager: AddressManager
                                                                                                                                                            nodeInfo: NodeInfo
                                                                                                                                                            peerId: PeerId
                                                                                                                                                            transportManager: TransportManager
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_upnp_nat.UPnPNATInit.html b/interfaces/_libp2p_upnp_nat.UPnPNATInit.html index 8ef1879b49..201a848a25 100644 --- a/interfaces/_libp2p_upnp_nat.UPnPNATInit.html +++ b/interfaces/_libp2p_upnp_nat.UPnPNATInit.html @@ -1,13 +1,13 @@ -UPnPNATInit | libp2p
                                                                                                                                                            interface UPnPNATInit {
                                                                                                                                                                description?: string;
                                                                                                                                                                externalAddress?: string;
                                                                                                                                                                gateway?: string;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                localAddress?: string;
                                                                                                                                                                ttl?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            description? +UPnPNATInit | libp2p
                                                                                                                                                            interface UPnPNATInit {
                                                                                                                                                                description?: string;
                                                                                                                                                                externalAddress?: string;
                                                                                                                                                                gateway?: string;
                                                                                                                                                                keepAlive?: boolean;
                                                                                                                                                                localAddress?: string;
                                                                                                                                                                ttl?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            description?: string

                                                                                                                                                            A string value to use for the port mapping description on the gateway

                                                                                                                                                            -
                                                                                                                                                            externalAddress?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            -
                                                                                                                                                            gateway?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            -
                                                                                                                                                            keepAlive?: boolean

                                                                                                                                                            Whether to automatically refresh UPnP port mappings when their TTL is reached

                                                                                                                                                            -
                                                                                                                                                            localAddress?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            -
                                                                                                                                                            ttl?: number

                                                                                                                                                            How long UPnP port mappings should last for in seconds (minimum 1200)

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            externalAddress?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            +
                                                                                                                                                            gateway?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            +
                                                                                                                                                            keepAlive?: boolean

                                                                                                                                                            Whether to automatically refresh UPnP port mappings when their TTL is reached

                                                                                                                                                            +
                                                                                                                                                            localAddress?: string

                                                                                                                                                            Pass a value to use instead of auto-detection

                                                                                                                                                            +
                                                                                                                                                            ttl?: number

                                                                                                                                                            How long UPnP port mappings should last for in seconds (minimum 1200)

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.abstract_stream.AbstractStreamInit.html b/interfaces/_libp2p_utils.abstract_stream.AbstractStreamInit.html index 7e813e933f..6b2a121859 100644 --- a/interfaces/_libp2p_utils.abstract_stream.AbstractStreamInit.html +++ b/interfaces/_libp2p_utils.abstract_stream.AbstractStreamInit.html @@ -1,4 +1,4 @@ -AbstractStreamInit | libp2p
                                                                                                                                                            interface AbstractStreamInit {
                                                                                                                                                                closeTimeout?: number;
                                                                                                                                                                direction: Direction;
                                                                                                                                                                id: string;
                                                                                                                                                                log: Logger;
                                                                                                                                                                metadata?: Record<string, unknown>;
                                                                                                                                                                sendCloseWriteTimeout?: number;
                                                                                                                                                                onAbort?(err): void;
                                                                                                                                                                onCloseRead?(): void;
                                                                                                                                                                onCloseWrite?(): void;
                                                                                                                                                                onEnd?(err?): void;
                                                                                                                                                                onReset?(): void;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            closeTimeout? +AbstractStreamInit | libp2p
                                                                                                                                                            interface AbstractStreamInit {
                                                                                                                                                                closeTimeout?: number;
                                                                                                                                                                direction: Direction;
                                                                                                                                                                id: string;
                                                                                                                                                                log: Logger;
                                                                                                                                                                metadata?: Record<string, unknown>;
                                                                                                                                                                sendCloseWriteTimeout?: number;
                                                                                                                                                                onAbort?(err): void;
                                                                                                                                                                onCloseRead?(): void;
                                                                                                                                                                onCloseWrite?(): void;
                                                                                                                                                                onEnd?(err?): void;
                                                                                                                                                                onReset?(): void;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            closeTimeout? direction id log @@ -11,15 +11,15 @@ onReset?

                                                                                                                                                            Properties

                                                                                                                                                            closeTimeout?: number

                                                                                                                                                            How long to wait in ms for stream data to be written to the underlying connection when closing the writable end of the stream. (default: 500)

                                                                                                                                                            -
                                                                                                                                                            direction: Direction

                                                                                                                                                            The stream direction

                                                                                                                                                            -
                                                                                                                                                            id: string

                                                                                                                                                            A unique identifier for this stream

                                                                                                                                                            -
                                                                                                                                                            log: Logger

                                                                                                                                                            A Logger implementation used to log stream-specific information

                                                                                                                                                            -
                                                                                                                                                            metadata?: Record<string, unknown>

                                                                                                                                                            User specific stream metadata

                                                                                                                                                            -
                                                                                                                                                            sendCloseWriteTimeout?: number

                                                                                                                                                            After the stream sink has closed, a limit on how long it takes to send +

                                                                                                                                                            direction: Direction

                                                                                                                                                            The stream direction

                                                                                                                                                            +
                                                                                                                                                            id: string

                                                                                                                                                            A unique identifier for this stream

                                                                                                                                                            +
                                                                                                                                                            log: Logger

                                                                                                                                                            A Logger implementation used to log stream-specific information

                                                                                                                                                            +
                                                                                                                                                            metadata?: Record<string, unknown>

                                                                                                                                                            User specific stream metadata

                                                                                                                                                            +
                                                                                                                                                            sendCloseWriteTimeout?: number

                                                                                                                                                            After the stream sink has closed, a limit on how long it takes to send a close-write message to the remote peer.

                                                                                                                                                            -

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutInit.html b/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutInit.html index 9f19905217..0fc0b69c3b 100644 --- a/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutInit.html +++ b/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutInit.html @@ -1,8 +1,8 @@ -AdaptiveTimeoutInit | libp2p
                                                                                                                                                            interface AdaptiveTimeoutInit {
                                                                                                                                                                failureMultiplier?: number;
                                                                                                                                                                initialValue?: number;
                                                                                                                                                                interval?: number;
                                                                                                                                                                metricName?: string;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                minTimeout?: number;
                                                                                                                                                                timeoutMultiplier?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            failureMultiplier? +AdaptiveTimeoutInit | libp2p
                                                                                                                                                            interface AdaptiveTimeoutInit {
                                                                                                                                                                failureMultiplier?: number;
                                                                                                                                                                initialValue?: number;
                                                                                                                                                                interval?: number;
                                                                                                                                                                metricName?: string;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                minTimeout?: number;
                                                                                                                                                                timeoutMultiplier?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            failureMultiplier?: number
                                                                                                                                                            initialValue?: number
                                                                                                                                                            interval?: number
                                                                                                                                                            metricName?: string
                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            minTimeout?: number
                                                                                                                                                            timeoutMultiplier?: number
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            failureMultiplier?: number
                                                                                                                                                            initialValue?: number
                                                                                                                                                            interval?: number
                                                                                                                                                            metricName?: string
                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            minTimeout?: number
                                                                                                                                                            timeoutMultiplier?: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutSignal.html b/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutSignal.html index f7645f1299..b3fb239315 100644 --- a/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutSignal.html +++ b/interfaces/_libp2p_utils.adaptive_timeout.AdaptiveTimeoutSignal.html @@ -1,4 +1,4 @@ -AdaptiveTimeoutSignal | libp2p
                                                                                                                                                            interface AdaptiveTimeoutSignal {
                                                                                                                                                                aborted: boolean;
                                                                                                                                                                clear: (() => void);
                                                                                                                                                                onabort: null | ((this, ev) => any);
                                                                                                                                                                reason: any;
                                                                                                                                                                start: number;
                                                                                                                                                                timeout: number;
                                                                                                                                                                addEventListener<K>(type, listener, options?): void;
                                                                                                                                                                addEventListener(type, listener, options?): void;
                                                                                                                                                                addEventListener<K>(type, listener, options?): void;
                                                                                                                                                                addEventListener(type, listener, options?): void;
                                                                                                                                                                dispatchEvent(event): boolean;
                                                                                                                                                                dispatchEvent(event): boolean;
                                                                                                                                                                removeEventListener<K>(type, listener, options?): void;
                                                                                                                                                                removeEventListener(type, listener, options?): void;
                                                                                                                                                                removeEventListener<K>(type, listener, options?): void;
                                                                                                                                                                removeEventListener(type, listener, options?): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy

                                                                                                                                                            Properties

                                                                                                                                                            aborted +AdaptiveTimeoutSignal | libp2p
                                                                                                                                                            interface AdaptiveTimeoutSignal {
                                                                                                                                                                aborted: boolean;
                                                                                                                                                                clear: (() => void);
                                                                                                                                                                onabort: null | ((this, ev) => any);
                                                                                                                                                                reason: any;
                                                                                                                                                                start: number;
                                                                                                                                                                timeout: number;
                                                                                                                                                                addEventListener<K>(type, listener, options?): void;
                                                                                                                                                                addEventListener(type, listener, options?): void;
                                                                                                                                                                addEventListener<K>(type, listener, options?): void;
                                                                                                                                                                addEventListener(type, listener, options?): void;
                                                                                                                                                                dispatchEvent(event): boolean;
                                                                                                                                                                dispatchEvent(event): boolean;
                                                                                                                                                                removeEventListener<K>(type, listener, options?): void;
                                                                                                                                                                removeEventListener(type, listener, options?): void;
                                                                                                                                                                removeEventListener<K>(type, listener, options?): void;
                                                                                                                                                                removeEventListener(type, listener, options?): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                                throwIfAborted(): void;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy

                                                                                                                                                            Properties

                                                                                                                                                            clear: (() => void)

                                                                                                                                                            Type declaration

                                                                                                                                                              • (): void
                                                                                                                                                              • Returns void

                                                                                                                                                            onabort: null | ((this, ev) => any)

                                                                                                                                                            Type declaration

                                                                                                                                                            reason: any
                                                                                                                                                            start: number
                                                                                                                                                            timeout: number

                                                                                                                                                            Methods

                                                                                                                                                            • Type Parameters

                                                                                                                                                              • K extends "abort"

                                                                                                                                                              Parameters

                                                                                                                                                              • type: K
                                                                                                                                                              • listener: ((this, ev) => any)
                                                                                                                                                                  • (this, ev): any
                                                                                                                                                                  • Parameters

                                                                                                                                                                    Returns any

                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Parameters

                                                                                                                                                              • type: string
                                                                                                                                                              • listener: EventListenerOrEventListenerObject
                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Type Parameters

                                                                                                                                                              • K extends "abort"

                                                                                                                                                              Parameters

                                                                                                                                                              • type: K
                                                                                                                                                              • listener: ((this, ev) => any)
                                                                                                                                                                  • (this, ev): any
                                                                                                                                                                  • Parameters

                                                                                                                                                                    Returns any

                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Parameters

                                                                                                                                                              • type: string
                                                                                                                                                              • listener: EventListenerOrEventListenerObject
                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                                                                                                                                              +
                                                                                                                                                            start: number
                                                                                                                                                            timeout: number

                                                                                                                                                            Methods

                                                                                                                                                            • Type Parameters

                                                                                                                                                              • K extends "abort"

                                                                                                                                                              Parameters

                                                                                                                                                              • type: K
                                                                                                                                                              • listener: ((this, ev) => any)
                                                                                                                                                                  • (this, ev): any
                                                                                                                                                                  • Parameters

                                                                                                                                                                    Returns any

                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Parameters

                                                                                                                                                              • type: string
                                                                                                                                                              • listener: EventListenerOrEventListenerObject
                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Type Parameters

                                                                                                                                                              • K extends "abort"

                                                                                                                                                              Parameters

                                                                                                                                                              • type: K
                                                                                                                                                              • listener: ((this, ev) => any)
                                                                                                                                                                  • (this, ev): any
                                                                                                                                                                  • Parameters

                                                                                                                                                                    Returns any

                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Parameters

                                                                                                                                                              • type: string
                                                                                                                                                              • listener: EventListenerOrEventListenerObject
                                                                                                                                                              • Optional options: boolean | AddEventListenerOptions

                                                                                                                                                              Returns void

                                                                                                                                                            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                                                                                                                                              MDN Reference

                                                                                                                                                              Parameters

                                                                                                                                                              Returns boolean

                                                                                                                                                            • Dispatches a synthetic event event to target and returns true if either event's cancelable attribute value is false or its preventDefault() method was not invoked, and false otherwise.

                                                                                                                                                              MDN Reference

                                                                                                                                                              diff --git a/interfaces/_libp2p_utils.adaptive_timeout.GetTimeoutSignalOptions.html b/interfaces/_libp2p_utils.adaptive_timeout.GetTimeoutSignalOptions.html index aba77bc34b..44523313e4 100644 --- a/interfaces/_libp2p_utils.adaptive_timeout.GetTimeoutSignalOptions.html +++ b/interfaces/_libp2p_utils.adaptive_timeout.GetTimeoutSignalOptions.html @@ -1,3 +1,3 @@ -GetTimeoutSignalOptions | libp2p
                                                                                                                                                              interface GetTimeoutSignalOptions {
                                                                                                                                                                  signal?: AbortSignal;
                                                                                                                                                                  timeoutFactor?: number;
                                                                                                                                                              }

                                                                                                                                                              Properties

                                                                                                                                                              signal? +GetTimeoutSignalOptions | libp2p
                                                                                                                                                              interface GetTimeoutSignalOptions {
                                                                                                                                                                  signal?: AbortSignal;
                                                                                                                                                                  timeoutFactor?: number;
                                                                                                                                                              }

                                                                                                                                                              Properties

                                                                                                                                                              signal?: AbortSignal
                                                                                                                                                              timeoutFactor?: number
                                                                                                                                                              \ No newline at end of file +

                                                                                                                                                              Properties

                                                                                                                                                              signal?: AbortSignal
                                                                                                                                                              timeoutFactor?: number
                                                                                                                                                              \ No newline at end of file diff --git a/interfaces/_libp2p_utils.close.SafelyCloseConnectionOptions.html b/interfaces/_libp2p_utils.close.SafelyCloseConnectionOptions.html index 22ce36c4d1..6db670c6fd 100644 --- a/interfaces/_libp2p_utils.close.SafelyCloseConnectionOptions.html +++ b/interfaces/_libp2p_utils.close.SafelyCloseConnectionOptions.html @@ -2,10 +2,10 @@ the optional signal property.

                                                                                                                                                              Example

                                                                                                                                                              const controller = new AbortController()

                                                                                                                                                              aLongRunningOperation({
                                                                                                                                                              signal: controller.signal
                                                                                                                                                              })

                                                                                                                                                              // later

                                                                                                                                                              controller.abort()
                                                                                                                                                              -
                                                                                                                                                            interface SafelyCloseConnectionOptions {
                                                                                                                                                                closableProtocols?: string[];
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface SafelyCloseConnectionOptions {
                                                                                                                                                                closableProtocols?: string[];
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            closableProtocols?: string[]

                                                                                                                                                            Only close the stream if it either has no protocol streams open or only ones in this list.

                                                                                                                                                            Default

                                                                                                                                                            ['/ipfs/id/1.0.0']
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.filters.BloomFilterOptions.html b/interfaces/_libp2p_utils.filters.BloomFilterOptions.html index c7389ec00b..8985778a94 100644 --- a/interfaces/_libp2p_utils.filters.BloomFilterOptions.html +++ b/interfaces/_libp2p_utils.filters.BloomFilterOptions.html @@ -1,4 +1,4 @@ -BloomFilterOptions | libp2p
                                                                                                                                                            interface BloomFilterOptions {
                                                                                                                                                                bits?: number;
                                                                                                                                                                hashes?: number;
                                                                                                                                                                seeds?: number[];
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            bits? +BloomFilterOptions | libp2p
                                                                                                                                                            interface BloomFilterOptions {
                                                                                                                                                                bits?: number;
                                                                                                                                                                hashes?: number;
                                                                                                                                                                seeds?: number[];
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            bits?: number
                                                                                                                                                            hashes?: number
                                                                                                                                                            seeds?: number[]
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            bits?: number
                                                                                                                                                            hashes?: number
                                                                                                                                                            seeds?: number[]
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.filters.CuckooFilterInit.html b/interfaces/_libp2p_utils.filters.CuckooFilterInit.html index ddea7e8a02..830705e87f 100644 --- a/interfaces/_libp2p_utils.filters.CuckooFilterInit.html +++ b/interfaces/_libp2p_utils.filters.CuckooFilterInit.html @@ -1,11 +1,11 @@ -CuckooFilterInit | libp2p
                                                                                                                                                            interface CuckooFilterInit {
                                                                                                                                                                bucketSize?: number;
                                                                                                                                                                filterSize: number;
                                                                                                                                                                fingerprintSize?: number;
                                                                                                                                                                hash?: Hash;
                                                                                                                                                                seed?: number;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            bucketSize? +CuckooFilterInit | libp2p
                                                                                                                                                            interface CuckooFilterInit {
                                                                                                                                                                bucketSize?: number;
                                                                                                                                                                filterSize: number;
                                                                                                                                                                fingerprintSize?: number;
                                                                                                                                                                hash?: Hash;
                                                                                                                                                                seed?: number;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            bucketSize?: number

                                                                                                                                                            How many items to put in each bucket

                                                                                                                                                            -
                                                                                                                                                            filterSize: number

                                                                                                                                                            How many items the filter is expected to contain

                                                                                                                                                            -
                                                                                                                                                            fingerprintSize?: number

                                                                                                                                                            How many bytes the fingerprint is expected to be

                                                                                                                                                            -
                                                                                                                                                            hash?: Hash

                                                                                                                                                            A non-cryptographic hash implementation

                                                                                                                                                            -
                                                                                                                                                            seed?: number

                                                                                                                                                            A number used to seed the hash

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            filterSize: number

                                                                                                                                                            How many items the filter is expected to contain

                                                                                                                                                            +
                                                                                                                                                            fingerprintSize?: number

                                                                                                                                                            How many bytes the fingerprint is expected to be

                                                                                                                                                            +
                                                                                                                                                            hash?: Hash

                                                                                                                                                            A non-cryptographic hash implementation

                                                                                                                                                            +
                                                                                                                                                            seed?: number

                                                                                                                                                            A number used to seed the hash

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.filters.Filter.html b/interfaces/_libp2p_utils.filters.Filter.html index 58f57a03f2..900e096ee2 100644 --- a/interfaces/_libp2p_utils.filters.Filter.html +++ b/interfaces/_libp2p_utils.filters.Filter.html @@ -1,4 +1,4 @@ -Filter | libp2p
                                                                                                                                                            interface Filter {
                                                                                                                                                                add(item): void;
                                                                                                                                                                has(item): boolean;
                                                                                                                                                                remove?(buf): boolean;
                                                                                                                                                            }

                                                                                                                                                            Implemented by

                                                                                                                                                            Methods

                                                                                                                                                            add +Filter | libp2p
                                                                                                                                                            interface Filter {
                                                                                                                                                                add(item): void;
                                                                                                                                                                has(item): boolean;
                                                                                                                                                                remove?(buf): boolean;
                                                                                                                                                            }

                                                                                                                                                            Implemented by

                                                                                                                                                            Methods

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.filters.ScalableCuckooFilterInit.html b/interfaces/_libp2p_utils.filters.ScalableCuckooFilterInit.html index f57df7ea4a..0bda7ee132 100644 --- a/interfaces/_libp2p_utils.filters.ScalableCuckooFilterInit.html +++ b/interfaces/_libp2p_utils.filters.ScalableCuckooFilterInit.html @@ -1,13 +1,13 @@ -ScalableCuckooFilterInit | libp2p

                                                                                                                                                            Interface ScalableCuckooFilterInit

                                                                                                                                                            interface ScalableCuckooFilterInit {
                                                                                                                                                                bucketSize?: number;
                                                                                                                                                                filterSize: number;
                                                                                                                                                                fingerprintSize?: number;
                                                                                                                                                                hash?: Hash;
                                                                                                                                                                scale?: number;
                                                                                                                                                                seed?: number;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            bucketSize? +ScalableCuckooFilterInit | libp2p

                                                                                                                                                            Interface ScalableCuckooFilterInit

                                                                                                                                                            interface ScalableCuckooFilterInit {
                                                                                                                                                                bucketSize?: number;
                                                                                                                                                                filterSize: number;
                                                                                                                                                                fingerprintSize?: number;
                                                                                                                                                                hash?: Hash;
                                                                                                                                                                scale?: number;
                                                                                                                                                                seed?: number;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            bucketSize?: number

                                                                                                                                                            How many items to put in each bucket

                                                                                                                                                            -
                                                                                                                                                            filterSize: number

                                                                                                                                                            How many items the filter is expected to contain

                                                                                                                                                            -
                                                                                                                                                            fingerprintSize?: number

                                                                                                                                                            How many bytes the fingerprint is expected to be

                                                                                                                                                            -
                                                                                                                                                            hash?: Hash

                                                                                                                                                            A non-cryptographic hash implementation

                                                                                                                                                            -
                                                                                                                                                            scale?: number

                                                                                                                                                            A number to multiply maxItems by when adding new sub-filters

                                                                                                                                                            -
                                                                                                                                                            seed?: number

                                                                                                                                                            A number used to seed the hash

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            filterSize: number

                                                                                                                                                            How many items the filter is expected to contain

                                                                                                                                                            +
                                                                                                                                                            fingerprintSize?: number

                                                                                                                                                            How many bytes the fingerprint is expected to be

                                                                                                                                                            +
                                                                                                                                                            hash?: Hash

                                                                                                                                                            A non-cryptographic hash implementation

                                                                                                                                                            +
                                                                                                                                                            scale?: number

                                                                                                                                                            A number to multiply maxItems by when adding new sub-filters

                                                                                                                                                            +
                                                                                                                                                            seed?: number

                                                                                                                                                            A number used to seed the hash

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.peer_queue.PeerQueueJobOptions.html b/interfaces/_libp2p_utils.peer_queue.PeerQueueJobOptions.html index 7143df990e..3d77fb80ee 100644 --- a/interfaces/_libp2p_utils.peer_queue.PeerQueueJobOptions.html +++ b/interfaces/_libp2p_utils.peer_queue.PeerQueueJobOptions.html @@ -2,6 +2,6 @@ the optional signal property.

                                                                                                                                                            Example

                                                                                                                                                            const controller = new AbortController()

                                                                                                                                                            aLongRunningOperation({
                                                                                                                                                            signal: controller.signal
                                                                                                                                                            })

                                                                                                                                                            // later

                                                                                                                                                            controller.abort()
                                                                                                                                                            -
                                                                                                                                                            interface PeerQueueJobOptions {
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface PeerQueueJobOptions {
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            peerId: PeerId
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            peerId: PeerId
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.priority_queue.PriorityQueueJobOptions.html b/interfaces/_libp2p_utils.priority_queue.PriorityQueueJobOptions.html index e99dd4ee05..3f8cc724c3 100644 --- a/interfaces/_libp2p_utils.priority_queue.PriorityQueueJobOptions.html +++ b/interfaces/_libp2p_utils.priority_queue.PriorityQueueJobOptions.html @@ -2,6 +2,6 @@ the optional signal property.

                                                                                                                                                            Example

                                                                                                                                                            const controller = new AbortController()

                                                                                                                                                            aLongRunningOperation({
                                                                                                                                                            signal: controller.signal
                                                                                                                                                            })

                                                                                                                                                            // later

                                                                                                                                                            controller.abort()
                                                                                                                                                            -
                                                                                                                                                            interface PriorityQueueJobOptions {
                                                                                                                                                                priority: number;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface PriorityQueueJobOptions {
                                                                                                                                                                priority: number;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            priority: number
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            priority: number
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.Comparator.html b/interfaces/_libp2p_utils.queue.Comparator.html index eff560ce73..bafdb467de 100644 --- a/interfaces/_libp2p_utils.queue.Comparator.html +++ b/interfaces/_libp2p_utils.queue.Comparator.html @@ -1 +1 @@ -Comparator | libp2p

                                                                                                                                                            Interface Comparator<T>

                                                                                                                                                            interface Comparator<T> ((a, b) => -1 | 0 | 1)

                                                                                                                                                            Type Parameters

                                                                                                                                                            • T
                                                                                                                                                            \ No newline at end of file +Comparator | libp2p

                                                                                                                                                            Interface Comparator<T>

                                                                                                                                                            interface Comparator<T> ((a, b) => -1 | 0 | 1)

                                                                                                                                                            Type Parameters

                                                                                                                                                            • T
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.JobMatcher.html b/interfaces/_libp2p_utils.queue.JobMatcher.html index 85dff48d23..67c7fe5c6f 100644 --- a/interfaces/_libp2p_utils.queue.JobMatcher.html +++ b/interfaces/_libp2p_utils.queue.JobMatcher.html @@ -1 +1 @@ -JobMatcher | libp2p

                                                                                                                                                            Interface JobMatcher<JobOptions>

                                                                                                                                                            interface JobMatcher<JobOptions> ((options?) => boolean)

                                                                                                                                                            Type Parameters

                                                                                                                                                            \ No newline at end of file +JobMatcher | libp2p

                                                                                                                                                            Interface JobMatcher<JobOptions>

                                                                                                                                                            interface JobMatcher<JobOptions> ((options?) => boolean)

                                                                                                                                                            Type Parameters

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.QueueEvents.html b/interfaces/_libp2p_utils.queue.QueueEvents.html index 0d855e49c4..d6b657518f 100644 --- a/interfaces/_libp2p_utils.queue.QueueEvents.html +++ b/interfaces/_libp2p_utils.queue.QueueEvents.html @@ -1,4 +1,4 @@ -QueueEvents | libp2p

                                                                                                                                                            Interface QueueEvents<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueEvents<JobReturnType, JobOptions> {
                                                                                                                                                                active: CustomEvent<any>;
                                                                                                                                                                add: CustomEvent<any>;
                                                                                                                                                                completed: CustomEvent<JobReturnType>;
                                                                                                                                                                empty: CustomEvent<any>;
                                                                                                                                                                error: CustomEvent<Error>;
                                                                                                                                                                failure: CustomEvent<QueueJobFailure<JobReturnType, JobOptions>>;
                                                                                                                                                                idle: CustomEvent<any>;
                                                                                                                                                                next: CustomEvent<any>;
                                                                                                                                                                success: CustomEvent<QueueJobSuccess<JobReturnType, JobOptions>>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            active +QueueEvents | libp2p

                                                                                                                                                            Interface QueueEvents<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueEvents<JobReturnType, JobOptions> {
                                                                                                                                                                active: CustomEvent<any>;
                                                                                                                                                                add: CustomEvent<any>;
                                                                                                                                                                completed: CustomEvent<JobReturnType>;
                                                                                                                                                                empty: CustomEvent<any>;
                                                                                                                                                                error: CustomEvent<Error>;
                                                                                                                                                                failure: CustomEvent<QueueJobFailure<JobReturnType, JobOptions>>;
                                                                                                                                                                idle: CustomEvent<any>;
                                                                                                                                                                next: CustomEvent<any>;
                                                                                                                                                                success: CustomEvent<QueueJobSuccess<JobReturnType, JobOptions>>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            active add completed empty @@ -8,14 +8,14 @@ next success

                                                                                                                                                            Properties

                                                                                                                                                            active: CustomEvent<any>

                                                                                                                                                            A job is about to start running

                                                                                                                                                            -
                                                                                                                                                            add: CustomEvent<any>

                                                                                                                                                            A job was added to the queue

                                                                                                                                                            -

                                                                                                                                                            A job has finished successfully

                                                                                                                                                            -
                                                                                                                                                            empty: CustomEvent<any>

                                                                                                                                                            The queue is empty, jobs may be running

                                                                                                                                                            -

                                                                                                                                                            A job has failed

                                                                                                                                                            -

                                                                                                                                                            Emitted just after `"error", a job has failed - this event gives access to +

                                                                                                                                                            add: CustomEvent<any>

                                                                                                                                                            A job was added to the queue

                                                                                                                                                            +

                                                                                                                                                            A job has finished successfully

                                                                                                                                                            +
                                                                                                                                                            empty: CustomEvent<any>

                                                                                                                                                            The queue is empty, jobs may be running

                                                                                                                                                            +

                                                                                                                                                            A job has failed

                                                                                                                                                            +

                                                                                                                                                            Emitted just after `"error", a job has failed - this event gives access to the job and the thrown error

                                                                                                                                                            -
                                                                                                                                                            idle: CustomEvent<any>

                                                                                                                                                            All jobs have finished and the queue is empty

                                                                                                                                                            -
                                                                                                                                                            next: CustomEvent<any>

                                                                                                                                                            A job has finished or failed

                                                                                                                                                            -

                                                                                                                                                            Emitted just after `"completed", a job has finished successfully - this +

                                                                                                                                                            idle: CustomEvent<any>

                                                                                                                                                            All jobs have finished and the queue is empty

                                                                                                                                                            +
                                                                                                                                                            next: CustomEvent<any>

                                                                                                                                                            A job has finished or failed

                                                                                                                                                            +

                                                                                                                                                            Emitted just after `"completed", a job has finished successfully - this event gives access to the job and it's result

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.QueueInit.html b/interfaces/_libp2p_utils.queue.QueueInit.html index 932887f214..b1d4ff78c4 100644 --- a/interfaces/_libp2p_utils.queue.QueueInit.html +++ b/interfaces/_libp2p_utils.queue.QueueInit.html @@ -1,4 +1,4 @@ -QueueInit | libp2p

                                                                                                                                                            Interface QueueInit<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueInit<JobReturnType, JobOptions> {
                                                                                                                                                                concurrency?: number;
                                                                                                                                                                metricName?: string;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                sort?: Comparator<Job<JobOptions, JobReturnType>>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            concurrency? +QueueInit | libp2p

                                                                                                                                                            Interface QueueInit<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueInit<JobReturnType, JobOptions> {
                                                                                                                                                                concurrency?: number;
                                                                                                                                                                metricName?: string;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                sort?: Comparator<Job<JobOptions, JobReturnType>>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            concurrency? metricName? metrics? sort? @@ -6,7 +6,7 @@

                                                                                                                                                            Minimum: 1.

                                                                                                                                                            Default

                                                                                                                                                            Infinity
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            metricName?: string

                                                                                                                                                            The name of the metric for the queue length

                                                                                                                                                            -
                                                                                                                                                            metrics?: Metrics

                                                                                                                                                            An implementation of the libp2p Metrics interface

                                                                                                                                                            -

                                                                                                                                                            An optional function that will sort the queue after a job has been added

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            metricName?: string

                                                                                                                                                            The name of the metric for the queue length

                                                                                                                                                            +
                                                                                                                                                            metrics?: Metrics

                                                                                                                                                            An implementation of the libp2p Metrics interface

                                                                                                                                                            +

                                                                                                                                                            An optional function that will sort the queue after a job has been added

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.QueueJobFailure.html b/interfaces/_libp2p_utils.queue.QueueJobFailure.html index 403ee4143c..239cf2e34a 100644 --- a/interfaces/_libp2p_utils.queue.QueueJobFailure.html +++ b/interfaces/_libp2p_utils.queue.QueueJobFailure.html @@ -1,3 +1,3 @@ -QueueJobFailure | libp2p

                                                                                                                                                            Interface QueueJobFailure<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueJobFailure<JobReturnType, JobOptions> {
                                                                                                                                                                error: Error;
                                                                                                                                                                job: Job<JobOptions, JobReturnType>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            error +QueueJobFailure | libp2p

                                                                                                                                                            Interface QueueJobFailure<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueJobFailure<JobReturnType, JobOptions> {
                                                                                                                                                                error: Error;
                                                                                                                                                                job: Job<JobOptions, JobReturnType>;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            error: Error
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            error: Error
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.QueueJobSuccess.html b/interfaces/_libp2p_utils.queue.QueueJobSuccess.html index 587e4e5923..498228b5f3 100644 --- a/interfaces/_libp2p_utils.queue.QueueJobSuccess.html +++ b/interfaces/_libp2p_utils.queue.QueueJobSuccess.html @@ -1,3 +1,3 @@ -QueueJobSuccess | libp2p

                                                                                                                                                            Interface QueueJobSuccess<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueJobSuccess<JobReturnType, JobOptions> {
                                                                                                                                                                job: Job<JobOptions, JobReturnType>;
                                                                                                                                                                result: JobReturnType;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            job +QueueJobSuccess | libp2p

                                                                                                                                                            Interface QueueJobSuccess<JobReturnType, JobOptions>

                                                                                                                                                            interface QueueJobSuccess<JobReturnType, JobOptions> {
                                                                                                                                                                job: Job<JobOptions, JobReturnType>;
                                                                                                                                                                result: JobReturnType;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.queue.RunFunction.html b/interfaces/_libp2p_utils.queue.RunFunction.html index fbf419369d..622ee6b420 100644 --- a/interfaces/_libp2p_utils.queue.RunFunction.html +++ b/interfaces/_libp2p_utils.queue.RunFunction.html @@ -1 +1 @@ -RunFunction | libp2p

                                                                                                                                                            Interface RunFunction<Options, ReturnType>

                                                                                                                                                            interface RunFunction<Options, ReturnType> ((opts?) => Promise<ReturnType>)

                                                                                                                                                            Type Parameters

                                                                                                                                                            \ No newline at end of file +RunFunction | libp2p

                                                                                                                                                            Interface RunFunction<Options, ReturnType>

                                                                                                                                                            interface RunFunction<Options, ReturnType> ((opts?) => Promise<ReturnType>)

                                                                                                                                                            Type Parameters

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.rate_limiter.GetKeySecDurationOptions.html b/interfaces/_libp2p_utils.rate_limiter.GetKeySecDurationOptions.html index 1af43072e1..913f8c0655 100644 --- a/interfaces/_libp2p_utils.rate_limiter.GetKeySecDurationOptions.html +++ b/interfaces/_libp2p_utils.rate_limiter.GetKeySecDurationOptions.html @@ -1,2 +1,2 @@ -GetKeySecDurationOptions | libp2p
                                                                                                                                                            interface GetKeySecDurationOptions {
                                                                                                                                                                customDuration?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            customDuration?: number
                                                                                                                                                            \ No newline at end of file +GetKeySecDurationOptions | libp2p
                                                                                                                                                            interface GetKeySecDurationOptions {
                                                                                                                                                                customDuration?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            customDuration?: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.rate_limiter.RateLimiterInit.html b/interfaces/_libp2p_utils.rate_limiter.RateLimiterInit.html index df3e5a90f8..4452002c81 100644 --- a/interfaces/_libp2p_utils.rate_limiter.RateLimiterInit.html +++ b/interfaces/_libp2p_utils.rate_limiter.RateLimiterInit.html @@ -1,4 +1,4 @@ -RateLimiterInit | libp2p
                                                                                                                                                            interface RateLimiterInit {
                                                                                                                                                                blockDuration?: number;
                                                                                                                                                                duration?: number;
                                                                                                                                                                execEvenly?: boolean;
                                                                                                                                                                execEvenlyMinDelayMs?: number;
                                                                                                                                                                keyPrefix?: string;
                                                                                                                                                                points?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            blockDuration? +RateLimiterInit | libp2p
                                                                                                                                                            interface RateLimiterInit {
                                                                                                                                                                blockDuration?: number;
                                                                                                                                                                duration?: number;
                                                                                                                                                                execEvenly?: boolean;
                                                                                                                                                                execEvenlyMinDelayMs?: number;
                                                                                                                                                                keyPrefix?: string;
                                                                                                                                                                points?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            blockDuration?: number

                                                                                                                                                            Block if consumed more than points in current duration for blockDuration seconds

                                                                                                                                                            Default

                                                                                                                                                            0
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            duration?: number

                                                                                                                                                            Per seconds

                                                                                                                                                            +
                                                                                                                                                            duration?: number

                                                                                                                                                            Per seconds

                                                                                                                                                            Default

                                                                                                                                                            1
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            execEvenly?: boolean

                                                                                                                                                            Execute allowed actions evenly over duration

                                                                                                                                                            +
                                                                                                                                                            execEvenly?: boolean

                                                                                                                                                            Execute allowed actions evenly over duration

                                                                                                                                                            Default

                                                                                                                                                            false
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            execEvenlyMinDelayMs?: number

                                                                                                                                                            ms, works with execEvenly=true option

                                                                                                                                                            +
                                                                                                                                                            execEvenlyMinDelayMs?: number

                                                                                                                                                            ms, works with execEvenly=true option

                                                                                                                                                            Default

                                                                                                                                                            duration * 1000 / points
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            keyPrefix?: string

                                                                                                                                                            Default

                                                                                                                                                            rlflx
                                                                                                                                                            +
                                                                                                                                                            keyPrefix?: string

                                                                                                                                                            Default

                                                                                                                                                            rlflx
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            points?: number

                                                                                                                                                            Number of points

                                                                                                                                                            +
                                                                                                                                                            points?: number

                                                                                                                                                            Number of points

                                                                                                                                                            Default

                                                                                                                                                            4
                                                                                                                                                             
                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.rate_limiter.RateLimiterResult.html b/interfaces/_libp2p_utils.rate_limiter.RateLimiterResult.html index 9faba8bffe..b390e86bab 100644 --- a/interfaces/_libp2p_utils.rate_limiter.RateLimiterResult.html +++ b/interfaces/_libp2p_utils.rate_limiter.RateLimiterResult.html @@ -1,5 +1,5 @@ -RateLimiterResult | libp2p
                                                                                                                                                            interface RateLimiterResult {
                                                                                                                                                                consumedPoints: number;
                                                                                                                                                                isFirstInDuration: boolean;
                                                                                                                                                                msBeforeNext: number;
                                                                                                                                                                remainingPoints: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            consumedPoints +RateLimiterResult | libp2p
                                                                                                                                                            interface RateLimiterResult {
                                                                                                                                                                consumedPoints: number;
                                                                                                                                                                isFirstInDuration: boolean;
                                                                                                                                                                msBeforeNext: number;
                                                                                                                                                                remainingPoints: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            consumedPoints: number
                                                                                                                                                            isFirstInDuration: boolean
                                                                                                                                                            msBeforeNext: number
                                                                                                                                                            remainingPoints: number
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            consumedPoints: number
                                                                                                                                                            isFirstInDuration: boolean
                                                                                                                                                            msBeforeNext: number
                                                                                                                                                            remainingPoints: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.rate_limiter.RateRecord.html b/interfaces/_libp2p_utils.rate_limiter.RateRecord.html index f7be21ee44..bf30fe0649 100644 --- a/interfaces/_libp2p_utils.rate_limiter.RateRecord.html +++ b/interfaces/_libp2p_utils.rate_limiter.RateRecord.html @@ -1,4 +1,4 @@ -RateRecord | libp2p
                                                                                                                                                            interface RateRecord {
                                                                                                                                                                expiresAt?: Date;
                                                                                                                                                                timeoutId?: Timeout;
                                                                                                                                                                value: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            expiresAt? +RateRecord | libp2p
                                                                                                                                                            interface RateRecord {
                                                                                                                                                                expiresAt?: Date;
                                                                                                                                                                timeoutId?: Timeout;
                                                                                                                                                                value: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            expiresAt?: Date
                                                                                                                                                            timeoutId?: Timeout
                                                                                                                                                            value: number
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            expiresAt?: Date
                                                                                                                                                            timeoutId?: Timeout
                                                                                                                                                            value: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.stream_to_ma_conn.StreamProperties.html b/interfaces/_libp2p_utils.stream_to_ma_conn.StreamProperties.html index 42212a2a78..a095c3e3a3 100644 --- a/interfaces/_libp2p_utils.stream_to_ma_conn.StreamProperties.html +++ b/interfaces/_libp2p_utils.stream_to_ma_conn.StreamProperties.html @@ -1,9 +1,9 @@ -StreamProperties | libp2p
                                                                                                                                                            interface StreamProperties {
                                                                                                                                                                localAddr: Multiaddr;
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                remoteAddr: Multiaddr;
                                                                                                                                                                stream: Stream;
                                                                                                                                                                onDataRead?(buf): void;
                                                                                                                                                                onDataWrite?(buf): void;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            localAddr +StreamProperties | libp2p
                                                                                                                                                            interface StreamProperties {
                                                                                                                                                                localAddr: Multiaddr;
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                remoteAddr: Multiaddr;
                                                                                                                                                                stream: Stream;
                                                                                                                                                                onDataRead?(buf): void;
                                                                                                                                                                onDataWrite?(buf): void;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            localAddr: Multiaddr
                                                                                                                                                            remoteAddr: Multiaddr
                                                                                                                                                            stream: Stream

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            localAddr: Multiaddr
                                                                                                                                                            remoteAddr: Multiaddr
                                                                                                                                                            stream: Stream

                                                                                                                                                            Methods

                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.tracked_list.CreateTrackedListInit.html b/interfaces/_libp2p_utils.tracked_list.CreateTrackedListInit.html index 0ff9dfdf5b..d0cd779681 100644 --- a/interfaces/_libp2p_utils.tracked_list.CreateTrackedListInit.html +++ b/interfaces/_libp2p_utils.tracked_list.CreateTrackedListInit.html @@ -1,5 +1,5 @@ -CreateTrackedListInit | libp2p
                                                                                                                                                            interface CreateTrackedListInit {
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            metrics? +CreateTrackedListInit | libp2p
                                                                                                                                                            interface CreateTrackedListInit {
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics

                                                                                                                                                            A metrics implementation

                                                                                                                                                            -
                                                                                                                                                            name: string

                                                                                                                                                            The metric name to use

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            name: string

                                                                                                                                                            The metric name to use

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.tracked_map.CreateTrackedMapInit.html b/interfaces/_libp2p_utils.tracked_map.CreateTrackedMapInit.html index 10b00f2e62..823f358205 100644 --- a/interfaces/_libp2p_utils.tracked_map.CreateTrackedMapInit.html +++ b/interfaces/_libp2p_utils.tracked_map.CreateTrackedMapInit.html @@ -1,5 +1,5 @@ -CreateTrackedMapInit | libp2p
                                                                                                                                                            interface CreateTrackedMapInit {
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            metrics? +CreateTrackedMapInit | libp2p
                                                                                                                                                            interface CreateTrackedMapInit {
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics

                                                                                                                                                            A metrics implementation

                                                                                                                                                            -
                                                                                                                                                            name: string

                                                                                                                                                            The metric name to use

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            name: string

                                                                                                                                                            The metric name to use

                                                                                                                                                            +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_utils.tracked_map.TrackedMapInit.html b/interfaces/_libp2p_utils.tracked_map.TrackedMapInit.html index 6b1336fb8f..27a6fd2525 100644 --- a/interfaces/_libp2p_utils.tracked_map.TrackedMapInit.html +++ b/interfaces/_libp2p_utils.tracked_map.TrackedMapInit.html @@ -1,3 +1,3 @@ -TrackedMapInit | libp2p
                                                                                                                                                            interface TrackedMapInit {
                                                                                                                                                                metrics: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            metrics +TrackedMapInit | libp2p
                                                                                                                                                            interface TrackedMapInit {
                                                                                                                                                                metrics: Metrics;
                                                                                                                                                                name: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            metrics: Metrics
                                                                                                                                                            name: string
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            metrics: Metrics
                                                                                                                                                            name: string
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_webrtc.DataChannelOptions.html b/interfaces/_libp2p_webrtc.DataChannelOptions.html index e397416c59..df97097681 100644 --- a/interfaces/_libp2p_webrtc.DataChannelOptions.html +++ b/interfaces/_libp2p_webrtc.DataChannelOptions.html @@ -1,4 +1,4 @@ -DataChannelOptions | libp2p

                                                                                                                                                            Interface DataChannelOptions

                                                                                                                                                            interface DataChannelOptions {
                                                                                                                                                                bufferedAmountLowEventTimeout?: number;
                                                                                                                                                                closeTimeout?: number;
                                                                                                                                                                drainTimeout?: number;
                                                                                                                                                                maxBufferedAmount?: number;
                                                                                                                                                                maxMessageSize?: number;
                                                                                                                                                                openTimeout?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            bufferedAmountLowEventTimeout? +DataChannelOptions | libp2p

                                                                                                                                                            Interface DataChannelOptions

                                                                                                                                                            interface DataChannelOptions {
                                                                                                                                                                bufferedAmountLowEventTimeout?: number;
                                                                                                                                                                closeTimeout?: number;
                                                                                                                                                                drainTimeout?: number;
                                                                                                                                                                maxBufferedAmount?: number;
                                                                                                                                                                maxMessageSize?: number;
                                                                                                                                                                openTimeout?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            bufferedAmountLowEventTimeout?: number

                                                                                                                                                            When bufferedAmount is above maxBufferedAmount, we pause sending until the bufferedAmountLow event fires - this controls how long we wait for that event in ms (default: 30s)

                                                                                                                                                            -
                                                                                                                                                            closeTimeout?: number

                                                                                                                                                            When closing a stream we first send a FIN flag to the remote and wait +

                                                                                                                                                            closeTimeout?: number

                                                                                                                                                            When closing a stream we first send a FIN flag to the remote and wait for a FIN_ACK reply before closing the underlying RTCDataChannel - this controls how long we wait for the acknowledgement in ms (default: 5s)

                                                                                                                                                            -
                                                                                                                                                            drainTimeout?: number

                                                                                                                                                            When closing a stream, we wait for bufferedAmount to become 0 before +

                                                                                                                                                            drainTimeout?: number

                                                                                                                                                            When closing a stream, we wait for bufferedAmount to become 0 before closing the underlying RTCDataChannel - this controls how long we wait in ms (default: 30s)

                                                                                                                                                            -
                                                                                                                                                            maxBufferedAmount?: number

                                                                                                                                                            If the channel's bufferedAmount grows over this amount in bytes, wait +

                                                                                                                                                            maxBufferedAmount?: number

                                                                                                                                                            If the channel's bufferedAmount grows over this amount in bytes, wait for it to drain before sending more data (default: 16MB)

                                                                                                                                                            -
                                                                                                                                                            maxMessageSize?: number

                                                                                                                                                            The maximum message size sendable over the channel in bytes (default 16KB)

                                                                                                                                                            -
                                                                                                                                                            openTimeout?: number

                                                                                                                                                            When sending the first data message, if the channel is not in the "open" +

                                                                                                                                                            maxMessageSize?: number

                                                                                                                                                            The maximum message size sendable over the channel in bytes (default 16KB)

                                                                                                                                                            +
                                                                                                                                                            openTimeout?: number

                                                                                                                                                            When sending the first data message, if the channel is not in the "open" state, wait this long for the "open" event to fire.

                                                                                                                                                            -
                                                                                                                                                            \ No newline at end of file +
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_websockets.index.WebSocketsComponents.html b/interfaces/_libp2p_websockets.index.WebSocketsComponents.html index 6211f5277a..64b7a297c2 100644 --- a/interfaces/_libp2p_websockets.index.WebSocketsComponents.html +++ b/interfaces/_libp2p_websockets.index.WebSocketsComponents.html @@ -1,3 +1,3 @@ -WebSocketsComponents | libp2p
                                                                                                                                                            interface WebSocketsComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            logger +WebSocketsComponents | libp2p
                                                                                                                                                            interface WebSocketsComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_websockets.index.WebSocketsInit.html b/interfaces/_libp2p_websockets.index.WebSocketsInit.html index f006cb5a7c..ac54d67a17 100644 --- a/interfaces/_libp2p_websockets.index.WebSocketsInit.html +++ b/interfaces/_libp2p_websockets.index.WebSocketsInit.html @@ -2,9 +2,9 @@ the optional signal property.

                                                                                                                                                            Example

                                                                                                                                                            const controller = new AbortController()

                                                                                                                                                            aLongRunningOperation({
                                                                                                                                                            signal: controller.signal
                                                                                                                                                            })

                                                                                                                                                            // later

                                                                                                                                                            controller.abort()
                                                                                                                                                            -
                                                                                                                                                            interface WebSocketsInit {
                                                                                                                                                                closeOnEnd?: boolean;
                                                                                                                                                                filter?: MultiaddrFilter;
                                                                                                                                                                server?: Server<typeof IncomingMessage, typeof ServerResponse>;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                websocket?: ClientOptions;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            interface WebSocketsInit {
                                                                                                                                                                closeOnEnd?: boolean;
                                                                                                                                                                filter?: MultiaddrFilter;
                                                                                                                                                                server?: Server<typeof IncomingMessage, typeof ServerResponse>;
                                                                                                                                                                signal?: AbortSignal;
                                                                                                                                                                websocket?: ClientOptions;
                                                                                                                                                            }

                                                                                                                                                            Hierarchy (view full)

                                                                                                                                                            Properties

                                                                                                                                                            closeOnEnd?: boolean
                                                                                                                                                            server?: Server<typeof IncomingMessage, typeof ServerResponse>
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            websocket?: ClientOptions
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            closeOnEnd?: boolean
                                                                                                                                                            server?: Server<typeof IncomingMessage, typeof ServerResponse>
                                                                                                                                                            signal?: AbortSignal
                                                                                                                                                            websocket?: ClientOptions
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_websockets.index.WebSocketsMetrics.html b/interfaces/_libp2p_websockets.index.WebSocketsMetrics.html index 677e353e3a..18130dfec7 100644 --- a/interfaces/_libp2p_websockets.index.WebSocketsMetrics.html +++ b/interfaces/_libp2p_websockets.index.WebSocketsMetrics.html @@ -1,2 +1,2 @@ -WebSocketsMetrics | libp2p
                                                                                                                                                            interface WebSocketsMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<any>;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<any>
                                                                                                                                                            \ No newline at end of file +WebSocketsMetrics | libp2p
                                                                                                                                                            interface WebSocketsMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<any>;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<any>
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_webtransport.WebTransportCertificate.html b/interfaces/_libp2p_webtransport.WebTransportCertificate.html index d14dca8f74..1a3c15848e 100644 --- a/interfaces/_libp2p_webtransport.WebTransportCertificate.html +++ b/interfaces/_libp2p_webtransport.WebTransportCertificate.html @@ -1,6 +1,6 @@ WebTransportCertificate | libp2p

                                                                                                                                                            Interface WebTransportCertificate

                                                                                                                                                            PEM format server certificate and private key

                                                                                                                                                            -
                                                                                                                                                            interface WebTransportCertificate {
                                                                                                                                                                hash: MultihashDigest<number>;
                                                                                                                                                                pem: string;
                                                                                                                                                                privateKey: string;
                                                                                                                                                                secret: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            interface WebTransportCertificate {
                                                                                                                                                                hash: MultihashDigest<number>;
                                                                                                                                                                pem: string;
                                                                                                                                                                privateKey: string;
                                                                                                                                                                secret: string;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            hash: MultihashDigest<number>
                                                                                                                                                            pem: string
                                                                                                                                                            privateKey: string
                                                                                                                                                            secret: string
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            hash: MultihashDigest<number>
                                                                                                                                                            pem: string
                                                                                                                                                            privateKey: string
                                                                                                                                                            secret: string
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_webtransport.WebTransportComponents.html b/interfaces/_libp2p_webtransport.WebTransportComponents.html index 598bdcd68a..22bfca3921 100644 --- a/interfaces/_libp2p_webtransport.WebTransportComponents.html +++ b/interfaces/_libp2p_webtransport.WebTransportComponents.html @@ -1,5 +1,5 @@ -WebTransportComponents | libp2p

                                                                                                                                                            Interface WebTransportComponents

                                                                                                                                                            interface WebTransportComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                privateKey: PrivateKey;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            logger +WebTransportComponents | libp2p

                                                                                                                                                            Interface WebTransportComponents

                                                                                                                                                            interface WebTransportComponents {
                                                                                                                                                                logger: ComponentLogger;
                                                                                                                                                                metrics?: Metrics;
                                                                                                                                                                peerId: PeerId;
                                                                                                                                                                privateKey: PrivateKey;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            peerId: PeerId
                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            metrics?: Metrics
                                                                                                                                                            peerId: PeerId
                                                                                                                                                            privateKey: PrivateKey
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_webtransport.WebTransportInit.html b/interfaces/_libp2p_webtransport.WebTransportInit.html index 6e6724c397..b0d9bef777 100644 --- a/interfaces/_libp2p_webtransport.WebTransportInit.html +++ b/interfaces/_libp2p_webtransport.WebTransportInit.html @@ -1,3 +1,3 @@ -WebTransportInit | libp2p
                                                                                                                                                            interface WebTransportInit {
                                                                                                                                                                certificates?: WebTransportCertificate[];
                                                                                                                                                                maxInboundStreams?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            certificates? +WebTransportInit | libp2p
                                                                                                                                                            interface WebTransportInit {
                                                                                                                                                                certificates?: WebTransportCertificate[];
                                                                                                                                                                maxInboundStreams?: number;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            certificates?: WebTransportCertificate[]
                                                                                                                                                            maxInboundStreams?: number
                                                                                                                                                            \ No newline at end of file +

                                                                                                                                                            Properties

                                                                                                                                                            certificates?: WebTransportCertificate[]
                                                                                                                                                            maxInboundStreams?: number
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/_libp2p_webtransport.WebTransportMetrics.html b/interfaces/_libp2p_webtransport.WebTransportMetrics.html index a1d612c961..691292d4ed 100644 --- a/interfaces/_libp2p_webtransport.WebTransportMetrics.html +++ b/interfaces/_libp2p_webtransport.WebTransportMetrics.html @@ -1,2 +1,2 @@ -WebTransportMetrics | libp2p
                                                                                                                                                            interface WebTransportMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<any>;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<any>
                                                                                                                                                            \ No newline at end of file +WebTransportMetrics | libp2p
                                                                                                                                                            interface WebTransportMetrics {
                                                                                                                                                                dialerEvents: CounterGroup<any>;
                                                                                                                                                            }

                                                                                                                                                            Properties

                                                                                                                                                            Properties

                                                                                                                                                            dialerEvents: CounterGroup<any>
                                                                                                                                                            \ No newline at end of file diff --git a/interfaces/libp2p.index.Libp2pInit.html b/interfaces/libp2p.index.Libp2pInit.html index e42c086fdc..8b41f38103 100644 --- a/interfaces/libp2p.index.Libp2pInit.html +++ b/interfaces/libp2p.index.Libp2pInit.html @@ -1,5 +1,5 @@ Libp2pInit | libp2p

                                                                                                                                                            Interface Libp2pInit<T>

                                                                                                                                                            For Libp2p configurations and modules details read the Configuration Document.

                                                                                                                                                            -
                                                                                                                                                            interface Libp2pInit<T> {
                                                                                                                                                                addresses?: AddressManagerInit;
                                                                                                                                                                connectionEncrypters?: ((components) => ConnectionEncrypter<unknown>)[];
                                                                                                                                                                connectionGater?: ConnectionGater;
                                                                                                                                                                connectionManager?: ConnectionManagerInit;
                                                                                                                                                                connectionMonitor?: ConnectionMonitorInit;
                                                                                                                                                                contentRouters?: ((components) => ContentRouting)[];
                                                                                                                                                                datastore?: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                                                                                                                dns?: DNS;
                                                                                                                                                                logger?: ComponentLogger;
                                                                                                                                                                nodeInfo?: NodeInfo;
                                                                                                                                                                peerDiscovery?: ((components) => PeerDiscovery)[];
                                                                                                                                                                peerRouters?: ((components) => PeerRouting)[];
                                                                                                                                                                peerStore?: PersistentPeerStoreInit;
                                                                                                                                                                privateKey?: PrivateKey;
                                                                                                                                                                services?: ServiceFactoryMap<T>;
                                                                                                                                                                streamMuxers?: ((components) => StreamMuxerFactory)[];
                                                                                                                                                                transportManager?: TransportManagerInit;
                                                                                                                                                                transports?: ((components) => Transport<ProgressEvent<any, unknown>>)[];
                                                                                                                                                                connectionProtector?(components): ConnectionProtector;
                                                                                                                                                                metrics?(components): Metrics;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            interface Libp2pInit<T> {
                                                                                                                                                                addresses?: AddressManagerInit;
                                                                                                                                                                connectionEncrypters?: ((components) => ConnectionEncrypter<unknown>)[];
                                                                                                                                                                connectionGater?: ConnectionGater;
                                                                                                                                                                connectionManager?: ConnectionManagerInit;
                                                                                                                                                                connectionMonitor?: ConnectionMonitorInit;
                                                                                                                                                                contentRouters?: ((components) => ContentRouting)[];
                                                                                                                                                                datastore?: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>;
                                                                                                                                                                dns?: DNS;
                                                                                                                                                                logger?: ComponentLogger;
                                                                                                                                                                nodeInfo?: NodeInfo;
                                                                                                                                                                peerDiscovery?: ((components) => PeerDiscovery)[];
                                                                                                                                                                peerRouters?: ((components) => PeerRouting)[];
                                                                                                                                                                peerStore?: PersistentPeerStoreInit;
                                                                                                                                                                privateKey?: PrivateKey;
                                                                                                                                                                services?: ServiceFactoryMap<T>;
                                                                                                                                                                streamMuxers?: ((components) => StreamMuxerFactory)[];
                                                                                                                                                                transportManager?: TransportManagerInit;
                                                                                                                                                                transports?: ((components) => Transport<ProgressEvent<any, unknown>>)[];
                                                                                                                                                                connectionProtector?(components): ConnectionProtector;
                                                                                                                                                                metrics?(components): Metrics;
                                                                                                                                                            }

                                                                                                                                                            Type Parameters

                                                                                                                                                            Properties

                                                                                                                                                            addresses?: AddressManagerInit

                                                                                                                                                            Addresses for transport listening and to advertise to the network

                                                                                                                                                            -
                                                                                                                                                            connectionEncrypters?: ((components) => ConnectionEncrypter<unknown>)[]

                                                                                                                                                            Connection encrypters ensure that data sent over connections cannot be +

                                                                                                                                                            connectionEncrypters?: ((components) => ConnectionEncrypter<unknown>)[]

                                                                                                                                                            Connection encrypters ensure that data sent over connections cannot be eavesdropped on, and that the remote peer posesses the private key that corresponds to the public key that it's Peer ID is derived from.

                                                                                                                                                            -

                                                                                                                                                            Type declaration

                                                                                                                                                            connectionGater?: ConnectionGater

                                                                                                                                                            A connection gater can deny new connections based on user criteria

                                                                                                                                                            -
                                                                                                                                                            connectionManager?: ConnectionManagerInit

                                                                                                                                                            libp2p Connection Manager configuration

                                                                                                                                                            -
                                                                                                                                                            connectionMonitor?: ConnectionMonitorInit

                                                                                                                                                            libp2p Connection Monitor configuration

                                                                                                                                                            -
                                                                                                                                                            contentRouters?: ((components) => ContentRouting)[]

                                                                                                                                                            Content routers provide implementations for content routing queries

                                                                                                                                                            -

                                                                                                                                                            Type declaration

                                                                                                                                                            datastore?: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                                                                                                            An optional datastore to persist peer information, DHT records, etc.

                                                                                                                                                            +

                                                                                                                                                            Type declaration

                                                                                                                                                            connectionGater?: ConnectionGater

                                                                                                                                                            A connection gater can deny new connections based on user criteria

                                                                                                                                                            +
                                                                                                                                                            connectionManager?: ConnectionManagerInit

                                                                                                                                                            libp2p Connection Manager configuration

                                                                                                                                                            +
                                                                                                                                                            connectionMonitor?: ConnectionMonitorInit

                                                                                                                                                            libp2p Connection Monitor configuration

                                                                                                                                                            +
                                                                                                                                                            contentRouters?: ((components) => ContentRouting)[]

                                                                                                                                                            Content routers provide implementations for content routing queries

                                                                                                                                                            +

                                                                                                                                                            Type declaration

                                                                                                                                                            datastore?: Datastore<{}, {}, {}, {}, {}, {}, {}, {}, {}, {}>

                                                                                                                                                            An optional datastore to persist peer information, DHT records, etc.

                                                                                                                                                            An in-memory datastore will be used if one is not provided.

                                                                                                                                                            -

                                                                                                                                                            Type declaration

                                                                                                                                                              Type declaration

                                                                                                                                                                Type declaration

                                                                                                                                                                  Type declaration

                                                                                                                                                                    Type declaration

                                                                                                                                                                      Type declaration

                                                                                                                                                                        Type declaration

                                                                                                                                                                          Type declaration

                                                                                                                                                                            Type declaration

                                                                                                                                                                              Type declaration

                                                                                                                                                                                dns?: DNS

                                                                                                                                                                                An optional DNS resolver configuration. If omitted the default DNS resolver +

                                                                                                                                                                                Type declaration

                                                                                                                                                                                  Type declaration

                                                                                                                                                                                    Type declaration

                                                                                                                                                                                      Type declaration

                                                                                                                                                                                        Type declaration

                                                                                                                                                                                          Type declaration

                                                                                                                                                                                            Type declaration

                                                                                                                                                                                              Type declaration

                                                                                                                                                                                                Type declaration

                                                                                                                                                                                                  Type declaration

                                                                                                                                                                                                    dns?: DNS

                                                                                                                                                                                                    An optional DNS resolver configuration. If omitted the default DNS resolver for the platform will be used which means node:dns on Node.js and DNS-JSON-over-HTTPS for browsers using Google and Cloudflare servers.

                                                                                                                                                                                                    -

                                                                                                                                                                                                    An optional logging implementation that can be used to write runtime logs.

                                                                                                                                                                                                    +

                                                                                                                                                                                                    An optional logging implementation that can be used to write runtime logs.

                                                                                                                                                                                                    Set the DEBUG env var or the debug key on LocalStorage to see logs.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    Node.js:

                                                                                                                                                                                                    $ DEBUG="*libp2p:*" node myscript.js
                                                                                                                                                                                                    @@ -40,19 +40,19 @@
                                                                                                                                                                                                     

                                                                                                                                                                                                    Browsers:

                                                                                                                                                                                                    localStorage.setItem('debug', '*libp2p:*')
                                                                                                                                                                                                     
                                                                                                                                                                                                    -
                                                                                                                                                                                                    nodeInfo?: NodeInfo

                                                                                                                                                                                                    Metadata about the node - implementation name, version number, etc

                                                                                                                                                                                                    -
                                                                                                                                                                                                    peerDiscovery?: ((components) => PeerDiscovery)[]

                                                                                                                                                                                                    Peer discovery mechanisms allow finding peers on the network

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    peerRouters?: ((components) => PeerRouting)[]

                                                                                                                                                                                                    Peer routers provide implementations for peer routing queries

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    libp2p PeerStore configuration

                                                                                                                                                                                                    -
                                                                                                                                                                                                    privateKey?: PrivateKey

                                                                                                                                                                                                    The private key is used in cryptographic operations and the Peer ID derived +

                                                                                                                                                                                                    nodeInfo?: NodeInfo

                                                                                                                                                                                                    Metadata about the node - implementation name, version number, etc

                                                                                                                                                                                                    +
                                                                                                                                                                                                    peerDiscovery?: ((components) => PeerDiscovery)[]

                                                                                                                                                                                                    Peer discovery mechanisms allow finding peers on the network

                                                                                                                                                                                                    +

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    peerRouters?: ((components) => PeerRouting)[]

                                                                                                                                                                                                    Peer routers provide implementations for peer routing queries

                                                                                                                                                                                                    +

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    libp2p PeerStore configuration

                                                                                                                                                                                                    +
                                                                                                                                                                                                    privateKey?: PrivateKey

                                                                                                                                                                                                    The private key is used in cryptographic operations and the Peer ID derived from it's corresponding public key is used to identify the node to other peers on the network.

                                                                                                                                                                                                    If this is not passed a new Ed25519 private key will be generated.

                                                                                                                                                                                                    -
                                                                                                                                                                                                    services?: ServiceFactoryMap<T>

                                                                                                                                                                                                    Arbitrary libp2p modules

                                                                                                                                                                                                    -
                                                                                                                                                                                                    streamMuxers?: ((components) => StreamMuxerFactory)[]

                                                                                                                                                                                                    Stream muxers allow the creation of many data streams over a single +

                                                                                                                                                                                                    services?: ServiceFactoryMap<T>

                                                                                                                                                                                                    Arbitrary libp2p modules

                                                                                                                                                                                                    +
                                                                                                                                                                                                    streamMuxers?: ((components) => StreamMuxerFactory)[]

                                                                                                                                                                                                    Stream muxers allow the creation of many data streams over a single connection.

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    transportManager?: TransportManagerInit

                                                                                                                                                                                                    libp2p transport manager configuration

                                                                                                                                                                                                    -
                                                                                                                                                                                                    transports?: ((components) => Transport<ProgressEvent<any, unknown>>)[]

                                                                                                                                                                                                    Transports are low-level communication channels

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    Methods

                                                                                                                                                                                                    \ No newline at end of file +

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    transportManager?: TransportManagerInit

                                                                                                                                                                                                    libp2p transport manager configuration

                                                                                                                                                                                                    +
                                                                                                                                                                                                    transports?: ((components) => Transport<ProgressEvent<any, unknown>>)[]

                                                                                                                                                                                                    Transports are low-level communication channels

                                                                                                                                                                                                    +

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    Methods

                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_crypto.hmac.html b/modules/_libp2p_crypto.hmac.html index d1553f4887..f60512648f 100644 --- a/modules/_libp2p_crypto.hmac.html +++ b/modules/_libp2p_crypto.hmac.html @@ -1,6 +1,6 @@ hmac | libp2p

                                                                                                                                                                                                    Exposes an interface to the Keyed-Hash Message Authentication Code (HMAC) as defined in U.S. Federal Information Processing Standards Publication 198. An HMAC is a cryptographic hash that uses a key to sign a message. The receiver verifies the hash by recomputing it using the same key.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { create } from '@libp2p/hmac'

                                                                                                                                                                                                    const hash = 'SHA1' // 'SHA256' || 'SHA512'
                                                                                                                                                                                                    const hmac = await crypto.hmac.create(hash, uint8ArrayFromString('secret'))
                                                                                                                                                                                                    const sig = await hmac.digest(uint8ArrayFromString('hello world'))
                                                                                                                                                                                                    console.log(sig)
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_crypto.index.html b/modules/_libp2p_crypto.index.html index 795cda8619..0727f50430 100644 --- a/modules/_libp2p_crypto.index.html +++ b/modules/_libp2p_crypto.index.html @@ -1,7 +1,7 @@ index | libp2p

                                                                                                                                                                                                    The libp2p-crypto library depends on the Web Crypto API in the browser. Web Crypto is available in all modern browsers, however browsers restrict its usage to Secure Contexts.

                                                                                                                                                                                                    This means you will not be able to use some @libp2p/crypto functions in the browser when the page is served over HTTP.

                                                                                                                                                                                                    To enable the Web Crypto API and allow @libp2p/crypto to work fully, please serve your page over HTTPS.

                                                                                                                                                                                                    -

                                                                                                                                                                                                    References

                                                                                                                                                                                                    References

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    pbkdf2 randomBytes diff --git a/modules/_libp2p_crypto.keys.html b/modules/_libp2p_crypto.keys.html index 603f2e888f..ebd266a9b8 100644 --- a/modules/_libp2p_crypto.keys.html +++ b/modules/_libp2p_crypto.keys.html @@ -2,7 +2,7 @@

                                                                                                                                                                                                    The generateKeyPair, marshalPublicKey, and marshalPrivateKey functions accept a string type argument.

                                                                                                                                                                                                    Currently the 'RSA', 'ed25519', and secp256k1 types are supported, although ed25519 and secp256k1 keys support only signing and verification of messages.

                                                                                                                                                                                                    For encryption / decryption support, RSA keys should be used.

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    generateEphemeralKeyPair generateKeyPair generateKeyPairFromSeed keyStretcher diff --git a/modules/_libp2p_interface_compliance_tests.connection.html b/modules/_libp2p_interface_compliance_tests.connection.html index 5bc78c373f..53a5823c10 100644 --- a/modules/_libp2p_interface_compliance_tests.connection.html +++ b/modules/_libp2p_interface_compliance_tests.connection.html @@ -1,2 +1,2 @@ -connection | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    default +connection | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.connection_encryption.html b/modules/_libp2p_interface_compliance_tests.connection_encryption.html index def204edc2..809771d572 100644 --- a/modules/_libp2p_interface_compliance_tests.connection_encryption.html +++ b/modules/_libp2p_interface_compliance_tests.connection_encryption.html @@ -1,3 +1,3 @@ -connection-encryption | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    ConnectionEncrypterSetupArgs +connection-encryption | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.index.html b/modules/_libp2p_interface_compliance_tests.index.html index 6f55273f58..5dd8004be0 100644 --- a/modules/_libp2p_interface_compliance_tests.index.html +++ b/modules/_libp2p_interface_compliance_tests.index.html @@ -1,2 +1,2 @@ -index | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    TestSetup +index | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.is_valid_tick.html b/modules/_libp2p_interface_compliance_tests.is_valid_tick.html index d4e1218352..9523dd4162 100644 --- a/modules/_libp2p_interface_compliance_tests.is_valid_tick.html +++ b/modules/_libp2p_interface_compliance_tests.is_valid_tick.html @@ -1,2 +1,2 @@ -is-valid-tick | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    isValidTick +is-valid-tick | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.matchers.html b/modules/_libp2p_interface_compliance_tests.matchers.html index 992cdd3ded..19405c9d8a 100644 --- a/modules/_libp2p_interface_compliance_tests.matchers.html +++ b/modules/_libp2p_interface_compliance_tests.matchers.html @@ -1,3 +1,3 @@ -matchers | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    matchMultiaddr +matchers | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.mocks.html b/modules/_libp2p_interface_compliance_tests.mocks.html index d595e50445..4cb847a676 100644 --- a/modules/_libp2p_interface_compliance_tests.mocks.html +++ b/modules/_libp2p_interface_compliance_tests.mocks.html @@ -1,4 +1,4 @@ -mocks | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    MockNetworkComponents +mocks | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Variables

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    connectionPair diff --git a/modules/_libp2p_interface_compliance_tests.peer_discovery.html b/modules/_libp2p_interface_compliance_tests.peer_discovery.html index 872c9bc31c..e9b7632c8c 100644 --- a/modules/_libp2p_interface_compliance_tests.peer_discovery.html +++ b/modules/_libp2p_interface_compliance_tests.peer_discovery.html @@ -1,2 +1,2 @@ -peer-discovery | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    default +peer-discovery | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.pubsub.html b/modules/_libp2p_interface_compliance_tests.pubsub.html index 8a0ba8ea57..2d7cfc9b79 100644 --- a/modules/_libp2p_interface_compliance_tests.pubsub.html +++ b/modules/_libp2p_interface_compliance_tests.pubsub.html @@ -1,4 +1,4 @@ -pubsub | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    PubSubArgs +pubsub | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.stream_muxer.html b/modules/_libp2p_interface_compliance_tests.stream_muxer.html index 9ed29ad179..7373a83de9 100644 --- a/modules/_libp2p_interface_compliance_tests.stream_muxer.html +++ b/modules/_libp2p_interface_compliance_tests.stream_muxer.html @@ -1,2 +1,2 @@ -stream-muxer | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    default +stream-muxer | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_interface_compliance_tests.transport.html b/modules/_libp2p_interface_compliance_tests.transport.html index 4af79a8f60..b6e574ee4a 100644 --- a/modules/_libp2p_interface_compliance_tests.transport.html +++ b/modules/_libp2p_interface_compliance_tests.transport.html @@ -1,4 +1,4 @@ -transport | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Connector +transport | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_kad_dht.MessageType.html b/modules/_libp2p_kad_dht.MessageType.html index 3d729b274c..348a62b05e 100644 --- a/modules/_libp2p_kad_dht.MessageType.html +++ b/modules/_libp2p_kad_dht.MessageType.html @@ -1,3 +1,3 @@ MessageType | libp2p

                                                                                                                                                                                                    The types of messages sent to peers during DHT queries

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_pubsub.index.html b/modules/_libp2p_pubsub.index.html index fc818e753a..1e050ba1c6 100644 --- a/modules/_libp2p_pubsub.index.html +++ b/modules/_libp2p_pubsub.index.html @@ -1,6 +1,6 @@ index | libp2p

                                                                                                                                                                                                    A set of components to be extended in order to create a pubsub implementation.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { PubSubBaseProtocol } from '@libp2p/pubsub'
                                                                                                                                                                                                    import type { PubSubRPC, PublishResult, PubSubRPCMessage, PeerId, Message } from '@libp2p/interface'
                                                                                                                                                                                                    import type { Uint8ArrayList } from 'uint8arraylist'

                                                                                                                                                                                                    class MyPubsubImplementation extends PubSubBaseProtocol {
                                                                                                                                                                                                    decodeRpc (bytes: Uint8Array | Uint8ArrayList): PubSubRPC {
                                                                                                                                                                                                    throw new Error('Not implemented')
                                                                                                                                                                                                    }

                                                                                                                                                                                                    encodeRpc (rpc: PubSubRPC): Uint8Array {
                                                                                                                                                                                                    throw new Error('Not implemented')
                                                                                                                                                                                                    }

                                                                                                                                                                                                    encodeMessage (rpc: PubSubRPCMessage): Uint8Array {
                                                                                                                                                                                                    throw new Error('Not implemented')
                                                                                                                                                                                                    }

                                                                                                                                                                                                    async publishMessage (sender: PeerId, message: Message): Promise<PublishResult> {
                                                                                                                                                                                                    throw new Error('Not implemented')
                                                                                                                                                                                                    }
                                                                                                                                                                                                    }
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_pubsub.peer_streams.html b/modules/_libp2p_pubsub.peer_streams.html index 2e6bd1a87e..1b6209a8d0 100644 --- a/modules/_libp2p_pubsub.peer_streams.html +++ b/modules/_libp2p_pubsub.peer_streams.html @@ -1,4 +1,4 @@ -peer-streams | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    PeerStreams +peer-streams | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_pubsub.utils.html b/modules/_libp2p_pubsub.utils.html index 94a1ca8068..8093c100a7 100644 --- a/modules/_libp2p_pubsub.utils.html +++ b/modules/_libp2p_pubsub.utils.html @@ -1,4 +1,4 @@ -utils | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    anyMatch +utils | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    anyMatch bigIntFromBytes bigIntToBytes ensureArray diff --git a/modules/_libp2p_utils.abort_options.html b/modules/_libp2p_utils.abort_options.html index d5019c88fd..e6e29b1218 100644 --- a/modules/_libp2p_utils.abort_options.html +++ b/modules/_libp2p_utils.abort_options.html @@ -1,2 +1,2 @@ -abort-options | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    createTimeoutOptions +abort-options | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.abstract_stream.html b/modules/_libp2p_utils.abstract_stream.html index 44e4908c65..61c70e350e 100644 --- a/modules/_libp2p_utils.abstract_stream.html +++ b/modules/_libp2p_utils.abstract_stream.html @@ -1,3 +1,3 @@ -abstract-stream | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    AbstractStream +abstract-stream | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.adaptive_timeout.html b/modules/_libp2p_utils.adaptive_timeout.html index 65f00b710a..907fca2be3 100644 --- a/modules/_libp2p_utils.adaptive_timeout.html +++ b/modules/_libp2p_utils.adaptive_timeout.html @@ -1,4 +1,4 @@ -adaptive-timeout | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    AdaptiveTimeout +adaptive-timeout | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    AdaptiveTimeoutInit AdaptiveTimeoutSignal GetTimeoutSignalOptions diff --git a/modules/_libp2p_utils.address_sort.html b/modules/_libp2p_utils.address_sort.html index c805a65595..e9f47cd5ab 100644 --- a/modules/_libp2p_utils.address_sort.html +++ b/modules/_libp2p_utils.address_sort.html @@ -1,7 +1,7 @@ address-sort | libp2p

                                                                                                                                                                                                    Provides strategies to sort a list of multiaddrs.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { publicAddressesFirst } from '@libp2p/utils/address-sort'
                                                                                                                                                                                                    import { multiaddr } from '@multformats/multiaddr'


                                                                                                                                                                                                    const addresses = [
                                                                                                                                                                                                    multiaddr('/ip4/127.0.0.1/tcp/9000'),
                                                                                                                                                                                                    multiaddr('/ip4/82.41.53.1/tcp/9000')
                                                                                                                                                                                                    ].sort(publicAddressesFirst)

                                                                                                                                                                                                    console.info(addresses)
                                                                                                                                                                                                    // ['/ip4/82.41.53.1/tcp/9000', '/ip4/127.0.0.1/tcp/9000']
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    certifiedAddressesFirst circuitRelayAddressesLast defaultAddressSort publicAddressesFirst diff --git a/modules/_libp2p_utils.array_equals.html b/modules/_libp2p_utils.array_equals.html index 848137400b..30a4d242e7 100644 --- a/modules/_libp2p_utils.array_equals.html +++ b/modules/_libp2p_utils.array_equals.html @@ -1,5 +1,5 @@ array-equals | libp2p

                                                                                                                                                                                                    Provides strategies ensure arrays are equivalent.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { arrayEquals } from '@libp2p/utils/array-equals'
                                                                                                                                                                                                    import { multiaddr } from '@multformats/multiaddr'

                                                                                                                                                                                                    const ma1 = multiaddr('/ip4/127.0.0.1/tcp/9000'),
                                                                                                                                                                                                    const ma2 = multiaddr('/ip4/82.41.53.1/tcp/9000')

                                                                                                                                                                                                    console.info(arrayEquals([ma1], [ma1])) // true
                                                                                                                                                                                                    console.info(arrayEquals([ma1], [ma2])) // false
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.close.html b/modules/_libp2p_utils.close.html index 69314fbeba..464eab03eb 100644 --- a/modules/_libp2p_utils.close.html +++ b/modules/_libp2p_utils.close.html @@ -1,4 +1,4 @@ -close | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    SafelyCloseConnectionOptions +close | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.close_source.html b/modules/_libp2p_utils.close_source.html index 734463cab5..d8168c2a7f 100644 --- a/modules/_libp2p_utils.close_source.html +++ b/modules/_libp2p_utils.close_source.html @@ -1,2 +1,2 @@ -close-source | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    closeSource +close-source | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.filters.html b/modules/_libp2p_utils.filters.html index dd177bb90b..8c2d0f266e 100644 --- a/modules/_libp2p_utils.filters.html +++ b/modules/_libp2p_utils.filters.html @@ -1,4 +1,4 @@ -filters | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    BloomFilter +filters | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    BloomFilterOptions diff --git a/modules/_libp2p_utils.index.html b/modules/_libp2p_utils.index.html index eaf00a8d81..fb8829629d 100644 --- a/modules/_libp2p_utils.index.html +++ b/modules/_libp2p_utils.index.html @@ -7,4 +7,4 @@

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    Each function should be imported directly.

                                                                                                                                                                                                    import { ipPortToMultiaddr } from '@libp2p/utils/ip-port-to-multiaddr'

                                                                                                                                                                                                    const ma = ipPortToMultiaddr('127.0.0.1', 9000)
                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.ip_port_to_multiaddr.html b/modules/_libp2p_utils.ip_port_to_multiaddr.html index 1197d897f4..d43d58a46e 100644 --- a/modules/_libp2p_utils.ip_port_to_multiaddr.html +++ b/modules/_libp2p_utils.ip_port_to_multiaddr.html @@ -1,2 +1,2 @@ -ip-port-to-multiaddr | libp2p

                                                                                                                                                                                                    Module ip-port-to-multiaddr

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    ipPortToMultiaddr +ip-port-to-multiaddr | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.is_promise.html b/modules/_libp2p_utils.is_promise.html index 3b286bef87..ef043acab8 100644 --- a/modules/_libp2p_utils.is_promise.html +++ b/modules/_libp2p_utils.is_promise.html @@ -1,2 +1,2 @@ -is-promise | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    isPromise +is-promise | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.moving_average.html b/modules/_libp2p_utils.moving_average.html index 23a44e751c..60cc327dd6 100644 --- a/modules/_libp2p_utils.moving_average.html +++ b/modules/_libp2p_utils.moving_average.html @@ -1,2 +1,2 @@ -moving-average | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    MovingAverage +moving-average | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.multiaddr_is_loopback.html b/modules/_libp2p_utils.multiaddr_is_loopback.html index 0042e177fd..519b40e638 100644 --- a/modules/_libp2p_utils.multiaddr_is_loopback.html +++ b/modules/_libp2p_utils.multiaddr_is_loopback.html @@ -1,2 +1,2 @@ -multiaddr/is-loopback | libp2p

                                                                                                                                                                                                    Module multiaddr/is-loopback

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    isLoopback +multiaddr/is-loopback | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.multiaddr_is_private.html b/modules/_libp2p_utils.multiaddr_is_private.html index 9991c9523a..d4a6add647 100644 --- a/modules/_libp2p_utils.multiaddr_is_private.html +++ b/modules/_libp2p_utils.multiaddr_is_private.html @@ -1,2 +1,2 @@ -multiaddr/is-private | libp2p

                                                                                                                                                                                                    Module multiaddr/is-private

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    isPrivate +multiaddr/is-private | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.peer_queue.html b/modules/_libp2p_utils.peer_queue.html index e08530f377..670141da7d 100644 --- a/modules/_libp2p_utils.peer_queue.html +++ b/modules/_libp2p_utils.peer_queue.html @@ -1,3 +1,3 @@ -peer-queue | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    PeerQueue +peer-queue | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.priority_queue.html b/modules/_libp2p_utils.priority_queue.html index 628fbf6971..38b51bc92a 100644 --- a/modules/_libp2p_utils.priority_queue.html +++ b/modules/_libp2p_utils.priority_queue.html @@ -1,3 +1,3 @@ -priority-queue | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    PriorityQueue +priority-queue | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.private_ip.html b/modules/_libp2p_utils.private_ip.html index c9f05dcda6..5489369cc4 100644 --- a/modules/_libp2p_utils.private_ip.html +++ b/modules/_libp2p_utils.private_ip.html @@ -1,2 +1,2 @@ -private-ip | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    isPrivateIp +private-ip | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.queue.html b/modules/_libp2p_utils.queue.html index 120c6516fc..2de611603b 100644 --- a/modules/_libp2p_utils.queue.html +++ b/modules/_libp2p_utils.queue.html @@ -1,4 +1,4 @@ -queue | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Queue +queue | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Comparator JobMatcher QueueEvents diff --git a/modules/_libp2p_utils.rate_limiter.html b/modules/_libp2p_utils.rate_limiter.html index 2d910d10c9..162cd5f943 100644 --- a/modules/_libp2p_utils.rate_limiter.html +++ b/modules/_libp2p_utils.rate_limiter.html @@ -1,4 +1,4 @@ -rate-limiter | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    RateLimiter +rate-limiter | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Classes

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    GetKeySecDurationOptions RateLimiterInit RateLimiterResult diff --git a/modules/_libp2p_utils.stream_to_ma_conn.html b/modules/_libp2p_utils.stream_to_ma_conn.html index 991f02ab41..59fd2171fb 100644 --- a/modules/_libp2p_utils.stream_to_ma_conn.html +++ b/modules/_libp2p_utils.stream_to_ma_conn.html @@ -1,3 +1,3 @@ -stream-to-ma-conn | libp2p

                                                                                                                                                                                                    Module stream-to-ma-conn

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    StreamProperties +stream-to-ma-conn | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.tracked_list.html b/modules/_libp2p_utils.tracked_list.html index 6c3095784e..d509960b95 100644 --- a/modules/_libp2p_utils.tracked_list.html +++ b/modules/_libp2p_utils.tracked_list.html @@ -1,3 +1,3 @@ -tracked-list | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    CreateTrackedListInit +tracked-list | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_utils.tracked_map.html b/modules/_libp2p_utils.tracked_map.html index bf538fb197..2eab63a0f5 100644 --- a/modules/_libp2p_utils.tracked_map.html +++ b/modules/_libp2p_utils.tracked_map.html @@ -1,4 +1,4 @@ -tracked-map | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    CreateTrackedMapInit +tracked-map | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/modules/_libp2p_websockets.filters.html b/modules/_libp2p_websockets.filters.html index 6af992402b..491c7d6c9e 100644 --- a/modules/_libp2p_websockets.filters.html +++ b/modules/_libp2p_websockets.filters.html @@ -1,4 +1,4 @@ -filters | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    all +filters | libp2p

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Functions

                                                                                                                                                                                                    all dnsWsOrWss dnsWss wss diff --git a/modules/_libp2p_websockets.index.html b/modules/_libp2p_websockets.index.html index 739a438154..3eb0246e59 100644 --- a/modules/_libp2p_websockets.index.html +++ b/modules/_libp2p_websockets.index.html @@ -21,7 +21,7 @@

                                                                                                                                                                                                    Example: Allow dialing insecure WebSockets

                                                                                                                                                                                                    import { createLibp2p } from 'libp2p'
                                                                                                                                                                                                    import { webSockets } from '@libp2p/websockets'
                                                                                                                                                                                                    import * as filters from '@libp2p/websockets/filters'

                                                                                                                                                                                                    const node = await createLibp2p({
                                                                                                                                                                                                    transports: [
                                                                                                                                                                                                    webSockets({
                                                                                                                                                                                                    // connect to all sockets, even insecure ones
                                                                                                                                                                                                    filter: filters.all
                                                                                                                                                                                                    })
                                                                                                                                                                                                    ]
                                                                                                                                                                                                    })
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Type Aliases

                                                                                                                                                                                                    WebSocketsDialEvents diff --git a/modules/libp2p.index.html b/modules/libp2p.index.html index 00d00dc714..e98a341c6d 100644 --- a/modules/libp2p.index.html +++ b/modules/libp2p.index.html @@ -1,7 +1,7 @@ index | libp2p

                                                                                                                                                                                                    Module index

                                                                                                                                                                                                    Use the createLibp2p function to create a libp2p node.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { createLibp2p } from 'libp2p'

                                                                                                                                                                                                    const node = await createLibp2p({
                                                                                                                                                                                                    // ...other options
                                                                                                                                                                                                    })
                                                                                                                                                                                                    -

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Interfaces

                                                                                                                                                                                                    Type Aliases

                                                                                                                                                                                                    Libp2pOptions ServiceFactoryMap diff --git a/modules/libp2p.version.html b/modules/libp2p.version.html index 08d3df76a8..3a973a0211 100644 --- a/modules/libp2p.version.html +++ b/modules/libp2p.version.html @@ -1,3 +1,3 @@ -version | libp2p

                                                                                                                                                                                                    Module version

                                                                                                                                                                                                    Index

                                                                                                                                                                                                    Variables

                                                                                                                                                                                                    name +version | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_devtools_metrics.ApplicationMessage.html b/types/_libp2p_devtools_metrics.ApplicationMessage.html index b8607fe2a2..57fd58254f 100644 --- a/types/_libp2p_devtools_metrics.ApplicationMessage.html +++ b/types/_libp2p_devtools_metrics.ApplicationMessage.html @@ -1,2 +1,2 @@ ApplicationMessage | libp2p
                                                                                                                                                                                                    ApplicationMessage: RPCMessage

                                                                                                                                                                                                    Messages that are sent from the application page to the DevTools panel

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_devtools_metrics.DevToolsMessage.html b/types/_libp2p_devtools_metrics.DevToolsMessage.html index 25728ae6d8..70df4c62d0 100644 --- a/types/_libp2p_devtools_metrics.DevToolsMessage.html +++ b/types/_libp2p_devtools_metrics.DevToolsMessage.html @@ -1,2 +1,2 @@ DevToolsMessage | libp2p

                                                                                                                                                                                                    Messages that are sent from the DevTools panel page to the application page

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_devtools_metrics.WorkerMessage.html b/types/_libp2p_devtools_metrics.WorkerMessage.html index 0b64b0d87c..bde4e23521 100644 --- a/types/_libp2p_devtools_metrics.WorkerMessage.html +++ b/types/_libp2p_devtools_metrics.WorkerMessage.html @@ -1,2 +1,2 @@ WorkerMessage | libp2p

                                                                                                                                                                                                    Messages that are sent from the service worker

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.CalculateMetric.html b/types/_libp2p_interface.CalculateMetric.html index b1f4d8d0ff..90175fd35d 100644 --- a/types/_libp2p_interface.CalculateMetric.html +++ b/types/_libp2p_interface.CalculateMetric.html @@ -1,3 +1,3 @@ CalculateMetric | libp2p

                                                                                                                                                                                                    Type alias CalculateMetric<T>

                                                                                                                                                                                                    CalculateMetric<T>: (() => T) | (() => Promise<T>)

                                                                                                                                                                                                    A function that returns a tracked metric which may be expensive to calculate so it is only invoked when metrics are being scraped

                                                                                                                                                                                                    -

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    • T = number

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                      • (): T
                                                                                                                                                                                                      • Returns T

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    \ No newline at end of file +

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    • T = number

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                      • (): T
                                                                                                                                                                                                      • Returns T

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.ConnectionStatus.html b/types/_libp2p_interface.ConnectionStatus.html index c18601b071..5138752042 100644 --- a/types/_libp2p_interface.ConnectionStatus.html +++ b/types/_libp2p_interface.ConnectionStatus.html @@ -1 +1 @@ -ConnectionStatus | libp2p

                                                                                                                                                                                                    Type alias ConnectionStatus

                                                                                                                                                                                                    ConnectionStatus: "open" | "closing" | "closed"
                                                                                                                                                                                                    \ No newline at end of file +ConnectionStatus | libp2p

                                                                                                                                                                                                    Type alias ConnectionStatus

                                                                                                                                                                                                    ConnectionStatus: "open" | "closing" | "closed"
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.Direction.html b/types/_libp2p_interface.Direction.html index b6248b7675..d14e5721ee 100644 --- a/types/_libp2p_interface.Direction.html +++ b/types/_libp2p_interface.Direction.html @@ -1,2 +1,2 @@ Direction | libp2p
                                                                                                                                                                                                    Direction: "inbound" | "outbound"

                                                                                                                                                                                                    Outbound connections are opened by the local node, inbound streams are opened by the remote

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.EventHandler.html b/types/_libp2p_interface.EventHandler.html index ac4035cde1..8e9d0701f5 100644 --- a/types/_libp2p_interface.EventHandler.html +++ b/types/_libp2p_interface.EventHandler.html @@ -1 +1 @@ -EventHandler | libp2p

                                                                                                                                                                                                    Type alias EventHandler<EventType>

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    • EventType
                                                                                                                                                                                                    \ No newline at end of file +EventHandler | libp2p

                                                                                                                                                                                                    Type alias EventHandler<EventType>

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    • EventType
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.InboundConnectionUpgradeEvents.html b/types/_libp2p_interface.InboundConnectionUpgradeEvents.html index 13484fc81d..81fd7325c7 100644 --- a/types/_libp2p_interface.InboundConnectionUpgradeEvents.html +++ b/types/_libp2p_interface.InboundConnectionUpgradeEvents.html @@ -1 +1 @@ -InboundConnectionUpgradeEvents | libp2p

                                                                                                                                                                                                    Type alias InboundConnectionUpgradeEvents

                                                                                                                                                                                                    InboundConnectionUpgradeEvents: ProgressEvent<"upgrader:encrypt-inbound-connection"> | ProgressEvent<"upgrader:multiplex-inbound-connection">
                                                                                                                                                                                                    \ No newline at end of file +InboundConnectionUpgradeEvents | libp2p

                                                                                                                                                                                                    Type alias InboundConnectionUpgradeEvents

                                                                                                                                                                                                    InboundConnectionUpgradeEvents: ProgressEvent<"upgrader:encrypt-inbound-connection"> | ProgressEvent<"upgrader:multiplex-inbound-connection">
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.KeyType.html b/types/_libp2p_interface.KeyType.html index 3a18ce5389..531729bf7b 100644 --- a/types/_libp2p_interface.KeyType.html +++ b/types/_libp2p_interface.KeyType.html @@ -1 +1 @@ -KeyType | libp2p
                                                                                                                                                                                                    KeyType: "RSA" | "Ed25519" | "secp256k1"
                                                                                                                                                                                                    \ No newline at end of file +KeyType | libp2p
                                                                                                                                                                                                    KeyType: "RSA" | "Ed25519" | "secp256k1"
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.Libp2pStatus.html b/types/_libp2p_interface.Libp2pStatus.html index 9ba8fcf97a..c95d147d6c 100644 --- a/types/_libp2p_interface.Libp2pStatus.html +++ b/types/_libp2p_interface.Libp2pStatus.html @@ -1 +1 @@ -Libp2pStatus | libp2p
                                                                                                                                                                                                    Libp2pStatus: "starting" | "started" | "stopping" | "stopped"
                                                                                                                                                                                                    \ No newline at end of file +Libp2pStatus | libp2p
                                                                                                                                                                                                    Libp2pStatus: "starting" | "started" | "stopping" | "stopped"
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.Message.html b/types/_libp2p_interface.Message.html index ec27efd5e9..805d154a61 100644 --- a/types/_libp2p_interface.Message.html +++ b/types/_libp2p_interface.Message.html @@ -1 +1 @@ -Message | libp2p
                                                                                                                                                                                                    \ No newline at end of file +Message | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.OpenConnectionProgressEvents.html b/types/_libp2p_interface.OpenConnectionProgressEvents.html index a45eab5a90..043331aeb2 100644 --- a/types/_libp2p_interface.OpenConnectionProgressEvents.html +++ b/types/_libp2p_interface.OpenConnectionProgressEvents.html @@ -1 +1 @@ -OpenConnectionProgressEvents | libp2p

                                                                                                                                                                                                    Type alias OpenConnectionProgressEvents

                                                                                                                                                                                                    OpenConnectionProgressEvents: TransportManagerDialProgressEvents | ProgressEvent<"dial-queue:already-connected"> | ProgressEvent<"dial-queue:already-in-dial-queue"> | ProgressEvent<"dial-queue:add-to-dial-queue"> | ProgressEvent<"dial-queue:start-dial"> | ProgressEvent<"dial-queue:calculated-addresses", Address[]> | OutboundConnectionUpgradeEvents
                                                                                                                                                                                                    \ No newline at end of file +OpenConnectionProgressEvents | libp2p

                                                                                                                                                                                                    Type alias OpenConnectionProgressEvents

                                                                                                                                                                                                    OpenConnectionProgressEvents: TransportManagerDialProgressEvents | ProgressEvent<"dial-queue:already-connected"> | ProgressEvent<"dial-queue:already-in-dial-queue"> | ProgressEvent<"dial-queue:add-to-dial-queue"> | ProgressEvent<"dial-queue:start-dial"> | ProgressEvent<"dial-queue:calculated-addresses", Address[]> | OutboundConnectionUpgradeEvents
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.OutboundConnectionUpgradeEvents.html b/types/_libp2p_interface.OutboundConnectionUpgradeEvents.html index fd75b87506..bc0202ee7d 100644 --- a/types/_libp2p_interface.OutboundConnectionUpgradeEvents.html +++ b/types/_libp2p_interface.OutboundConnectionUpgradeEvents.html @@ -1 +1 @@ -OutboundConnectionUpgradeEvents | libp2p

                                                                                                                                                                                                    Type alias OutboundConnectionUpgradeEvents

                                                                                                                                                                                                    OutboundConnectionUpgradeEvents: ProgressEvent<"upgrader:encrypt-outbound-connection"> | ProgressEvent<"upgrader:multiplex-outbound-connection">
                                                                                                                                                                                                    \ No newline at end of file +OutboundConnectionUpgradeEvents | libp2p

                                                                                                                                                                                                    Type alias OutboundConnectionUpgradeEvents

                                                                                                                                                                                                    OutboundConnectionUpgradeEvents: ProgressEvent<"upgrader:encrypt-outbound-connection"> | ProgressEvent<"upgrader:multiplex-outbound-connection">
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.PeerId.html b/types/_libp2p_interface.PeerId.html index 3795b78d02..9885caaacd 100644 --- a/types/_libp2p_interface.PeerId.html +++ b/types/_libp2p_interface.PeerId.html @@ -1,3 +1,3 @@ PeerId | libp2p

                                                                                                                                                                                                    This is a union of all known PeerId types - use the .type field to disambiguate them

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.PeerIdType.html b/types/_libp2p_interface.PeerIdType.html index 8c1cd6c90d..f073809b59 100644 --- a/types/_libp2p_interface.PeerIdType.html +++ b/types/_libp2p_interface.PeerIdType.html @@ -1 +1 @@ -PeerIdType | libp2p
                                                                                                                                                                                                    \ No newline at end of file +PeerIdType | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.PendingDialStatus.html b/types/_libp2p_interface.PendingDialStatus.html index 8b99e9cab7..d98f14a7a8 100644 --- a/types/_libp2p_interface.PendingDialStatus.html +++ b/types/_libp2p_interface.PendingDialStatus.html @@ -1 +1 @@ -PendingDialStatus | libp2p

                                                                                                                                                                                                    Type alias PendingDialStatus

                                                                                                                                                                                                    PendingDialStatus: "queued" | "active" | "error" | "success"
                                                                                                                                                                                                    \ No newline at end of file +PendingDialStatus | libp2p

                                                                                                                                                                                                    Type alias PendingDialStatus

                                                                                                                                                                                                    PendingDialStatus: "queued" | "active" | "error" | "success"
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.PrivateKey.html b/types/_libp2p_interface.PrivateKey.html index 9a7b21dadd..f9652d6827 100644 --- a/types/_libp2p_interface.PrivateKey.html +++ b/types/_libp2p_interface.PrivateKey.html @@ -1 +1 @@ -PrivateKey | libp2p
                                                                                                                                                                                                    \ No newline at end of file +PrivateKey | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.PublicKey.html b/types/_libp2p_interface.PublicKey.html index 5015fb3c37..e01fdf6576 100644 --- a/types/_libp2p_interface.PublicKey.html +++ b/types/_libp2p_interface.PublicKey.html @@ -1 +1 @@ -PublicKey | libp2p
                                                                                                                                                                                                    \ No newline at end of file +PublicKey | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.ReadStatus.html b/types/_libp2p_interface.ReadStatus.html index 8e1f1f4887..f0b0e9ac9c 100644 --- a/types/_libp2p_interface.ReadStatus.html +++ b/types/_libp2p_interface.ReadStatus.html @@ -2,4 +2,4 @@

                                                                                                                                                                                                    ready - the readable end is ready for reading closing - the readable end is closing closed - the readable end has closed

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.ServiceMap.html b/types/_libp2p_interface.ServiceMap.html index 0654251f14..076b8734ae 100644 --- a/types/_libp2p_interface.ServiceMap.html +++ b/types/_libp2p_interface.ServiceMap.html @@ -2,4 +2,4 @@ services key

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    const node = await createLibp2p({
                                                                                                                                                                                                    // ...other options
                                                                                                                                                                                                    services: {
                                                                                                                                                                                                    myService: myService({
                                                                                                                                                                                                    // ...service options
                                                                                                                                                                                                    })
                                                                                                                                                                                                    }
                                                                                                                                                                                                    })

                                                                                                                                                                                                    // invoke methods on the service
                                                                                                                                                                                                    node.services.myService.anOperation()
                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.SignaturePolicy.html b/types/_libp2p_interface.SignaturePolicy.html index 9b1882e961..ae999942a4 100644 --- a/types/_libp2p_interface.SignaturePolicy.html +++ b/types/_libp2p_interface.SignaturePolicy.html @@ -1 +1 @@ -SignaturePolicy | libp2p

                                                                                                                                                                                                    Type alias SignaturePolicy

                                                                                                                                                                                                    SignaturePolicy: typeof StrictSign | typeof StrictNoSign
                                                                                                                                                                                                    \ No newline at end of file +SignaturePolicy | libp2p

                                                                                                                                                                                                    Type alias SignaturePolicy

                                                                                                                                                                                                    SignaturePolicy: typeof StrictSign | typeof StrictNoSign
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.StreamStatus.html b/types/_libp2p_interface.StreamStatus.html index c22b551671..06f90837ed 100644 --- a/types/_libp2p_interface.StreamStatus.html +++ b/types/_libp2p_interface.StreamStatus.html @@ -1,2 +1,2 @@ StreamStatus | libp2p
                                                                                                                                                                                                    StreamStatus: "open" | "closing" | "closed" | "aborted" | "reset"

                                                                                                                                                                                                    The states a stream can be in

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.TransportManagerDialProgressEvents.html b/types/_libp2p_interface.TransportManagerDialProgressEvents.html index 4a62bfb100..78251dd9f5 100644 --- a/types/_libp2p_interface.TransportManagerDialProgressEvents.html +++ b/types/_libp2p_interface.TransportManagerDialProgressEvents.html @@ -1 +1 @@ -TransportManagerDialProgressEvents | libp2p

                                                                                                                                                                                                    Type alias TransportManagerDialProgressEvents

                                                                                                                                                                                                    TransportManagerDialProgressEvents: ProgressEvent<"transport-manager:selected-transport", string>
                                                                                                                                                                                                    \ No newline at end of file +TransportManagerDialProgressEvents | libp2p

                                                                                                                                                                                                    Type alias TransportManagerDialProgressEvents

                                                                                                                                                                                                    TransportManagerDialProgressEvents: ProgressEvent<"transport-manager:selected-transport", string>
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_interface.WriteStatus.html b/types/_libp2p_interface.WriteStatus.html index f048b558ba..17efeae39c 100644 --- a/types/_libp2p_interface.WriteStatus.html +++ b/types/_libp2p_interface.WriteStatus.html @@ -4,4 +4,4 @@ done - the source passed to the .sink function yielded all values without error closing - the writable end is closing closed - the writable end has closed

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_kad_dht.DHTProgressEvents.html b/types/_libp2p_kad_dht.DHTProgressEvents.html index e4e8c67ec2..cfef5233eb 100644 --- a/types/_libp2p_kad_dht.DHTProgressEvents.html +++ b/types/_libp2p_kad_dht.DHTProgressEvents.html @@ -1 +1 @@ -DHTProgressEvents | libp2p

                                                                                                                                                                                                    Type alias DHTProgressEvents

                                                                                                                                                                                                    DHTProgressEvents: ProgressEvent<"kad-dht:query:send-query", SendQueryEvent> | ProgressEvent<"kad-dht:query:peer-response", PeerResponseEvent> | ProgressEvent<"kad-dht:query:final-peer", FinalPeerEvent> | ProgressEvent<"kad-dht:query:query-error", QueryErrorEvent> | ProgressEvent<"kad-dht:query:provider", ProviderEvent> | ProgressEvent<"kad-dht:query:value", ValueEvent> | ProgressEvent<"kad-dht:query:add-peer", AddPeerEvent> | ProgressEvent<"kad-dht:query:dial-peer", DialPeerEvent>
                                                                                                                                                                                                    \ No newline at end of file +DHTProgressEvents | libp2p

                                                                                                                                                                                                    Type alias DHTProgressEvents

                                                                                                                                                                                                    DHTProgressEvents: ProgressEvent<"kad-dht:query:send-query", SendQueryEvent> | ProgressEvent<"kad-dht:query:peer-response", PeerResponseEvent> | ProgressEvent<"kad-dht:query:final-peer", FinalPeerEvent> | ProgressEvent<"kad-dht:query:query-error", QueryErrorEvent> | ProgressEvent<"kad-dht:query:provider", ProviderEvent> | ProgressEvent<"kad-dht:query:value", ValueEvent> | ProgressEvent<"kad-dht:query:add-peer", AddPeerEvent> | ProgressEvent<"kad-dht:query:dial-peer", DialPeerEvent>
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_kad_dht.MessageName.html b/types/_libp2p_kad_dht.MessageName.html index 50cd53c7a8..2a7f50f947 100644 --- a/types/_libp2p_kad_dht.MessageName.html +++ b/types/_libp2p_kad_dht.MessageName.html @@ -1 +1 @@ -MessageName | libp2p

                                                                                                                                                                                                    Type alias MessageName

                                                                                                                                                                                                    MessageName: keyof typeof MessageType
                                                                                                                                                                                                    \ No newline at end of file +MessageName | libp2p

                                                                                                                                                                                                    Type alias MessageName

                                                                                                                                                                                                    MessageName: keyof typeof MessageType
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_kad_dht.QueryEvent.html b/types/_libp2p_kad_dht.QueryEvent.html index 5985246612..bbfdf3c7b5 100644 --- a/types/_libp2p_kad_dht.QueryEvent.html +++ b/types/_libp2p_kad_dht.QueryEvent.html @@ -1 +1 @@ -QueryEvent | libp2p
                                                                                                                                                                                                    \ No newline at end of file +QueryEvent | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_kad_dht.Selectors.html b/types/_libp2p_kad_dht.Selectors.html index e683073e49..e6989624f4 100644 --- a/types/_libp2p_kad_dht.Selectors.html +++ b/types/_libp2p_kad_dht.Selectors.html @@ -1,2 +1,2 @@ Selectors | libp2p

                                                                                                                                                                                                    Type alias Selectors

                                                                                                                                                                                                    Selectors: Record<string, SelectFn>

                                                                                                                                                                                                    Selectors are a map of key prefixes to selector functions

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_kad_dht.Validators.html b/types/_libp2p_kad_dht.Validators.html index 5b7379b111..1ab8e7c8eb 100644 --- a/types/_libp2p_kad_dht.Validators.html +++ b/types/_libp2p_kad_dht.Validators.html @@ -1,2 +1,2 @@ Validators | libp2p

                                                                                                                                                                                                    Type alias Validators

                                                                                                                                                                                                    Validators: Record<string, ValidateFn>

                                                                                                                                                                                                    Validators are a map of key prefixes to validator functions

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_tcp.TCPDialEvents.html b/types/_libp2p_tcp.TCPDialEvents.html index ed05d71915..528fd42223 100644 --- a/types/_libp2p_tcp.TCPDialEvents.html +++ b/types/_libp2p_tcp.TCPDialEvents.html @@ -1 +1 @@ -TCPDialEvents | libp2p

                                                                                                                                                                                                    Type alias TCPDialEvents

                                                                                                                                                                                                    TCPDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"tcp:open-connection">
                                                                                                                                                                                                    \ No newline at end of file +TCPDialEvents | libp2p

                                                                                                                                                                                                    Type alias TCPDialEvents

                                                                                                                                                                                                    TCPDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"tcp:open-connection">
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_utils.queue.JobStatus.html b/types/_libp2p_utils.queue.JobStatus.html index 85bfb568ef..9725823c60 100644 --- a/types/_libp2p_utils.queue.JobStatus.html +++ b/types/_libp2p_utils.queue.JobStatus.html @@ -1 +1 @@ -JobStatus | libp2p
                                                                                                                                                                                                    JobStatus: "queued" | "running" | "errored" | "complete"
                                                                                                                                                                                                    \ No newline at end of file +JobStatus | libp2p
                                                                                                                                                                                                    JobStatus: "queued" | "running" | "errored" | "complete"
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_websockets.index.WebSocketsDialEvents.html b/types/_libp2p_websockets.index.WebSocketsDialEvents.html index 38b36a16ba..aefaac6232 100644 --- a/types/_libp2p_websockets.index.WebSocketsDialEvents.html +++ b/types/_libp2p_websockets.index.WebSocketsDialEvents.html @@ -1 +1 @@ -WebSocketsDialEvents | libp2p
                                                                                                                                                                                                    WebSocketsDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"websockets:open-connection">
                                                                                                                                                                                                    \ No newline at end of file +WebSocketsDialEvents | libp2p
                                                                                                                                                                                                    WebSocketsDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"websockets:open-connection">
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/_libp2p_webtransport.WebTransportDialEvents.html b/types/_libp2p_webtransport.WebTransportDialEvents.html index 613d0b3d0d..1c0a5e8dac 100644 --- a/types/_libp2p_webtransport.WebTransportDialEvents.html +++ b/types/_libp2p_webtransport.WebTransportDialEvents.html @@ -1 +1 @@ -WebTransportDialEvents | libp2p

                                                                                                                                                                                                    Type alias WebTransportDialEvents

                                                                                                                                                                                                    WebTransportDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"webtransport:wait-for-session"> | ProgressEvent<"webtransport:open-authentication-stream"> | ProgressEvent<"webtransport:secure-outbound-connection"> | ProgressEvent<"webtransport:close-authentication-stream">
                                                                                                                                                                                                    \ No newline at end of file +WebTransportDialEvents | libp2p

                                                                                                                                                                                                    Type alias WebTransportDialEvents

                                                                                                                                                                                                    WebTransportDialEvents: OutboundConnectionUpgradeEvents | ProgressEvent<"webtransport:wait-for-session"> | ProgressEvent<"webtransport:open-authentication-stream"> | ProgressEvent<"webtransport:secure-outbound-connection"> | ProgressEvent<"webtransport:close-authentication-stream">
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/libp2p.index.Libp2pOptions.html b/types/libp2p.index.Libp2pOptions.html index 656b2df0bf..80888dc039 100644 --- a/types/libp2p.index.Libp2pOptions.html +++ b/types/libp2p.index.Libp2pOptions.html @@ -1 +1 @@ -Libp2pOptions | libp2p

                                                                                                                                                                                                    Type alias Libp2pOptions<T>

                                                                                                                                                                                                    Libp2pOptions<T>: Libp2pInit<T> & {
                                                                                                                                                                                                        start?: boolean;
                                                                                                                                                                                                    }

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    • Optional start?: boolean
                                                                                                                                                                                                    \ No newline at end of file +Libp2pOptions | libp2p

                                                                                                                                                                                                    Type alias Libp2pOptions<T>

                                                                                                                                                                                                    Libp2pOptions<T>: Libp2pInit<T> & {
                                                                                                                                                                                                        start?: boolean;
                                                                                                                                                                                                    }

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    Type declaration

                                                                                                                                                                                                    • Optional start?: boolean
                                                                                                                                                                                                    \ No newline at end of file diff --git a/types/libp2p.index.ServiceFactoryMap.html b/types/libp2p.index.ServiceFactoryMap.html index 56cfaff620..b155c45bb9 100644 --- a/types/libp2p.index.ServiceFactoryMap.html +++ b/types/libp2p.index.ServiceFactoryMap.html @@ -1 +1 @@ -ServiceFactoryMap | libp2p

                                                                                                                                                                                                    Type alias ServiceFactoryMap<T>

                                                                                                                                                                                                    ServiceFactoryMap<T>: {
                                                                                                                                                                                                        [Property in keyof T]: ((components) => T[Property])
                                                                                                                                                                                                    }

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    \ No newline at end of file +ServiceFactoryMap | libp2p

                                                                                                                                                                                                    Type alias ServiceFactoryMap<T>

                                                                                                                                                                                                    ServiceFactoryMap<T>: {
                                                                                                                                                                                                        [Property in keyof T]: ((components) => T[Property])
                                                                                                                                                                                                    }

                                                                                                                                                                                                    Type Parameters

                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_circuit_relay_v2.RELAY_V2_HOP_CODEC.html b/variables/_libp2p_circuit_relay_v2.RELAY_V2_HOP_CODEC.html index b75d3ce03d..75fd944a77 100644 --- a/variables/_libp2p_circuit_relay_v2.RELAY_V2_HOP_CODEC.html +++ b/variables/_libp2p_circuit_relay_v2.RELAY_V2_HOP_CODEC.html @@ -1,2 +1,2 @@ RELAY_V2_HOP_CODEC | libp2p

                                                                                                                                                                                                    Variable RELAY_V2_HOP_CODECConst

                                                                                                                                                                                                    RELAY_V2_HOP_CODEC: "/libp2p/circuit/relay/0.2.0/hop" = '/libp2p/circuit/relay/0.2.0/hop'

                                                                                                                                                                                                    The hop protocol

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_circuit_relay_v2.RELAY_V2_STOP_CODEC.html b/variables/_libp2p_circuit_relay_v2.RELAY_V2_STOP_CODEC.html index 11fddf9c1a..ea9c517039 100644 --- a/variables/_libp2p_circuit_relay_v2.RELAY_V2_STOP_CODEC.html +++ b/variables/_libp2p_circuit_relay_v2.RELAY_V2_STOP_CODEC.html @@ -1,2 +1,2 @@ RELAY_V2_STOP_CODEC | libp2p

                                                                                                                                                                                                    Variable RELAY_V2_STOP_CODECConst

                                                                                                                                                                                                    RELAY_V2_STOP_CODEC: "/libp2p/circuit/relay/0.2.0/stop" = '/libp2p/circuit/relay/0.2.0/stop'

                                                                                                                                                                                                    the stop protocol

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_dcutr.multicodec.html b/variables/_libp2p_dcutr.multicodec.html index b2ba6e76e7..2147f79d43 100644 --- a/variables/_libp2p_dcutr.multicodec.html +++ b/variables/_libp2p_dcutr.multicodec.html @@ -1,2 +1,2 @@ multicodec | libp2p

                                                                                                                                                                                                    Variable multicodecConst

                                                                                                                                                                                                    multicodec: "/libp2p/dcutr" = '/libp2p/dcutr'

                                                                                                                                                                                                    The DCUtR protocol

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.LIBP2P_DEVTOOLS_METRICS_KEY.html b/variables/_libp2p_devtools_metrics.LIBP2P_DEVTOOLS_METRICS_KEY.html index 0026d5426c..6b3dc8f2ad 100644 --- a/variables/_libp2p_devtools_metrics.LIBP2P_DEVTOOLS_METRICS_KEY.html +++ b/variables/_libp2p_devtools_metrics.LIBP2P_DEVTOOLS_METRICS_KEY.html @@ -1 +1 @@ -LIBP2P_DEVTOOLS_METRICS_KEY | libp2p

                                                                                                                                                                                                    Variable LIBP2P_DEVTOOLS_METRICS_KEYConst

                                                                                                                                                                                                    LIBP2P_DEVTOOLS_METRICS_KEY: "________libp2p_devtools_metrics" = '________libp2p_devtools_metrics'
                                                                                                                                                                                                    \ No newline at end of file +LIBP2P_DEVTOOLS_METRICS_KEY | libp2p

                                                                                                                                                                                                    Variable LIBP2P_DEVTOOLS_METRICS_KEYConst

                                                                                                                                                                                                    LIBP2P_DEVTOOLS_METRICS_KEY: "________libp2p_devtools_metrics" = '________libp2p_devtools_metrics'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.SOURCE_CONTENT_SCRIPT.html b/variables/_libp2p_devtools_metrics.SOURCE_CONTENT_SCRIPT.html index a9c9bc5a35..a10bf6b1d7 100644 --- a/variables/_libp2p_devtools_metrics.SOURCE_CONTENT_SCRIPT.html +++ b/variables/_libp2p_devtools_metrics.SOURCE_CONTENT_SCRIPT.html @@ -1 +1 @@ -SOURCE_CONTENT_SCRIPT | libp2p

                                                                                                                                                                                                    Variable SOURCE_CONTENT_SCRIPTConst

                                                                                                                                                                                                    SOURCE_CONTENT_SCRIPT: "@libp2p/devtools-metrics:content" = '@libp2p/devtools-metrics:content'
                                                                                                                                                                                                    \ No newline at end of file +SOURCE_CONTENT_SCRIPT | libp2p

                                                                                                                                                                                                    Variable SOURCE_CONTENT_SCRIPTConst

                                                                                                                                                                                                    SOURCE_CONTENT_SCRIPT: "@libp2p/devtools-metrics:content" = '@libp2p/devtools-metrics:content'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.SOURCE_DEVTOOLS.html b/variables/_libp2p_devtools_metrics.SOURCE_DEVTOOLS.html index aaf3d4a6e2..3244aa803e 100644 --- a/variables/_libp2p_devtools_metrics.SOURCE_DEVTOOLS.html +++ b/variables/_libp2p_devtools_metrics.SOURCE_DEVTOOLS.html @@ -1 +1 @@ -SOURCE_DEVTOOLS | libp2p

                                                                                                                                                                                                    Variable SOURCE_DEVTOOLSConst

                                                                                                                                                                                                    SOURCE_DEVTOOLS: "@libp2p/devtools-metrics:devtools" = '@libp2p/devtools-metrics:devtools'
                                                                                                                                                                                                    \ No newline at end of file +SOURCE_DEVTOOLS | libp2p

                                                                                                                                                                                                    Variable SOURCE_DEVTOOLSConst

                                                                                                                                                                                                    SOURCE_DEVTOOLS: "@libp2p/devtools-metrics:devtools" = '@libp2p/devtools-metrics:devtools'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.SOURCE_METRICS.html b/variables/_libp2p_devtools_metrics.SOURCE_METRICS.html index 7274315490..cb934cae91 100644 --- a/variables/_libp2p_devtools_metrics.SOURCE_METRICS.html +++ b/variables/_libp2p_devtools_metrics.SOURCE_METRICS.html @@ -1 +1 @@ -SOURCE_METRICS | libp2p
                                                                                                                                                                                                    SOURCE_METRICS: "@libp2p/devtools-metrics:metrics" = '@libp2p/devtools-metrics:metrics'
                                                                                                                                                                                                    \ No newline at end of file +SOURCE_METRICS | libp2p
                                                                                                                                                                                                    SOURCE_METRICS: "@libp2p/devtools-metrics:metrics" = '@libp2p/devtools-metrics:metrics'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.SOURCE_SERVICE_WORKER.html b/variables/_libp2p_devtools_metrics.SOURCE_SERVICE_WORKER.html index 5d7a43134d..d3953459ad 100644 --- a/variables/_libp2p_devtools_metrics.SOURCE_SERVICE_WORKER.html +++ b/variables/_libp2p_devtools_metrics.SOURCE_SERVICE_WORKER.html @@ -1 +1 @@ -SOURCE_SERVICE_WORKER | libp2p

                                                                                                                                                                                                    Variable SOURCE_SERVICE_WORKERConst

                                                                                                                                                                                                    SOURCE_SERVICE_WORKER: "@libp2p/devtools-metrics:worker" = '@libp2p/devtools-metrics:worker'
                                                                                                                                                                                                    \ No newline at end of file +SOURCE_SERVICE_WORKER | libp2p

                                                                                                                                                                                                    Variable SOURCE_SERVICE_WORKERConst

                                                                                                                                                                                                    SOURCE_SERVICE_WORKER: "@libp2p/devtools-metrics:worker" = '@libp2p/devtools-metrics:worker'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_devtools_metrics.valueCodecs.html b/variables/_libp2p_devtools_metrics.valueCodecs.html index 2d44d3153a..f798f8659a 100644 --- a/variables/_libp2p_devtools_metrics.valueCodecs.html +++ b/variables/_libp2p_devtools_metrics.valueCodecs.html @@ -1 +1 @@ -valueCodecs | libp2p
                                                                                                                                                                                                    valueCodecs: ValueCodec<any>[] = ...
                                                                                                                                                                                                    \ No newline at end of file +valueCodecs | libp2p
                                                                                                                                                                                                    valueCodecs: ValueCodec<any>[] = ...
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_floodsub.multicodec.html b/variables/_libp2p_floodsub.multicodec.html index ae41c425b0..8996c7eb81 100644 --- a/variables/_libp2p_floodsub.multicodec.html +++ b/variables/_libp2p_floodsub.multicodec.html @@ -1 +1 @@ -multicodec | libp2p

                                                                                                                                                                                                    Variable multicodecConst

                                                                                                                                                                                                    multicodec: "/floodsub/1.0.0" = '/floodsub/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file +multicodec | libp2p

                                                                                                                                                                                                    Variable multicodecConst

                                                                                                                                                                                                    multicodec: "/floodsub/1.0.0" = '/floodsub/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.KEEP_ALIVE.html b/variables/_libp2p_interface.KEEP_ALIVE.html index 7ae7c36ce5..498cb0a361 100644 --- a/variables/_libp2p_interface.KEEP_ALIVE.html +++ b/variables/_libp2p_interface.KEEP_ALIVE.html @@ -1 +1 @@ -KEEP_ALIVE | libp2p

                                                                                                                                                                                                    Variable KEEP_ALIVEConst

                                                                                                                                                                                                    KEEP_ALIVE: "keep-alive" = 'keep-alive'
                                                                                                                                                                                                    \ No newline at end of file +KEEP_ALIVE | libp2p

                                                                                                                                                                                                    Variable KEEP_ALIVEConst

                                                                                                                                                                                                    KEEP_ALIVE: "keep-alive" = 'keep-alive'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.StrictNoSign.html b/variables/_libp2p_interface.StrictNoSign.html index 2987906641..8096cd191b 100644 --- a/variables/_libp2p_interface.StrictNoSign.html +++ b/variables/_libp2p_interface.StrictNoSign.html @@ -9,4 +9,4 @@
                                                                                                                                                                                                  • Propagate only if the fields are absent, reject otherwise.
                                                                                                                                                                                                  • A message_id function will not be able to use the above fields, and should instead rely on the data field. A commonplace strategy is to calculate a hash.
                                                                                                                                                                                                  • -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.StrictSign.html b/variables/_libp2p_interface.StrictSign.html index 4d5a0754cf..602eb997a6 100644 --- a/variables/_libp2p_interface.StrictSign.html +++ b/variables/_libp2p_interface.StrictSign.html @@ -7,4 +7,4 @@
                                                                                                                                                                                                  • Enforce the fields to be present, reject otherwise.
                                                                                                                                                                                                  • Propagate only if the fields are valid and signature can be verified, reject otherwise.
                                                                                                                                                                                                  • -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.connectionSymbol.html b/variables/_libp2p_interface.connectionSymbol.html index afb91efe7e..0d18f76944 100644 --- a/variables/_libp2p_interface.connectionSymbol.html +++ b/variables/_libp2p_interface.connectionSymbol.html @@ -1 +1 @@ -connectionSymbol | libp2p

                                                                                                                                                                                                    Variable connectionSymbolConst

                                                                                                                                                                                                    connectionSymbol: typeof connectionSymbol = ...
                                                                                                                                                                                                    \ No newline at end of file +connectionSymbol | libp2p

                                                                                                                                                                                                    Variable connectionSymbolConst

                                                                                                                                                                                                    connectionSymbol: typeof connectionSymbol = ...
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.contentRoutingSymbol.html b/variables/_libp2p_interface.contentRoutingSymbol.html index 7275621286..d4be687df7 100644 --- a/variables/_libp2p_interface.contentRoutingSymbol.html +++ b/variables/_libp2p_interface.contentRoutingSymbol.html @@ -3,4 +3,4 @@ Symbol.Iterable can be used to return an Iterable from an Iterator.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { contentRoutingSymbol, ContentRouting } from '@libp2p/content-routing'

                                                                                                                                                                                                    class MyContentRouter implements ContentRouting {
                                                                                                                                                                                                    get [contentRoutingSymbol] () {
                                                                                                                                                                                                    return this
                                                                                                                                                                                                    }

                                                                                                                                                                                                    // ...other methods
                                                                                                                                                                                                    }
                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.peerDiscoverySymbol.html b/variables/_libp2p_interface.peerDiscoverySymbol.html index 553edf003e..acb687476e 100644 --- a/variables/_libp2p_interface.peerDiscoverySymbol.html +++ b/variables/_libp2p_interface.peerDiscoverySymbol.html @@ -3,4 +3,4 @@ Symbol.Iterable can be used to return an Iterable from an Iterator.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { peerDiscovery, PeerDiscovery } from '@libp2p/peer-discovery'

                                                                                                                                                                                                    class MyPeerDiscoverer implements PeerDiscovery {
                                                                                                                                                                                                    get [peerDiscovery] () {
                                                                                                                                                                                                    return this
                                                                                                                                                                                                    }

                                                                                                                                                                                                    // ...other methods
                                                                                                                                                                                                    }
                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.peerIdSymbol.html b/variables/_libp2p_interface.peerIdSymbol.html index 9b2ec7b3e6..7fe13e64f3 100644 --- a/variables/_libp2p_interface.peerIdSymbol.html +++ b/variables/_libp2p_interface.peerIdSymbol.html @@ -1,3 +1,3 @@ peerIdSymbol | libp2p

                                                                                                                                                                                                    Variable peerIdSymbolConst

                                                                                                                                                                                                    peerIdSymbol: typeof peerIdSymbol = ...

                                                                                                                                                                                                    All PeerId implementations must use this symbol as the name of a property with a boolean true value

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.peerRoutingSymbol.html b/variables/_libp2p_interface.peerRoutingSymbol.html index 1d41b403ab..3ccfe5cb56 100644 --- a/variables/_libp2p_interface.peerRoutingSymbol.html +++ b/variables/_libp2p_interface.peerRoutingSymbol.html @@ -3,4 +3,4 @@ Symbol.Iterable can be used to return an Iterable from an Iterator.

                                                                                                                                                                                                    Example

                                                                                                                                                                                                    import { peerRouting, PeerRouting } from '@libp2p/peer-routing'

                                                                                                                                                                                                    class MyPeerRouter implements PeerRouting {
                                                                                                                                                                                                    get [peerRouting] () {
                                                                                                                                                                                                    return this
                                                                                                                                                                                                    }

                                                                                                                                                                                                    // ...other methods
                                                                                                                                                                                                    }
                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.serviceCapabilities.html b/variables/_libp2p_interface.serviceCapabilities.html index 098f78f7fa..51bc1636cd 100644 --- a/variables/_libp2p_interface.serviceCapabilities.html +++ b/variables/_libp2p_interface.serviceCapabilities.html @@ -2,4 +2,4 @@ provide to other libp2p services.

                                                                                                                                                                                                    The service should define a property with this symbol as the key and the value should be a string array of provided capabilities.

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.serviceDependencies.html b/variables/_libp2p_interface.serviceDependencies.html index 9db25da90f..d923cb4dbe 100644 --- a/variables/_libp2p_interface.serviceDependencies.html +++ b/variables/_libp2p_interface.serviceDependencies.html @@ -2,4 +2,4 @@ require from other libp2p services.

                                                                                                                                                                                                    The service should define a property with this symbol as the key and the value should be a string array of required capabilities.

                                                                                                                                                                                                    -
                                                                                                                                                                                                    \ No newline at end of file +
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface.transportSymbol.html b/variables/_libp2p_interface.transportSymbol.html index 913b5a759c..70637498d2 100644 --- a/variables/_libp2p_interface.transportSymbol.html +++ b/variables/_libp2p_interface.transportSymbol.html @@ -1 +1 @@ -transportSymbol | libp2p

                                                                                                                                                                                                    Variable transportSymbolConst

                                                                                                                                                                                                    transportSymbol: typeof transportSymbol = ...
                                                                                                                                                                                                    \ No newline at end of file +transportSymbol | libp2p

                                                                                                                                                                                                    Variable transportSymbolConst

                                                                                                                                                                                                    transportSymbol: typeof transportSymbol = ...
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_interface_compliance_tests.mocks.mockNetwork.html b/variables/_libp2p_interface_compliance_tests.mocks.mockNetwork.html index 60a0991284..762bf883b2 100644 --- a/variables/_libp2p_interface_compliance_tests.mocks.mockNetwork.html +++ b/variables/_libp2p_interface_compliance_tests.mocks.mockNetwork.html @@ -1 +1 @@ -mockNetwork | libp2p
                                                                                                                                                                                                    \ No newline at end of file +mockNetwork | libp2p
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_multistream_select.PROTOCOL_ID.html b/variables/_libp2p_multistream_select.PROTOCOL_ID.html index 0c6b62e403..557ceea6b3 100644 --- a/variables/_libp2p_multistream_select.PROTOCOL_ID.html +++ b/variables/_libp2p_multistream_select.PROTOCOL_ID.html @@ -1 +1 @@ -PROTOCOL_ID | libp2p
                                                                                                                                                                                                    PROTOCOL_ID: "/multistream/1.0.0" = '/multistream/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file +PROTOCOL_ID | libp2p
                                                                                                                                                                                                    PROTOCOL_ID: "/multistream/1.0.0" = '/multistream/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_ping.PING_PROTOCOL.html b/variables/_libp2p_ping.PING_PROTOCOL.html index 8711a6aabc..1c090916b3 100644 --- a/variables/_libp2p_ping.PING_PROTOCOL.html +++ b/variables/_libp2p_ping.PING_PROTOCOL.html @@ -1 +1 @@ -PING_PROTOCOL | libp2p

                                                                                                                                                                                                    Variable PING_PROTOCOLConst

                                                                                                                                                                                                    PING_PROTOCOL: "/ipfs/ping/1.0.0" = '/ipfs/ping/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file +PING_PROTOCOL | libp2p

                                                                                                                                                                                                    Variable PING_PROTOCOLConst

                                                                                                                                                                                                    PING_PROTOCOL: "/ipfs/ping/1.0.0" = '/ipfs/ping/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_tls.PROTOCOL.html b/variables/_libp2p_tls.PROTOCOL.html index 1359efff09..c0b700775a 100644 --- a/variables/_libp2p_tls.PROTOCOL.html +++ b/variables/_libp2p_tls.PROTOCOL.html @@ -1 +1 @@ -PROTOCOL | libp2p

                                                                                                                                                                                                    Variable PROTOCOLConst

                                                                                                                                                                                                    PROTOCOL: "/tls/1.0.0" = '/tls/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file +PROTOCOL | libp2p

                                                                                                                                                                                                    Variable PROTOCOLConst

                                                                                                                                                                                                    PROTOCOL: "/tls/1.0.0" = '/tls/1.0.0'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_FAILURE_MULTIPLIER.html b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_FAILURE_MULTIPLIER.html index 280bdb3c49..eb63dd8a4d 100644 --- a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_FAILURE_MULTIPLIER.html +++ b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_FAILURE_MULTIPLIER.html @@ -1 +1 @@ -DEFAULT_FAILURE_MULTIPLIER | libp2p

                                                                                                                                                                                                    Variable DEFAULT_FAILURE_MULTIPLIERConst

                                                                                                                                                                                                    DEFAULT_FAILURE_MULTIPLIER: 2 = 2
                                                                                                                                                                                                    \ No newline at end of file +DEFAULT_FAILURE_MULTIPLIER | libp2p

                                                                                                                                                                                                    Variable DEFAULT_FAILURE_MULTIPLIERConst

                                                                                                                                                                                                    DEFAULT_FAILURE_MULTIPLIER: 2 = 2
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_MIN_TIMEOUT.html b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_MIN_TIMEOUT.html index e74259de7a..acdc36e097 100644 --- a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_MIN_TIMEOUT.html +++ b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_MIN_TIMEOUT.html @@ -1 +1 @@ -DEFAULT_MIN_TIMEOUT | libp2p
                                                                                                                                                                                                    DEFAULT_MIN_TIMEOUT: 2000 = 2000
                                                                                                                                                                                                    \ No newline at end of file +DEFAULT_MIN_TIMEOUT | libp2p
                                                                                                                                                                                                    DEFAULT_MIN_TIMEOUT: 2000 = 2000
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_TIMEOUT_MULTIPLIER.html b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_TIMEOUT_MULTIPLIER.html index 57ca370ceb..9a6a53ff16 100644 --- a/variables/_libp2p_utils.adaptive_timeout.DEFAULT_TIMEOUT_MULTIPLIER.html +++ b/variables/_libp2p_utils.adaptive_timeout.DEFAULT_TIMEOUT_MULTIPLIER.html @@ -1 +1 @@ -DEFAULT_TIMEOUT_MULTIPLIER | libp2p

                                                                                                                                                                                                    Variable DEFAULT_TIMEOUT_MULTIPLIERConst

                                                                                                                                                                                                    DEFAULT_TIMEOUT_MULTIPLIER: 1.2 = 1.2
                                                                                                                                                                                                    \ No newline at end of file +DEFAULT_TIMEOUT_MULTIPLIER | libp2p

                                                                                                                                                                                                    Variable DEFAULT_TIMEOUT_MULTIPLIERConst

                                                                                                                                                                                                    DEFAULT_TIMEOUT_MULTIPLIER: 1.2 = 1.2
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/libp2p.version.name.html b/variables/libp2p.version.name.html index 88c9ea6531..100d4da0c5 100644 --- a/variables/libp2p.version.name.html +++ b/variables/libp2p.version.name.html @@ -1 +1 @@ -name | libp2p

                                                                                                                                                                                                    Variable nameConst

                                                                                                                                                                                                    name: "libp2p" = 'libp2p'
                                                                                                                                                                                                    \ No newline at end of file +name | libp2p

                                                                                                                                                                                                    Variable nameConst

                                                                                                                                                                                                    name: "libp2p" = 'libp2p'
                                                                                                                                                                                                    \ No newline at end of file diff --git a/variables/libp2p.version.version.html b/variables/libp2p.version.version.html index d3701601f4..b162cc3b23 100644 --- a/variables/libp2p.version.version.html +++ b/variables/libp2p.version.version.html @@ -1 +1 @@ -version | libp2p

                                                                                                                                                                                                    Variable versionConst

                                                                                                                                                                                                    version: "2.0.2" = '2.0.2'
                                                                                                                                                                                                    \ No newline at end of file +version | libp2p

                                                                                                                                                                                                    Variable versionConst

                                                                                                                                                                                                    version: "2.0.2" = '2.0.2'
                                                                                                                                                                                                    \ No newline at end of file