All Downloads are FREE. Search and download functionalities are using the official Maven repository.
Search JAR files by class name

Download bt-core JAR 1.10 with all dependencies


BitTorrent Client Library (Core)

Files of the artifact bt-core version 1.10 from the group com.github.atomashpolskiy.

Artifact bt-core
Group com.github.atomashpolskiy
Version 1.10
Last update 05. December 2021
Tags: client library core bittorrent
Organization not specified
URL Not specified
License not specified
Dependencies amount 3
Dependencies bt-bencoding, slf4j-api, guice,
There are maybe transitive dependencies!
The newest version!
Show more of this group  Show more artifacts with this name
Show all versions of bt-core Show documentation

Please rate this JAR file. Is it a good library?

bt-core
Rate from 1 - 5, Rated 1.00 based on 1 reviews

10 downloads

Source code of bt-core version 1.10

META-INF
META-INF.META-INF.MANIFEST.MF
META-INF.maven.com.github.atomashpolskiy.bt-core
META-INF.maven.com.github.atomashpolskiy.bt-core.META-INF.maven.com.github.atomashpolskiy.bt-core.pom.properties
META-INF.maven.com.github.atomashpolskiy.bt-core.META-INF.maven.com.github.atomashpolskiy.bt-core.pom.xml
bt
bt.bt.BaseClientBuilder
bt.bt.Bt
bt.bt.BtClientBuilder
bt.bt.BtException
bt.bt.BufferingMap
bt.bt.CountingThreadFactory
bt.bt.DefaultClient
bt.bt.LazyClient
bt.bt.StandaloneClientBuilder
bt.bt.TorrentClientBuilder
bt.data
bt.data.bt.data.Bitfield
bt.data.bt.data.BlockSet
bt.data.bt.data.ChunkDescriptor
bt.data.bt.data.ChunkVerifier
bt.data.bt.data.CompletableTorrentFile
bt.data.bt.data.DataDescriptor
bt.data.bt.data.DataDescriptorFactory
bt.data.bt.data.DataRange
bt.data.bt.data.DataRangeVisitor
bt.data.bt.data.DataReader
bt.data.bt.data.DataReaderChannel
bt.data.bt.data.DataReaderFactory
bt.data.bt.data.DefaultChunkDescriptor
bt.data.bt.data.DefaultChunkVerifier
bt.data.bt.data.DefaultDataDescriptor
bt.data.bt.data.IDataDescriptorFactory
bt.data.bt.data.LocalBitfield
bt.data.bt.data.PeerBitfield
bt.data.bt.data.PieceUtils
bt.data.bt.data.ReadWriteDataRange
bt.data.bt.data.Storage
bt.data.bt.data.StorageUnit
bt.data.digest
bt.data.digest.bt.data.digest.Digester
bt.data.digest.bt.data.digest.JavaSecurityDigester
bt.data.digest.bt.data.digest.SHA1Digester
bt.data.digest.bt.data.digest.SoftThreadLocal
bt.data.file
bt.data.file.bt.data.file.CachedOpenFile
bt.data.file.bt.data.file.FileCacheKey
bt.data.file.bt.data.file.FileSystemStorage
bt.data.file.bt.data.file.FileSystemStorageUnit
bt.data.file.bt.data.file.OpenFileCache
bt.data.file.bt.data.file.PathNormalizer
bt.data.range
bt.data.range.bt.data.range.BlockRange
bt.data.range.bt.data.range.ByteRange
bt.data.range.bt.data.range.DelegatingDataRange
bt.data.range.bt.data.range.DelegatingRange
bt.data.range.bt.data.range.MutableBlockSet
bt.data.range.bt.data.range.Range
bt.data.range.bt.data.range.Ranges
bt.data.range.bt.data.range.SynchronizedBlockSet
bt.data.range.bt.data.range.SynchronizedDataRange
bt.data.range.bt.data.range.SynchronizedRange
bt.event
bt.event.bt.event.BaseEvent
bt.event.bt.event.Event
bt.event.bt.event.EventBus
bt.event.bt.event.EventSink
bt.event.bt.event.EventSource
bt.event.bt.event.MetadataAvailableEvent
bt.event.bt.event.PeerBitfieldUpdatedEvent
bt.event.bt.event.PeerConnectedEvent
bt.event.bt.event.PeerDisconnectedEvent
bt.event.bt.event.PeerDiscoveredEvent
bt.event.bt.event.PieceVerifiedEvent
bt.event.bt.event.TorrentEvent
bt.event.bt.event.TorrentStartedEvent
bt.event.bt.event.TorrentStoppedEvent
bt.magnet
bt.magnet.bt.magnet.MagnetUri
bt.magnet.bt.magnet.MagnetUriParser
bt.magnet.bt.magnet.UtMetadata
bt.magnet.bt.magnet.UtMetadataMessageHandler
bt.metainfo
bt.metainfo.bt.metainfo.DefaultTorrent
bt.metainfo.bt.metainfo.DefaultTorrentFile
bt.metainfo.bt.metainfo.IMetadataService
bt.metainfo.bt.metainfo.MetadataConstants
bt.metainfo.bt.metainfo.MetadataService
bt.metainfo.bt.metainfo.Torrent
bt.metainfo.bt.metainfo.TorrentFile
bt.metainfo.bt.metainfo.TorrentId
bt.metainfo.bt.metainfo.TorrentSource
bt.module
bt.module.bt.module.BitTorrentProtocol
bt.module.bt.module.BtModuleProvider
bt.module.bt.module.ClientExecutor
bt.module.bt.module.Contribute
bt.module.bt.module.ExtendedMessageHandlers
bt.module.bt.module.MessageHandlers
bt.module.bt.module.MessagingAgents
bt.module.bt.module.PeerConnectionSelector
bt.module.bt.module.ProtocolModule
bt.module.bt.module.ProtocolModuleExtender
bt.module.bt.module.ServiceModule
bt.module.bt.module.ServiceModuleExtender
bt.module.bt.module.TrackerFactories
bt.net
bt.net.bt.net.BigIntegers
bt.net.bt.net.BitfieldConnectionHandler
bt.net.bt.net.ByteChannelReader
bt.net.bt.net.ConnectionHandler
bt.net.bt.net.ConnectionHandlerFactory
bt.net.bt.net.ConnectionKey
bt.net.bt.net.ConnectionResult
bt.net.bt.net.ConnectionRoutine
bt.net.bt.net.ConnectionSource
bt.net.bt.net.DataReceiver
bt.net.bt.net.DataReceivingLoop
bt.net.bt.net.HandshakeHandler
bt.net.bt.net.IConnectionHandlerFactory
bt.net.bt.net.IConnectionSource
bt.net.bt.net.IMessageDispatcher
bt.net.bt.net.IPeerConnectionFactory
bt.net.bt.net.IPeerConnectionPool
bt.net.bt.net.IncomingConnectionListener
bt.net.bt.net.IncomingHandshakeHandler
bt.net.bt.net.InetPeer
bt.net.bt.net.InetPeerAddress
bt.net.bt.net.InternetProtocolUtils
bt.net.bt.net.MessageDispatcher
bt.net.bt.net.OutgoingHandshakeHandler
bt.net.bt.net.Peer
bt.net.bt.net.PeerConnection
bt.net.bt.net.PeerConnectionAcceptor
bt.net.bt.net.PeerConnectionFactory
bt.net.bt.net.PeerConnectionPool
bt.net.bt.net.PeerId
bt.net.bt.net.SharedSelector
bt.net.bt.net.SocketChannelConnectionAcceptor
bt.net.bt.net.SocketPeerConnection
bt.net.bt.net.WriteOnlyPeerConnection
bt.net.buffer
bt.net.buffer.bt.net.buffer.BorrowedBuffer
bt.net.buffer.bt.net.buffer.BufferManager
bt.net.buffer.bt.net.buffer.BufferMutator
bt.net.buffer.bt.net.buffer.BufferedData
bt.net.buffer.bt.net.buffer.Buffers
bt.net.buffer.bt.net.buffer.ByteBufferView
bt.net.buffer.bt.net.buffer.DelegatingByteBufferView
bt.net.buffer.bt.net.buffer.IBufferManager
bt.net.buffer.bt.net.buffer.SplicedByteBufferView
bt.net.crypto
bt.net.crypto.bt.net.crypto.CipherBufferMutator
bt.net.crypto.bt.net.crypto.EncryptedChannel
bt.net.crypto.bt.net.crypto.MSEHandshakeProcessor
bt.net.crypto.bt.net.crypto.MSEKeyPairGenerator
bt.net.extended
bt.net.extended.bt.net.extended.ExtendedHandshakeConsumer
bt.net.extended.bt.net.extended.ExtendedProtocolHandshakeHandler
bt.net.pipeline
bt.net.pipeline.bt.net.pipeline.BufferedPieceRegistry
bt.net.pipeline.bt.net.pipeline.ChannelHandler
bt.net.pipeline.bt.net.pipeline.ChannelHandlerContext
bt.net.pipeline.bt.net.pipeline.ChannelPipeline
bt.net.pipeline.bt.net.pipeline.ChannelPipelineBuilder
bt.net.pipeline.bt.net.pipeline.ChannelPipelineFactory
bt.net.pipeline.bt.net.pipeline.DefaultChannelPipeline
bt.net.pipeline.bt.net.pipeline.IBufferedPieceRegistry
bt.net.pipeline.bt.net.pipeline.IChannelPipelineFactory
bt.net.pipeline.bt.net.pipeline.InboundMessageProcessor
bt.net.pipeline.bt.net.pipeline.MessageDeserializer
bt.net.pipeline.bt.net.pipeline.MessageSerializer
bt.net.pipeline.bt.net.pipeline.SocketChannelHandler
bt.net.portmapping
bt.net.portmapping.bt.net.portmapping.PortMapProtocol
bt.net.portmapping.bt.net.portmapping.PortMapper
bt.net.portmapping.impl
bt.net.portmapping.impl.bt.net.portmapping.impl.NoOpPortMapper
bt.net.portmapping.impl.bt.net.portmapping.impl.PortMappingInitializer
bt.net.portmapping.impl.bt.net.portmapping.impl.PortMappingModule
bt.peer
bt.peer.bt.peer.IPeerRegistry
bt.peer.bt.peer.PeerOptions
bt.peer.bt.peer.PeerRegistry
bt.peer.bt.peer.PeerSource
bt.peer.bt.peer.PeerSourceFactory
bt.peer.bt.peer.ScheduledPeerSource
bt.peer.bt.peer.TrackerPeerSource
bt.peer.bt.peer.TrackerPeerSourceFactory
bt.peer.lan
bt.peer.lan.bt.peer.lan.AnnounceGroup
bt.peer.lan.bt.peer.lan.AnnounceGroupChannel
bt.peer.lan.bt.peer.lan.AnnounceMessage
bt.peer.lan.bt.peer.lan.Cookie
bt.peer.lan.bt.peer.lan.ILocalServiceDiscoveryInfo
bt.peer.lan.bt.peer.lan.ILocalServiceDiscoveryService
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryAnnouncer
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryConfig
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryInfo
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryModule
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryPeerSourceFactory
bt.peer.lan.bt.peer.lan.LocalServiceDiscoveryService
bt.peerexchange
bt.peerexchange.bt.peerexchange.PeerEvent
bt.peerexchange.bt.peerexchange.PeerExchange
bt.peerexchange.bt.peerexchange.PeerExchangeConfig
bt.peerexchange.bt.peerexchange.PeerExchangeMessageHandler
bt.peerexchange.bt.peerexchange.PeerExchangeModule
bt.peerexchange.bt.peerexchange.PeerExchangePeerSource
bt.peerexchange.bt.peerexchange.PeerExchangePeerSourceFactory
bt.processor
bt.processor.bt.processor.ChainProcessor
bt.processor.bt.processor.ContextFinalizer
bt.processor.bt.processor.ProcessingContext
bt.processor.bt.processor.ProcessingStage
bt.processor.bt.processor.Processor
bt.processor.bt.processor.ProcessorFactory
bt.processor.bt.processor.RoutingProcessingStage
bt.processor.bt.processor.TerminateOnErrorProcessingStage
bt.processor.bt.processor.TorrentProcessorFactory
bt.processor.listener
bt.processor.listener.bt.processor.listener.ListenerSource
bt.processor.listener.bt.processor.listener.ProcessingEvent
bt.processor.magnet
bt.processor.magnet.bt.processor.magnet.FetchMetadataStage
bt.processor.magnet.bt.processor.magnet.InitializeMagnetTorrentProcessingStage
bt.processor.magnet.bt.processor.magnet.MagnetContext
bt.processor.magnet.bt.processor.magnet.ProcessMagnetTorrentStage
bt.processor.torrent
bt.processor.torrent.bt.processor.torrent.ChooseFilesStage
bt.processor.torrent.bt.processor.torrent.CreateSessionStage
bt.processor.torrent.bt.processor.torrent.FetchTorrentStage
bt.processor.torrent.bt.processor.torrent.FilePiecePriorityMapper
bt.processor.torrent.bt.processor.torrent.InitializeTorrentProcessingStage
bt.processor.torrent.bt.processor.torrent.ProcessTorrentStage
bt.processor.torrent.bt.processor.torrent.SeedStage
bt.processor.torrent.bt.processor.torrent.TorrentContext
bt.processor.torrent.bt.processor.torrent.TorrentContextFinalizer
bt.protocol
bt.protocol.bt.protocol.BitOrder
bt.protocol.bt.protocol.Bitfield
bt.protocol.bt.protocol.Cancel
bt.protocol.bt.protocol.Choke
bt.protocol.bt.protocol.DecodingContext
bt.protocol.bt.protocol.EncodingContext
bt.protocol.bt.protocol.Handshake
bt.protocol.bt.protocol.HandshakeFactory
bt.protocol.bt.protocol.Have
bt.protocol.bt.protocol.IExtendedHandshakeFactory
bt.protocol.bt.protocol.IHandshakeFactory
bt.protocol.bt.protocol.Interested
bt.protocol.bt.protocol.InvalidMessageException
bt.protocol.bt.protocol.KeepAlive
bt.protocol.bt.protocol.Message
bt.protocol.bt.protocol.NotInterested
bt.protocol.bt.protocol.Piece
bt.protocol.bt.protocol.Protocol
bt.protocol.bt.protocol.Protocols
bt.protocol.bt.protocol.Request
bt.protocol.bt.protocol.StandardBittorrentProtocol
bt.protocol.bt.protocol.Unchoke
bt.protocol.crypto
bt.protocol.crypto.bt.protocol.crypto.EncryptionPolicy
bt.protocol.crypto.bt.protocol.crypto.MSECipher
bt.protocol.extended
bt.protocol.extended.bt.protocol.extended.AlphaSortedMapping
bt.protocol.extended.bt.protocol.extended.ExtendedHandshake
bt.protocol.extended.bt.protocol.extended.ExtendedHandshakeFactory
bt.protocol.extended.bt.protocol.extended.ExtendedHandshakeMessageHandler
bt.protocol.extended.bt.protocol.extended.ExtendedMessage
bt.protocol.extended.bt.protocol.extended.ExtendedMessageTypeMapping
bt.protocol.extended.bt.protocol.extended.ExtendedProtocol
bt.protocol.handler
bt.protocol.handler.bt.protocol.handler.BaseMessageHandler
bt.protocol.handler.bt.protocol.handler.BitfieldHandler
bt.protocol.handler.bt.protocol.handler.CancelHandler
bt.protocol.handler.bt.protocol.handler.ChokeHandler
bt.protocol.handler.bt.protocol.handler.HaveHandler
bt.protocol.handler.bt.protocol.handler.InterestedHandler
bt.protocol.handler.bt.protocol.handler.MessageHandler
bt.protocol.handler.bt.protocol.handler.NotInterestedHandler
bt.protocol.handler.bt.protocol.handler.PieceHandler
bt.protocol.handler.bt.protocol.handler.RequestHandler
bt.protocol.handler.bt.protocol.handler.UnchokeHandler
bt.protocol.handler.bt.protocol.handler.UniqueMessageHandler
bt.runtime
bt.runtime.bt.runtime.BtClient
bt.runtime.bt.runtime.BtRuntime
bt.runtime.bt.runtime.BtRuntimeBuilder
bt.runtime.bt.runtime.Config
bt.service
bt.service.bt.service.ApplicationService
bt.service.bt.service.ClasspathApplicationService
bt.service.bt.service.CryptoUtil
bt.service.bt.service.ExecutorServiceProvider
bt.service.bt.service.IRuntimeLifecycleBinder
bt.service.bt.service.IdentityService
bt.service.bt.service.LifecycleBinding
bt.service.bt.service.NetworkUtil
bt.service.bt.service.RuntimeLifecycleBinder
bt.service.bt.service.Version
bt.service.bt.service.VersionAwareIdentityService
bt.torrent
bt.torrent.bt.torrent.AdhocTorrentRegistry
bt.torrent.bt.torrent.BitfieldBasedStatistics
bt.torrent.bt.torrent.DefaultTorrentDescriptor
bt.torrent.bt.torrent.DefaultTorrentSessionState
bt.torrent.bt.torrent.PieceStatistics
bt.torrent.bt.torrent.TorrentDescriptor
bt.torrent.bt.torrent.TorrentRegistry
bt.torrent.bt.torrent.TorrentSessionState
bt.torrent.bt.torrent.TrackerAnnouncer
bt.torrent.annotation
bt.torrent.annotation.bt.torrent.annotation.Consumes
bt.torrent.annotation.bt.torrent.annotation.Produces
bt.torrent.callbacks
bt.torrent.callbacks.bt.torrent.callbacks.FileDownloadCompleteCallback
bt.torrent.compiler
bt.torrent.compiler.bt.torrent.compiler.CompilerVisitor
bt.torrent.compiler.bt.torrent.compiler.ConsumerInfo
bt.torrent.compiler.bt.torrent.compiler.MessagingAgentCompiler
bt.torrent.compiler.bt.torrent.compiler.ProducerInfo
bt.torrent.data
bt.torrent.data.bt.torrent.data.BlockCache
bt.torrent.data.bt.torrent.data.BlockRead
bt.torrent.data.bt.torrent.data.BlockReader
bt.torrent.data.bt.torrent.data.BlockWrite
bt.torrent.data.bt.torrent.data.DataWorker
bt.torrent.data.bt.torrent.data.DefaultDataWorker
bt.torrent.data.bt.torrent.data.LRUBlockCache
bt.torrent.data.bt.torrent.data.NoCache
bt.torrent.fileselector
bt.torrent.fileselector.bt.torrent.fileselector.FilePriority
bt.torrent.fileselector.bt.torrent.fileselector.FilePrioritySelector
bt.torrent.fileselector.bt.torrent.fileselector.FilePrioritySkipSelector
bt.torrent.fileselector.bt.torrent.fileselector.SelectionResult
bt.torrent.fileselector.bt.torrent.fileselector.TorrentFileSelector
bt.torrent.fileselector.bt.torrent.fileselector.UpdatedFilePriority
bt.torrent.maker
bt.torrent.maker.bt.torrent.maker.TorrentBuilder
bt.torrent.maker.bt.torrent.maker.TorrentMaker
bt.torrent.messaging
bt.torrent.messaging.bt.torrent.messaging.Assignment
bt.torrent.messaging.bt.torrent.messaging.Assignments
bt.torrent.messaging.bt.torrent.messaging.BitfieldCollectingConsumer
bt.torrent.messaging.bt.torrent.messaging.BitfieldConsumer
bt.torrent.messaging.bt.torrent.messaging.Choker
bt.torrent.messaging.bt.torrent.messaging.ConnectionState
bt.torrent.messaging.bt.torrent.messaging.DefaultMessageRouter
bt.torrent.messaging.bt.torrent.messaging.ExchangedMetadata
bt.torrent.messaging.bt.torrent.messaging.GenericConsumer
bt.torrent.messaging.bt.torrent.messaging.IPeerWorkerFactory
bt.torrent.messaging.bt.torrent.messaging.Mapper
bt.torrent.messaging.bt.torrent.messaging.MessageConsumer
bt.torrent.messaging.bt.torrent.messaging.MessageContext
bt.torrent.messaging.bt.torrent.messaging.MessageProducer
bt.torrent.messaging.bt.torrent.messaging.MessageRouter
bt.torrent.messaging.bt.torrent.messaging.MetadataConsumer
bt.torrent.messaging.bt.torrent.messaging.MetadataProducer
bt.torrent.messaging.bt.torrent.messaging.PeerRequestConsumer
bt.torrent.messaging.bt.torrent.messaging.PeerWorker
bt.torrent.messaging.bt.torrent.messaging.PeerWorkerFactory
bt.torrent.messaging.bt.torrent.messaging.PieceConsumer
bt.torrent.messaging.bt.torrent.messaging.RequestProducer
bt.torrent.messaging.bt.torrent.messaging.RoutingPeerWorker
bt.torrent.messaging.bt.torrent.messaging.TorrentWorker
bt.torrent.selector
bt.torrent.selector.bt.torrent.selector.IncompletePiecesValidator
bt.torrent.selector.bt.torrent.selector.PackedIntComparator
bt.torrent.selector.bt.torrent.selector.PieceSelector
bt.torrent.selector.bt.torrent.selector.PrioritizedPieceSelector
bt.torrent.selector.bt.torrent.selector.RandomizedRarestFirstSelector
bt.torrent.selector.bt.torrent.selector.RarestFirstSelector
bt.torrent.selector.bt.torrent.selector.SequentialSelector
bt.torrent.selector.bt.torrent.selector.ShuffleUtils
bt.torrent.selector.bt.torrent.selector.ValidatingSelector
bt.tracker
bt.tracker.bt.tracker.AnnounceKey
bt.tracker.bt.tracker.CompactPeerInfo
bt.tracker.bt.tracker.ITrackerService
bt.tracker.bt.tracker.MultiTracker
bt.tracker.bt.tracker.SecretKey
bt.tracker.bt.tracker.Tracker
bt.tracker.bt.tracker.TrackerFactory
bt.tracker.bt.tracker.TrackerRequestBuilder
bt.tracker.bt.tracker.TrackerResponse
bt.tracker.bt.tracker.TrackerService
bt.tracker.udp
bt.tracker.udp.bt.tracker.udp.AnnounceRequest
bt.tracker.udp.bt.tracker.udp.AnnounceResponseHandler
bt.tracker.udp.bt.tracker.udp.ConnectRequest
bt.tracker.udp.bt.tracker.udp.ConnectResponseHandler
bt.tracker.udp.bt.tracker.udp.Session
bt.tracker.udp.bt.tracker.udp.UdpMessageWorker
bt.tracker.udp.bt.tracker.udp.UdpTracker
bt.tracker.udp.bt.tracker.udp.UdpTrackerFactory
bt.tracker.udp.bt.tracker.udp.UdpTrackerMessage
bt.tracker.udp.bt.tracker.udp.UdpTrackerResponseHandler
.infodict.yml
.metainfo.yml
.tracker_response.yml




© 2015 - 2024 Weber Informatics LLC | Privacy Policy