Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y 

A

accept() - Method in interface bt.net.PeerConnectionAcceptor
Makes an attempt to accept a new connection and returns a routine for establishing the connection.
accept() - Method in class bt.net.SocketChannelConnectionAcceptor
 
activate() - Method in interface bt.net.pipeline.ChannelHandler
 
activate() - Method in class bt.net.pipeline.SocketChannelHandler
 
activateChannel(SelectableChannel) - Method in interface bt.net.DataReceiver
Activate selection for the provided channel.
activateChannel(SelectableChannel) - Method in class bt.net.DataReceivingLoop
 
add(K, E) - Method in class bt.BufferingMap
Add a new element into the corresponding bucket (a new bucket will be created, if mapping for this key does not exist yet).
add(String, String) - Method in class bt.tracker.http.urlencoding.TrackerQueryBuilder
Add a named field with a string value
add(String, byte[]) - Method in class bt.tracker.http.urlencoding.TrackerQueryBuilder
Add a named field with a binary byte value
add(String, long) - Method in class bt.tracker.http.urlencoding.TrackerQueryBuilder
Add a named field with a long value
addAnnounceGroup(Collection<String>) - Method in class bt.torrent.maker.TorrentBuilder
 
addBinding(IRuntimeLifecycleBinder.LifecycleEvent, LifecycleBinding) - Method in interface bt.service.IRuntimeLifecycleBinder
Register a hook to run upon runtime lifecycle phase
addBinding(IRuntimeLifecycleBinder.LifecycleEvent, LifecycleBinding) - Method in class bt.service.RuntimeLifecycleBinder
 
addBitfield(ConnectionKey, PeerBitfield) - Method in class bt.torrent.BitfieldBasedStatistics
Add peer's bitfield.
addBlock(TorrentId, Peer, int, int, BufferedData) - Method in interface bt.torrent.data.DataWorker
Add a write block request.
addBlock(TorrentId, Peer, int, int, BufferedData) - Method in class bt.torrent.data.DefaultDataWorker
 
addBlockRequest(TorrentId, Peer, int, int, int) - Method in interface bt.torrent.data.DataWorker
Add a read block request.
addBlockRequest(TorrentId, Peer, int, int, int) - Method in class bt.torrent.data.DefaultDataWorker
 
addBufferedPiece(int, int, BufferedData) - Method in class bt.net.pipeline.BufferedPieceRegistry
 
addBufferedPiece(int, int, BufferedData) - Method in interface bt.net.pipeline.IBufferedPieceRegistry
 
addConnectionAcceptor(Class<? extends PeerConnectionAcceptor>) - Method in class bt.module.ServiceModuleExtender
Contribute a peer connection acceptor type.
addConnectionAcceptor(PeerConnectionAcceptor) - Method in class bt.module.ServiceModuleExtender
Contribute a peer connection acceptor.
addConnectionIfAbsent(PeerConnection) - Method in interface bt.net.IPeerConnectionPool
 
addConnectionIfAbsent(PeerConnection) - Method in class bt.net.PeerConnectionPool
 
addExtendedMessageHandler(String, Class<? extends MessageHandler<M>>) - Method in class bt.module.ProtocolModuleExtender
Contribute a message handler type, that will process BEP-10 messages of the given type.
addExtendedMessageHandler(String, MessageHandler<M>) - Method in class bt.module.ProtocolModuleExtender
Contribute a message handler instance, that will process BEP-10 messages of the given type.
addFile(Path) - Method in class bt.torrent.maker.TorrentBuilder
Add a file to be included within the torrent
addFiles(Path...) - Method in class bt.torrent.maker.TorrentBuilder
 
addHandshakeHandler(Class<? extends HandshakeHandler>) - Method in class bt.module.ProtocolModuleExtender
Contribute a handshake handler type.
addHandshakeHandler(HandshakeHandler) - Method in class bt.module.ProtocolModuleExtender
Contribute a handshake handler instance.
addItem(T) - Method in class bt.dht.stream.StreamAdapter
 
addListener(ProcessingEvent, BiFunction<C, ProcessingStage<C>, ProcessingStage<C>>) - Method in class bt.processor.listener.ListenerSource
Add processing event listener.
addMessageConsumer(ConnectionKey, Consumer<Message>) - Method in interface bt.net.IMessageDispatcher
Add a message consumer to receive messages from a remote peer for a given torrent.
addMessageConsumer(ConnectionKey, Consumer<Message>) - Method in class bt.net.MessageDispatcher
 
addMessageHandler(int, Class<? extends MessageHandler<M>>) - Method in class bt.module.ProtocolModuleExtender
Contribute a message handler type, that will process BEP-3 messages with the given ID.
addMessageHandler(int, MessageHandler<M>) - Method in class bt.module.ProtocolModuleExtender
Contribute a message handler instance, that will process BEP-3 messages with the given ID.
addMessageSupplier(ConnectionKey, Supplier<Message>) - Method in interface bt.net.IMessageDispatcher
Add a message supplier to send messages to a remote peer for a given torrent.
addMessageSupplier(ConnectionKey, Supplier<Message>) - Method in class bt.net.MessageDispatcher
 
addMessageType(String, Integer) - Method in class bt.protocol.extended.ExtendedHandshake.Builder
Adds a mapping between message type name and its' numeric ID.
addMessagingAgent(Object) - Method in class bt.module.ServiceModuleExtender
Contribute a messaging agent instance.
addMessagingAgentType(Class<?>) - Method in class bt.module.ServiceModuleExtender
Contribute a messaging agent type.
addNode(Peer) - Method in interface bt.dht.DHTService
Add a DHT node.
addNode(Peer) - Method in class bt.dht.MldhtService
 
addPeer(TorrentId, Peer) - Method in interface bt.peer.IPeerRegistry
Add peer for a given torrent and notify all peer consumers.
addPeer(TorrentId, Peer) - Method in class bt.peer.PeerRegistry
 
addPeerSource(TorrentId, AnnounceKey) - Method in interface bt.peer.IPeerRegistry
Register a new tracker peer source for a given torrent, based on the provided announce key.
addPeerSource(TorrentId, AnnounceKey) - Method in class bt.peer.PeerRegistry
 
addPeerSourceFactory(Class<? extends PeerSourceFactory>) - Method in class bt.module.ServiceModuleExtender
Add a peer source factory type.
addPeerSourceFactory(PeerSourceFactory) - Method in class bt.module.ServiceModuleExtender
Add a peer source factory instance.
addPiece(ConnectionKey, Integer) - Method in class bt.torrent.BitfieldBasedStatistics
Update peer's bitfield by indicating that the peer has a given piece.
addPortMapper(PortMapper) - Method in class bt.module.ServiceModuleExtender
Contribute a port mapper instance.
addPortMapper(Class<? extends PortMapper>) - Method in class bt.module.ServiceModuleExtender
Contribute a port mapper type.
addTrackerFactory(Class<? extends TrackerFactory>, String, String...) - Method in class bt.module.ServiceModuleExtender
Contribute a tracker factory type for some URL protocol(s).
addTrackerFactory(TrackerFactory, String, String...) - Method in class bt.module.ServiceModuleExtender
Contribute a tracker factory instance for some URL protocol(s).
AdhocTorrentRegistry - Class in bt.torrent
Simple in-memory torrent registry, that creates new descriptors upon request.
AdhocTorrentRegistry(IDataDescriptorFactory, EventSource) - Constructor for class bt.torrent.AdhocTorrentRegistry
 
after() - Method in class bt.processor.magnet.FetchMetadataStage
 
after() - Method in class bt.processor.magnet.InitializeMagnetTorrentProcessingStage
 
after() - Method in interface bt.processor.ProcessingStage
 
after() - Method in class bt.processor.torrent.ChooseFilesStage
 
after() - Method in class bt.processor.torrent.CreateSessionStage
 
after() - Method in class bt.processor.torrent.FetchTorrentStage
 
after() - Method in class bt.processor.torrent.InitializeTorrentProcessingStage
 
after() - Method in class bt.processor.torrent.ProcessTorrentStage
 
after() - Method in class bt.processor.torrent.SeedStage
 
afterDownloaded(Consumer<Torrent>) - Method in class bt.TorrentClientBuilder
Provide a callback to invoke when downloading has completed
afterFileDownloaded(FileDownloadCompleteCallback) - Method in class bt.TorrentClientBuilder
Provide a callback to invoke when an individual file in the torrent has completed and verified
afterFilesChosen(Runnable) - Method in class bt.TorrentClientBuilder
Provide a callback to invoke when the files have been chosen
afterTorrentFetched(Consumer<Torrent>) - Method in class bt.TorrentClientBuilder
Provide a callback to invoke when torrent's metadata has been fetched.
AlphaSortedMapping - Class in bt.protocol.extended
Represents a set of mappings, in which numeric IDs are assigned to message type names sequentially starting with 1, in the alphanumeric order of type names.
AlphaSortedMapping(Map<String, MessageHandler<? extends ExtendedMessage>>) - Constructor for class bt.protocol.extended.AlphaSortedMapping
 
announce() - Method in interface bt.peer.lan.ILocalServiceDiscoveryService
Perform LSD announce.
announce() - Method in class bt.peer.lan.LocalServiceDiscoveryService
 
announce(String) - Method in class bt.torrent.maker.TorrentBuilder
 
ANNOUNCE_KEY - Static variable in class bt.metainfo.MetadataConstants
ANNOUNCE_LIST_KEY - Static variable in class bt.metainfo.MetadataConstants
AnnounceGroup - Class in bt.peer.lan
Configuration object, that represents an LSD multicast group.
AnnounceGroup(InetSocketAddress, int) - Constructor for class bt.peer.lan.AnnounceGroup
 
AnnounceGroupChannel - Class in bt.peer.lan
Repairable datagram channel.
AnnounceGroupChannel(AnnounceGroup, Selector, Collection<NetworkInterface>) - Constructor for class bt.peer.lan.AnnounceGroupChannel
 
AnnounceKey - Class in bt.tracker
This class encapsulates information about trackers, that can be used for getting a particular torrent.
AnnounceKey(String) - Constructor for class bt.tracker.AnnounceKey
Create a single-tracker announce key
AnnounceKey(List<List<String>>) - Constructor for class bt.tracker.AnnounceKey
Create a multi-tracker announce key See BEP-12: Multitracker Metadata Extension for more details
ApplicationService - Interface in bt.service
 
apply(Object) - Method in interface bt.bencoding.model.BEObjectModelBuilder
 
assign(ConnectionKey) - Method in class bt.torrent.messaging.Assignments
 
Assignments - Class in bt.torrent.messaging
 
Assignments(LocalBitfield, ValidatingSelector, BitfieldBasedStatistics, Config) - Constructor for class bt.torrent.messaging.Assignments
 
async() - Method in class bt.service.LifecycleBinding.Builder
Mark this binding for asynchronous execution
attachClient(BtClient) - Method in class bt.runtime.BtRuntime
Attach the provided client to this runtime.
autoLoadModules() - Method in class bt.runtime.BtRuntimeBuilder
If this option is set, Bt will use the service loading mechanism to load any modules that are available on application's classpath.
autoLoadModules() - Method in class bt.StandaloneClientBuilder
If this option is set, Bt will use the service loading mechanism to load any modules that are available on application's classpath.

B

BaseClientBuilder<B extends BaseClientBuilder> - Class in bt
Provides basic capabilities to build a Bt client.
BaseClientBuilder() - Constructor for class bt.BaseClientBuilder
 
BaseEvent - Class in bt.event
Globally ordered, timestamped event.
BaseEvent(long, long) - Constructor for class bt.event.BaseEvent
 
BaseMessageHandler<T extends Message> - Class in bt.protocol.handler
Base class for MessageHandler implementations, that work with a single message type.
BaseMessageHandler() - Constructor for class bt.protocol.handler.BaseMessageHandler
 
BEEncoder - Class in bt.bencoding.serializers
BEncoding encoder.
BEEncoder() - Constructor for class bt.bencoding.serializers.BEEncoder
 
BEInteger - Class in bt.bencoding.types
BEncoded integer.
BEInteger(Number) - Constructor for class bt.bencoding.types.BEInteger
 
BEInteger(byte[], Number) - Constructor for class bt.bencoding.types.BEInteger
 
BEList - Class in bt.bencoding.types
BEncoded list.
BEList(List<? extends BEObject<?>>) - Constructor for class bt.bencoding.types.BEList
 
BEList(byte[], List<? extends BEObject<?>>) - Constructor for class bt.bencoding.types.BEList
 
BEMap - Class in bt.bencoding.types
BEncoded dictionary.
BEMap(Map<String, BEObject<?>>) - Constructor for class bt.bencoding.types.BEMap
 
BEMap(byte[], Map<String, BEObject<?>>) - Constructor for class bt.bencoding.types.BEMap
 
BEObject<T> - Interface in bt.bencoding.model
Generic bencoded object.
BEObjectModel - Interface in bt.bencoding.model
Object model.
BEObjectModelBuilder<T> - Interface in bt.bencoding.model
Builds an object model from a Java-type based definition.
BEObjectModelBuilderFactory - Interface in bt.bencoding.model
Factory of model builders.
BEObjectModelLoader - Interface in bt.bencoding.model
Loads model definitions.
BEParser - Class in bt.bencoding.serializers
BEncoding parser.
BEParser(URL) - Constructor for class bt.bencoding.serializers.BEParser
Create a parser for the provided URL's content.
BEParser(InputStream) - Constructor for class bt.bencoding.serializers.BEParser
Create a parser for the provided binary input.
BEParser(byte[]) - Constructor for class bt.bencoding.serializers.BEParser
Create a parser for the provided bencoded document.
BEString - Class in bt.bencoding.types
BEncoded string.
BEString(byte[]) - Constructor for class bt.bencoding.types.BEString
 
BEString(String) - Constructor for class bt.bencoding.types.BEString
 
BEType - Enum in bt.bencoding
BEncoding object types.
BigIntegers - Class in bt.net
Utility class that provides convenient shortcuts for working with java.math.BigInteger as if it was unsigned
BigIntegers() - Constructor for class bt.net.BigIntegers
 
BinaryQueryNamedValue - Class in bt.tracker.http.urlencoding
A class that represents a parameter in the query string, along with it's decoded value.
BinaryQueryNamedValue(String, byte[]) - Constructor for class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Create a new named value that is in a query string
BinaryQueryNamedValue(String, String) - Constructor for class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Create a new named value that is in a query string.
BinaryQueryNamedValue(String, String, Charset) - Constructor for class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Create a new named value that is in a query string
BinaryQueryNamedValue(String, long) - Constructor for class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Create a new named value that is in a query string.
bind(Runnable) - Static method in class bt.service.LifecycleBinding
 
bindHandler(ChannelHandler) - Method in interface bt.net.pipeline.ChannelPipeline
Attach channel handler to this pipeline
bindHandler(ChannelHandler) - Method in class bt.net.pipeline.DefaultChannelPipeline
 
Bitfield - Class in bt.data
Status of torrent's data.
Bitfield(int) - Constructor for class bt.data.Bitfield
Creates empty bitfield.
Bitfield(int, BitSet) - Constructor for class bt.data.Bitfield
Creates a bitfield for with the bitset initially set to the passed in BitSet
Bitfield - Class in bt.protocol
 
Bitfield(byte[]) - Constructor for class bt.protocol.Bitfield
 
BITFIELD_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
BitfieldBasedStatistics - Class in bt.torrent
Acts as a storage for peers' bitfields and provides aggregate piece statistics.
BitfieldBasedStatistics(Bitfield) - Constructor for class bt.torrent.BitfieldBasedStatistics
Create statistics, based on the local peer's bitfield.
BitfieldCollectingConsumer - Class in bt.torrent.messaging
Accumulates received bitfields and haves without validating anything.
BitfieldCollectingConsumer() - Constructor for class bt.torrent.messaging.BitfieldCollectingConsumer
 
BitfieldConnectionHandler - Class in bt.net
Sends local bitfield to a newly connected remote peer.
BitfieldConnectionHandler(TorrentRegistry) - Constructor for class bt.net.BitfieldConnectionHandler
 
BitfieldConsumer - Class in bt.torrent.messaging
Consumes peer bitfield.
BitfieldConsumer(Bitfield, BitfieldBasedStatistics, EventSink) - Constructor for class bt.torrent.messaging.BitfieldConsumer
 
BitfieldHandler - Class in bt.protocol.handler
 
BitfieldHandler() - Constructor for class bt.protocol.handler.BitfieldHandler
 
bitmask - Variable in class bt.data.Bitfield
Bitmask indicating availability of pieces.
BitOrder - Enum in bt.protocol
 
BitTorrentProtocol - Annotation Type in bt.module
Annotates the primary message handler, that implements core BitTorrent protocol.
BlockCache - Interface in bt.torrent.data
 
blockCount() - Method in interface bt.data.BlockSet
Get the total number of blocks in this block set.
blockCount() - Method in class bt.data.range.MutableBlockSet
 
blockCount() - Method in class bt.data.range.SynchronizedBlockSet
 
BlockRange<T extends Range<T>> - Class in bt.data.range
 
blockRange(T, long) - Static method in class bt.data.range.Ranges
 
BlockRead - Class in bt.torrent.data
Read block command.
BlockReader - Interface in bt.torrent.data
 
BlockSet - Interface in bt.data
 
blockSize() - Method in interface bt.data.BlockSet
Get the size of a block in this set.
blockSize() - Method in class bt.data.range.MutableBlockSet
 
blockSize() - Method in class bt.data.range.SynchronizedBlockSet
 
BlockWrite - Class in bt.torrent.data
Write block command.
borrowByteBuffer() - Method in class bt.net.buffer.BufferManager
 
borrowByteBuffer() - Method in interface bt.net.buffer.IBufferManager
Temporarily borrow a direct byte buffer.
BorrowedBuffer<T extends Buffer> - Interface in bt.net.buffer
Re-usable buffer.
bt - package bt
 
Bt - Class in bt
Main entry point to building Bt clients
Bt() - Constructor for class bt.Bt
 
bt.bencoding - package bt.bencoding
 
bt.bencoding.model - package bt.bencoding.model
 
bt.bencoding.model.rule - package bt.bencoding.model.rule
 
bt.bencoding.serializers - package bt.bencoding.serializers
 
bt.bencoding.types - package bt.bencoding.types
 
bt.data - package bt.data
 
bt.data.digest - package bt.data.digest
 
bt.data.file - package bt.data.file
 
bt.data.range - package bt.data.range
 
bt.dht - package bt.dht
 
bt.dht.stream - package bt.dht.stream
 
bt.event - package bt.event
 
bt.magnet - package bt.magnet
 
bt.metainfo - package bt.metainfo
 
bt.module - package bt.module
 
bt.net - package bt.net
 
bt.net.buffer - package bt.net.buffer
 
bt.net.crypto - package bt.net.crypto
 
bt.net.extended - package bt.net.extended
 
bt.net.pipeline - package bt.net.pipeline
 
bt.net.portmapping - package bt.net.portmapping
 
bt.net.portmapping.impl - package bt.net.portmapping.impl
 
bt.peer - package bt.peer
 
bt.peer.lan - package bt.peer.lan
 
bt.peerexchange - package bt.peerexchange
 
bt.portmapping.upnp - package bt.portmapping.upnp
 
bt.portmapping.upnp.jetty - package bt.portmapping.upnp.jetty
 
bt.processor - package bt.processor
 
bt.processor.listener - package bt.processor.listener
 
bt.processor.magnet - package bt.processor.magnet
 
bt.processor.torrent - package bt.processor.torrent
 
bt.protocol - package bt.protocol
 
bt.protocol.crypto - package bt.protocol.crypto
 
bt.protocol.extended - package bt.protocol.extended
 
bt.protocol.handler - package bt.protocol.handler
 
bt.runtime - package bt.runtime
 
bt.service - package bt.service
 
bt.torrent - package bt.torrent
 
bt.torrent.annotation - package bt.torrent.annotation
 
bt.torrent.callbacks - package bt.torrent.callbacks
 
bt.torrent.compiler - package bt.torrent.compiler
 
bt.torrent.data - package bt.torrent.data
 
bt.torrent.fileselector - package bt.torrent.fileselector
 
bt.torrent.maker - package bt.torrent.maker
 
bt.torrent.messaging - package bt.torrent.messaging
 
bt.torrent.selector - package bt.torrent.selector
 
bt.tracker - package bt.tracker
 
bt.tracker.http - package bt.tracker.http
 
bt.tracker.http.urlencoding - package bt.tracker.http.urlencoding
 
bt.tracker.udp - package bt.tracker.udp
 
BtClient - Interface in bt.runtime
Main API for interaction with a torrent processing worker.
BtClientBuilder - Class in bt
Builds a client and attaches it to the provided runtime.
BtClientBuilder() - Constructor for class bt.BtClientBuilder
 
BtException - Exception in bt
Generic Bt exception
BtException(String, Throwable) - Constructor for exception bt.BtException
 
BtException(String) - Constructor for exception bt.BtException
 
BtModuleProvider - Interface in bt.module
Provides the support for auto-loading of modules.
BtParseException - Exception in bt.bencoding.serializers
BEncoded document parse exception.
BtParseException(String, byte[], Throwable) - Constructor for exception bt.bencoding.serializers.BtParseException
 
BtParseException(String, byte[]) - Constructor for exception bt.bencoding.serializers.BtParseException
 
BtRuntime - Class in bt.runtime
A runtime is an orchestrator of multiple simultaneous torrent sessions.
BtRuntimeBuilder - Class in bt.runtime
Runtime builder.
BtRuntimeBuilder() - Constructor for class bt.runtime.BtRuntimeBuilder
Create runtime builder with default config.
BtRuntimeBuilder(Config) - Constructor for class bt.runtime.BtRuntimeBuilder
Create runtime builder with provided config.
buffer() - Method in class bt.net.buffer.BufferedData
 
BufferedData - Class in bt.net.buffer
 
BufferedData(ByteBufferView) - Constructor for class bt.net.buffer.BufferedData
 
BufferedPieceRegistry - Class in bt.net.pipeline
 
BufferedPieceRegistry() - Constructor for class bt.net.pipeline.BufferedPieceRegistry
 
BufferingMap<K,E> - Class in bt
Convenient utility class to create maps, that act as temporary buffers for storing values between their initial collection and retrieval for further processing.
BufferingMap(Supplier<? extends Collection<E>>) - Constructor for class bt.BufferingMap
 
BufferManager - Class in bt.net.buffer
 
BufferManager(Config) - Constructor for class bt.net.buffer.BufferManager
 
BufferMutator - Interface in bt.net.buffer
 
Buffers - Class in bt.net.buffer
 
Buffers() - Constructor for class bt.net.buffer.Buffers
 
build() - Method in class bt.BaseClientBuilder
 
build(InetPeerAddress) - Static method in class bt.net.InetPeer
 
build(InetAddress, int) - Static method in class bt.net.InetPeer
 
build(InetAddress) - Static method in class bt.net.InetPeer
 
build() - Method in class bt.net.InetPeer.Builder
 
build() - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
build() - Method in class bt.protocol.extended.ExtendedHandshake.Builder
 
build() - Method in class bt.runtime.BtRuntimeBuilder
 
build() - Method in class bt.service.LifecycleBinding.Builder
 
build() - Method in class bt.StandaloneClientBuilder
 
build() - Method in class bt.torrent.fileselector.SelectionResult.Builder
Deprecated.
 
build() - Method in class bt.torrent.maker.TorrentBuilder
Build the torrent
Builder(TorrentId) - Constructor for class bt.magnet.MagnetUri.Builder
 
builder(InetPeerAddress) - Static method in class bt.net.InetPeer
 
builder(InetAddress, int) - Static method in class bt.net.InetPeer
 
builder(InetAddress) - Static method in class bt.net.InetPeer
 
builder() - Static method in class bt.protocol.extended.ExtendedHandshake
 
builder() - Static method in class bt.runtime.BtRuntime
 
builder(Config) - Static method in class bt.runtime.BtRuntime
 
buildKey(int, int, int) - Method in class bt.torrent.messaging.Mapper
Create a unique key for a block request, cancel request or received piece.
buildModel(T) - Method in interface bt.bencoding.model.BEObjectModelBuilder
Build an object model from the provided model definition.
buildModel(Map) - Method in class bt.bencoding.model.JUMModelBuilder
 
buildPeerId(byte[]) - Method in class bt.service.VersionAwareIdentityService
 
buildPipeline(Peer) - Method in class bt.net.pipeline.ChannelPipelineFactory
 
buildPipeline(Peer) - Method in interface bt.net.pipeline.IChannelPipelineFactory
Start building a pipeline for the given peer.
buildProcessingContext(BtRuntime) - Method in class bt.BaseClientBuilder
 
buildProcessingContext(BtRuntime) - Method in class bt.TorrentClientBuilder
 
buildQueryUrl(List<BinaryQueryNamedValue>) - Static method in class bt.tracker.http.urlencoding.QueryBuilderUtil
Build a url query for a torrent tracker from the named values
buildReadWriteDataRange(List<StorageUnit>) - Static method in class bt.data.PieceUtils
Builds a read write data range with the ordered passed in storage units
buildUri() - Method in class bt.magnet.MagnetUri.Builder
 
ByteBufferView - Interface in bt.net.buffer
 
ByteChannelReader - Class in bt.net
 
ByteRange - Class in bt.data.range
Binary data range.
ByteRange(byte[]) - Constructor for class bt.data.range.ByteRange
Create a binary range from a byte array.
ByteRange(byte[], int, int) - Constructor for class bt.data.range.ByteRange
Create a binary range from a subrange of a byte array.
ByteRange(ByteBuffer) - Constructor for class bt.data.range.ByteRange
Create a binary range from a byte buffer.

C

calculateNumberOfChunks(long, long) - Static method in class bt.data.PieceUtils
Calculate the number of chunks there are in a torrent based on the totalSize and chunkSize
cancel() - Method in interface bt.net.ConnectionRoutine
Cancel connection establishing and release related resources.
Cancel - Class in bt.protocol
 
Cancel(int, int, int) - Constructor for class bt.protocol.Cancel
 
CANCEL_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
CancelHandler - Class in bt.protocol.handler
 
CancelHandler() - Constructor for class bt.protocol.handler.CancelHandler
 
canReadInt(ByteBufferView) - Static method in class bt.protocol.Protocols
Check that remaining bytes in buffer are enough to read an int
capacity() - Method in class bt.data.file.FileSystemStorageUnit
 
capacity() - Method in interface bt.data.StorageUnit
Get total maximum capacity of this storage.
capacity() - Method in interface bt.net.buffer.ByteBufferView
 
capacity() - Method in class bt.net.buffer.DelegatingByteBufferView
 
capacity() - Method in class bt.net.buffer.SplicedByteBufferView
 
cast(Class<T>, Object, Object) - Static method in class bt.bencoding.model.ClassUtil
 
castList(Class<T>, List<?>) - Static method in class bt.bencoding.model.ClassUtil
 
ChainProcessor<C extends ProcessingContext> - Class in bt.processor
Base implementation of a generic asynchronous executor of processing chains.
ChainProcessor(ProcessingStage<C>, ExecutorService) - Constructor for class bt.processor.ChainProcessor
Create processor for a given processing chain.
ChainProcessor(ProcessingStage<C>, ExecutorService, ContextFinalizer<C>) - Constructor for class bt.processor.ChainProcessor
Create processor for a given processing chain.
channel(ByteChannel) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
ChannelHandler - Interface in bt.net.pipeline
Provides API for direct messaging via a channel (usually non-blocking).
ChannelHandlerContext - Interface in bt.net.pipeline
Provides the means to notify the messaging pipeline about certain events.
ChannelPipeline - Interface in bt.net.pipeline
Encapsulates the algorithm of encoding/decoding data, that is transfered between two peers.
ChannelPipelineBuilder - Class in bt.net.pipeline
 
ChannelPipelineFactory - Class in bt.net.pipeline
 
ChannelPipelineFactory(IBufferManager, IBufferedPieceRegistry) - Constructor for class bt.net.pipeline.ChannelPipelineFactory
 
checkAndMarkVerified(int) - Method in class bt.data.Bitfield
Marks the piece as verified and returns whether it was verified before it was marked as verified.
checkDuplicateConnections(TorrentId, Peer) - Method in interface bt.net.IPeerConnectionPool
 
checkDuplicateConnections(TorrentId, Peer) - Method in class bt.net.PeerConnectionPool
 
Choke - Class in bt.protocol
 
CHOKE_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
ChokeHandler - Class in bt.protocol.handler
 
ChokeHandler() - Constructor for class bt.protocol.handler.ChokeHandler
 
ChooseFilesStage<C extends TorrentContext> - Class in bt.processor.torrent
 
ChooseFilesStage(ProcessingStage<C>, TorrentRegistry, Config) - Constructor for class bt.processor.torrent.ChooseFilesStage
 
CHUNK_HASHES_KEY - Static variable in class bt.metainfo.MetadataConstants
CHUNK_SIZE_KEY - Static variable in class bt.metainfo.MetadataConstants
ChunkDescriptor - Interface in bt.data
Each torrent is split into chunks (also called "pieces").
ChunkVerifier - Interface in bt.data
Implements data verification strategy.
CipherBufferMutator - Class in bt.net.crypto
Mutator, that performs encryption or decryption of data.
CipherBufferMutator(Cipher) - Constructor for class bt.net.crypto.CipherBufferMutator
 
claim(int) - Method in class bt.torrent.messaging.Assignments
 
ClasspathApplicationService - Class in bt.service
Reads application version info from a manifest file, located on the application's classpath.
ClasspathApplicationService() - Constructor for class bt.service.ClasspathApplicationService
 
ClassUtil - Class in bt.bencoding.model
Provides utility functions for unchecked conversions.
ClassUtil() - Constructor for class bt.bencoding.model.ClassUtil
 
clear() - Method in interface bt.data.BlockSet
Reset block presence information (may not perform actual deletion of data)
clear() - Method in class bt.data.range.MutableBlockSet
 
clear() - Method in class bt.data.range.SynchronizedBlockSet
 
client() - Static method in class bt.Bt
Create a standalone client builder with a private runtime
client(BtRuntime) - Static method in class bt.Bt
Create a standard client builder with the provided runtime
ClientExecutor - Annotation Type in bt.module
Annotates ExecutorService, that should be used for creating client executors.
close() - Method in class bt.bencoding.serializers.BEParser
 
close() - Method in class bt.data.DataReaderChannel
 
close() - Method in class bt.data.file.FileSystemStorageUnit
 
close(FileCacheKey) - Method in class bt.data.file.OpenFileCache
Close the file associated with this cache key if it is open
close() - Method in class bt.data.file.OpenFileCache
Close all open files in this storage system.
close() - Method in class bt.net.crypto.EncryptedChannel
 
close() - Method in interface bt.net.pipeline.ChannelHandler
Request to close.
close() - Method in class bt.net.pipeline.SocketChannelHandler
 
close() - Method in class bt.net.SharedSelector
 
close() - Method in class bt.net.SocketPeerConnection
 
close() - Method in class bt.tracker.http.HttpTracker
 
closeQuietly() - Method in interface bt.net.PeerConnection
Close the connection without throwing an IOException.
closeQuietly() - Method in class bt.net.SocketPeerConnection
 
closeQuietly() - Method in class bt.peer.lan.AnnounceGroupChannel
 
collectPeers(Consumer<Peer>) - Method in class bt.dht.DHTPeerSource
 
collectPeers(Consumer<Peer>) - Method in class bt.peer.ScheduledPeerSource
 
collectStageListeners(ListenerSource<C>) - Method in class bt.BaseClientBuilder
 
collectStageListeners(ListenerSource<C>) - Method in class bt.TorrentClientBuilder
 
CompactPeerInfo - Class in bt.tracker
Wrapper for binary representation of a list of peers, which is used by the majority of HTTP trackers and all UDP trackers.
CompactPeerInfo(byte[], CompactPeerInfo.AddressType) - Constructor for class bt.tracker.CompactPeerInfo
Create a list of peers from its' binary representation, using the specified address type for decoding individual addresses.
CompactPeerInfo(byte[], CompactPeerInfo.AddressType, byte[]) - Constructor for class bt.tracker.CompactPeerInfo
Create a list of peers from its' binary representation, using the specified address type for decoding individual addresses.
CompactPeerInfo.AddressType - Enum in bt.tracker
Address family
compare(Long, Long) - Method in class bt.torrent.selector.PackedIntComparator
 
compareTo(BaseEvent) - Method in class bt.event.BaseEvent
 
compileAndVisit(Object, CompilerVisitor) - Method in class bt.torrent.compiler.MessagingAgentCompiler
Parse an arbitrary object.
CompilerVisitor - Interface in bt.torrent.compiler
Instances of this class provide callbacks for the MessagingAgentCompiler.
CompletableTorrentFile - Class in bt.data
A class that keeps track of how many more chunks must complete before this file finishes.
CompletableTorrentFile(TorrentFile, long, Consumer<TorrentFile>) - Constructor for class bt.data.CompletableTorrentFile
 
complete() - Method in interface bt.torrent.TorrentDescriptor
Signal that the torrent has been successfully downloaded and verified
complete() - Method in class bt.torrent.TrackerAnnouncer
 
complete() - Method in class bt.tracker.TrackerRequestBuilder
Announce to tracker, that the client has completed downloading the torrent.
config(Config) - Method in class bt.runtime.BtRuntimeBuilder
Set runtime config.
Config - Class in bt.runtime
Provides runtime configuration parameters.
Config() - Constructor for class bt.runtime.Config
Create a config with default parameters.
Config(Config) - Constructor for class bt.runtime.Config
Clone the provided config.
config(Config) - Method in class bt.StandaloneClientBuilder
Set runtime configuration.
configure(Binder) - Method in class bt.dht.DHTModule
 
configure(Binder) - Method in class bt.module.ProtocolModule
 
configure(Binder) - Method in class bt.module.ServiceModule
 
configure(Binder) - Method in class bt.net.portmapping.impl.PortMappingModule
 
configure(Binder) - Method in class bt.peer.lan.LocalServiceDiscoveryModule
 
configure(Binder) - Method in class bt.peerexchange.PeerExchangeModule
 
configure() - Method in class bt.portmapping.upnp.UpnpPortMapperModule
 
configure(Binder) - Method in class bt.tracker.http.HttpTrackerModule
 
ConnectionHandler - Interface in bt.net
Handles new peer connections.
ConnectionHandlerFactory - Class in bt.net
Note that this class implements a service.
ConnectionHandlerFactory(IHandshakeFactory, TorrentRegistry, Collection<HandshakeHandler>, Duration) - Constructor for class bt.net.ConnectionHandlerFactory
 
ConnectionKey - Class in bt.net
 
ConnectionKey(Peer, int, TorrentId) - Constructor for class bt.net.ConnectionKey
 
ConnectionResult - Class in bt.net
 
ConnectionRoutine - Interface in bt.net
Encapsulates a procedure for establishing the connection.
ConnectionSource - Class in bt.net
 
ConnectionSource(Set<PeerConnectionAcceptor>, IPeerConnectionFactory, IPeerConnectionPool, IRuntimeLifecycleBinder, Config) - Constructor for class bt.net.ConnectionSource
 
ConnectionState - Class in bt.torrent.messaging
Contains basic information about a connection's state.
consume(ExtendedHandshake, MessageContext) - Method in class bt.net.extended.ExtendedHandshakeConsumer
 
consume(ExtendedHandshake, MessageContext) - Method in class bt.peerexchange.PeerExchangePeerSourceFactory
 
consume(PeerExchange, MessageContext) - Method in class bt.peerexchange.PeerExchangePeerSourceFactory
 
consume(Bitfield, MessageContext) - Method in class bt.torrent.messaging.BitfieldCollectingConsumer
 
consume(Have, MessageContext) - Method in class bt.torrent.messaging.BitfieldCollectingConsumer
 
consume(Bitfield, MessageContext) - Method in class bt.torrent.messaging.BitfieldConsumer
 
consume(Have, MessageContext) - Method in class bt.torrent.messaging.BitfieldConsumer
 
consume(Message, MessageContext) - Method in class bt.torrent.messaging.DefaultMessageRouter
 
consume(KeepAlive) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(Choke, MessageContext) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(Unchoke, MessageContext) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(Interested, MessageContext) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(NotInterested, MessageContext) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(Cancel, MessageContext) - Method in class bt.torrent.messaging.GenericConsumer
 
consume(T, MessageContext) - Method in interface bt.torrent.messaging.MessageConsumer
 
consume(Message, MessageContext) - Method in interface bt.torrent.messaging.MessageRouter
Route a message to consumers.
consume(ExtendedHandshake, MessageContext) - Method in class bt.torrent.messaging.MetadataConsumer
 
consume(UtMetadata, MessageContext) - Method in class bt.torrent.messaging.MetadataConsumer
 
consume(UtMetadata, MessageContext) - Method in class bt.torrent.messaging.MetadataProducer
 
consume(Request, MessageContext) - Method in class bt.torrent.messaging.PeerRequestConsumer
 
consume(Piece, MessageContext) - Method in class bt.torrent.messaging.PieceConsumer
 
consumer() - Static method in class bt.torrent.messaging.GenericConsumer
 
Consumes - Annotation Type in bt.torrent.annotation
Annotates messaging agents, that act as message consumers.
containsKey(K) - Method in class bt.BufferingMap
 
ContextFinalizer<C extends ProcessingContext> - Interface in bt.processor
Used to finalize context and cleanup resources, when processing completes normally or terminates abruptly due to error
Contribute - Annotation Type in bt.module
Annotates a method in a Module, that would like to make a contribution to some other module in the same runtime.
contributeExtendedMessageHandler(Binder) - Static method in class bt.module.ProtocolModule
Deprecated.
since 1.5 in favor of ProtocolModuleExtender.addExtendedMessageHandler(String, Class) and its' overloaded versions
contributeHandshakeHandler(Binder) - Static method in class bt.module.ProtocolModule
Deprecated.
since 1.5 in favor of ProtocolModuleExtender.addHandshakeHandler(Class) and its' overloaded versions
contributeMessageHandler(Binder) - Static method in class bt.module.ProtocolModule
Deprecated.
since 1.5 in favor of ProtocolModuleExtender.addMessageHandler(int, Class) and its' overloaded versions
contributeMessagingAgent(Binder) - Static method in class bt.module.ServiceModule
contributePeerSourceFactory(Binder) - Static method in class bt.module.ServiceModule
Deprecated.
since 1.5 in favor of ServiceModuleExtender.addPeerSourceFactory(Class) and its' overloaded versions
contributeTrackerFactory(Binder) - Static method in class bt.module.ServiceModule
Deprecated.
since 1.5 in favor of ServiceModuleExtender.addTrackerFactory(Class, String, String...) and its' overloaded versions
Cookie - Class in bt.peer.lan
Opaque valueStr, allowing the sending client to filter out its own announces if it receives them via multicast loopback.
copyOf(BitSet) - Static method in class bt.protocol.Protocols
Get a copy of the provided bitset.
count() - Method in class bt.torrent.messaging.Assignments
 
countdown() - Method in class bt.data.CompletableTorrentFile
Countdown the number of chunks needed by 1.
CountingThreadFactory - Class in bt
 
CountingThreadFactory(String, boolean) - Constructor for class bt.CountingThreadFactory
 
createChannel() - Method in interface bt.data.DataReader
Create a sequential view of torrent's data in the form of a ReadableByteChannel.
createCopy() - Method in interface bt.data.digest.Digester
Clone the digester so any thread local variables will be cleaned up when the clone is GC'd
createCopy() - Method in class bt.data.digest.JavaSecurityDigester
 
CREATED_BY_KEY - Static variable in class bt.metainfo.MetadataConstants
Not in protocol definition, but seems to be widely used
createdBy(String) - Method in class bt.torrent.maker.TorrentBuilder
Set the author of the torrent stored in the created by flag.
createDescriptor(Torrent, Storage, FileDownloadCompleteCallback) - Method in class bt.data.DataDescriptorFactory
 
createDescriptor(Torrent, Storage, FileDownloadCompleteCallback) - Method in interface bt.data.IDataDescriptorFactory
Create a data descriptor for a given torrent with the storage provided as the data back-end.
createEmpty() - Method in interface bt.data.StorageUnit
Creates this empty unit in the file system
createHandshake(TorrentId) - Method in class bt.protocol.HandshakeFactory
 
createHandshake(TorrentId) - Method in interface bt.protocol.IHandshakeFactory
Create a handshake, that can be used to initialize peer connections for a given torrent.
createIncomingConnection(Peer, SocketChannel) - Method in interface bt.net.IPeerConnectionFactory
 
createIncomingConnection(Peer, SocketChannel) - Method in class bt.net.PeerConnectionFactory
 
createMagnetProcessor() - Method in class bt.processor.TorrentProcessorFactory
 
createNamespace() - Method in class bt.portmapping.upnp.jetty.JettyAsyncUpnpServiceConfiguration
 
createOutgoingConnection(Peer, TorrentId) - Method in interface bt.net.IPeerConnectionFactory
 
createOutgoingConnection(Peer, TorrentId) - Method in class bt.net.PeerConnectionFactory
 
createPeerWorker(ConnectionKey) - Method in interface bt.torrent.messaging.IPeerWorkerFactory
Create a torrent-aware peer worker for a given peer connection.
createPeerWorker(ConnectionKey) - Method in class bt.torrent.messaging.PeerWorkerFactory
 
createPiecePriorityMapper(DataDescriptor, List<TorrentFile>, FilePrioritySelector) - Static method in class bt.processor.torrent.FilePiecePriorityMapper
Create a new File Pieces priority mapper from a priority updater.
createPiecePriorityMapper(DataDescriptor, List<TorrentFile>, FilePrioritySkipSelector) - Static method in class bt.processor.torrent.FilePiecePriorityMapper
Create a new File Pieces priority mapper from a choosing file selector
createReader(Torrent, DataDescriptor) - Method in class bt.data.DataReaderFactory
 
CreateSessionStage<C extends TorrentContext> - Class in bt.processor.torrent
 
CreateSessionStage(ProcessingStage<C>, TorrentRegistry, EventSource, IConnectionSource, IMessageDispatcher, Set<Object>, Config) - Constructor for class bt.processor.torrent.CreateSessionStage
 
createStreamClient() - Method in class bt.portmapping.upnp.jetty.JettyAsyncUpnpServiceConfiguration
 
createStreamServer(NetworkAddressFactory) - Method in class bt.portmapping.upnp.jetty.JettyAsyncUpnpServiceConfiguration
 
createTorrentProcessor() - Method in class bt.processor.TorrentProcessorFactory
 
createTrackerQuery(HttpTracker.TrackerRequestType, TrackerRequestBuilder) - Method in class bt.tracker.http.HttpTracker
Build the query to send to the tracker.
CREATION_DATE_KEY - Static variable in class bt.metainfo.MetadataConstants
Not in protocol definition, but seems to be widely used
creationDate(Date) - Method in class bt.torrent.maker.TorrentBuilder
Set the creation date of the torrent.
CryptoUtil - Class in bt.service
This utility class provides cryptographic functions.
CryptoUtil() - Constructor for class bt.service.CryptoUtil
 

D

daemonFactory(String) - Static method in class bt.CountingThreadFactory
 
data(int, int, byte[]) - Static method in class bt.magnet.UtMetadata
Create metadata response for a given piece.
DataDescriptor - Interface in bt.data
Torrent's data descriptor.
DataDescriptorFactory - Class in bt.data
Note that this class implements a service.
DataDescriptorFactory(DataReaderFactory, ChunkVerifier, int) - Constructor for class bt.data.DataDescriptorFactory
 
DataRange - Interface in bt.data
Represents a range of binary data, abstracting the mapping of data onto the storage layer.
dataRange(BlockRange<DataRange>) - Static method in class bt.data.range.Ranges
 
DataRangeVisitor - Interface in bt.data
Traverses a data range on a per-unit basis.
DataReader - Interface in bt.data
Provides convenient ways to work with torrent's data.
DataReaderChannel - Class in bt.data
Note that this class is not a part of the public API and is a subject to change.
DataReaderChannel(DataDescriptor, long) - Constructor for class bt.data.DataReaderChannel
 
DataReaderFactory - Class in bt.data
Note that this class is not a part of the public API and is a subject to change.
DataReaderFactory(EventSource) - Constructor for class bt.data.DataReaderFactory
 
DataReceiver - Interface in bt.net
 
DataReceivingLoop - Class in bt.net
 
DataReceivingLoop(SharedSelector, IRuntimeLifecycleBinder, Config) - Constructor for class bt.net.DataReceivingLoop
 
DataWorker - Interface in bt.torrent.data
Data worker is responsible for processing blocks and block requests, received from peers.
deactivate() - Method in interface bt.net.pipeline.ChannelHandler
 
deactivate() - Method in class bt.net.pipeline.SocketChannelHandler
 
deactivateChannel(SelectableChannel) - Method in interface bt.net.DataReceiver
De-activate selection for the provided channel.
deactivateChannel(SelectableChannel) - Method in class bt.net.DataReceivingLoop
 
decode(DecodingContext, ByteBufferView) - Method in class bt.magnet.UtMetadataMessageHandler
 
decode() - Method in interface bt.net.pipeline.ChannelPipeline
 
decode() - Method in class bt.net.pipeline.DefaultChannelPipeline
 
decode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.BaseMessageHandler
 
decode(DecodingContext, ByteBufferView) - Method in interface bt.protocol.handler.MessageHandler
Tries to decode message from the byte buffer.
decode(DecodingContext, ByteBufferView) - Method in class bt.protocol.StandardBittorrentProtocol
 
decoders(BufferMutator, BufferMutator...) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
decodeUnsigned(ByteBuffer, int) - Static method in class bt.net.BigIntegers
Decode an unsigned big integer from the provided buffer.
DecodingContext - Class in bt.protocol
Instances of this class contain all necessary information for a message handler to decode a peer's message, and also act as a means to carry message throughout the decoding chain.
DecodingContext(Peer) - Constructor for class bt.protocol.DecodingContext
Create a decoding context for a particular peer.
DEFAULT_BUFFER_SIZE - Static variable in class bt.data.digest.SHA1Digester
 
DefaultChannelPipeline - Class in bt.net.pipeline
 
DefaultChannelPipeline(Peer, MessageHandler<Message>, BorrowedBuffer<ByteBuffer>, BorrowedBuffer<ByteBuffer>, List<BufferMutator>, List<BufferMutator>, IBufferedPieceRegistry) - Constructor for class bt.net.pipeline.DefaultChannelPipeline
 
DefaultChunkVerifier - Class in bt.data
 
DefaultChunkVerifier(Digester, int) - Constructor for class bt.data.DefaultChunkVerifier
 
DefaultDataWorker - Class in bt.torrent.data
 
DefaultDataWorker(IRuntimeLifecycleBinder, TorrentRegistry, ChunkVerifier, BlockCache, Config) - Constructor for class bt.torrent.data.DefaultDataWorker
 
DefaultMessageRouter - Class in bt.torrent.messaging
 
DefaultMessageRouter() - Constructor for class bt.torrent.messaging.DefaultMessageRouter
 
DefaultMessageRouter(Collection<Object>) - Constructor for class bt.torrent.messaging.DefaultMessageRouter
 
defaultOptions() - Static method in class bt.peer.PeerOptions
Returns default options.
defaultRuntime() - Static method in class bt.runtime.BtRuntime
Creates a vanilla runtime with default configuration
DefaultTorrentSessionState - Class in bt.torrent
 
DefaultTorrentSessionState(Supplier<DataDescriptor>, TorrentWorker, PrioritizedPieceSelector) - Constructor for class bt.torrent.DefaultTorrentSessionState
 
DelegatingByteBufferView - Class in bt.net.buffer
 
DelegatingByteBufferView(ByteBuffer) - Constructor for class bt.net.buffer.DelegatingByteBufferView
 
DelegatingDataRange<T extends Range<T>> - Class in bt.data.range
Adapter to a range, that indirectly encapsulates DataRange (most probably via delegation chain).
DelegatingRange<T extends Range<T>> - Interface in bt.data.range
 
description(String) - Method in class bt.service.LifecycleBinding.Builder
 
detachClient(BtClient) - Method in class bt.runtime.BtRuntime
Detach the client from this runtime.
DHTConfig - Class in bt.dht
Provides configuration for DHT facilities.
DHTConfig() - Constructor for class bt.dht.DHTConfig
 
DHTHandshakeHandler - Class in bt.dht
 
DHTHandshakeHandler(DHTConfig) - Constructor for class bt.dht.DHTHandshakeHandler
 
DHTModule - Class in bt.dht
 
DHTModule() - Constructor for class bt.dht.DHTModule
 
DHTModule(DHTConfig) - Constructor for class bt.dht.DHTModule
 
DHTModuleProvider - Class in bt.dht
 
DHTModuleProvider() - Constructor for class bt.dht.DHTModuleProvider
 
DHTPeerSource - Class in bt.dht
 
DHTPeerSourceFactory - Class in bt.dht
Factory of DHT peer sources
DHTPeerSourceFactory(IRuntimeLifecycleBinder, DHTService, Config) - Constructor for class bt.dht.DHTPeerSourceFactory
 
DHTService - Interface in bt.dht
Provides an interface to DHT services
digest(DataRange) - Method in interface bt.data.digest.Digester
Calculates a digest of a data range.
digest(Range<?>) - Method in interface bt.data.digest.Digester
Calculates Digest of a binary range.
digest(DataRange) - Method in class bt.data.digest.JavaSecurityDigester
 
digest(Range<?>) - Method in class bt.data.digest.JavaSecurityDigester
 
Digester - Interface in bt.data.digest
Calculates hash of some binary data.
digestForced(DataRange) - Method in interface bt.data.digest.Digester
Calculates a digest of a data range.
digestForced(DataRange) - Method in class bt.data.digest.JavaSecurityDigester
 
disableAutomaticShutdown() - Method in class bt.runtime.BtRuntimeBuilder
Disable automatic runtime shutdown, when all clients have been stopped.
disableLocalServiceDiscovery() - Method in class bt.runtime.BtRuntimeBuilder
If this options is set, Bt will not automatically load standard extension LocalServiceDiscoveryModule
disablePeerExchange() - Method in class bt.runtime.BtRuntimeBuilder
If this options is set, Bt will not automatically load standard extension PeerExchangeModule
disableStandardExtensions() - Method in class bt.runtime.BtRuntimeBuilder
If this options is set, Bt will not automatically load standard extensions, such as PEX or LSD.
dispose() - Method in class bt.net.buffer.BufferedData
 
doBuild(Peer, ByteChannel, MessageHandler<Message>, Optional<BorrowedBuffer<ByteBuffer>>, Optional<BorrowedBuffer<ByteBuffer>>, List<BufferMutator>, List<BufferMutator>) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.extended.ExtendedProtocol
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.BaseMessageHandler
Decode the payload of a message (excluding message prefix -- see StandardBittorrentProtocol.MESSAGE_PREFIX_SIZE) and place it into the provided context.
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.BitfieldHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.CancelHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.ChokeHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.HaveHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.InterestedHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.NotInterestedHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.PieceHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.PortMessageHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.RequestHandler
 
doDecode(DecodingContext, ByteBufferView) - Method in class bt.protocol.handler.UnchokeHandler
 
doEncode(EncodingContext, ExtendedMessage, ByteBuffer) - Method in class bt.protocol.extended.ExtendedProtocol
 
doEncode(EncodingContext, T, ByteBuffer) - Method in class bt.protocol.handler.BaseMessageHandler
Encode the payload of a message (excluding message prefix -- see StandardBittorrentProtocol.MESSAGE_PREFIX_SIZE) and write it into the provided buffer.
doEncode(EncodingContext, Bitfield, ByteBuffer) - Method in class bt.protocol.handler.BitfieldHandler
 
doEncode(EncodingContext, Cancel, ByteBuffer) - Method in class bt.protocol.handler.CancelHandler
 
doEncode(EncodingContext, Choke, ByteBuffer) - Method in class bt.protocol.handler.ChokeHandler
 
doEncode(EncodingContext, Have, ByteBuffer) - Method in class bt.protocol.handler.HaveHandler
 
doEncode(EncodingContext, Interested, ByteBuffer) - Method in class bt.protocol.handler.InterestedHandler
 
doEncode(EncodingContext, NotInterested, ByteBuffer) - Method in class bt.protocol.handler.NotInterestedHandler
 
doEncode(EncodingContext, Piece, ByteBuffer) - Method in class bt.protocol.handler.PieceHandler
 
doEncode(EncodingContext, Port, ByteBuffer) - Method in class bt.protocol.handler.PortMessageHandler
 
doEncode(EncodingContext, Request, ByteBuffer) - Method in class bt.protocol.handler.RequestHandler
 
doEncode(EncodingContext, Unchoke, ByteBuffer) - Method in class bt.protocol.handler.UnchokeHandler
 
doExecute(MagnetContext) - Method in class bt.processor.magnet.FetchMetadataStage
 
doExecute(MagnetContext) - Method in class bt.processor.magnet.InitializeMagnetTorrentProcessingStage
 
doExecute(C, ProcessingStage<C>) - Method in class bt.processor.RoutingProcessingStage
Execute current stage and calculate the next stage.
doExecute(C, ProcessingStage<C>) - Method in class bt.processor.TerminateOnErrorProcessingStage
 
doExecute(C) - Method in class bt.processor.TerminateOnErrorProcessingStage
Perform processing.
doExecute(C) - Method in class bt.processor.torrent.ChooseFilesStage
 
doExecute(C) - Method in class bt.processor.torrent.CreateSessionStage
 
doExecute(TorrentContext) - Method in class bt.processor.torrent.FetchTorrentStage
 
doExecute(C) - Method in class bt.processor.torrent.InitializeTorrentProcessingStage
 
doExecute(C) - Method in class bt.processor.torrent.ProcessTorrentStage
 
doExecute(C) - Method in class bt.processor.torrent.SeedStage
 
duplicate() - Method in interface bt.net.buffer.ByteBufferView
 
duplicate() - Method in class bt.net.buffer.DelegatingByteBufferView
 
duplicate() - Method in class bt.net.buffer.SplicedByteBufferView
 

E

encode(BEString, OutputStream) - Method in class bt.bencoding.serializers.BEEncoder
Write bencoded string to a binary output.
encode(BEInteger, OutputStream) - Method in class bt.bencoding.serializers.BEEncoder
Write bencoded integer to a binary output.
encode(BEList, OutputStream) - Method in class bt.bencoding.serializers.BEEncoder
Write bencoded list to a binary output.
encode(BEMap, OutputStream) - Method in class bt.bencoding.serializers.BEEncoder
Write bencoded dictionary to a binary output.
encode(EncodingContext, UtMetadata, ByteBuffer) - Method in class bt.magnet.UtMetadataMessageHandler
 
encode(Message) - Method in interface bt.net.pipeline.ChannelPipeline
 
encode(Message) - Method in class bt.net.pipeline.DefaultChannelPipeline
 
encode(EncodingContext, T, ByteBuffer) - Method in class bt.protocol.handler.BaseMessageHandler
 
encode(EncodingContext, T, ByteBuffer) - Method in interface bt.protocol.handler.MessageHandler
Tries to encode the provided message and place the result into the byte buffer.
encode(EncodingContext, Message, ByteBuffer) - Method in class bt.protocol.StandardBittorrentProtocol
 
encoder() - Static method in class bt.bencoding.serializers.BEEncoder
Get default encoder.
encoders(BufferMutator, BufferMutator...) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
encodeUnsigned(BigInteger, int) - Static method in class bt.net.BigIntegers
Encode an arbitrary big integer to its' binary representation, without unnecessary leading zeros that are used in two's-complement form.
EncodingContext - Class in bt.protocol
 
EncodingContext(Peer) - Constructor for class bt.protocol.EncodingContext
 
EncryptedChannel - Class in bt.net.crypto
Decorates a byte channel with encryption
EncryptedChannel(ByteChannel, Cipher, Cipher) - Constructor for class bt.net.crypto.EncryptedChannel
Create an encrypted byte channel.
ENCRYPTION_PROPERTY - Static variable in class bt.protocol.extended.ExtendedHandshake
 
EncryptionPolicy - Enum in bt.protocol.crypto
Message Stream Encryption policy
equals(Object) - Method in class bt.bencoding.types.BEInteger
 
equals(Object) - Method in class bt.bencoding.types.BEList
 
equals(Object) - Method in class bt.bencoding.types.BEMap
 
equals(Object) - Method in class bt.bencoding.types.BEString
 
equals(Object) - Method in class bt.data.file.FileCacheKey
 
equals(Object) - Method in class bt.event.BaseEvent
 
equals(Object) - Method in class bt.metainfo.TorrentId
 
equals(Object) - Method in class bt.net.ConnectionKey
 
equals(Object) - Method in class bt.net.InetPeerAddress
 
equals(Object) - Method in class bt.net.PeerId
 
equals(Object) - Method in class bt.tracker.AnnounceKey
 
establish() - Method in interface bt.net.ConnectionRoutine
Try to establish the connection.
Event - Interface in bt.event
 
EventBus - Class in bt.event
Basic implementation of event bus, that connects event producers and listeners.
EventBus() - Constructor for class bt.event.EventBus
 
EventSink - Interface in bt.event
Provides API to generate runtime events.
EventSource - Interface in bt.event
Provides API for hooking into the stream of runtime events.
exceptional(Throwable) - Static method in class bt.tracker.TrackerResponse
 
ExclusiveRule - Class in bt.bencoding.model.rule
Used to mark a subset of the model's attributes as mutually exclusive.
ExclusiveRule(Collection<Set<String>>, List<String>) - Constructor for class bt.bencoding.model.rule.ExclusiveRule
 
ExclusiveRule(Collection<Set<String>>) - Constructor for class bt.bencoding.model.rule.ExclusiveRule
 
execute(C) - Method in interface bt.processor.ProcessingStage
 
execute(C) - Method in class bt.processor.RoutingProcessingStage
 
ExecutorServiceProvider - Class in bt.service
 
ExecutorServiceProvider(Config) - Constructor for class bt.service.ExecutorServiceProvider
 
existsOnFileSystem(FileCacheKey) - Method in class bt.data.file.OpenFileCache
Check if the the File exists on the file system.
extend(Binder) - Static method in class bt.module.ProtocolModule
Returns the extender for contributing custom extensions to the ProtocolModule.
extend(Binder) - Static method in class bt.module.ServiceModule
Returns the extender for contributing custom extensions to the ServiceModule.
EXTENDED_MESSAGE_ID - Static variable in class bt.protocol.extended.ExtendedProtocol
Unique message type ID for all extended message types.
ExtendedHandshake - Class in bt.protocol.extended
Extended handshake is sent during connection initialization procedure by peers that support BEP-10: Extension Protocol.
ExtendedHandshake.Builder - Class in bt.protocol.extended
Convenient builder that provides the means to build an extended handshake by specifying one message type mapping at a time.
ExtendedHandshakeConsumer - Class in bt.net.extended
 
ExtendedHandshakeConsumer(IPeerConnectionPool) - Constructor for class bt.net.extended.ExtendedHandshakeConsumer
 
ExtendedHandshakeFactory - Class in bt.protocol.extended
Note that this class implements a service.
ExtendedHandshakeFactory(TorrentRegistry, ExtendedMessageTypeMapping, ApplicationService, Config) - Constructor for class bt.protocol.extended.ExtendedHandshakeFactory
 
ExtendedMessage - Class in bt.protocol.extended
Base class for all extended messages.
ExtendedMessage() - Constructor for class bt.protocol.extended.ExtendedMessage
 
ExtendedMessageHandlers - Annotation Type in bt.module
Annotates individual message handlers, that work with extended protocol message types.
ExtendedMessageTypeMapping - Interface in bt.protocol.extended
Represents a set of mappings between message types (both literal names and Java types) and their numeric IDs.
ExtendedProtocol - Class in bt.protocol.extended
Built-in support for extensions protocols.
ExtendedProtocol(ExtendedMessageTypeMapping, Map<String, MessageHandler<? extends ExtendedMessage>>) - Constructor for class bt.protocol.extended.ExtendedProtocol
 
ExtendedProtocolHandshakeHandler - Class in bt.net.extended
Sets a reserved bit, indicating that BEP-10: Extension Protocol is supported by the local client.
ExtendedProtocolHandshakeHandler(IExtendedHandshakeFactory) - Constructor for class bt.net.extended.ExtendedProtocolHandshakeHandler
 

F

factory(String) - Static method in class bt.CountingThreadFactory
 
failure(String, Throwable) - Static method in class bt.net.ConnectionResult
 
failure(String) - Static method in class bt.net.ConnectionResult
 
failure(String) - Static method in class bt.tracker.TrackerResponse
 
FetchMetadataStage - Class in bt.processor.magnet
 
FetchMetadataStage(ProcessingStage<MagnetContext>, IMetadataService, TorrentRegistry, IPeerRegistry, EventSink, Config) - Constructor for class bt.processor.magnet.FetchMetadataStage
 
FetchTorrentStage - Class in bt.processor.torrent
 
FetchTorrentStage(ProcessingStage<TorrentContext>, EventSink) - Constructor for class bt.processor.torrent.FetchTorrentStage
 
FILE_PATH_ELEMENTS_KEY - Static variable in class bt.metainfo.MetadataConstants
FILE_SIZE_KEY - Static variable in class bt.metainfo.MetadataConstants
FileCacheKey - Class in bt.data.file
The key for a file that can have a handle open and cached for it.
FileCacheKey(Path, long) - Constructor for class bt.data.file.FileCacheKey
Construct a new File Cache Key
FileDownloadCompleteCallback - Interface in bt.torrent.callbacks
This is a functional interface to make a callback when a file downloaded in a torrent is complete
fileDownloadCompleted(Torrent, TorrentFile, Storage) - Method in interface bt.torrent.callbacks.FileDownloadCompleteCallback
 
fileFinishedCallback(TorrentFile) - Method in class bt.data.LocalBitfield
 
FilePiecePriorityMapper - Class in bt.processor.torrent
A class which creates BitSets of the pieces that are skipped or high priority from the list of files that are prioritized and skipped in a torrent.
FilePriority - Enum in bt.torrent.fileselector
An enum which specifies the priority of a file for downloading.
FilePrioritySelector - Interface in bt.torrent.fileselector
 
FilePrioritySkipSelector - Interface in bt.torrent.fileselector
 
FILES_KEY - Static variable in class bt.metainfo.MetadataConstants
fileSelector(FilePrioritySkipSelector) - Method in class bt.TorrentClientBuilder
Provide a file selector for partial download of the torrent.
FileSystemStorage - Class in bt.data.file
Provides file-system based storage for torrent files.
FileSystemStorage(File) - Constructor for class bt.data.file.FileSystemStorage
Create a file-system based storage inside a given directory.
FileSystemStorage(Path) - Constructor for class bt.data.file.FileSystemStorage
 
FileSystemStorage(Path, int) - Constructor for class bt.data.file.FileSystemStorage
Construct a new FileSystemStorage
FileSystemStorageUnit - Class in bt.data.file
 
FileSystemStorageUnit(OpenFileCache, Path) - Constructor for class bt.data.file.FileSystemStorageUnit
 
finalizeContext(C) - Method in interface bt.processor.ContextFinalizer
Perform finalization and cleanup.
finalizeContext(C) - Method in class bt.processor.torrent.TorrentContextFinalizer
 
finish(Integer) - Method in class bt.torrent.messaging.Assignments
 
finishStream() - Method in class bt.dht.stream.StreamAdapter
Caller should invoke this method, if the underlying stream should not expect to receive any more items and can terminate at will.
fireChannelActive() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
fireChannelInactive() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
fireChannelRegistered() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
fireChannelUnregistered() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
fireDataReceived() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
fireMetadataAvailable(TorrentId, Torrent) - Method in class bt.event.EventBus
 
fireMetadataAvailable(TorrentId, Torrent) - Method in interface bt.event.EventSink
Generate event, that torrent's metadata has been fetched.
firePeerBitfieldUpdated(TorrentId, ConnectionKey, Bitfield) - Method in class bt.event.EventBus
 
firePeerBitfieldUpdated(TorrentId, ConnectionKey, Bitfield) - Method in interface bt.event.EventSink
Generate event, that local information about some peer's data has been updated.
firePeerConnected(ConnectionKey) - Method in class bt.event.EventBus
 
firePeerConnected(ConnectionKey) - Method in interface bt.event.EventSink
Generate event, that a new connection with some peer has been established.
firePeerDisconnected(ConnectionKey) - Method in class bt.event.EventBus
 
firePeerDisconnected(ConnectionKey) - Method in interface bt.event.EventSink
Generate event, that a connection with some peer has been terminated.
firePeerDiscovered(TorrentId, Peer) - Method in class bt.event.EventBus
 
firePeerDiscovered(TorrentId, Peer) - Method in interface bt.event.EventSink
Generate event, that a new peer has been discovered for some torrent.
firePieceVerified(TorrentId, int) - Method in class bt.event.EventBus
 
firePieceVerified(TorrentId, int) - Method in interface bt.event.EventSink
Generate event, that the downloading and verification of one of torrent's pieces has been finished.
fireTorrentStarted(TorrentId) - Method in class bt.event.EventBus
 
fireTorrentStarted(TorrentId) - Method in interface bt.event.EventSink
Generate event, that processing of some torrent has begun.
fireTorrentStopped(TorrentId) - Method in class bt.event.EventBus
 
fireTorrentStopped(TorrentId) - Method in interface bt.event.EventSink
Generate event, that processing of some torrent has finished.
flush() - Method in class bt.data.file.FileSystemStorage
 
flush() - Method in class bt.data.file.OpenFileCache
Flush all buffered data to the file system
flush() - Method in interface bt.data.Storage
Flushes any buffered data in this storage backend
flush() - Method in interface bt.net.pipeline.ChannelHandler
Request to write pending outgoing data to the underlying channel.
flush() - Method in class bt.net.pipeline.SocketChannelHandler
 
forChannel(ReadableByteChannel) - Static method in class bt.net.ByteChannelReader
 
forEachVerifiedPiece(IntConsumer) - Method in class bt.data.PeerBitfield
 
forInitiator(byte[], TorrentId) - Static method in class bt.protocol.crypto.MSECipher
Create MSE cipher for connection initiator
forReceiver(byte[], TorrentId) - Static method in class bt.protocol.crypto.MSECipher
Create MSE cipher for receiver of the connection request
fromByteArray(byte[]) - Method in interface bt.metainfo.IMetadataService
Builds a torrent object from its binary representation.
fromByteArray(byte[]) - Method in class bt.metainfo.MetadataService
 
fromBytes(byte[]) - Static method in class bt.metainfo.TorrentId
Create a TorrentId instance from a binary representation.
fromBytes(byte[]) - Static method in class bt.net.PeerId
Deserialize a binary peer ID representation.
fromHex(String) - Static method in class bt.protocol.Protocols
Get binary data from its' hex-encoded representation (regardless of case).
fromInputStream(InputStream) - Method in interface bt.metainfo.IMetadataService
Builds a torrent object from its binary representation.
fromInputStream(InputStream) - Method in class bt.metainfo.MetadataService
 
fromString(String) - Static method in class bt.peer.lan.Cookie
Parse cookie from its' string representation.
fromUrl(URL) - Method in interface bt.metainfo.IMetadataService
Builds a torrent object from its binary representation located at url.
fromUrl(URL) - Method in class bt.metainfo.MetadataService
 

G

GenericConsumer - Class in bt.torrent.messaging
Consumer that is responsible for processing some of the very basic messages.
GenericConsumer() - Constructor for class bt.torrent.messaging.GenericConsumer
 
get() - Method in interface bt.net.buffer.ByteBufferView
 
get(byte[]) - Method in interface bt.net.buffer.ByteBufferView
 
get() - Method in class bt.net.buffer.DelegatingByteBufferView
 
get(byte[]) - Method in class bt.net.buffer.DelegatingByteBufferView
 
get() - Method in class bt.net.buffer.SplicedByteBufferView
 
get(byte[]) - Method in class bt.net.buffer.SplicedByteBufferView
 
get() - Method in class bt.service.ExecutorServiceProvider
 
get(TorrentId, int, int, int) - Method in interface bt.torrent.data.BlockCache
 
get(TorrentId, int, int, int) - Method in class bt.torrent.data.LRUBlockCache
 
get(TorrentId, int, int, int) - Method in class bt.torrent.data.NoCache
 
get(ConnectionKey) - Method in class bt.torrent.messaging.Assignments
 
getAcceptorAddress() - Method in class bt.runtime.Config
 
getAcceptorPort() - Method in class bt.runtime.Config
 
getAddress() - Method in class bt.net.InetPeerAddress
 
getAddress() - Method in class bt.peer.lan.AnnounceGroup
 
getAlgorithm() - Method in class bt.data.digest.JavaSecurityDigester
 
getAllFilesToDownload() - Method in class bt.processor.torrent.FilePiecePriorityMapper
Return the list of all files that are downloaded (not skipped)
getAllNonSkippedFiles() - Method in interface bt.processor.ProcessingContext
Returns a list of all of the files that will be downloaded in this torrent, or empty if not known
getAllNonSkippedFiles() - Method in class bt.processor.torrent.TorrentContext
 
getAllPiecesForFiles(Set<TorrentFile>) - Method in interface bt.data.DataDescriptor
Get all pieces that contain any part of the set of files
getAnnounce() - Method in class bt.torrent.maker.TorrentBuilder
 
getAnnounceGroups() - Method in class bt.torrent.maker.TorrentBuilder
 
getAnnounceKey() - Method in interface bt.metainfo.Torrent
 
getAnnouncer() - Method in class bt.processor.torrent.TorrentContext
 
getAssignments() - Method in class bt.processor.torrent.TorrentContext
 
getBit(byte[], BitOrder, int) - Static method in class bt.protocol.Protocols
Gets i-th bit in a bitmask.
getBitfield() - Method in interface bt.data.DataDescriptor
 
getBitfield() - Method in class bt.event.PeerBitfieldUpdatedEvent
 
getBitfield() - Method in class bt.processor.torrent.TorrentContext
 
getBitfield() - Method in class bt.protocol.Bitfield
 
getBitfieldConsumer() - Method in class bt.processor.magnet.MagnetContext
 
getBitfields() - Method in class bt.torrent.messaging.BitfieldCollectingConsumer
 
getBitmask() - Method in class bt.data.Bitfield
 
getBlockSet() - Method in class bt.data.range.BlockRange
 
getBootstrapNodes() - Method in class bt.dht.DHTConfig
 
getBufferedPiece(int, int) - Method in class bt.net.pipeline.BufferedPieceRegistry
 
getBufferedPiece(int, int) - Method in interface bt.net.pipeline.IBufferedPieceRegistry
 
getBytes() - Method in class bt.data.range.BlockRange
 
getBytes(ByteBuffer) - Method in class bt.data.range.BlockRange
 
getBytes() - Method in class bt.data.range.ByteRange
 
getBytes(ByteBuffer) - Method in class bt.data.range.ByteRange
 
getBytes() - Method in class bt.data.range.DelegatingDataRange
 
getBytes(ByteBuffer) - Method in class bt.data.range.DelegatingDataRange
 
getBytes() - Method in interface bt.data.range.Range
Get all data in this range
getBytes(ByteBuffer) - Method in interface bt.data.range.Range
Read all data in this range to the provided buffer.
getBytes() - Method in class bt.data.range.SynchronizedDataRange
 
getBytes(ByteBuffer) - Method in class bt.data.range.SynchronizedDataRange
 
getBytes() - Method in class bt.data.range.SynchronizedRange
Get all data in this range
getBytes(ByteBuffer) - Method in class bt.data.range.SynchronizedRange
 
getBytes() - Method in class bt.metainfo.TorrentId
 
getBytes() - Method in class bt.net.PeerId
 
getCancelledPeerRequests() - Method in class bt.torrent.messaging.ConnectionState
Get keys of block requests, that have been cancelled by remote peer.
getCapacity() - Method in class bt.data.file.FileCacheKey
Get the capacity of this file
getChecksum() - Method in interface bt.data.ChunkDescriptor
Expected hash of this chunk's contents as indicated in torrent file.
getChunkDescriptors() - Method in interface bt.data.DataDescriptor
 
getChunkHashes() - Method in interface bt.metainfo.Torrent
 
getChunkSize() - Method in interface bt.metainfo.Torrent
 
getClients() - Method in class bt.runtime.BtRuntime
Get all clients, that are attached to this runtime.
getCompatibleGroups() - Method in interface bt.peer.lan.ILocalServiceDiscoveryInfo
 
getCompatibleGroups() - Method in class bt.peer.lan.LocalServiceDiscoveryInfo
 
getConfig() - Method in class bt.runtime.BtRuntime
 
getConfig() - Method in class bt.runtime.BtRuntimeBuilder
Get this builder's config.
getConnectedPeers() - Method in class bt.torrent.DefaultTorrentSessionState
 
getConnectedPeers() - Method in interface bt.torrent.TorrentSessionState
 
getConnection() - Method in class bt.net.ConnectionResult
 
getConnection(Peer, TorrentId) - Method in class bt.net.ConnectionSource
 
getConnection(Peer, TorrentId) - Method in interface bt.net.IConnectionSource
Deprecated.
This is no longer used
getConnection(Peer, TorrentId) - Method in interface bt.net.IPeerConnectionPool
 
getConnection(ConnectionKey) - Method in interface bt.net.IPeerConnectionPool
 
getConnection(Peer, TorrentId) - Method in class bt.net.PeerConnectionPool
 
getConnection(ConnectionKey) - Method in class bt.net.PeerConnectionPool
 
getConnectionAsync(Peer, TorrentId) - Method in class bt.net.ConnectionSource
 
getConnectionAsync(Peer, TorrentId) - Method in interface bt.net.IConnectionSource
Get connection for a given peer and torrent ID asynchronously.
getConnectionKey() - Method in class bt.event.PeerBitfieldUpdatedEvent
 
getConnectionKey() - Method in class bt.event.PeerConnectedEvent
 
getConnectionKey() - Method in class bt.event.PeerDisconnectedEvent
 
getConnectionKey() - Method in class bt.torrent.messaging.MessageContext
 
getConnectionState() - Method in class bt.torrent.messaging.MessageContext
 
getConnectionState() - Method in interface bt.torrent.messaging.PeerWorker
 
getConnectionState(ConnectionKey) - Method in class bt.torrent.messaging.TorrentWorker
Get the current state of a connection with a particular peer.
getConsumedType() - Method in interface bt.torrent.messaging.MessageConsumer
 
getContent() - Method in interface bt.bencoding.model.BEObject
 
getContent() - Method in class bt.bencoding.types.BEInteger
 
getContent() - Method in class bt.bencoding.types.BEList
 
getContent() - Method in class bt.bencoding.types.BEMap
 
getContent() - Method in class bt.bencoding.types.BEString
 
getContextType() - Method in class bt.processor.listener.ListenerSource
 
getCount(int) - Method in class bt.torrent.BitfieldBasedStatistics
 
getCount(int) - Method in interface bt.torrent.PieceStatistics
 
getCreatedBy() - Method in interface bt.metainfo.Torrent
 
getCreatedBy() - Method in class bt.torrent.maker.TorrentBuilder
 
getCreationDate() - Method in interface bt.metainfo.Torrent
 
getCreationDate() - Method in class bt.torrent.maker.TorrentBuilder
getData() - Method in interface bt.data.ChunkDescriptor
Get chunk's data accessor.
getData() - Method in class bt.magnet.UtMetadata
 
getData() - Method in class bt.protocol.extended.ExtendedHandshake
 
getDataDescriptor() - Method in interface bt.torrent.TorrentDescriptor
 
getDecryptionCipher() - Method in class bt.protocol.crypto.MSECipher
 
getDelegate() - Method in class bt.data.range.BlockRange
 
getDelegate() - Method in class bt.data.range.DelegatingDataRange
 
getDelegate() - Method in interface bt.data.range.DelegatingRange
 
getDelegate() - Method in class bt.data.range.SynchronizedDataRange
 
getDelegate() - Method in class bt.data.range.SynchronizedRange
 
getDescription() - Method in class bt.bencoding.model.rule.ExclusiveRule
 
getDescription() - Method in class bt.bencoding.model.rule.RequiredRule
 
getDescription() - Method in interface bt.bencoding.model.rule.Rule
 
getDescription() - Method in class bt.service.LifecycleBinding
 
getDescriptor(Torrent) - Method in class bt.torrent.AdhocTorrentRegistry
 
getDescriptor(TorrentId) - Method in class bt.torrent.AdhocTorrentRegistry
 
getDescriptor(Torrent) - Method in interface bt.torrent.TorrentRegistry
Deprecated.
getDescriptor(TorrentId) - Method in interface bt.torrent.TorrentRegistry
Get a torrent descriptor for a given torrent, if exists.
getDisplayName() - Method in class bt.magnet.MagnetUri
Represents the "dn" parameter.
getDownloaded() - Method in class bt.torrent.DefaultTorrentSessionState
 
getDownloaded() - Method in class bt.torrent.messaging.ConnectionState
 
getDownloaded() - Method in interface bt.torrent.TorrentSessionState
 
getEncryptionCipher() - Method in class bt.protocol.crypto.MSECipher
 
getEncryptionPolicy() - Method in class bt.peer.PeerOptions
 
getEncryptionPolicy() - Method in class bt.runtime.Config
 
getError() - Method in class bt.net.ConnectionResult
 
getError() - Method in class bt.torrent.data.BlockRead
 
getError() - Method in class bt.torrent.data.BlockWrite
 
getError() - Method in class bt.tracker.TrackerResponse
 
getErrorMessage() - Method in class bt.tracker.TrackerResponse
 
getEventSource() - Method in class bt.runtime.BtRuntime
 
getEventVal() - Method in enum bt.tracker.http.HttpTracker.TrackerRequestType
 
getExchangedMetadata() - Method in interface bt.metainfo.TorrentSource
Returns the part of metadata that is shared with other peers per BEP-9.
getFile() - Method in class bt.data.file.FileCacheKey
Get the file that this key represents
getFileCompletionCallback() - Method in class bt.processor.torrent.TorrentContext
 
getFiles() - Method in interface bt.metainfo.Torrent
 
getFiles() - Method in class bt.torrent.maker.TorrentBuilder
 
getFileSelector() - Method in class bt.processor.torrent.TorrentContext
 
getFilesForPiece(int) - Method in interface bt.data.DataDescriptor
getGroup() - Method in class bt.peer.lan.AnnounceGroupChannel
 
getHandshake(TorrentId) - Method in class bt.protocol.extended.ExtendedHandshakeFactory
 
getHandshake(TorrentId) - Method in interface bt.protocol.IExtendedHandshakeFactory
 
getHashingBufferSize() - Method in class bt.runtime.Config
Get the digest buffer size
getHashingBufferSize() - Method in class bt.torrent.maker.TorrentBuilder
Get the digest buffer size
getHaves() - Method in class bt.torrent.messaging.BitfieldCollectingConsumer
 
getHighPriorityPieces() - Method in class bt.processor.torrent.FilePiecePriorityMapper
Get the BitSet of pieces that were marked as high priority from this priority mapper
getHostname() - Method in class bt.net.InetPeerAddress
 
getId() - Method in class bt.event.BaseEvent
 
getId() - Method in interface bt.event.Event
 
getIdForTypeName(String) - Method in class bt.protocol.extended.AlphaSortedMapping
 
getIdForTypeName(String) - Method in interface bt.protocol.extended.ExtendedMessageTypeMapping
Get numeric ID for a message type with a given literal name.
getIncomingHandler() - Method in class bt.net.ConnectionHandlerFactory
 
getIncomingHandler() - Method in interface bt.net.IConnectionHandlerFactory
 
getInetAddress() - Method in class bt.net.InetPeer
 
getInetAddress() - Method in interface bt.net.Peer
 
getInetAddressFromNetworkInterfaces() - Static method in class bt.service.NetworkUtil
Get address for a local internet link.
getInjector() - Method in class bt.runtime.BtRuntime
 
getInt() - Method in interface bt.net.buffer.ByteBufferView
 
getInt() - Method in class bt.net.buffer.DelegatingByteBufferView
 
getInt() - Method in class bt.net.buffer.SplicedByteBufferView
 
getIntBytes(int) - Static method in class bt.protocol.Protocols
Get 4-bytes binary representation of an Integer.
getInterval() - Method in class bt.tracker.TrackerResponse
 
getIterationIdx(int) - Method in class bt.torrent.selector.RandomizedRarestFirstSelector
 
getIterationIdx(int) - Method in class bt.torrent.selector.RarestFirstSelector
 
getLastActive() - Method in interface bt.net.PeerConnection
 
getLastActive() - Method in class bt.net.SocketPeerConnection
 
getLastChoked() - Method in class bt.torrent.messaging.ConnectionState
 
getLeecherCount() - Method in class bt.tracker.TrackerResponse
 
getLeft() - Method in interface bt.data.DataDescriptor
Get the amount of data left to verify
getLeft() - Method in class bt.torrent.DefaultTorrentSessionState
 
getLeft() - Method in interface bt.torrent.TorrentSessionState
Get the number of bytes left to verify, or TorrentSessionState.UNKNOWN if unknown (torrent not yet fetched)
getLength() - Method in class bt.protocol.Cancel
 
getLength() - Method in class bt.protocol.Piece
 
getLength() - Method in class bt.protocol.Request
 
getLength() - Method in class bt.torrent.data.BlockRead
 
getLength() - Method in class bt.torrent.data.BlockWrite
 
getListeners(ProcessingEvent) - Method in class bt.processor.listener.ListenerSource
 
getListeningPort() - Method in class bt.dht.DHTConfig
 
getLiteralIP(InetAddress) - Static method in class bt.net.InternetProtocolUtils
Returns InetAddress.toString() without the hostname part and forward slash.
getLocalAddress() - Method in class bt.net.SocketChannelConnectionAcceptor
 
getLocalPeer() - Method in interface bt.peer.IPeerRegistry
Returns local peer, that represents current runtime in the swarm.
getLocalPeer() - Method in class bt.peer.PeerRegistry
 
getLocalPeerId() - Method in interface bt.service.IdentityService
 
getLocalPeerId() - Method in class bt.service.VersionAwareIdentityService
 
getLocalPorts() - Method in interface bt.peer.lan.ILocalServiceDiscoveryInfo
 
getLocalPorts() - Method in class bt.peer.lan.LocalServiceDiscoveryInfo
 
getLocalServiceDiscoveryAnnounceGroups() - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
getLocalServiceDiscoveryAnnounceInterval() - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
getLocalServiceDiscoveryMaxTorrentsPerAnnounce() - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
getLock() - Method in class bt.data.range.SynchronizedRange
 
getLongBytes(long) - Static method in class bt.protocol.Protocols
Get 8-bytes binary representation of a Long.
getMagnetUri() - Method in class bt.processor.magnet.MagnetContext
 
getMajor() - Method in class bt.service.Version
 
getMaxConcurrentlyActivePeerConnectionsPerTorrent() - Method in class bt.runtime.Config
 
getMaxEventsPerMessage() - Method in class bt.peerexchange.PeerExchangeConfig
 
getMaxIOQueueSize() - Method in class bt.runtime.Config
 
getMaxMessageInterval() - Method in class bt.peerexchange.PeerExchangeConfig
 
getMaxMessageProcessingInterval() - Method in class bt.runtime.Config
 
getMaxNumOpenFiles() - Method in class bt.torrent.maker.TorrentBuilder
getMaxOutstandingRequests() - Method in class bt.runtime.Config
 
getMaxPeerConnections() - Method in class bt.runtime.Config
 
getMaxPeerConnectionsPerTorrent() - Method in class bt.runtime.Config
 
getMaxPendingConnectionRequests() - Method in class bt.runtime.Config
 
getMaxPieceReceivingTime() - Method in class bt.runtime.Config
 
getMaxSimultaneouslyAssignedPieces() - Method in class bt.runtime.Config
 
getMaxTransferBlockSize() - Method in class bt.runtime.Config
 
getMessage() - Method in class bt.net.ConnectionResult
 
getMessage() - Method in class bt.protocol.DecodingContext
 
getMessageId() - Method in class bt.protocol.Bitfield
 
getMessageId() - Method in class bt.protocol.Cancel
 
getMessageId() - Method in class bt.protocol.Choke
 
getMessageId() - Method in class bt.protocol.extended.ExtendedMessage
 
getMessageId() - Method in class bt.protocol.Handshake
 
getMessageId() - Method in class bt.protocol.Have
 
getMessageId() - Method in class bt.protocol.Interested
 
getMessageId() - Method in class bt.protocol.KeepAlive
 
getMessageId() - Method in interface bt.protocol.Message
 
getMessageId() - Method in class bt.protocol.NotInterested
 
getMessageId() - Method in class bt.protocol.Piece
 
getMessageId() - Method in class bt.protocol.Port
 
getMessageId() - Method in class bt.protocol.Request
 
getMessageId() - Method in class bt.protocol.Unchoke
 
getMessages() - Method in class bt.bencoding.model.ValidationResult
 
getMetadata() - Method in interface bt.metainfo.TorrentSource
Returns metadata that contains all necessary information to fully re-create the torrent.
getMetadataExchangeBlockSize() - Method in class bt.runtime.Config
 
getMetadataExchangeMaxSize() - Method in class bt.runtime.Config
 
getMinEventsPerMessage() - Method in class bt.peerexchange.PeerExchangeConfig
 
getMinInterval() - Method in class bt.tracker.TrackerResponse
 
getMinMessageInterval() - Method in class bt.peerexchange.PeerExchangeConfig
 
getMinor() - Method in class bt.service.Version
 
getMsePrivateKeySize() - Method in class bt.runtime.Config
 
getMseWaitBetweenReads() - Method in class bt.runtime.Config
 
getName() - Method in interface bt.metainfo.Torrent
 
getName() - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Get the name of this named value
getNamePrefix() - Method in class bt.service.ExecutorServiceProvider
 
getNetworkBufferSize() - Method in class bt.runtime.Config
 
getNetworkInterface() - Method in class bt.net.SocketChannelConnectionAcceptor
 
getNetworkInterfaces() - Method in interface bt.peer.lan.ILocalServiceDiscoveryInfo
 
getNetworkInterfaces() - Method in class bt.peer.lan.LocalServiceDiscoveryInfo
 
getNextPieces(BitSet, PieceStatistics) - Method in interface bt.torrent.selector.PieceSelector
Select pieces based on the chunks which are relevant.
getNextPieces(BitSet, PieceStatistics) - Method in class bt.torrent.selector.PrioritizedPieceSelector
 
getNextPieces(BitSet, PieceStatistics) - Method in class bt.torrent.selector.RandomizedRarestFirstSelector
 
getNextPieces(BitSet, PieceStatistics) - Method in class bt.torrent.selector.RarestFirstSelector
 
getNextPieces(BitSet, PieceStatistics) - Method in class bt.torrent.selector.SequentialSelector
 
getNextPieces(PeerBitfield, PieceStatistics) - Method in class bt.torrent.selector.ValidatingSelector
 
getNumberOfPeersToRequestFromTracker() - Method in class bt.runtime.Config
 
getNumHashingThreads() - Method in class bt.torrent.maker.TorrentBuilder
 
getNumOfHashingThreads() - Method in class bt.runtime.Config
 
getNumWant() - Method in class bt.tracker.TrackerRequestBuilder
Get the number of peers to request from the tracker, or null if the default value should be used
getOffset() - Method in class bt.protocol.Cancel
 
getOffset() - Method in class bt.protocol.Piece
 
getOffset() - Method in class bt.protocol.Request
 
getOffset() - Method in class bt.torrent.data.BlockRead
 
getOffset() - Method in class bt.torrent.data.BlockWrite
 
getOptions() - Method in class bt.net.InetPeer
 
getOptions() - Method in interface bt.net.Peer
 
getOrCreateBuilder(Class<T>) - Method in interface bt.bencoding.model.BEObjectModelBuilderFactory
Create a model builder.
getOrCreateDescriptor(Torrent, Storage) - Method in class bt.torrent.AdhocTorrentRegistry
 
getOrCreateDescriptor(Torrent, Storage) - Method in interface bt.torrent.TorrentRegistry
Deprecated.
getOutgoingHandler(TorrentId) - Method in class bt.net.ConnectionHandlerFactory
 
getOutgoingHandler(TorrentId) - Method in interface bt.net.IConnectionHandlerFactory
 
getPathElements() - Method in interface bt.metainfo.TorrentFile
 
getPeer() - Method in class bt.event.PeerBitfieldUpdatedEvent
 
getPeer() - Method in class bt.event.PeerConnectedEvent
 
getPeer() - Method in class bt.event.PeerDisconnectedEvent
 
getPeer() - Method in class bt.event.PeerDiscoveredEvent
 
getPeer() - Method in class bt.net.ConnectionKey
 
getPeer() - Method in class bt.protocol.DecodingContext
 
getPeer() - Method in class bt.protocol.EncodingContext
 
getPeer() - Method in class bt.torrent.data.BlockRead
 
getPeer() - Method in class bt.torrent.data.BlockWrite
 
getPeer() - Method in class bt.torrent.messaging.MessageContext
 
getPeerAddress() - Method in class bt.runtime.Config
 
getPeerAddresses() - Method in class bt.magnet.MagnetUri
Represents the collection of values of "x.pe" parameters.
getPeerBitfield(ConnectionKey) - Method in class bt.torrent.BitfieldBasedStatistics
Get peer's bitfield, if present.
getPeerConnectionInactivityThreshold() - Method in class bt.runtime.Config
 
getPeerConnectionRetryCount() - Method in class bt.runtime.Config
 
getPeerConnectionRetryInterval() - Method in class bt.runtime.Config
 
getPeerConnectionTimeout() - Method in class bt.runtime.Config
 
getPeerDiscoveryInterval() - Method in class bt.runtime.Config
 
getPeerHandshakeTimeout() - Method in class bt.runtime.Config
 
getPeerId() - Method in class bt.net.InetPeer
 
getPeerId() - Method in interface bt.net.Peer
 
getPeerId() - Method in class bt.protocol.Handshake
 
getPeers(Torrent) - Method in interface bt.dht.DHTService
Deprecated.
since 1.3 in favor of DHTService.getPeers(TorrentId)
getPeers(TorrentId) - Method in interface bt.dht.DHTService
Creates a peer lookup for a given torrent.
getPeers(Torrent) - Method in class bt.dht.MldhtService
 
getPeers(TorrentId) - Method in class bt.dht.MldhtService
 
getPeers() - Method in interface bt.peer.PeerSource
Get the list of peers.
getPeers() - Method in class bt.peer.ScheduledPeerSource
 
getPeers() - Method in class bt.torrent.messaging.TorrentWorker
Get all peers, that this torrent worker is currently working with.
getPeers() - Method in class bt.tracker.TrackerResponse
 
getPeerSource(TorrentId) - Method in class bt.dht.DHTPeerSourceFactory
 
getPeerSource(TorrentId) - Method in class bt.peer.lan.LocalServiceDiscoveryPeerSourceFactory
 
getPeerSource(Torrent) - Method in interface bt.peer.PeerSourceFactory
Deprecated.
getPeerSource(TorrentId) - Method in interface bt.peer.PeerSourceFactory
Create a peer source for a given torrent.
getPeerSource(TorrentId) - Method in class bt.peerexchange.PeerExchangePeerSourceFactory
 
getPendingRequests() - Method in class bt.torrent.messaging.ConnectionState
Get keys of block requests, that have been sent to the remote peer.
getPendingWrites() - Method in class bt.torrent.messaging.ConnectionState
Get pending block writes, mapped by keys of corresponding requests.
getPieceIndex() - Method in class bt.event.PieceVerifiedEvent
 
getPieceIndex() - Method in class bt.magnet.UtMetadata
 
getPieceIndex() - Method in class bt.protocol.Cancel
 
getPieceIndex() - Method in class bt.protocol.Have
 
getPieceIndex() - Method in class bt.protocol.Piece
 
getPieceIndex() - Method in class bt.protocol.Request
 
getPieceIndex() - Method in class bt.torrent.data.BlockRead
 
getPieceIndex() - Method in class bt.torrent.data.BlockWrite
 
getPiecesComplete() - Method in class bt.data.Bitfield
 
getPiecesComplete() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesComplete() - Method in interface bt.torrent.TorrentSessionState
 
getPieceSelector() - Method in class bt.processor.torrent.TorrentContext
 
getPiecesIncomplete() - Method in class bt.data.Bitfield
 
getPiecesIncomplete() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesIncomplete() - Method in interface bt.torrent.TorrentSessionState
 
getPieceSize() - Method in class bt.torrent.maker.TorrentBuilder
 
getPiecesNotSkipped() - Method in class bt.data.LocalBitfield
 
getPiecesNotSkipped() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesNotSkipped() - Method in interface bt.torrent.TorrentSessionState
 
getPiecesRemaining() - Method in class bt.data.LocalBitfield
 
getPiecesRemaining() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesRemaining() - Method in interface bt.torrent.TorrentSessionState
 
getPiecesSkipped() - Method in class bt.data.LocalBitfield
 
getPiecesSkipped() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesSkipped() - Method in interface bt.torrent.TorrentSessionState
 
getPieceStatistics() - Method in class bt.processor.torrent.TorrentContext
 
getPiecesTotal() - Method in class bt.data.Bitfield
 
getPiecesTotal() - Method in class bt.torrent.BitfieldBasedStatistics
 
getPiecesTotal() - Method in class bt.torrent.DefaultTorrentSessionState
 
getPiecesTotal() - Method in interface bt.torrent.PieceStatistics
 
getPiecesTotal() - Method in interface bt.torrent.TorrentSessionState
 
getPiecesWithOnlyFiles(Set<TorrentFile>) - Method in interface bt.data.DataDescriptor
Get the set of pieces that only contain parts of the the set of files
getPort() - Method in class bt.net.InetPeer
 
getPort() - Method in class bt.net.InetPeerAddress
 
getPort() - Method in interface bt.net.Peer
 
getPort() - Method in class bt.protocol.extended.ExtendedHandshake
 
getPort() - Method in class bt.protocol.Port
 
getProtocolFamily(InetAddress) - Static method in class bt.net.InternetProtocolUtils
 
getReader() - Method in interface bt.data.DataDescriptor
Get the data reader interface, which provides convenient ways to work with torrent's data (e.g.
getReader() - Method in class bt.torrent.data.BlockRead
 
getRemoteAddress() - Method in interface bt.net.ConnectionRoutine
 
getRemotePeer() - Method in interface bt.net.PeerConnection
 
getRemotePeer() - Method in class bt.net.SocketPeerConnection
 
getRemotePort() - Method in class bt.event.PeerConnectedEvent
 
getRemotePort() - Method in class bt.event.PeerDisconnectedEvent
 
getRemotePort() - Method in class bt.net.ConnectionKey
 
getRemotePort() - Method in interface bt.net.PeerConnection
 
getRemotePort() - Method in class bt.net.SocketPeerConnection
 
getReserved() - Method in class bt.protocol.Handshake
 
getRootPath() - Method in class bt.torrent.maker.TorrentBuilder
 
getRouter() - Method in class bt.processor.torrent.TorrentContext
 
getRunnable() - Method in class bt.service.LifecycleBinding
 
getScannedContents() - Method in exception bt.bencoding.serializers.BtParseException
Get the scanned portion of the source document.
getSecretKey() - Method in interface bt.service.IdentityService
 
getSecretKey() - Method in class bt.service.VersionAwareIdentityService
 
getSeederCount() - Method in class bt.tracker.TrackerResponse
 
getSessionState() - Method in interface bt.torrent.TorrentDescriptor
Get the session state of this torrent.
getSha1Digest(byte[]) - Static method in class bt.service.CryptoUtil
Calculate SHA-1 digest of a byte array.
getShort() - Method in interface bt.net.buffer.ByteBufferView
 
getShort() - Method in class bt.net.buffer.DelegatingByteBufferView
 
getShort() - Method in class bt.net.buffer.SplicedByteBufferView
 
getShortBytes(int) - Static method in class bt.protocol.Protocols
Get 2-bytes binary representation of a Short.
getShouldChoke() - Method in class bt.torrent.messaging.ConnectionState
 
getShutdownHookTimeout() - Method in class bt.runtime.Config
 
getSize() - Method in interface bt.metainfo.Torrent
 
getSize() - Method in interface bt.metainfo.TorrentFile
 
getSkippedBitmask() - Method in class bt.data.LocalBitfield
 
getSkippedPieces() - Method in class bt.processor.torrent.FilePiecePriorityMapper
Get the BitSet of pieces that were marked as skipped from this priority mapper
getSource() - Method in interface bt.metainfo.Torrent
 
getSourceType() - Method in interface bt.bencoding.model.BEObjectModelBuilder
 
getSourceType() - Method in class bt.bencoding.model.JUMModelBuilder
 
getState() - Method in interface bt.processor.ProcessingContext
 
getState() - Method in class bt.processor.torrent.TorrentContext
 
getStorage() - Method in interface bt.processor.ProcessingContext
 
getStorage() - Method in class bt.processor.torrent.TorrentContext
 
getSubrange(long, long) - Method in interface bt.data.DataRange
Build a subrange of this data range.
getSubrange(long) - Method in interface bt.data.DataRange
Build a subrange of this data range.
getSubrange(long, long) - Method in class bt.data.range.BlockRange
 
getSubrange(long) - Method in class bt.data.range.BlockRange
 
getSubrange(long, long) - Method in class bt.data.range.ByteRange
 
getSubrange(long) - Method in class bt.data.range.ByteRange
 
getSubrange(long, long) - Method in class bt.data.range.DelegatingDataRange
 
getSubrange(long) - Method in class bt.data.range.DelegatingDataRange
 
getSubrange(long, long) - Method in interface bt.data.range.Range
Build a subrange of this data range.
getSubrange(long) - Method in interface bt.data.range.Range
Build a subrange of this data range.
getSubrange(long, long) - Method in class bt.data.range.SynchronizedDataRange
 
getSubrange(long) - Method in class bt.data.range.SynchronizedDataRange
 
getSubrange(long, long) - Method in class bt.data.range.SynchronizedRange
Build a subrange of this data range.
getSubrange(long) - Method in class bt.data.range.SynchronizedRange
Build a subrange of this data range.
getSupportedMessageTypes() - Method in class bt.protocol.extended.ExtendedHandshake
 
getSupportedTypes() - Method in class bt.magnet.UtMetadataMessageHandler
 
getSupportedTypes() - Method in class bt.protocol.extended.ExtendedProtocol
 
getSupportedTypes() - Method in class bt.protocol.handler.UniqueMessageHandler
 
getSupportedTypes() - Method in interface bt.protocol.Protocol
 
getSupportedTypes() - Method in class bt.protocol.StandardBittorrentProtocol
 
getTimeoutedAssignmentPeerBanDuration() - Method in class bt.runtime.Config
 
getTimestamp() - Method in class bt.event.BaseEvent
 
getTimestamp() - Method in interface bt.event.Event
Relative time of event.
getTimeToLive() - Method in class bt.peer.lan.AnnounceGroup
 
getTorrent() - Method in class bt.event.MetadataAvailableEvent
 
getTorrent() - Method in interface bt.processor.ProcessingContext
 
getTorrent() - Method in class bt.processor.torrent.TorrentContext
 
getTorrent(TorrentId) - Method in class bt.torrent.AdhocTorrentRegistry
 
getTorrent(TorrentId) - Method in interface bt.torrent.TorrentRegistry
Get a torrent with a given torrent ID, if exists.
getTorrentFile() - Method in class bt.data.CompletableTorrentFile
 
getTorrentId() - Method in class bt.event.MetadataAvailableEvent
 
getTorrentId() - Method in class bt.event.PeerBitfieldUpdatedEvent
 
getTorrentId() - Method in class bt.event.PeerConnectedEvent
 
getTorrentId() - Method in class bt.event.PeerDisconnectedEvent
 
getTorrentId() - Method in class bt.event.PeerDiscoveredEvent
 
getTorrentId() - Method in class bt.event.PieceVerifiedEvent
 
getTorrentId() - Method in interface bt.event.TorrentEvent
 
getTorrentId() - Method in class bt.event.TorrentStartedEvent
 
getTorrentId() - Method in class bt.event.TorrentStoppedEvent
 
getTorrentId() - Method in class bt.magnet.MagnetUri
Represents the "xt" parameter.
getTorrentId() - Method in interface bt.metainfo.Torrent
 
getTorrentId() - Method in class bt.net.ConnectionKey
 
getTorrentId() - Method in interface bt.net.PeerConnection
 
getTorrentId() - Method in class bt.net.SocketPeerConnection
 
getTorrentId() - Method in class bt.processor.magnet.MagnetContext
 
getTorrentId() - Method in interface bt.processor.ProcessingContext
 
getTorrentId() - Method in class bt.processor.torrent.TorrentContext
 
getTorrentId() - Method in class bt.protocol.Handshake
 
getTorrentId() - Method in class bt.torrent.messaging.MessageContext
 
getTorrentId() - Method in class bt.tracker.TrackerRequestBuilder
 
getTorrentIds() - Method in class bt.torrent.AdhocTorrentRegistry
 
getTorrentIds() - Method in interface bt.torrent.TorrentRegistry
Get all torrents, that have been registered in the runtime.
getTorrents() - Method in class bt.torrent.AdhocTorrentRegistry
 
getTorrents() - Method in interface bt.torrent.TorrentRegistry
Get all torrents, that have been registered in the runtime.
getTorrentSupplier() - Method in class bt.processor.torrent.TorrentContext
 
getTotalSize() - Method in class bt.magnet.UtMetadata
 
getTracker(String) - Method in class bt.tracker.http.HttpTrackerFactory
 
getTracker(String) - Method in interface bt.tracker.ITrackerService
Get a single tracker by its' URL
getTracker(AnnounceKey) - Method in interface bt.tracker.ITrackerService
Get a tracker by its announce key
getTracker(String) - Method in interface bt.tracker.TrackerFactory
Create a client for the tracker, identified by its' URL
getTracker(String) - Method in class bt.tracker.TrackerService
 
getTracker(AnnounceKey) - Method in class bt.tracker.TrackerService
 
getTracker(String) - Method in class bt.tracker.udp.UdpTrackerFactory
 
getTrackerId() - Method in class bt.tracker.TrackerResponse
 
getTrackerQueryInterval() - Method in class bt.runtime.Config
 
getTrackerTimeout() - Method in class bt.runtime.Config
Tracker/peer source timeout See Config.setTrackerTimeout(Duration) for the explanation on how this is used
getTrackerUrl() - Method in class bt.tracker.AnnounceKey
 
getTrackerUrls() - Method in class bt.magnet.MagnetUri
Represents the collection of values of "tr" parameters.
getTrackerUrls() - Method in class bt.tracker.AnnounceKey
 
getTransferBlockSize() - Method in class bt.runtime.Config
 
getType() - Method in interface bt.bencoding.model.BEObject
 
getType() - Method in interface bt.bencoding.model.BEObjectModel
 
getType() - Method in class bt.bencoding.types.BEInteger
 
getType() - Method in class bt.bencoding.types.BEList
 
getType() - Method in class bt.bencoding.types.BEMap
 
getType() - Method in class bt.bencoding.types.BEString
 
getType() - Method in class bt.magnet.UtMetadata
 
getTypeNameForId(Integer) - Method in class bt.protocol.extended.AlphaSortedMapping
 
getTypeNameForId(Integer) - Method in interface bt.protocol.extended.ExtendedMessageTypeMapping
Get literal name of a message type with a given numeric ID.
getTypeNameForJavaType(Class<?>) - Method in class bt.protocol.extended.AlphaSortedMapping
 
getTypeNameForJavaType(Class<?>) - Method in interface bt.protocol.extended.ExtendedMessageTypeMapping
Get literal name for a message type.
getUnit(Torrent, TorrentFile) - Method in class bt.data.file.FileSystemStorage
 
getUnit(Torrent, TorrentFile) - Method in interface bt.data.Storage
Get a storage unit for a particular torrent file.
getUnreachablePeerBanDuration() - Method in class bt.runtime.Config
 
getUploaded() - Method in class bt.torrent.DefaultTorrentSessionState
 
getUploaded() - Method in class bt.torrent.messaging.ConnectionState
 
getUploaded() - Method in interface bt.torrent.TorrentSessionState
 
getUrlEncodedValue() - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
 
getValue() - Method in interface bt.bencoding.model.BEObject
 
getValue() - Method in class bt.bencoding.types.BEInteger
 
getValue() - Method in class bt.bencoding.types.BEList
 
getValue() - Method in class bt.bencoding.types.BEMap
 
getValue() - Method in class bt.bencoding.types.BEString
 
getValue() - Method in class bt.data.digest.SoftThreadLocal
 
getValue() - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Get the value of this named value
getValue(Charset) - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Get the value of this named value as a String decoded from the specified charset
getValueAsLong() - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Get the value of this named value as a long
getValueAsString() - Method in class bt.bencoding.types.BEString
 
getValueAsUtf8Str() - Method in class bt.tracker.http.urlencoding.BinaryQueryNamedValue
Get the value of this named value as a String decoded from UTF-8
getVerificationFuture() - Method in class bt.torrent.data.BlockWrite
Get future, that will complete when the block is verified.
getVersion() - Method in class bt.protocol.extended.ExtendedHandshakeFactory
 
getVersion() - Method in interface bt.service.ApplicationService
 
getVersion() - Method in class bt.service.ClasspathApplicationService
 
getWarningMessage() - Method in class bt.tracker.TrackerResponse
 

H

handleConnection(PeerConnection) - Method in interface bt.net.ConnectionHandler
Determines whether the connection can be established or should be immediately dropped.
Handshake - Class in bt.protocol
Standard handshake message.
Handshake(byte[], TorrentId, PeerId) - Constructor for class bt.protocol.Handshake
 
HandshakeFactory - Class in bt.protocol
Note that this class implements a service.
HandshakeFactory(Provider<IPeerRegistry>) - Constructor for class bt.protocol.HandshakeFactory
 
HandshakeHandler - Interface in bt.net
Extension point for additional processing of incoming and outgoing handshakes.
hashCode() - Method in class bt.bencoding.types.BEInteger
 
hashCode() - Method in class bt.bencoding.types.BEList
 
hashCode() - Method in class bt.bencoding.types.BEMap
 
hashCode() - Method in class bt.bencoding.types.BEString
 
hashCode() - Method in class bt.data.file.FileCacheKey
 
hashCode() - Method in class bt.event.BaseEvent
 
hashCode() - Method in class bt.metainfo.TorrentId
 
hashCode() - Method in class bt.net.ConnectionKey
 
hashCode() - Method in class bt.net.InetPeerAddress
 
hashCode() - Method in class bt.net.PeerId
 
hashCode() - Method in class bt.tracker.AnnounceKey
 
hashingBufferSize(int) - Method in class bt.torrent.maker.TorrentBuilder
Set the size of the io buffer used for reading from files to verify their digest.
hasRemaining() - Method in interface bt.net.buffer.ByteBufferView
 
hasRemaining() - Method in class bt.net.buffer.DelegatingByteBufferView
 
hasRemaining() - Method in class bt.net.buffer.SplicedByteBufferView
 
Have - Class in bt.protocol
 
Have(int) - Constructor for class bt.protocol.Have
 
HAVE_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
HaveHandler - Class in bt.protocol.handler
 
HaveHandler() - Constructor for class bt.protocol.handler.HaveHandler
 
HttpTracker - Class in bt.tracker.http
Simple implementation of an HTTP tracker client.
HttpTracker(String, TorrentRegistry, IdentityService, IPeerRegistry, EncryptionPolicy, InetAddress, int, Duration) - Constructor for class bt.tracker.http.HttpTracker
 
HttpTracker.TrackerRequestType - Enum in bt.tracker.http
 
HttpTrackerFactory - Class in bt.tracker.http
Creates HTTP tracker clients.
HttpTrackerFactory(TorrentRegistry, IdentityService, IPeerRegistry, Config) - Constructor for class bt.tracker.http.HttpTrackerFactory
 
HttpTrackerModule - Class in bt.tracker.http
Provides support for integration with HTTP trackers.
HttpTrackerModule() - Constructor for class bt.tracker.http.HttpTrackerModule
 
HttpTrackerModuleProvider - Class in bt.tracker.http
 
HttpTrackerModuleProvider() - Constructor for class bt.tracker.http.HttpTrackerModuleProvider
 

I

IBufferedPieceRegistry - Interface in bt.net.pipeline
 
IBufferManager - Interface in bt.net.buffer
Provides the means to temporarily borrow a direct buffer.
IChannelPipelineFactory - Interface in bt.net.pipeline
 
IConnectionHandlerFactory - Interface in bt.net
 
IConnectionSource - Interface in bt.net
Provides the main API for getting connections to remote peers.
IDataDescriptorFactory - Interface in bt.data
Factory of torrent data descriptors.
IdentityService - Interface in bt.service
Identity service.
IExtendedHandshakeFactory - Interface in bt.protocol
 
IHandshakeFactory - Interface in bt.protocol
Factory of standard BitTorrent handshakes.
ILocalServiceDiscoveryInfo - Interface in bt.peer.lan
Provides information required for operation of Local Service Discovery.
ILocalServiceDiscoveryService - Interface in bt.peer.lan
Provides BEP-14 support.
IMessageDispatcher - Interface in bt.net
Provides access to messaging with remote peers.
IMetadataService - Interface in bt.metainfo
Service for creating torrents from bencoded sources.
inboundBuffer(BorrowedBuffer<ByteBuffer>) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
InboundMessageProcessor - Class in bt.net.pipeline
Inspired by Bip Buffer (https://www.codeproject.com/Articles/3479/The-Bip-Buffer-The-Circular-Buffer-with-a-Twist)
InboundMessageProcessor(Peer, ByteBuffer, MessageDeserializer, List<BufferMutator>, IBufferedPieceRegistry) - Constructor for class bt.net.pipeline.InboundMessageProcessor
 
IncomingConnectionListener - Class in bt.net
 
IncomingConnectionListener(Set<PeerConnectionAcceptor>, ExecutorService, IPeerConnectionPool, Config) - Constructor for class bt.net.IncomingConnectionListener
 
IncompletePiecesValidator - Class in bt.torrent.selector
 
IncompletePiecesValidator(Bitfield) - Constructor for class bt.torrent.selector.IncompletePiecesValidator
 
incrementDownloaded(long) - Method in class bt.torrent.messaging.ConnectionState
 
incrementUploaded(long) - Method in class bt.torrent.messaging.ConnectionState
 
InetPeer - Class in bt.net
 
InetPeer.Builder - Class in bt.net
 
InetPeerAddress - Class in bt.net
Holds parts of inet address and resolves it on demand.
InetPeerAddress(String, int) - Constructor for class bt.net.InetPeerAddress
 
infoHashFromBase32(String) - Static method in class bt.protocol.Protocols
Get 20-bytes long info hash from its' base32-encoded representation (regardless of case).
INFOMAP_KEY - Static variable in class bt.metainfo.MetadataConstants
init() - Method in class bt.data.DataReaderChannel
 
init() - Method in class bt.data.digest.SoftThreadLocal
 
initEagerly() - Method in class bt.BaseClientBuilder
Initialize the client eagerly.
InitializeMagnetTorrentProcessingStage - Class in bt.processor.magnet
 
InitializeMagnetTorrentProcessingStage(ProcessingStage<MagnetContext>, IPeerConnectionPool, TorrentRegistry, DataWorker, IBufferedPieceRegistry, EventSink, Config) - Constructor for class bt.processor.magnet.InitializeMagnetTorrentProcessingStage
 
InitializeTorrentProcessingStage<C extends TorrentContext> - Class in bt.processor.torrent
 
InitializeTorrentProcessingStage(ProcessingStage<C>, IPeerConnectionPool, TorrentRegistry, DataWorker, IBufferedPieceRegistry, EventSink, Config) - Constructor for class bt.processor.torrent.InitializeTorrentProcessingStage
 
initialValue() - Method in class bt.data.digest.SoftThreadLocal
 
initSelector(int) - Method in interface bt.torrent.selector.PieceSelector
Init any structures to iterate through numPieces pieces in some iteration order
initSelector(int) - Method in class bt.torrent.selector.PrioritizedPieceSelector
 
initSelector(int) - Method in class bt.torrent.selector.RandomizedRarestFirstSelector
 
instance() - Static method in class bt.protocol.Choke
 
instance() - Static method in class bt.protocol.Interested
 
instance() - Static method in class bt.protocol.KeepAlive
 
instance() - Static method in class bt.protocol.NotInterested
 
instance() - Static method in class bt.protocol.Unchoke
 
Interested - Class in bt.protocol
 
INTERESTED_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
InterestedHandler - Class in bt.protocol.handler
 
InterestedHandler() - Constructor for class bt.protocol.handler.InterestedHandler
 
InternetProtocolUtils - Class in bt.net
 
InternetProtocolUtils() - Constructor for class bt.net.InternetProtocolUtils
 
InvalidMessageException - Exception in bt.protocol
Generic exception, that indicates that a message is invalid.
InvalidMessageException(String) - Constructor for exception bt.protocol.InvalidMessageException
 
IPeerConnectionFactory - Interface in bt.net
Used for creating peer connections, both incoming and outgoing.
IPeerConnectionPool - Interface in bt.net
Provides connection pooling.
IPeerRegistry - Interface in bt.peer
Shared registry of all peers, known to the current runtime.
IPeerWorkerFactory - Interface in bt.torrent.messaging
 
IRuntimeLifecycleBinder - Interface in bt.service
Application lifecycle management API.
IRuntimeLifecycleBinder.LifecycleEvent - Enum in bt.service
Lifecycle events
IS_DIGIT - Static variable in class bt.bencoding.serializers.BEParser
 
isActive() - Method in interface bt.torrent.TorrentDescriptor
 
isAsync() - Method in class bt.service.LifecycleBinding
 
isChoking() - Method in class bt.torrent.messaging.ConnectionState
 
isClosed() - Method in interface bt.net.PeerConnection
 
isClosed() - Method in interface bt.net.pipeline.ChannelHandler
 
isClosed() - Method in class bt.net.pipeline.SocketChannelHandler
 
isClosed() - Method in class bt.net.SocketPeerConnection
 
isCompatible(EncryptionPolicy) - Method in enum bt.protocol.crypto.EncryptionPolicy
 
isComplete(int) - Method in class bt.data.Bitfield
Shortcut method to find out if the piece has been downloaded.
isComplete() - Method in interface bt.data.BlockSet
Shortcut method to determine if all blocks are present
isComplete() - Method in class bt.data.range.MutableBlockSet
 
isComplete() - Method in class bt.data.range.SynchronizedBlockSet
 
isDisposed() - Method in class bt.net.buffer.BufferedData
 
isEmpty() - Method in interface bt.data.BlockSet
Shortcut method to determine if no blocks are present
isEmpty() - Method in class bt.data.range.MutableBlockSet
 
isEmpty() - Method in class bt.data.range.SynchronizedBlockSet
 
isEndgame() - Method in class bt.torrent.messaging.Assignments
 
isInterested() - Method in class bt.torrent.messaging.ConnectionState
 
isIP4(InetSocketAddress) - Static method in class bt.net.InternetProtocolUtils
 
isIP6(InetSocketAddress) - Static method in class bt.net.InternetProtocolUtils
 
isKeySizeSupported(int) - Static method in class bt.protocol.crypto.MSECipher
 
isMseDisabled() - Method in class bt.runtime.Config
 
isMultiKey() - Method in class bt.tracker.AnnounceKey
 
isOpen() - Method in class bt.data.DataReaderChannel
 
isOpen() - Method in class bt.net.crypto.EncryptedChannel
 
isOpen() - Method in class bt.net.SharedSelector
 
isPeerChoking() - Method in class bt.torrent.messaging.ConnectionState
 
isPeerInterested() - Method in class bt.torrent.messaging.ConnectionState
 
isPieceVerified(int) - Method in class bt.data.Bitfield
 
isPortUnknown() - Method in class bt.net.InetPeer
 
isPortUnknown() - Method in interface bt.net.Peer
 
isPresent(int) - Method in interface bt.data.BlockSet
Check if block is present.
isPresent(int) - Method in class bt.data.range.MutableBlockSet
 
isPresent(int) - Method in class bt.data.range.SynchronizedBlockSet
 
isPrivate() - Method in interface bt.metainfo.Torrent
 
isPrivate() - Method in class bt.torrent.maker.TorrentBuilder
isRejected() - Method in class bt.torrent.data.BlockRead
 
isRejected() - Method in class bt.torrent.data.BlockWrite
 
isReservedBitSet(int) - Method in class bt.protocol.Handshake
Check if a reserved bit is set.
isRunning() - Method in class bt.runtime.BtRuntime
 
isSet(byte[], BitOrder, int) - Static method in class bt.protocol.Protocols
Check if i-th bit in the bitmask is set.
isSnapshot() - Method in class bt.service.Version
 
isStarted() - Method in interface bt.runtime.BtClient
Check if this client is started.
isSuccess() - Method in class bt.bencoding.model.ValidationResult
 
isSuccess() - Method in class bt.net.ConnectionResult
 
isSuccess() - Method in class bt.tracker.TrackerResponse
 
isSupportedAndActive(TorrentId) - Method in class bt.torrent.AdhocTorrentRegistry
 
isSupportedAndActive(TorrentId) - Method in interface bt.torrent.TorrentRegistry
 
isSupportedProtocol(String) - Method in interface bt.tracker.ITrackerService
Check if the protocol specified in the tracker's URL is supported.
isSupportedProtocol(String) - Method in class bt.tracker.TrackerService
 
isVerified(int) - Method in class bt.data.Bitfield
Shortcut method to find out if the piece has been downloaded and verified.
iterator() - Method in class bt.tracker.CompactPeerInfo
 
ITrackerService - Interface in bt.tracker
This service acts a factory of trackers.

J

JavaSecurityDigester - Class in bt.data.digest
A class to produce arbitrary digests for DataRange or Range.
JavaSecurityDigester(String, int) - Constructor for class bt.data.digest.JavaSecurityDigester
 
JettyAsyncUpnpServiceConfiguration - Class in bt.portmapping.upnp.jetty
 
JettyAsyncUpnpServiceConfiguration() - Constructor for class bt.portmapping.upnp.jetty.JettyAsyncUpnpServiceConfiguration
 
JUMModelBuilder - Class in bt.bencoding.model
Builds an object model from a Map-based definition.
JUMModelBuilder() - Constructor for class bt.bencoding.model.JUMModelBuilder
 

K

KeepAlive - Class in bt.protocol
 
keyFor(SelectableChannel) - Method in class bt.net.SharedSelector
 
keys() - Method in class bt.net.SharedSelector
 

L

lastBlockSize() - Method in interface bt.data.BlockSet
Get the size of the last block in this set
lastBlockSize() - Method in class bt.data.range.MutableBlockSet
 
lastBlockSize() - Method in class bt.data.range.SynchronizedBlockSet
 
length() - Method in interface bt.data.BlockSet
Get the total length of this block set
length() - Method in interface bt.data.digest.Digester
Return the length of this digest
length() - Method in class bt.data.digest.JavaSecurityDigester
 
length() - Method in class bt.data.range.BlockRange
 
length() - Method in class bt.data.range.ByteRange
 
length() - Method in class bt.data.range.DelegatingDataRange
 
length() - Method in class bt.data.range.MutableBlockSet
 
length() - Method in interface bt.data.range.Range
 
length() - Method in class bt.data.range.SynchronizedBlockSet
 
length() - Method in class bt.data.range.SynchronizedDataRange
 
length() - Method in class bt.data.range.SynchronizedRange
length() - Static method in class bt.metainfo.TorrentId
 
length() - Method in class bt.net.buffer.BufferedData
 
length() - Static method in class bt.net.PeerId
 
length() - Method in enum bt.tracker.CompactPeerInfo.AddressType
 
lenientParser() - Static method in class bt.magnet.MagnetUriParser
Creates a parser, that will suppress parsing errors, that do not prevent identification of torrent ID, e.g.
LifecycleBinding - Class in bt.service
 
LifecycleBinding.Builder - Class in bt.service
 
limit() - Method in interface bt.net.buffer.ByteBufferView
 
limit(int) - Method in interface bt.net.buffer.ByteBufferView
 
limit() - Method in class bt.net.buffer.DelegatingByteBufferView
 
limit(int) - Method in class bt.net.buffer.DelegatingByteBufferView
 
limit() - Method in class bt.net.buffer.SplicedByteBufferView
 
limit(int) - Method in class bt.net.buffer.SplicedByteBufferView
 
ListenerSource<C extends ProcessingContext> - Class in bt.processor.listener
Accumulates processing event listeners for a particular type of processing context
ListenerSource(Class<C>) - Constructor for class bt.processor.listener.ListenerSource
Create an instance of listener source for a particular type of processing context
load(InputStream) - Method in interface bt.bencoding.model.BEObjectModelLoader
Load model definition from a given source.
load(InputStream) - Method in class bt.bencoding.model.YamlBEObjectModelLoader
 
LocalBitfield - Class in bt.data
This class represents a bitfield for a local torrent
LocalBitfield(int, List<List<CompletableTorrentFile>>) - Constructor for class bt.data.LocalBitfield
 
LocalServiceDiscoveryConfig - Class in bt.peer.lan
 
LocalServiceDiscoveryConfig() - Constructor for class bt.peer.lan.LocalServiceDiscoveryConfig
 
LocalServiceDiscoveryInfo - Class in bt.peer.lan
 
LocalServiceDiscoveryInfo(Set<SocketChannelConnectionAcceptor>, Collection<AnnounceGroup>) - Constructor for class bt.peer.lan.LocalServiceDiscoveryInfo
 
LocalServiceDiscoveryModule - Class in bt.peer.lan
 
LocalServiceDiscoveryModule() - Constructor for class bt.peer.lan.LocalServiceDiscoveryModule
 
LocalServiceDiscoveryModule(LocalServiceDiscoveryConfig) - Constructor for class bt.peer.lan.LocalServiceDiscoveryModule
 
LocalServiceDiscoveryPeerSourceFactory - Class in bt.peer.lan
 
LocalServiceDiscoveryPeerSourceFactory(Collection<AnnounceGroupChannel>, IRuntimeLifecycleBinder, Cookie, LocalServiceDiscoveryConfig) - Constructor for class bt.peer.lan.LocalServiceDiscoveryPeerSourceFactory
 
LocalServiceDiscoveryService - Class in bt.peer.lan
 
LocalServiceDiscoveryService(Cookie, ILocalServiceDiscoveryInfo, Collection<AnnounceGroupChannel>, EventSource, IRuntimeLifecycleBinder, LocalServiceDiscoveryConfig) - Constructor for class bt.peer.lan.LocalServiceDiscoveryService
 
lock - Variable in class bt.data.Bitfield
 
lockAndGet() - Method in interface bt.net.buffer.BorrowedBuffer
Get the underlying buffer instance.
longValueExact() - Method in class bt.bencoding.types.BEInteger
 
LRUBlockCache - Class in bt.torrent.data
 
LRUBlockCache(TorrentRegistry, EventSource) - Constructor for class bt.torrent.data.LRUBlockCache
 

M

magnet(String) - Method in class bt.TorrentClientBuilder
Set magnet URI in BEP-9 format
magnet(MagnetUri) - Method in class bt.TorrentClientBuilder
Set magnet URI
MagnetContext - Class in bt.processor.magnet
 
MagnetContext(MagnetUri, PieceSelector, FilePrioritySkipSelector, FileDownloadCompleteCallback, Storage) - Constructor for class bt.processor.magnet.MagnetContext
 
MagnetContext(MagnetUri, PieceSelector, FilePrioritySkipSelector, Storage) - Constructor for class bt.processor.magnet.MagnetContext
 
MagnetContext(MagnetUri, PieceSelector, Storage) - Constructor for class bt.processor.magnet.MagnetContext
 
MagnetUri - Class in bt.magnet
Programmatic API for working with BEP-9 v1 magnet links.
MagnetUri.Builder - Class in bt.magnet
 
MagnetUriParser - Class in bt.magnet
 
makeTorrent() - Method in class bt.torrent.maker.TorrentMaker
Make the torrent from the builder specification
Mapper - Class in bt.torrent.messaging
Creates unique keys, that can be tested for equality with each other.
mapper() - Static method in class bt.torrent.messaging.Mapper
 
mapPort(int, String, PortMapProtocol, String) - Method in class bt.net.portmapping.impl.NoOpPortMapper
 
mapPort(int, String, PortMapProtocol, String) - Method in interface bt.net.portmapping.PortMapper
Map port for incoming connections on network gateway.
mapPort(int, String, PortMapProtocol, String) - Method in class bt.portmapping.upnp.UpnpPortMapper
 
markAvailable(long, long) - Method in class bt.data.range.MutableBlockSet
 
markLocalPieceVerified(int) - Method in class bt.data.LocalBitfield
 
markPeerPieceVerified(int) - Method in class bt.data.PeerBitfield
Mark piece as complete and verified.
markVerified(int) - Method in class bt.data.Bitfield
Mark piece as complete and verified.
maxLength() - Static method in class bt.peer.lan.Cookie
 
maxNumOpenFiles(int) - Method in class bt.torrent.maker.TorrentBuilder
Set the max number of open files during torrent creation.
Message - Interface in bt.protocol
Supertype of all BitTorrent messages.
MESSAGE_LENGTH_PREFIX_SIZE - Static variable in class bt.protocol.StandardBittorrentProtocol
BitTorrent message prefix size in bytes.
MESSAGE_PREFIX_SIZE - Static variable in class bt.protocol.StandardBittorrentProtocol
BitTorrent message prefix size in bytes.
MESSAGE_TYPE_MAPPING_KEY - Static variable in class bt.protocol.extended.ExtendedHandshake
Message type mapping key in the extended handshake.
MESSAGE_TYPE_SIZE - Static variable in class bt.protocol.StandardBittorrentProtocol
BitTorrent message ID size in bytes.
MessageConsumer<T extends Message> - Interface in bt.torrent.messaging
Message agent, that is interested in receiving messages of type T
MessageContext - Class in bt.torrent.messaging
Provides basic information about the context of a message (both inbound and outbound).
MessageDispatcher - Class in bt.net
Default single-threaded message dispatcher implementation.
MessageDispatcher(IRuntimeLifecycleBinder, IPeerConnectionPool, TorrentRegistry, Config) - Constructor for class bt.net.MessageDispatcher
 
MessageHandler<T extends Message> - Interface in bt.protocol.handler
Message encoder/decoder.
MessageHandlers - Annotation Type in bt.module
Annotates individual message handlers, that work with core BitTorrent message types.
MessageProducer - Interface in bt.torrent.messaging
Message agent, that is interested in producing messages
MessageRouter - Interface in bt.torrent.messaging
 
MessagingAgentCompiler - Class in bt.torrent.compiler
Messaging agent compiler.
MessagingAgentCompiler() - Constructor for class bt.torrent.compiler.MessagingAgentCompiler
 
MessagingAgents - Annotation Type in bt.module
Annotates agents (consumers and producers) that participate in torrent messaging.
MetadataAvailableEvent - Class in bt.event
Indicates, that torrent's metadata has been fetched.
MetadataAvailableEvent(long, long, TorrentId, Torrent) - Constructor for class bt.event.MetadataAvailableEvent
 
MetadataConstants - Class in bt.metainfo
Contains the string constants stored in a torrent file
MetadataConstants() - Constructor for class bt.metainfo.MetadataConstants
 
MetadataConsumer - Class in bt.torrent.messaging
 
MetadataConsumer(IMetadataService, TorrentId, Config) - Constructor for class bt.torrent.messaging.MetadataConsumer
 
MetadataProducer - Class in bt.torrent.messaging
 
MetadataProducer(Supplier<Torrent>, Config) - Constructor for class bt.torrent.messaging.MetadataProducer
 
MetadataService - Class in bt.metainfo
Note that this class implements a service.
MetadataService() - Constructor for class bt.metainfo.MetadataService
 
MldhtService - Class in bt.dht
 
MldhtService(IRuntimeLifecycleBinder, Config, DHTConfig, Set<PortMapper>, TorrentRegistry, EventSource) - Constructor for class bt.dht.MldhtService
 
module() - Method in class bt.dht.DHTModuleProvider
 
module() - Method in interface bt.module.BtModuleProvider
 
module() - Method in class bt.portmapping.upnp.UpnpPortMapperModuleProvider
 
module(Module) - Method in class bt.runtime.BtRuntimeBuilder
Contribute an extra module into the runtime.
module(Class<? extends Module>) - Method in class bt.runtime.BtRuntimeBuilder
Contribute an extra module into the runtime.
module(Module) - Method in class bt.StandaloneClientBuilder
Contribute an extra module into the runtime.
module(Class<? extends Module>) - Method in class bt.StandaloneClientBuilder
Contribute an extra module into the runtime.
module() - Method in class bt.tracker.http.HttpTrackerModuleProvider
 
MSECipher - Class in bt.protocol.crypto
RC4-drop1024 stream cipher, used in Message Stream Encryption protocol.
MSEHandshakeProcessor - Class in bt.net.crypto
Implements Message Stream Encryption protocol negotiation.
MSEHandshakeProcessor(TorrentRegistry, MessageHandler<Message>, Config) - Constructor for class bt.net.crypto.MSEHandshakeProcessor
 
MutableBlockSet - Class in bt.data.range
 
mutate(ByteBuffer) - Method in interface bt.net.buffer.BufferMutator
Mutates the data between buffer's position and limit.
mutate(ByteBuffer) - Method in class bt.net.crypto.CipherBufferMutator
 

N

name(String) - Method in class bt.magnet.MagnetUri.Builder
Set "dn" parameter.
negotiateIncoming(Peer, ByteChannel, ByteBuffer, ByteBuffer) - Method in class bt.net.crypto.MSEHandshakeProcessor
 
negotiateOutgoing(Peer, ByteChannel, TorrentId, ByteBuffer, ByteBuffer) - Method in class bt.net.crypto.MSEHandshakeProcessor
 
NetworkUtil - Class in bt.service
Provides useful network functions.
NetworkUtil() - Constructor for class bt.service.NetworkUtil
 
newCookie() - Static method in class bt.peer.lan.Cookie
 
newDigester() - Static method in class bt.data.digest.SHA1Digester
Creates a new Digester with a default buffer size
newDigester(int) - Static method in class bt.data.digest.SHA1Digester
Creates a new Digester with a default step size
newThread(Runnable) - Method in class bt.CountingThreadFactory
 
NoCache - Class in bt.torrent.data
 
NoCache(TorrentRegistry) - Constructor for class bt.torrent.data.NoCache
 
NoOpPortMapper - Class in bt.net.portmapping.impl
PortMapper that does nothing.
NoOpPortMapper() - Constructor for class bt.net.portmapping.impl.NoOpPortMapper
 
NOT_INTERESTED_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
NotInterested - Class in bt.protocol
 
NotInterestedHandler - Class in bt.protocol.handler
 
NotInterestedHandler() - Constructor for class bt.protocol.handler.NotInterestedHandler
 
numHashingThreads(int) - Method in class bt.torrent.maker.TorrentBuilder
Set the number of threads used to create sha1 hashes for the torrent being created any value less than 1 will use Java's common fork join pool.
numWant(Integer) - Method in class bt.tracker.TrackerRequestBuilder
Set the number of peers to request in this call to the tracker.

O

ok() - Static method in class bt.tracker.TrackerResponse
 
onCancel(Cancel) - Method in class bt.torrent.messaging.ConnectionState
Signal that remote peer has cancelled a previously issued block request.
onCompleted(C) - Method in class bt.processor.torrent.ProcessTorrentStage
 
onGet - Variable in class bt.data.digest.SoftThreadLocal
 
onMetadataAvailable(TorrentId, Consumer<MetadataAvailableEvent>) - Method in class bt.event.EventBus
 
onMetadataAvailable(TorrentId, Consumer<MetadataAvailableEvent>) - Method in interface bt.event.EventSource
Fired, when torrent's metadata has been fetched.
onPeerBitfieldUpdated(TorrentId, Consumer<PeerBitfieldUpdatedEvent>) - Method in class bt.event.EventBus
 
onPeerBitfieldUpdated(TorrentId, Consumer<PeerBitfieldUpdatedEvent>) - Method in interface bt.event.EventSource
Fired, when local information about some peer's data has been updated.
onPeerConnected(TorrentId, Consumer<PeerConnectedEvent>) - Method in class bt.event.EventBus
 
onPeerConnected(TorrentId, Consumer<PeerConnectedEvent>) - Method in interface bt.event.EventSource
Fired, when a new connection with some peer has been established.
onPeerDisconnected(TorrentId, Consumer<PeerDisconnectedEvent>) - Method in class bt.event.EventBus
 
onPeerDisconnected(TorrentId, Consumer<PeerDisconnectedEvent>) - Method in interface bt.event.EventSource
Fired, when a connection with some peer has been terminated.
onPeerDiscovered(TorrentId, Consumer<PeerDiscoveredEvent>) - Method in class bt.event.EventBus
 
onPeerDiscovered(TorrentId, Consumer<PeerDiscoveredEvent>) - Method in interface bt.event.EventSource
Fired, when a new peer has been discovered for some torrent.
onPieceVerified(int) - Method in class bt.data.DataReaderChannel
 
onPieceVerified(TorrentId, Consumer<PieceVerifiedEvent>) - Method in class bt.event.EventBus
 
onPieceVerified(TorrentId, Consumer<PieceVerifiedEvent>) - Method in interface bt.event.EventSource
Fired, when downloading and verification of one of torrent's pieces has been finished.
onShutdown(Runnable) - Method in interface bt.service.IRuntimeLifecycleBinder
Register an async hook to run upon runtime shutdown
onShutdown(String, Runnable) - Method in interface bt.service.IRuntimeLifecycleBinder
Register an async hook to run upon runtime shutdown
onShutdown(LifecycleBinding) - Method in interface bt.service.IRuntimeLifecycleBinder
Register a hook to run upon runtime shutdown
onShutdown(Runnable) - Method in class bt.service.RuntimeLifecycleBinder
 
onShutdown(String, Runnable) - Method in class bt.service.RuntimeLifecycleBinder
 
onShutdown(LifecycleBinding) - Method in class bt.service.RuntimeLifecycleBinder
 
onStartup(Runnable) - Method in interface bt.service.IRuntimeLifecycleBinder
Register a hook to run upon runtime startup
onStartup(String, Runnable) - Method in interface bt.service.IRuntimeLifecycleBinder
Register a hook to run upon runtime startup
onStartup(LifecycleBinding) - Method in interface bt.service.IRuntimeLifecycleBinder
Register a hook to run upon runtime startup
onStartup(Runnable) - Method in class bt.service.RuntimeLifecycleBinder
 
onStartup(String, Runnable) - Method in class bt.service.RuntimeLifecycleBinder
 
onStartup(LifecycleBinding) - Method in class bt.service.RuntimeLifecycleBinder
 
onTorrentStarted(TorrentId, Consumer<TorrentStartedEvent>) - Method in class bt.event.EventBus
 
onTorrentStarted(TorrentId, Consumer<TorrentStartedEvent>) - Method in interface bt.event.EventSource
Fired, when processing of some torrent has begun.
onTorrentStopped(TorrentId, Consumer<TorrentStoppedEvent>) - Method in class bt.event.EventBus
 
onTorrentStopped(TorrentId, Consumer<TorrentStoppedEvent>) - Method in interface bt.event.EventSource
Fired, when processing of some torrent has finished.
OpenFileCache - Class in bt.data.file
This is an LRU cache for open files.
OpenFileCache(int) - Constructor for class bt.data.file.OpenFileCache
Construct an LRU cache for managing open files
options(PeerOptions) - Method in class bt.net.InetPeer.Builder
 
outboundBuffer(BorrowedBuffer<ByteBuffer>) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 

P

PackedIntComparator - Class in bt.torrent.selector
First compares the least significant 32 bits of Long values, and if they are equal compares the most significant 32 bits.
PackedIntComparator() - Constructor for class bt.torrent.selector.PackedIntComparator
 
parse(String) - Method in class bt.magnet.MagnetUriParser
Create a magnet URI from its' string representation in BEP-9 format.
parse(URI) - Method in class bt.magnet.MagnetUriParser
Create a magnet URI from its' URI representation in BEP-9 format.
parser() - Static method in class bt.magnet.MagnetUriParser
Creates a parser, that will throw an exception, when some of the elements of the magnet link can not be parsed, e.g.
peer(InetPeerAddress) - Method in class bt.magnet.MagnetUri.Builder
Add "x.pe" parameter.
Peer - Interface in bt.net
Represents a peer, accessible on the Internet.
PeerBitfield - Class in bt.data
 
PeerBitfield(int) - Constructor for class bt.data.PeerBitfield
Create an empty bitfield for a peer
PeerBitfield(byte[], BitOrder, int) - Constructor for class bt.data.PeerBitfield
Creates bitfield based on a bitmask.
PeerBitfieldUpdatedEvent - Class in bt.event
Indicates, that local information about some peer's data has been updated.
PeerBitfieldUpdatedEvent(long, long, ConnectionKey, Bitfield) - Constructor for class bt.event.PeerBitfieldUpdatedEvent
 
PeerConnectedEvent - Class in bt.event
Indicates, that a new connection with some peer has been established.
PeerConnectedEvent(long, long, ConnectionKey) - Constructor for class bt.event.PeerConnectedEvent
 
PeerConnection - Interface in bt.net
Connection with a remote peer.
PeerConnectionAcceptor - Interface in bt.net
Handles incoming connection requests.
PeerConnectionFactory - Class in bt.net
 
PeerConnectionFactory(Selector, IConnectionHandlerFactory, IChannelPipelineFactory, MessageHandler<Message>, TorrentRegistry, IBufferManager, DataReceiver, EventSource, Config) - Constructor for class bt.net.PeerConnectionFactory
 
PeerConnectionPool - Class in bt.net
Note that this class implements a service.
PeerConnectionPool(EventSink, IRuntimeLifecycleBinder, Config) - Constructor for class bt.net.PeerConnectionPool
 
PeerConnectionSelector - Annotation Type in bt.module
Annotates Selector, that should be used for selecting peer connections.
PeerDisconnectedEvent - Class in bt.event
Indicates, that a connection with some peer has been terminated.
PeerDisconnectedEvent(long, long, ConnectionKey) - Constructor for class bt.event.PeerDisconnectedEvent
 
PeerDiscoveredEvent - Class in bt.event
Indicates, that a new peer has been discovered for some torrent.
PeerDiscoveredEvent(long, long, TorrentId, Peer) - Constructor for class bt.event.PeerDiscoveredEvent
 
PeerExchangeConfig - Class in bt.peerexchange
 
PeerExchangeConfig() - Constructor for class bt.peerexchange.PeerExchangeConfig
 
PeerExchangeModule - Class in bt.peerexchange
 
PeerExchangeModule() - Constructor for class bt.peerexchange.PeerExchangeModule
 
PeerExchangeModule(PeerExchangeConfig) - Constructor for class bt.peerexchange.PeerExchangeModule
 
PeerExchangePeerSourceFactory - Class in bt.peerexchange
Note that this class implements a service.
PeerExchangePeerSourceFactory(EventSource, IRuntimeLifecycleBinder, PeerExchangeConfig, Config) - Constructor for class bt.peerexchange.PeerExchangePeerSourceFactory
 
peerId(PeerId) - Method in class bt.net.InetPeer.Builder
 
PeerId - Class in bt.net
Convenient wrapper, that encapsulates a binary peer ID.
PeerOptions - Class in bt.peer
Provides information on various options, preferences and modes of operations of a particular peer.
PeerRegistry - Class in bt.peer
Note that this class implements a service.
PeerRegistry(IRuntimeLifecycleBinder, EventSource, IdentityService, TorrentRegistry, ITrackerService, EventSink, Set<PeerSourceFactory>, Config) - Constructor for class bt.peer.PeerRegistry
 
PeerRequestConsumer - Class in bt.torrent.messaging
Consumes block requests, received from the remote peer, and produces blocks.
PeerRequestConsumer(TorrentId, DataWorker) - Constructor for class bt.torrent.messaging.PeerRequestConsumer
 
PeerSource - Interface in bt.peer
A source of peers for a torrent
PeerSourceFactory - Interface in bt.peer
Factory of peer sources.
PeerWorker - Interface in bt.torrent.messaging
Instances of this class are responsible for providing a messaging interface with one particular peer within a torrent processing session.
PeerWorkerFactory - Class in bt.torrent.messaging
Note that this class implements a service.
PeerWorkerFactory(MessageRouter) - Constructor for class bt.torrent.messaging.PeerWorkerFactory
 
Piece - Class in bt.protocol
 
Piece(int, int, int, BlockReader) - Constructor for class bt.protocol.Piece
 
Piece(int, int, int) - Constructor for class bt.protocol.Piece
 
PIECE_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
PieceConsumer - Class in bt.torrent.messaging
Consumes blocks, received from the remote peer.
PieceConsumer(TorrentId, Bitfield, DataWorker, IBufferedPieceRegistry, EventSink) - Constructor for class bt.torrent.messaging.PieceConsumer
 
PieceHandler - Class in bt.protocol.handler
 
PieceHandler() - Constructor for class bt.protocol.handler.PieceHandler
 
PieceSelector - Interface in bt.torrent.selector
An interface for piece selection
pieceSize(int) - Method in class bt.torrent.maker.TorrentBuilder
Set the piece size of the torrent.
PieceStatistics - Interface in bt.torrent
Provides basic information about the availability of different pieces in the swarm.
piecesTotal - Variable in class bt.data.Bitfield
Total number of pieces in torrent.
PieceUtils - Class in bt.data
A utility class for functionality related to pieces
PieceUtils() - Constructor for class bt.data.PieceUtils
 
PieceVerifiedEvent - Class in bt.event
Indicates that the downloading and verification of one of torrent's pieces has been finished.
PieceVerifiedEvent(long, long, TorrentId, int) - Constructor for class bt.event.PieceVerifiedEvent
 
pipeline() - Method in interface bt.net.pipeline.ChannelHandlerContext
 
pollMessage() - Method in class bt.net.pipeline.InboundMessageProcessor
 
Port - Class in bt.protocol
 
Port(int) - Constructor for class bt.protocol.Port
 
PORT_ID - Static variable in class bt.protocol.handler.PortMessageHandler
 
PortMapper - Interface in bt.net.portmapping
Service, that maps ports for incoming connections on network gateway.
PortMappingInitializer - Class in bt.net.portmapping.impl
Initializes port mappings on application startup.
PortMappingInitializer(Set<PortMapper>, IRuntimeLifecycleBinder, Config) - Constructor for class bt.net.portmapping.impl.PortMappingInitializer
 
PortMappingModule - Class in bt.net.portmapping.impl
 
PortMappingModule() - Constructor for class bt.net.portmapping.impl.PortMappingModule
 
PortMapProtocol - Enum in bt.net.portmapping
Protocols available for port mapping.
PortMessageHandler - Class in bt.protocol.handler
 
PortMessageHandler() - Constructor for class bt.protocol.handler.PortMessageHandler
 
position() - Method in interface bt.net.buffer.ByteBufferView
 
position(int) - Method in interface bt.net.buffer.ByteBufferView
 
position() - Method in class bt.net.buffer.DelegatingByteBufferView
 
position(int) - Method in class bt.net.buffer.DelegatingByteBufferView
 
position() - Method in class bt.net.buffer.SplicedByteBufferView
 
position(int) - Method in class bt.net.buffer.SplicedByteBufferView
 
postMessage(Message) - Method in interface bt.net.PeerConnection
Send a message to remote peer.
postMessage(Message) - Method in class bt.net.SocketPeerConnection
 
prioritize(TorrentFile) - Method in interface bt.torrent.fileselector.FilePrioritySelector
 
prioritize(TorrentFile) - Method in interface bt.torrent.fileselector.FilePrioritySkipSelector
 
prioritize(TorrentFile) - Method in class bt.torrent.fileselector.TorrentFileSelector
Deprecated.
 
PrioritizedPieceSelector - Class in bt.torrent.selector
A piece selector that allows chunks to be prioritized.
PrioritizedPieceSelector(PieceSelector) - Constructor for class bt.torrent.selector.PrioritizedPieceSelector
 
PRIVATE_KEY - Static variable in class bt.metainfo.MetadataConstants
privateFlag(boolean) - Method in class bt.torrent.maker.TorrentBuilder
Set whether this torrent is a private torrent.
process(C, ListenerSource<C>) - Method in class bt.processor.ChainProcessor
 
process(C, ListenerSource<C>) - Method in interface bt.processor.Processor
Begin asynchronous processing of a given context.
processInboundData() - Method in class bt.net.pipeline.InboundMessageProcessor
 
processIncomingHandshake(PeerConnection, Handshake) - Method in class bt.dht.DHTHandshakeHandler
 
processIncomingHandshake(PeerConnection, Handshake) - Method in class bt.net.BitfieldConnectionHandler
 
processIncomingHandshake(PeerConnection, Handshake) - Method in class bt.net.extended.ExtendedProtocolHandshakeHandler
 
processIncomingHandshake(PeerConnection, Handshake) - Method in interface bt.net.HandshakeHandler
Process an incoming handshake, received from a remote peer.
ProcessingContext - Interface in bt.processor
Aggregates all data, that is specific to and required for some processing chain, and is used to transfer the processing state between different stages of this chain.
ProcessingEvent - Enum in bt.processor.listener
Significant milestone in torrent processing.
ProcessingStage<C extends ProcessingContext> - Interface in bt.processor
 
ProcessMagnetTorrentStage - Class in bt.processor.magnet
 
ProcessMagnetTorrentStage(ProcessingStage<MagnetContext>, TorrentRegistry, IPeerRegistry, ITrackerService, EventSink) - Constructor for class bt.processor.magnet.ProcessMagnetTorrentStage
 
Processor<C extends ProcessingContext> - Interface in bt.processor
Generic asynchronous context processor.
processor(Class<C>) - Method in interface bt.processor.ProcessorFactory
Build a processor for a given context type.
processor(Class<C>) - Method in class bt.processor.TorrentProcessorFactory
 
ProcessorFactory - Interface in bt.processor
Builds processors for different context types.
processOutgoingHandshake(Handshake) - Method in class bt.dht.DHTHandshakeHandler
 
processOutgoingHandshake(Handshake) - Method in class bt.net.BitfieldConnectionHandler
 
processOutgoingHandshake(Handshake) - Method in class bt.net.extended.ExtendedProtocolHandshakeHandler
 
processOutgoingHandshake(Handshake) - Method in interface bt.net.HandshakeHandler
Make amendments to an outgoing handshake, that will be sent to a remote peer.
ProcessTorrentStage<C extends TorrentContext> - Class in bt.processor.torrent
 
ProcessTorrentStage(ProcessingStage<C>, TorrentRegistry, IPeerRegistry, ITrackerService, EventSink) - Constructor for class bt.processor.torrent.ProcessTorrentStage
 
produce(Consumer<Message>, MessageContext) - Method in class bt.peerexchange.PeerExchangePeerSourceFactory
 
produce(Consumer<Message>, MessageContext) - Method in class bt.torrent.messaging.DefaultMessageRouter
 
produce(Consumer<Message>, MessageContext) - Method in interface bt.torrent.messaging.MessageProducer
Produce a message to the remote peer, if possible
produce(Consumer<Message>, MessageContext) - Method in interface bt.torrent.messaging.MessageRouter
Request a message from producers.
produce(Consumer<Message>, MessageContext) - Method in class bt.torrent.messaging.MetadataConsumer
 
produce(Consumer<Message>, MessageContext) - Method in class bt.torrent.messaging.MetadataProducer
 
produce(Consumer<Message>, MessageContext) - Method in class bt.torrent.messaging.PeerRequestConsumer
 
produce(Consumer<Message>) - Method in class bt.torrent.messaging.PieceConsumer
 
produce(Consumer<Message>, MessageContext) - Method in class bt.torrent.messaging.RequestProducer
 
Produces - Annotation Type in bt.torrent.annotation
Annotates messaging agents, that act as message producers.
property(String, BEObject<?>) - Method in class bt.protocol.extended.ExtendedHandshake.Builder
 
protocol(MessageHandler<Message>) - Method in class bt.net.pipeline.ChannelPipelineBuilder
 
Protocol<T> - Interface in bt.protocol
Protocol is responsible for determining message types.
ProtocolModule - Class in bt.module
This module contributes main protocol-related artifacts.
ProtocolModule() - Constructor for class bt.module.ProtocolModule
 
ProtocolModuleExtender - Class in bt.module
Used for contributing custom extensions to ProtocolModule
Protocols - Class in bt.protocol
Provides utility functions for binary protocol implementations.
Protocols() - Constructor for class bt.protocol.Protocols
 
provideConnectionHandlerFactory(IHandshakeFactory, TorrentRegistry, Set<HandshakeHandler>, ExtendedHandshakeFactory, Config) - Method in class bt.module.ProtocolModule
 
provideDataDescriptorFactory(Config, EventSource, ChunkVerifier) - Method in class bt.module.ServiceModule
 
provideDataWorker(IRuntimeLifecycleBinder, TorrentRegistry, ChunkVerifier, BlockCache, Config) - Method in class bt.module.ServiceModule
 
provideDigester(Config) - Method in class bt.module.ServiceModule
 
provideEventBus() - Method in class bt.module.ServiceModule
 
provideExtendedMessageTypeMapping(Map<String, MessageHandler<? extends ExtendedMessage>>) - Method in class bt.module.ProtocolModule
 
provideGroupChannels(ILocalServiceDiscoveryInfo, SharedSelector, IRuntimeLifecycleBinder) - Method in class bt.peer.lan.LocalServiceDiscoveryModule
 
provideLocalServiceDiscoveryCookie() - Method in class bt.peer.lan.LocalServiceDiscoveryModule
 
provideLocalServiceDiscoveryInfo(Set<PeerConnectionAcceptor>, LocalServiceDiscoveryConfig) - Method in class bt.peer.lan.LocalServiceDiscoveryModule
 
providePeerConnectionFactory(SharedSelector, IConnectionHandlerFactory, MessageHandler<Message>, TorrentRegistry, IChannelPipelineFactory, IBufferManager, DataReceiver, EventSource, Config) - Method in class bt.module.ServiceModule
 
provider() - Method in class bt.net.SharedSelector
 
provideSelector(IRuntimeLifecycleBinder) - Method in class bt.module.ServiceModule
 
provideSocketChannelConnectionAcceptor(SharedSelector, IPeerConnectionFactory, Config) - Method in class bt.module.ServiceModule
 
provideVerifier(Config, Digester) - Method in class bt.module.ServiceModule
 
putBytes(byte[]) - Method in class bt.data.range.BlockRange
 
putBytes(ByteBufferView) - Method in class bt.data.range.BlockRange
 
putBytes(byte[]) - Method in class bt.data.range.ByteRange
 
putBytes(ByteBufferView) - Method in class bt.data.range.ByteRange
 
putBytes(byte[]) - Method in class bt.data.range.DelegatingDataRange
 
putBytes(ByteBufferView) - Method in class bt.data.range.DelegatingDataRange
 
putBytes(byte[]) - Method in interface bt.data.range.Range
Put data at the beginning of this range.
putBytes(ByteBufferView) - Method in interface bt.data.range.Range
Put data from the provided buffer at the beginning of this range.
putBytes(byte[]) - Method in class bt.data.range.SynchronizedDataRange
 
putBytes(ByteBufferView) - Method in class bt.data.range.SynchronizedDataRange
 
putBytes(byte[]) - Method in class bt.data.range.SynchronizedRange
Put data at the beginning of this range.
putBytes(ByteBufferView) - Method in class bt.data.range.SynchronizedRange
 

Q

query() - Method in class bt.tracker.TrackerRequestBuilder
Query tracker for active peers.
QueryBuilderUtil - Class in bt.tracker.http.urlencoding
Utils for building tracker queries
QueryBuilderUtil() - Constructor for class bt.tracker.http.urlencoding.QueryBuilderUtil
 

R

randomizedRarest() - Static method in class bt.torrent.selector.RarestFirstSelector
Randomized rarest-first selector.
RandomizedRarestFirstSelector - Class in bt.torrent.selector
 
RandomizedRarestFirstSelector() - Constructor for class bt.torrent.selector.RandomizedRarestFirstSelector
 
randomizedRarestSelector() - Method in class bt.TorrentClientBuilder
Use rarest first piece selection strategy
Range<T extends Range<T>> - Interface in bt.data.range
Represents a range of binary data.
Ranges - Class in bt.data.range
 
Ranges() - Constructor for class bt.data.range.Ranges
 
rarest() - Static method in class bt.torrent.selector.RarestFirstSelector
Regular rarest-first selector.
RarestFirstSelector - Class in bt.torrent.selector
 
RarestFirstSelector() - Constructor for class bt.torrent.selector.RarestFirstSelector
 
rarestSelector() - Method in class bt.TorrentClientBuilder
Use rarest first piece selection strategy
read(Map, Class<T>, Object) - Static method in class bt.bencoding.model.ClassUtil
 
read(ByteBuffer) - Method in class bt.data.DataReaderChannel
 
read(ByteBuffer) - Method in class bt.net.ByteChannelReader
 
read(ByteBuffer) - Method in class bt.net.crypto.EncryptedChannel
 
read() - Method in interface bt.net.pipeline.ChannelHandler
Request to read incoming data from the underlying channel.
read() - Method in class bt.net.pipeline.SocketChannelHandler
 
readAtLeast(int) - Method in class bt.net.ByteChannelReader
 
readBetween(int, int) - Method in class bt.net.ByteChannelReader
 
readBlock(ByteBuffer, long) - Method in class bt.data.file.FileSystemStorageUnit
 
readBlock(FileCacheKey, ByteBuffer, long) - Method in class bt.data.file.OpenFileCache
Read a block from the provided file cache key
readBlock(ByteBuffer, long) - Method in interface bt.data.StorageUnit
Try to read a block of data into the provided buffer, starting with a given offset.
readBlock(byte[], long) - Method in interface bt.data.StorageUnit
Try to read a block of data into the provided array, starting with a given offset.
readBlockFully(ByteBuffer, long) - Method in class bt.data.file.FileSystemStorageUnit
 
readBlockFully(FileCacheKey, ByteBuffer, long) - Method in class bt.data.file.OpenFileCache
Fully read a block from the provided file cache key
readBlockFully(ByteBuffer, long) - Method in interface bt.data.StorageUnit
 
readExactly(int) - Method in class bt.net.ByteChannelReader
 
readFromChannel() - Method in interface bt.net.pipeline.ChannelHandlerContext
Request reading from the channel
readInt(byte[], int) - Static method in class bt.protocol.Protocols
Decode the binary representation of an Integer from a byte array.
readInt(ByteBuffer) - Static method in class bt.protocol.Protocols
Decode the binary representation of an Integer from a buffer.
readInt(ByteBufferView) - Static method in class bt.protocol.Protocols
Decode the binary representation of an Integer from a buffer.
readInteger() - Method in class bt.bencoding.serializers.BEParser
Try to read the document's root object as a bencoded integer.
readList() - Method in class bt.bencoding.serializers.BEParser
Try to read the document's root object as a bencoded list.
readLong(byte[], int) - Static method in class bt.protocol.Protocols
Decode the binary representation of a Long from a byte array.
readLong(ByteBuffer) - Static method in class bt.protocol.Protocols
Decode the binary representation of a Long from a buffer.
readMap() - Method in class bt.bencoding.serializers.BEParser
Try to read the document's root object as a bencoded dictionary.
readMessage(long) - Method in interface bt.net.PeerConnection
Attempt to read an incoming message within a specified time interval.
readMessage(long) - Method in class bt.net.SocketPeerConnection
 
readMessageNow() - Method in interface bt.net.PeerConnection
Attempt to read an incoming message.
readMessageNow() - Method in class bt.net.SocketPeerConnection
 
readMessageType(ByteBufferView) - Method in class bt.magnet.UtMetadataMessageHandler
 
readMessageType(ByteBufferView) - Method in class bt.protocol.extended.ExtendedProtocol
 
readMessageType(ByteBufferView) - Method in class bt.protocol.handler.UniqueMessageHandler
 
readMessageType(ByteBufferView) - Method in interface bt.protocol.Protocol
Tries to determine the message type based on the (part of the) message available in the byte buffer.
readMessageType(ByteBufferView) - Method in class bt.protocol.StandardBittorrentProtocol
 
readNoMoreThan(int) - Method in class bt.net.ByteChannelReader
 
readNotNull(Map, Class<T>, Object) - Static method in class bt.bencoding.model.ClassUtil
 
readShort(byte[], int) - Static method in class bt.protocol.Protocols
Decode the binary representation of a Short from a byte array.
readShort(ByteBuffer) - Static method in class bt.protocol.Protocols
Decode the binary representation of a Short from a buffer.
readShort(ByteBufferView) - Static method in class bt.protocol.Protocols
Decode the binary representation of a Short from a buffer.
readString() - Method in class bt.bencoding.serializers.BEParser
Try to read the document's root object as a bencoded string.
readTo(ByteBuffer) - Method in interface bt.torrent.data.BlockReader
 
readType() - Method in class bt.bencoding.serializers.BEParser
Read type of the root object of the bencoded document that this parser was created for.
receive() - Method in interface bt.net.pipeline.ChannelHandler
 
receive() - Method in class bt.net.pipeline.SocketChannelHandler
 
receive(ByteBuffer) - Method in class bt.peer.lan.AnnounceGroupChannel
 
register() - Method in interface bt.net.pipeline.ChannelHandler
 
register() - Method in class bt.net.pipeline.SocketChannelHandler
 
register(Torrent, Storage, FileDownloadCompleteCallback) - Method in class bt.torrent.AdhocTorrentRegistry
 
register(TorrentId) - Method in class bt.torrent.AdhocTorrentRegistry
 
register(Torrent, Storage, FileDownloadCompleteCallback) - Method in interface bt.torrent.TorrentRegistry
Get an existing torrent descriptor for a given torrent or create a new one if it does not exist.
register(TorrentId) - Method in interface bt.torrent.TorrentRegistry
Get an existing torrent descriptor for a given torrent ID or create a new one if it does not exist.
registerChannel(SelectableChannel, ChannelHandlerContext) - Method in interface bt.net.DataReceiver
Register a channel.
registerChannel(SelectableChannel, ChannelHandlerContext) - Method in class bt.net.DataReceivingLoop
 
registerMessagingAgent(Object) - Method in class bt.torrent.messaging.DefaultMessageRouter
 
registerMessagingAgent(Object) - Method in interface bt.torrent.messaging.MessageRouter
Add a messaging agent, that can act as a message consumer and/or producer.
registerPortMapping(PortMapping) - Method in class bt.portmapping.upnp.UpnpPortMappingServicesRegistrar
Creates corresponding UPNP serive for port mapping.
registerSessionState(TorrentId, TorrentSessionState) - Method in class bt.torrent.AdhocTorrentRegistry
 
registerSessionState(TorrentId, TorrentSessionState) - Method in interface bt.torrent.TorrentRegistry
Register a session state for the specified torrent
reject(int) - Static method in class bt.magnet.UtMetadata
Create metadata rejection response for a given piece.
release() - Method in interface bt.net.buffer.BorrowedBuffer
Release the underlying buffer.
remaining() - Method in interface bt.net.buffer.ByteBufferView
 
remaining() - Method in class bt.net.buffer.DelegatingByteBufferView
 
remaining() - Method in class bt.net.buffer.SplicedByteBufferView
 
remove(Assignment) - Method in class bt.torrent.messaging.Assignments
 
removeBitfield(ConnectionKey) - Method in class bt.torrent.BitfieldBasedStatistics
Remove peer's bitfield.
removeCopy(K) - Method in class bt.BufferingMap
Remove and return all elements for a given key.
removePeer(ConnectionKey) - Method in class bt.torrent.messaging.TorrentWorker
Called when a peer leaves the torrent processing session.
removeVerifiedPiecesFromBitset(BitSet) - Method in class bt.data.LocalBitfield
 
request(int) - Static method in class bt.magnet.UtMetadata
Create metadata request for a given piece.
Request - Class in bt.protocol
 
Request(int, int, int) - Constructor for class bt.protocol.Request
 
request(TorrentId) - Method in class bt.tracker.http.HttpTracker
 
request(Torrent) - Method in interface bt.tracker.Tracker
Deprecated.
since 1.3 in favor of Tracker.request(TorrentId)
request(TorrentId) - Method in interface bt.tracker.Tracker
Build a tracker request for a given torrent.
REQUEST_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
RequestHandler - Class in bt.protocol.handler
 
RequestHandler() - Constructor for class bt.protocol.handler.RequestHandler
 
RequestProducer - Class in bt.torrent.messaging
Produces block requests to the remote peer.
RequestProducer(DataDescriptor, int) - Constructor for class bt.torrent.messaging.RequestProducer
 
RequiredRule - Class in bt.bencoding.model.rule
Used to mark some attribute of an object model as required.
RequiredRule(List<String>) - Constructor for class bt.bencoding.model.rule.RequiredRule
 
reverseBits(byte[]) - Static method in class bt.protocol.Protocols
Returns a copy of the provided byte array with each byte reversed.
reverseBits(byte) - Static method in class bt.protocol.Protocols
Returns a reversed byte.
rootPath(Path) - Method in class bt.torrent.maker.TorrentBuilder
Set the root path of the torrent
RoutingProcessingStage<C extends ProcessingContext> - Class in bt.processor
Base class for chained processing stage implementations.
RoutingProcessingStage(ProcessingStage<C>) - Constructor for class bt.processor.RoutingProcessingStage
 
Rule - Interface in bt.bencoding.model.rule
Validation primitive.
run() - Method in class bt.net.DataReceivingLoop
 
runtime(BtRuntime) - Method in class bt.BaseClientBuilder
Set the runtime that the newly built client will be attached to.
RuntimeLifecycleBinder - Class in bt.service
Note that this class implements a service.
RuntimeLifecycleBinder() - Constructor for class bt.service.RuntimeLifecycleBinder
 

S

sameValue(Cookie, Cookie) - Static method in class bt.peer.lan.Cookie
Check if two cookies have the same value.
ScheduledPeerSource - Class in bt.peer
 
ScheduledPeerSource(ExecutorService, Duration) - Constructor for class bt.peer.ScheduledPeerSource
 
searchPattern(ByteBuffer, byte[]) - Static method in class bt.net.buffer.Buffers
Searches for the first pattern match in the provided buffer.
SecretKey - Interface in bt.tracker
A secret binary sequence, used for interaction with HTTP trackers.
SeedStage<C extends TorrentContext> - Class in bt.processor.torrent
 
SeedStage(ProcessingStage<C>, TorrentRegistry) - Constructor for class bt.processor.torrent.SeedStage
 
select(long) - Method in class bt.net.SharedSelector
 
select() - Method in class bt.net.SharedSelector
 
select() - Static method in class bt.torrent.fileselector.SelectionResult
Deprecated.
 
select(TorrentFile) - Method in class bt.torrent.fileselector.TorrentFileSelector
Deprecated.
Make a decision on whether to download or skip the given file.
selectedKeys() - Method in class bt.net.SharedSelector
 
selectFiles(List<TorrentFile>) - Method in class bt.torrent.fileselector.TorrentFileSelector
Deprecated.
Returns a list of decisions on whether to download or skip each of the given files, in the same order.
SelectionResult - Class in bt.torrent.fileselector
Deprecated.
use FilePriority instead
SelectionResult.Builder - Class in bt.torrent.fileselector
Deprecated.
 
selectNow() - Method in class bt.net.SharedSelector
 
selector(PieceSelector) - Method in class bt.TorrentClientBuilder
Set piece selection strategy
send(Message) - Method in interface bt.net.pipeline.ChannelHandler
 
send(Message) - Method in class bt.net.pipeline.SocketChannelHandler
 
send(ByteBuffer) - Method in class bt.peer.lan.AnnounceGroupChannel
 
sequential() - Static method in class bt.torrent.selector.SequentialSelector
 
SequentialSelector - Class in bt.torrent.selector
Selects pieces sequentially in the order of their availability.
SequentialSelector() - Constructor for class bt.torrent.selector.SequentialSelector
 
sequentialSelector() - Method in class bt.TorrentClientBuilder
Use sequential piece selection strategy
service(Class<T>) - Method in class bt.runtime.BtRuntime
Convenience method to get an instance of a shared DI service.
ServiceModule - Class in bt.module
This module contributes all core services, shared among all clients attached to a runtime.
ServiceModule() - Constructor for class bt.module.ServiceModule
 
ServiceModule(Config) - Constructor for class bt.module.ServiceModule
 
ServiceModuleExtender - Class in bt.module
Used for contributing custom extensions to ServiceModule
setAcceptorAddress(InetAddress) - Method in class bt.runtime.Config
 
setAcceptorPort(int) - Method in class bt.runtime.Config
 
setAllNonSkippedFiles(List<TorrentFile>) - Method in class bt.processor.torrent.TorrentContext
 
setAnnouncer(TrackerAnnouncer) - Method in class bt.processor.torrent.TorrentContext
 
setAssignments(Assignments) - Method in class bt.processor.torrent.TorrentContext
 
setBit(byte[], BitOrder, int) - Static method in class bt.protocol.Protocols
Sets i-th bit in a bitmask.
setBitfield(LocalBitfield) - Method in class bt.processor.torrent.TorrentContext
 
setBitfieldConsumer(BitfieldCollectingConsumer) - Method in class bt.processor.magnet.MagnetContext
 
setBootstrapNodes(Collection<InetPeerAddress>) - Method in class bt.dht.DHTConfig
 
setEncryptionPolicy(EncryptionPolicy) - Method in class bt.runtime.Config
 
setHashingBufferSize(int) - Method in class bt.runtime.Config
Set the size of the io buffer used for reading from files to verify their digest.
setHighPriorityPieces(BitSet) - Method in class bt.torrent.selector.PrioritizedPieceSelector
 
setHighPriorityPiecesIfNull(BitSet) - Method in class bt.torrent.selector.PrioritizedPieceSelector
 
setInterested(boolean) - Method in class bt.torrent.messaging.ConnectionState
 
setInterval(int) - Method in class bt.tracker.TrackerResponse
 
setLeecherCount(int) - Method in class bt.tracker.TrackerResponse
 
setListeningPort(int) - Method in class bt.dht.DHTConfig
 
setLocalServiceDiscoveryAnnounceGroups(Collection<AnnounceGroup>) - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
setLocalServiceDiscoveryAnnounceInterval(Duration) - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
setLocalServiceDiscoveryMaxTorrentsPerAnnounce(int) - Method in class bt.peer.lan.LocalServiceDiscoveryConfig
 
setMaxConcurrentlyActivePeerConnectionsPerTorrent(int) - Method in class bt.runtime.Config
Maximum number of peer connections that are allowed to request and receive pieces.
setMaxEventsPerMessage(int) - Method in class bt.peerexchange.PeerExchangeConfig
 
setMaxIOQueueSize(int) - Method in class bt.runtime.Config
 
setMaxMessageInterval(Duration) - Method in class bt.peerexchange.PeerExchangeConfig
 
setMaxMessageProcessingInterval(Duration) - Method in class bt.runtime.Config
This option is related to the adaptive message processing interval feature in the message dispatcher.
setMaxOutstandingRequests(int) - Method in class bt.runtime.Config
 
setMaxPeerConnections(int) - Method in class bt.runtime.Config
 
setMaxPeerConnectionsPerTorrent(int) - Method in class bt.runtime.Config
 
setMaxPendingConnectionRequests(int) - Method in class bt.runtime.Config
 
setMaxPieceReceivingTime(Duration) - Method in class bt.runtime.Config
 
setMaxSimultaneouslyAssignedPieces(int) - Method in class bt.runtime.Config
Set the number of pieces that are assigned to a single peer
setMaxTransferBlockSize(int) - Method in class bt.runtime.Config
 
setMessage(Message) - Method in class bt.protocol.DecodingContext
 
setMetadataExchangeBlockSize(int) - Method in class bt.runtime.Config
 
setMetadataExchangeMaxSize(int) - Method in class bt.runtime.Config
 
setMinEventsPerMessage(int) - Method in class bt.peerexchange.PeerExchangeConfig
 
setMinInterval(int) - Method in class bt.tracker.TrackerResponse
 
setMinMessageInterval(Duration) - Method in class bt.peerexchange.PeerExchangeConfig
 
setMseDisabled(boolean) - Method in class bt.runtime.Config
 
setMsePrivateKeySize(int) - Method in class bt.runtime.Config
 
setMseWaitBetweenReads(Duration) - Method in class bt.runtime.Config
 
setNetworkBufferSize(int) - Method in class bt.runtime.Config
 
setNumberOfPeersToRequestFromTracker(int) - Method in class bt.runtime.Config
 
setNumOfHashingThreads(int) - Method in class bt.runtime.Config
 
setPeerAddress(InetAddress) - Method in class bt.runtime.Config
Set the address to send to the tracker.
setPeerChoking(boolean) - Method in class bt.torrent.messaging.ConnectionState
 
setPeerConnectionInactivityThreshold(Duration) - Method in class bt.runtime.Config
 
setPeerConnectionRetryCount(int) - Method in class bt.runtime.Config
 
setPeerConnectionRetryInterval(Duration) - Method in class bt.runtime.Config
 
setPeerConnectionTimeout(Duration) - Method in class bt.runtime.Config
 
setPeerDiscoveryInterval(Duration) - Method in class bt.runtime.Config
 
setPeerHandshakeTimeout(Duration) - Method in class bt.runtime.Config
 
setPeerInterested(boolean) - Method in class bt.torrent.messaging.ConnectionState
 
setPeers(Iterable<Peer>) - Method in class bt.tracker.TrackerResponse
 
setPieceStatistics(BitfieldBasedStatistics) - Method in class bt.processor.torrent.TorrentContext
 
setPort(int) - Method in class bt.net.InetPeer
 
setReservedBit(int) - Method in class bt.protocol.Handshake
Set a reserved bit.
setRouter(MessageRouter) - Method in class bt.processor.torrent.TorrentContext
 
setSeederCount(int) - Method in class bt.tracker.TrackerResponse
 
setShouldChoke(boolean) - Method in class bt.torrent.messaging.ConnectionState
Propose choking/unchoking.
setShouldUseIPv6(boolean) - Method in class bt.dht.DHTConfig
 
setShouldUseRouterBootstrap(boolean) - Method in class bt.dht.DHTConfig
 
setShutdownHookTimeout(Duration) - Method in class bt.runtime.Config
 
setSkippedPieces(BitSet) - Method in class bt.data.LocalBitfield
Mark pieces to download/skip with the specified BitSet.
setState(TorrentSessionState) - Method in class bt.processor.torrent.TorrentContext
 
setTimeoutedAssignmentPeerBanDuration(Duration) - Method in class bt.runtime.Config
 
setTorrent(Torrent) - Method in class bt.processor.torrent.TorrentContext
 
setTorrentId(TorrentId) - Method in interface bt.net.PeerConnection
Associate this connection with the given torrent ID.
setTorrentId(TorrentId) - Method in class bt.net.SocketPeerConnection
 
setTorrentId(TorrentId) - Method in class bt.processor.magnet.MagnetContext
 
setTorrentId(TorrentId) - Method in class bt.processor.torrent.TorrentContext
 
setTrackerId(byte[]) - Method in class bt.tracker.TrackerResponse
 
setTrackerQueryInterval(Duration) - Method in class bt.runtime.Config
 
setTrackerTimeout(Duration) - Method in class bt.runtime.Config
Set the tracker/peer source timeout Currently used in the following contexts: - HTTP trackers: used as connection timeout and SO_TIMEOUT; default is 30 seconds - UDP trackers: used as an additional limit on maximal BEP-0015 timeout; formula is Math.min(3840 seconds, trackerTimeout) - all ScheduledPeerSources (HTTP, UDP, DHT): used during the first (initial) peer collection as a limit on the time to wait for the collection to finish before querying the next peer source; default is 10 seconds
setTransferBlockSize(int) - Method in class bt.runtime.Config
 
setUnreachablePeerBanDuration(Duration) - Method in class bt.runtime.Config
 
setValue(T) - Method in class bt.data.digest.SoftThreadLocal
 
setWarningMessage(String) - Method in class bt.tracker.TrackerResponse
 
SHA1Digester - Class in bt.data.digest
 
SHA1Digester() - Constructor for class bt.data.digest.SHA1Digester
 
SharedSelector - Class in bt.net
Selector decorator with some convenient extensions, like SharedSelector.wakeupAndRegister(SelectableChannel, int, Object).
SharedSelector(Selector) - Constructor for class bt.net.SharedSelector
 
shouldSkip() - Method in class bt.torrent.fileselector.SelectionResult
Deprecated.
 
shouldUseIPv6() - Method in class bt.dht.DHTConfig
 
shouldUseRouterBootstrap() - Method in class bt.dht.DHTConfig
 
shuffle(int[]) - Static method in class bt.torrent.selector.ShuffleUtils
 
shuffle(int[], Random) - Static method in class bt.torrent.selector.ShuffleUtils
Shuffle the passed in int array in-place with the specified Random
ShuffleUtils - Class in bt.torrent.selector
A class that has shuffle utility functions
ShuffleUtils() - Constructor for class bt.torrent.selector.ShuffleUtils
 
shutdown() - Method in class bt.net.DataReceivingLoop
 
shutdown() - Method in class bt.net.IncomingConnectionListener
 
shutdown() - Method in class bt.peer.lan.AnnounceGroupChannel
Close currently opened channel if present and prevent creation of new channels.
shutdown() - Method in class bt.runtime.BtRuntime
Manually initiate the runtime shutdown procedure, which includes: - stopping all attached clients - stopping all workers and executors, that were created inside this runtime and registered via IRuntimeLifecycleBinder
size() - Method in class bt.data.file.FileSystemStorageUnit
 
size(FileCacheKey) - Method in class bt.data.file.OpenFileCache
Get the size of the file referred to by key on disk
size() - Method in interface bt.data.StorageUnit
Get current amount of data in this storage.
size() - Method in interface bt.net.IPeerConnectionPool
 
size() - Method in class bt.net.PeerConnectionPool
 
skip() - Static method in class bt.torrent.fileselector.SelectionResult
Deprecated.
 
SocketChannelConnectionAcceptor - Class in bt.net
 
SocketChannelConnectionAcceptor(Selector, IPeerConnectionFactory, InetSocketAddress) - Constructor for class bt.net.SocketChannelConnectionAcceptor
 
SocketChannelHandler - Class in bt.net.pipeline
 
SocketChannelHandler(SocketChannel, BorrowedBuffer<ByteBuffer>, BorrowedBuffer<ByteBuffer>, Function<ChannelHandler, ChannelHandlerContext>, DataReceiver) - Constructor for class bt.net.pipeline.SocketChannelHandler
 
SocketPeerConnection - Class in bt.net
 
SoftThreadLocal<T> - Class in bt.data.digest
 
SoftThreadLocal(Supplier<T>) - Constructor for class bt.data.digest.SoftThreadLocal
 
SoftThreadLocal(Supplier<T>, Function<? super T, ? extends T>) - Constructor for class bt.data.digest.SoftThreadLocal
 
SplicedByteBufferView - Class in bt.net.buffer
 
SplicedByteBufferView(ByteBuffer, ByteBuffer) - Constructor for class bt.net.buffer.SplicedByteBufferView
 
StandaloneClientBuilder - Class in bt
Builds a standalone client with a private runtime
StandaloneClientBuilder() - Constructor for class bt.StandaloneClientBuilder
 
StandardBittorrentProtocol - Class in bt.protocol
 
StandardBittorrentProtocol(Map<Integer, MessageHandler<?>>) - Constructor for class bt.protocol.StandardBittorrentProtocol
 
start() - Method in interface bt.torrent.TorrentDescriptor
Issue a request to begin torrent processing
start() - Method in class bt.tracker.TrackerRequestBuilder
Announce to tracker, that the client is starting a torrent session.
startAsync() - Method in interface bt.runtime.BtClient
Start torrent processing asynchronously in a separate thread.
startAsync(Consumer<TorrentSessionState>, long) - Method in interface bt.runtime.BtClient
Start torrent processing asynchronously in a separate thread and schedule periodic callback invocations.
startedAsSeed() - Method in interface bt.data.DataDescriptor
Check if the torrent was finished upon initial hashing
startedAsSeed() - Method in class bt.torrent.DefaultTorrentSessionState
 
startedAsSeed() - Method in interface bt.torrent.TorrentSessionState
Check if the torrent was finished upon initial hashing
startup() - Method in class bt.net.IncomingConnectionListener
 
startup() - Method in class bt.runtime.BtRuntime
Manually start the runtime (possibly with no clients attached).
stop() - Method in interface bt.runtime.BtClient
Stop torrent processing.
stop() - Method in interface bt.torrent.TorrentDescriptor
Issue a request to stop torrent processing
stop() - Method in class bt.torrent.TrackerAnnouncer
 
stop() - Method in class bt.tracker.TrackerRequestBuilder
Announce to tracker, that the client is stopping a torrent session.
stopWhenDownloaded() - Method in class bt.TorrentClientBuilder
Stop processing, when the data has been downloaded.
Storage - Interface in bt.data
Data back-end.
storage(Storage) - Method in class bt.TorrentClientBuilder
Set the provided storage as the data back-end
StorageUnit - Interface in bt.data
Storage for a single torrent file
stream() - Method in class bt.dht.stream.StreamAdapter
 
StreamAdapter<T> - Class in bt.dht.stream
 
StreamAdapter() - Constructor for class bt.dht.stream.StreamAdapter
 
success(PeerConnection) - Static method in class bt.net.ConnectionResult
 
supplier - Variable in class bt.data.digest.SoftThreadLocal
 
sync(ByteBuffer, byte[]) - Method in class bt.net.ByteChannelReader
 
synchronizedBlockSet(BlockSet) - Static method in class bt.data.range.Ranges
 
SynchronizedBlockSet - Class in bt.data.range
 
SynchronizedBlockSet(BlockSet) - Constructor for class bt.data.range.SynchronizedBlockSet
 
SynchronizedBlockSet(BlockSet, SynchronizedRange<?>) - Constructor for class bt.data.range.SynchronizedBlockSet
 
synchronizedDataRange(DataRange) - Static method in class bt.data.range.Ranges
 
synchronizedDataRange(BlockRange<DataRange>) - Static method in class bt.data.range.Ranges
 
SynchronizedDataRange<T extends Range<T>> - Class in bt.data.range
Adapter to SynchronizedRange that indirectly encapsulates DataRange (most probably via delegation chain).
SynchronizedDataRange(SynchronizedRange<T>, Function<T, DataRange>) - Constructor for class bt.data.range.SynchronizedDataRange
 
synchronizedRange(T) - Static method in class bt.data.range.Ranges
 
SynchronizedRange<T extends Range<T>> - Class in bt.data.range
Data range synchronized with a shared lock.
SynchronizedRange(Range<T>) - Constructor for class bt.data.range.SynchronizedRange
Create a data range synchronized with a private lock.

T

TCPPORT_PROPERTY - Static variable in class bt.protocol.extended.ExtendedHandshake
 
TerminateOnErrorProcessingStage<C extends ProcessingContext> - Class in bt.processor
Base processing stage, that terminates processing chain in case of error.
TerminateOnErrorProcessingStage(ProcessingStage<C>) - Constructor for class bt.processor.TerminateOnErrorProcessingStage
 
test(int) - Method in class bt.torrent.selector.IncompletePiecesValidator
 
toByteArray(BitOrder) - Method in class bt.data.Bitfield
 
toHex(byte[]) - Static method in class bt.protocol.Protocols
Get hex-encoded representation of a binary array.
toQuery() - Method in class bt.tracker.http.urlencoding.TrackerQueryBuilder
Build the query from all of the added values
Torrent - Interface in bt.metainfo
 
torrent(URL) - Method in class bt.TorrentClientBuilder
Set torrent file URL
torrent(Supplier<Torrent>) - Method in class bt.TorrentClientBuilder
Set custom torrent file supplier
TORRENT_NAME_KEY - Static variable in class bt.metainfo.MetadataConstants
TORRENT_SIZE_KEY - Static variable in class bt.metainfo.MetadataConstants
TorrentBuilder - Class in bt.torrent.maker
A builder pattern to make torrent files conforming to BEP-003
TorrentBuilder() - Constructor for class bt.torrent.maker.TorrentBuilder
 
TorrentClientBuilder<B extends TorrentClientBuilder> - Class in bt
 
TorrentClientBuilder() - Constructor for class bt.TorrentClientBuilder
 
TorrentContext - Class in bt.processor.torrent
Accumulates data, that is specific to standard torrent download/upload.
TorrentContext(PieceSelector, FilePrioritySkipSelector, FileDownloadCompleteCallback, Storage, Supplier<Torrent>) - Constructor for class bt.processor.torrent.TorrentContext
 
TorrentContext(PieceSelector, FilePrioritySkipSelector, Storage, Supplier<Torrent>) - Constructor for class bt.processor.torrent.TorrentContext
 
TorrentContext(PieceSelector, Storage, Supplier<Torrent>) - Constructor for class bt.processor.torrent.TorrentContext
 
TorrentContextFinalizer<C extends TorrentContext> - Class in bt.processor.torrent
 
TorrentContextFinalizer(TorrentRegistry, EventSink) - Constructor for class bt.processor.torrent.TorrentContextFinalizer
 
TorrentDescriptor - Interface in bt.torrent
Provides an interface for controlling the state of a torrent processing session.
TorrentEvent - Interface in bt.event
Generic interface for events, that are specific to some torrent.
TorrentFile - Interface in bt.metainfo
Torrent file descriptor.
TorrentFileSelector - Class in bt.torrent.fileselector
Deprecated.
TorrentFileSelector() - Constructor for class bt.torrent.fileselector.TorrentFileSelector
Deprecated.
 
torrentId(TorrentId) - Static method in class bt.magnet.MagnetUri
Start building a magnet link for a given torrent.
TorrentId - Class in bt.metainfo
Object wrapper for binary torrent identifiers.
TorrentMaker - Class in bt.torrent.maker
A class which makes a torrent from the builder specification
TorrentMaker(TorrentBuilder) - Constructor for class bt.torrent.maker.TorrentMaker
Create a new torrent maker class with the specified torrent builder
TorrentProcessorFactory - Class in bt.processor
 
TorrentProcessorFactory(TorrentRegistry, DataWorker, IBufferedPieceRegistry, ITrackerService, ExecutorService, IPeerRegistry, IConnectionSource, IPeerConnectionPool, IMessageDispatcher, Set<Object>, IMetadataService, EventSource, EventSink, Config) - Constructor for class bt.processor.TorrentProcessorFactory
 
TorrentRegistry - Interface in bt.torrent
Registry of all torrents known to the current runtime.
TorrentSessionState - Interface in bt.torrent
Provides information about a particular torrent session.
TorrentSource - Interface in bt.metainfo
 
TorrentStartedEvent - Class in bt.event
Indicates, that processing of some torrent has begun.
TorrentStartedEvent(long, long, TorrentId) - Constructor for class bt.event.TorrentStartedEvent
 
TorrentStoppedEvent - Class in bt.event
Indicates, that processing of some torrent has finished.
TorrentStoppedEvent(long, long, TorrentId) - Constructor for class bt.event.TorrentStoppedEvent
 
TorrentWorker - Class in bt.torrent.messaging
Manages peer workers.
TorrentWorker(TorrentId, IMessageDispatcher, IConnectionSource, IPeerWorkerFactory, Supplier<LocalBitfield>, Supplier<Assignments>, Supplier<BitfieldBasedStatistics>, EventSource, Config) - Constructor for class bt.torrent.messaging.TorrentWorker
 
toSelectionResult() - Method in enum bt.torrent.fileselector.UpdatedFilePriority
 
toString() - Method in class bt.bencoding.model.rule.ExclusiveRule
 
toString() - Method in class bt.bencoding.model.rule.RequiredRule
 
toString() - Method in class bt.bencoding.types.BEInteger
 
toString() - Method in class bt.bencoding.types.BEList
 
toString() - Method in class bt.bencoding.types.BEMap
 
toString() - Method in class bt.bencoding.types.BEString
 
toString() - Method in class bt.data.file.FileSystemStorageUnit
 
toString() - Method in class bt.event.BaseEvent
 
toString() - Method in class bt.event.MetadataAvailableEvent
 
toString() - Method in class bt.event.PeerBitfieldUpdatedEvent
 
toString() - Method in class bt.event.PeerConnectedEvent
 
toString() - Method in class bt.event.PeerDisconnectedEvent
 
toString() - Method in class bt.event.PeerDiscoveredEvent
 
toString() - Method in class bt.event.PieceVerifiedEvent
 
toString() - Method in class bt.event.TorrentStartedEvent
 
toString() - Method in class bt.event.TorrentStoppedEvent
 
toString() - Method in class bt.magnet.UtMetadata
 
toString() - Method in class bt.metainfo.TorrentId
 
toString() - Method in class bt.net.buffer.DelegatingByteBufferView
 
toString() - Method in class bt.net.buffer.SplicedByteBufferView
 
toString() - Method in class bt.net.ConnectionKey
 
toString() - Method in class bt.net.InetPeer
 
toString() - Method in class bt.net.PeerId
 
toString() - Method in class bt.net.SocketPeerConnection
 
toString() - Method in class bt.peer.lan.Cookie
Write itself to the provided appendable entity.
toString() - Method in class bt.protocol.Bitfield
 
toString() - Method in class bt.protocol.Cancel
 
toString() - Method in class bt.protocol.Choke
 
toString() - Method in class bt.protocol.extended.ExtendedHandshake
 
toString() - Method in class bt.protocol.Handshake
 
toString() - Method in class bt.protocol.Have
 
toString() - Method in class bt.protocol.Interested
 
toString() - Method in class bt.protocol.KeepAlive
 
toString() - Method in class bt.protocol.NotInterested
 
toString() - Method in class bt.protocol.Piece
 
toString() - Method in class bt.protocol.Port
 
toString() - Method in class bt.protocol.Request
 
toString() - Method in class bt.protocol.Unchoke
 
toString() - Method in class bt.service.Version
 
toString() - Method in class bt.tracker.AnnounceKey
 
toString() - Method in class bt.tracker.http.HttpTracker
 
tracker(String) - Method in class bt.magnet.MagnetUri.Builder
Add "tr" parameter.
Tracker - Interface in bt.tracker
Generic tracker interface.
TrackerAnnouncer - Class in bt.torrent
 
TrackerAnnouncer(ITrackerService, Torrent, AnnounceKey, TorrentSessionState) - Constructor for class bt.torrent.TrackerAnnouncer
 
TrackerFactories - Annotation Type in bt.module
Annotates a collection of tracker factories for different protocols.
TrackerFactory - Interface in bt.tracker
Creates tracker clients.
TrackerQueryBuilder - Class in bt.tracker.http.urlencoding
A builder class to make a tracker query request with the correct encoding
TrackerQueryBuilder() - Constructor for class bt.tracker.http.urlencoding.TrackerQueryBuilder
 
TrackerRequestBuilder - Class in bt.tracker
Base class for tracker request builders.
TrackerRequestBuilder(TorrentId) - Constructor for class bt.tracker.TrackerRequestBuilder
Create a tracker request builder for a given torrent ID
TrackerResponse - Class in bt.tracker
Tracker response.
TrackerResponse() - Constructor for class bt.tracker.TrackerResponse
Create an empty success response.
TrackerResponse(String) - Constructor for class bt.tracker.TrackerResponse
Create a failure response with the provided message.
TrackerResponse(Throwable) - Constructor for class bt.tracker.TrackerResponse
Create an exceptional response with the provided exception.
TrackerService - Class in bt.tracker
Note that this class implements a service.
TrackerService(Map<String, TrackerFactory>) - Constructor for class bt.tracker.TrackerService
 
transferTo(ByteBuffer) - Method in interface bt.net.buffer.ByteBufferView
 
transferTo(FileChannel, long) - Method in interface bt.net.buffer.ByteBufferView
Transfer the contents of this byte buffer view to the file channel passed in.
transferTo(ByteBuffer) - Method in class bt.net.buffer.DelegatingByteBufferView
 
transferTo(FileChannel, long) - Method in class bt.net.buffer.DelegatingByteBufferView
 
transferTo(ByteBuffer) - Method in class bt.net.buffer.SplicedByteBufferView
 
transferTo(FileChannel, long) - Method in class bt.net.buffer.SplicedByteBufferView
 
triggerPeerCollection(TorrentId) - Method in interface bt.peer.IPeerRegistry
Trigger a collection of peers for the specified torrent.
triggerPeerCollection(TorrentId) - Method in class bt.peer.PeerRegistry
 

U

UdpTrackerFactory - Class in bt.tracker.udp
Creates UDP tracker clients.
UdpTrackerFactory(IdentityService, TorrentRegistry, Config) - Constructor for class bt.tracker.udp.UdpTrackerFactory
 
Unchoke - Class in bt.protocol
 
UNCHOKE_ID - Static variable in class bt.protocol.StandardBittorrentProtocol
 
UnchokeHandler - Class in bt.protocol.handler
 
UnchokeHandler() - Constructor for class bt.protocol.handler.UnchokeHandler
 
UniqueMessageHandler<T extends Message> - Class in bt.protocol.handler
 
UniqueMessageHandler(Class<T>) - Constructor for class bt.protocol.handler.UniqueMessageHandler
 
UNKNOWN - Static variable in interface bt.torrent.TorrentSessionState
The bytes returned when the data transfer is unknown
UNKNOWN_PORT - Static variable in class bt.net.InetPeer
 
unknownCookie() - Static method in class bt.peer.lan.Cookie
Cookie, that does not have a well-defined value.
unlock() - Method in interface bt.net.buffer.BorrowedBuffer
Unlock the buffer, thus allowing to BorrowedBuffer.release() it.
unregister() - Method in interface bt.net.pipeline.ChannelHandler
 
unregister() - Method in class bt.net.pipeline.SocketChannelHandler
 
unregisterChannel(SelectableChannel) - Method in interface bt.net.DataReceiver
 
unregisterChannel(SelectableChannel) - Method in class bt.net.DataReceivingLoop
 
unregisterMessagingAgent(Object) - Method in class bt.torrent.messaging.DefaultMessageRouter
 
unregisterMessagingAgent(Object) - Method in interface bt.torrent.messaging.MessageRouter
Remove a messaging agent, if it's registered in this message router.
update() - Method in interface bt.peer.PeerSource
Ask to update the list of peers (usually from an external source).
update() - Method in class bt.peer.ScheduledPeerSource
 
update(Set<ConnectionKey>, Set<ConnectionKey>) - Method in class bt.torrent.messaging.Assignments
 
UpdatedFilePriority - Enum in bt.torrent.fileselector
The possible statuses to update a file with while a torrent download is running.
updateFileDownloadPriority(ProcessingContext, FilePrioritySelector) - Method in class bt.torrent.DefaultTorrentSessionState
 
updateFileDownloadPriority(ProcessingContext, FilePrioritySelector) - Method in interface bt.torrent.TorrentSessionState
Update the priority of downloading specified files
updateFilePriorities(FilePrioritySelector) - Method in interface bt.runtime.BtClient
Update the priorities of the files to downloaded with the specified file priority selector.
UpnpPortMapper - Class in bt.portmapping.upnp
Maps network port on gateway device using UPNP service.
UpnpPortMapper(UpnpPortMappingServicesRegistrar) - Constructor for class bt.portmapping.upnp.UpnpPortMapper
 
UpnpPortMapperModule - Class in bt.portmapping.upnp
 
UpnpPortMapperModule() - Constructor for class bt.portmapping.upnp.UpnpPortMapperModule
 
UpnpPortMapperModuleProvider - Class in bt.portmapping.upnp
 
UpnpPortMapperModuleProvider() - Constructor for class bt.portmapping.upnp.UpnpPortMapperModuleProvider
 
UpnpPortMappingServicesRegistrar - Class in bt.portmapping.upnp
Creates UPNP service, and binds its lifecycle to the app's one.
UpnpPortMappingServicesRegistrar(IRuntimeLifecycleBinder, UpnpServiceConfiguration) - Constructor for class bt.portmapping.upnp.UpnpPortMappingServicesRegistrar
 
UtMetadata - Class in bt.magnet
BEP-9 extension message.
UtMetadata.Type - Enum in bt.magnet
 
UtMetadataMessageHandler - Class in bt.magnet
 
UtMetadataMessageHandler() - Constructor for class bt.magnet.UtMetadataMessageHandler
 

V

validate(Object) - Method in interface bt.bencoding.model.BEObjectModel
Validate a given object.
validate(Object) - Method in class bt.bencoding.model.rule.ExclusiveRule
 
validate(Object) - Method in class bt.bencoding.model.rule.RequiredRule
 
validate(Object) - Method in interface bt.bencoding.model.rule.Rule
Validate a given object.
validatePieceIndex(int) - Method in class bt.data.Bitfield
 
ValidatingSelector - Class in bt.torrent.selector
Decorator that applies a filter to the selector stream.
ValidatingSelector(LocalBitfield, BitSet, PieceSelector) - Constructor for class bt.torrent.selector.ValidatingSelector
Creates a filtering selector.
ValidationResult - Class in bt.bencoding.model
 
valueOf(String) - Static method in enum bt.bencoding.BEType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.magnet.UtMetadata.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.net.portmapping.PortMapProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.processor.listener.ProcessingEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.protocol.BitOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.protocol.crypto.EncryptionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.service.IRuntimeLifecycleBinder.LifecycleEvent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.torrent.fileselector.FilePriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.torrent.fileselector.UpdatedFilePriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.tracker.CompactPeerInfo.AddressType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum bt.tracker.http.HttpTracker.TrackerRequestType
Returns the enum constant of this type with the specified name.
values() - Static method in enum bt.bencoding.BEType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.magnet.UtMetadata.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.net.portmapping.PortMapProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.processor.listener.ProcessingEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.protocol.BitOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.protocol.crypto.EncryptionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.service.IRuntimeLifecycleBinder.LifecycleEvent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.torrent.fileselector.FilePriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.torrent.fileselector.UpdatedFilePriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.tracker.CompactPeerInfo.AddressType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum bt.tracker.http.HttpTracker.TrackerRequestType
Returns an array containing the constants of this enum type, in the order they are declared.
verify(List<ChunkDescriptor>, LocalBitfield) - Method in interface bt.data.ChunkVerifier
Conducts verification of the provided list of chunks and updates bitfield with the results.
verify(ChunkDescriptor) - Method in interface bt.data.ChunkVerifier
Conducts verification of the provided chunk.
verify(List<ChunkDescriptor>, LocalBitfield) - Method in class bt.data.DefaultChunkVerifier
 
verify(ChunkDescriptor) - Method in class bt.data.DefaultChunkVerifier
 
verifyIfPresent(ChunkDescriptor) - Method in interface bt.data.ChunkVerifier
 
verifyIfPresent(ChunkDescriptor) - Method in class bt.data.DefaultChunkVerifier
 
verifyPayloadHasLength(Class<? extends Message>, int, int) - Static method in class bt.protocol.Protocols
Convenience method to check if actual message length is the same as expected length.
Version - Class in bt.service
Application version info.
Version(int, int, boolean) - Constructor for class bt.service.Version
 
VERSION_PROPERTY - Static variable in class bt.protocol.extended.ExtendedHandshake
 
VersionAwareIdentityService - Class in bt.service
Note that this class implements a service.
VersionAwareIdentityService(ApplicationService) - Constructor for class bt.service.VersionAwareIdentityService
 
visitBindings(IRuntimeLifecycleBinder.LifecycleEvent, Consumer<LifecycleBinding>) - Method in interface bt.service.IRuntimeLifecycleBinder
Visitor interface for inspecting all registered hooks for a particular lifecycle event.
visitBindings(IRuntimeLifecycleBinder.LifecycleEvent, Consumer<LifecycleBinding>) - Method in class bt.service.RuntimeLifecycleBinder
 
visitConnections(TorrentId, Consumer<PeerConnection>) - Method in interface bt.net.IPeerConnectionPool
Visit connections for a given torrent ID.
visitConnections(TorrentId, Consumer<PeerConnection>) - Method in class bt.net.PeerConnectionPool
 
visitConsumer(Class<T>, MethodHandle) - Method in interface bt.torrent.compiler.CompilerVisitor
Visit a message consumer method.
visitMappings(BiConsumer<String, Integer>) - Method in class bt.protocol.extended.AlphaSortedMapping
 
visitMappings(BiConsumer<String, Integer>) - Method in interface bt.protocol.extended.ExtendedMessageTypeMapping
Visitor interface for all mappings, contained in this set.
visitProducer(MethodHandle) - Method in interface bt.torrent.compiler.CompilerVisitor
Visit a message producer method.
visitUnit(StorageUnit, long, long) - Method in interface bt.data.DataRangeVisitor
Visit (a part of) a file in a range of files
visitUnits(DataRangeVisitor) - Method in interface bt.data.DataRange
Traverse the storage units in this data range.
visitUnits(DataRangeVisitor) - Method in class bt.data.range.DelegatingDataRange
 
visitUnits(DataRangeVisitor) - Method in class bt.data.range.SynchronizedDataRange
 

W

waitBetweenReads(Duration) - Method in class bt.net.ByteChannelReader
 
waitForAllPieces() - Method in interface bt.data.DataDescriptor
Wait for all of the pieces of the torrent to download
waitForAllPieces() - Method in class bt.data.LocalBitfield
 
waitForTorrent() - Method in class bt.torrent.messaging.MetadataConsumer
 
wakeup() - Method in class bt.net.SharedSelector
 
wakeupAndRegister(SelectableChannel, int, Object) - Method in class bt.net.SharedSelector
Atomically wakeup and register the provided channel.
withEncryptionPolicy(EncryptionPolicy) - Method in class bt.peer.PeerOptions
 
withTimeout(Duration) - Method in class bt.net.ByteChannelReader
 
write(ByteBuffer) - Method in class bt.net.crypto.EncryptedChannel
 
writeBlock(ByteBuffer, long) - Method in class bt.data.file.FileSystemStorageUnit
 
writeBlock(ByteBufferView, long) - Method in class bt.data.file.FileSystemStorageUnit
 
writeBlock(FileCacheKey, ByteBuffer, long) - Method in class bt.data.file.OpenFileCache
Write a block to the provided file cache key
writeBlock(FileCacheKey, ByteBufferView, long) - Method in class bt.data.file.OpenFileCache
Write a block to the provided file cache key
writeBlock(ByteBuffer, long) - Method in interface bt.data.StorageUnit
Try to write a block of data from the provided buffer to this storage, starting with a given offset.
writeBlock(ByteBufferView, long) - Method in interface bt.data.StorageUnit
Try to write a block of data from the provided buffer to this storage, starting with a given offset.
writeBlock(byte[], long) - Method in interface bt.data.StorageUnit
Try to write a block of data to this storage, starting with a given offset.
writeBlockFully(ByteBuffer, long) - Method in class bt.data.file.FileSystemStorageUnit
 
writeBlockFully(ByteBufferView, long) - Method in class bt.data.file.FileSystemStorageUnit
 
writeBlockFully(FileCacheKey, ByteBuffer, long) - Method in class bt.data.file.OpenFileCache
Fully write a block from the provided file cache key
writeBlockFully(FileCacheKey, ByteBufferView, long) - Method in class bt.data.file.OpenFileCache
Fully write a block from the provided file cache key
writeBlockFully(ByteBuffer, long) - Method in interface bt.data.StorageUnit
 
writeBlockFully(ByteBufferView, long) - Method in interface bt.data.StorageUnit
 
writeBlockTo(ByteBuffer) - Method in class bt.protocol.Piece
 
writeTo(OutputStream) - Method in interface bt.bencoding.model.BEObject
Write this object's contents to the provided stream (excluding type prefix and terminator).
writeTo(OutputStream) - Method in class bt.bencoding.types.BEInteger
 
writeTo(OutputStream) - Method in class bt.bencoding.types.BEList
 
writeTo(OutputStream) - Method in class bt.bencoding.types.BEMap
 
writeTo(OutputStream) - Method in class bt.bencoding.types.BEString
 
writeTo(OutputStream) - Method in interface bt.tracker.SecretKey
Writes the secret key into the provided output stream.

Y

YamlBEObjectModelLoader - Class in bt.bencoding.model
Loads model definitions from YAML documents.
YamlBEObjectModelLoader() - Constructor for class bt.bencoding.model.YamlBEObjectModelLoader
 
A B C D E F G H I J K L M N O P Q R S T U V W Y 

Copyright © 2016–2021. All rights reserved.