Binary compatibility report for the libtorrent (Rasterbar) library  between 0.14.12 and 0.15.0 versions on x86

Test Info


Library Namelibtorrent (Rasterbar)
Version #10.14.12
Version #20.15.0
CPU Architecturex86
GCC Version4.5

Test Results


Total Header Files1
Total Shared Libraries1
Total Symbols / Types484 / 295
VerdictIncompatible
(39.46%)

Problem Summary


SeverityCount
Added Symbols-224
Removed SymbolsHigh55
Problems with
Data Types
High18
Medium36
Low99
Problems with
Symbols
High31
Medium2
Low0
Problems with
Constants
Low0

Added Symbols (224)


alert.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
alert_manager::alert_manager [in-charge] io_service& ios )
alert_manager::alert_manager [not-in-charge] io_service& ios )
alert_manager::set_dispatch_function boost::function<void(alert const&)>const& p1 )

allocator.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
page_aligned_allocator::free char*const block ) [static]
page_aligned_allocator::malloc page_aligned_allocator::size_type const bytes ) [static]
page_size ( )

disk_buffer_holder.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
disk_buffer_holder::disk_buffer_holder [in-charge] ( disk_buffer_pool& disk_pool, char* buf )
disk_buffer_holder::disk_buffer_holder [in-charge] ( disk_buffer_pool& disk_pool, char* buf, int num_blocks )
disk_buffer_holder::disk_buffer_holder [not-in-charge] ( disk_buffer_pool& disk_pool, char* buf )
disk_buffer_holder::disk_buffer_holder [not-in-charge] ( disk_buffer_pool& disk_pool, char* buf, int num_blocks )
disk_buffer_holder::reset char* buf, int num_blocks )

disk_io_thread.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
disk_buffer_pool::allocate_buffer char const* category )
disk_buffer_pool::allocate_buffers int blocks, char const* category )
disk_buffer_pool::disk_buffer_pool [in-charge] int block_size )
disk_buffer_pool::disk_buffer_pool [not-in-charge] int block_size )
disk_buffer_pool::free_buffer char* buf )
disk_buffer_pool::free_buffers char* buf, int blocks )
disk_buffer_pool::release_memory ( )
disk_io_thread::disk_io_thread [in-charge] ( io_service& ios, boost::function<void()>const& queue_callback, file_pool& fp, int block_size )
disk_io_thread::disk_io_thread [not-in-charge] ( io_service& ios, boost::function<void()>const& queue_callback, file_pool& fp, int block_size )
disk_io_thread::queue_buffer_size ( ) const
is_read_operation disk_io_job const& j )
operation_has_buffer disk_io_job const& j )

entry.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
entry::operator= lazy_entry const& p1 )

error_code.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
libtorrent_exception::what ( ) const
libtorrent_exception::~libtorrent_exception [in-charge-deleting] ( )
libtorrent_exception::~libtorrent_exception [in-charge] ( )

escape_string.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
convert_to_native std::string const& s )
from_hex char const* in, int len, char* out )
is_hex char const* in, int len )
is_print char c )
is_space char c )
maybe_url_encode std::string const& url )
need_encoding char const* str, int len )
read_until ( char const*& str, char delim, char const* end )
string_begins_no_case char const* s1, char const* s2 )
string_equal_no_case char const* s1, char const* s2 )
to_hex char const* in, int len, char* out )
to_lower char c )
unescape_string ( std::string const& s, boost::system::error_code& ec )

file.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
file::buf_alignment ( ) const
file::get_size boost::system::error_code& ec ) const
file::phys_offset size_type offset )
file::pos_alignment ( ) const
file::readv ( size_type file_offset, file::iovec_t const* bufs, int num_bufs, boost::system::error_code& ec )
file::size_alignment ( ) const
file::sparse_end size_type start ) const
file::writev ( size_type file_offset, file::iovec_t const* bufs, int num_bufs, boost::system::error_code& ec )

file_storage.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
file_storage::optimize int pad_file_limit )
file_storage::rename_file int index, std::wstring const& new_filename )
file_storage::set_name std::wstring const& n )

lazy_entry.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
lazy_entry::dict_at int i ) const
lazy_entry::dict_find_int char const* name ) const
print_entry lazy_entry const& e )

peer_info.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
source_rank int source_bitmask )

policy.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
policy::add_peer ( boost::asio::ip::tcp::endpoint const& remote, peer_id const& pid, int source, char flags )
policy::connect_one_peer int session_time )
policy::connection_closed ( peer_connection const& c, int session_time )
policy::erase_peer policy::peer* p )
policy::erase_peer std::_Deque_iterator<policy::peer*, policy::peer*&, policy::peer**> i )
policy::new_connection ( peer_connection& c, int session_time )
policy::peer::peer [in-charge] ( )
policy::peer::peer [in-charge] uint16_t port, bool connectable, int src )
policy::peer::peer [not-in-charge] ( )
policy::peer::peer [not-in-charge] uint16_t port, bool connectable, int src )
policy::set_connection policy::peer* p, peer_connection* c )
policy::set_failcount policy::peer* p, int f )

session.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
high_performance_seed ( )
min_memory_usage ( )
session::add_torrent ( add_torrent_params const& params, boost::system::error_code& ec )
session::get_io_service ( )
session::is_dht_running ( ) const
session::load_asnum_db wchar_t const* file )
session::load_country_db wchar_t const* file )
session::load_state lazy_entry const& e )
session::local_download_rate_limit ( ) const
session::local_upload_rate_limit ( ) const
session::max_connections ( ) const
session::max_uploads ( ) const
session::save_state entry& e, uint32_t flags ) const
session::session [in-charge] ( fingerprint const& print, int flags, int alert_mask )
session::session [in-charge] ( fingerprint const& print, std::pair<int, int> listen_port_range, char const* listen_interface, int flags, int alert_mask )
session::session [not-in-charge] ( fingerprint const& print, int flags, int alert_mask )
session::session [not-in-charge] ( fingerprint const& print, std::pair<int, int> listen_port_range, char const* listen_interface, int flags, int alert_mask )
session::set_alert_dispatch boost::function<void(alert const&)>const& fun )
session::set_local_download_rate_limit int bytes_per_second )
session::set_local_upload_rate_limit int bytes_per_second )
session::start_dht ( )

session_impl.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent::aux
initialize_timer::initialize_timer [in-charge] ( )
initialize_timer::initialize_timer [not-in-charge] ( )
session_impl::add_torrent ( libtorrent::add_torrent_params const& p1, boost::system::error_code& ec )
session_impl::allocate_disk_buffer char const* category )
session_impl::auto_manage_torrents ( std::vector<libtorrent::torrent*>& list, int hard_limit, int type_limit )
session_impl::choke_peer libtorrent::peer_connection& c )
session_impl::close_connection ( libtorrent::peer_connection const* p, boost::system::error_code const& ec )
session_impl::dequeue_check_torrent boost::shared_ptr<libtorrent::torrent>const& t )
session_impl::dht_state boost::mutex::scoped_lock& l ) const
session_impl::incoming_connection boost::shared_ptr<libtorrent::socket_type>const& s )
session_impl::load_asnum_db wchar_t const* file )
session_impl::load_country_db wchar_t const* file )
session_impl::load_state libtorrent::lazy_entry const& e )
session_impl::local_download_rate_limit ( ) const
session_impl::local_upload_rate_limit ( ) const
session_impl::maybe_update_udp_mapping int nat, int local_port, int external_port )
session_impl::on_accept_connection ( boost::shared_ptr<libtorrent::socket_type>const& s, boost::weak_ptr<boost::asio::basic_socket_acceptor<boost::asio::ip::tcp, boost::asio::socket_acceptor_service<boost::asio::ip::tcp> > > listener, boost::system::error_code const& e )
session_impl::on_dht_state_callback ( boost::condition& c, libtorrent::entry& e, bool& done ) const
session_impl::on_disk_queue ( )
session_impl::on_lsd_announce boost::system::error_code const& e )
session_impl::on_port_map_log char const* msg, int map_transport )
session_impl::on_port_mapping int mapping, int port, boost::system::error_code const& ec, int nat_transport )
session_impl::on_socks_accept ( boost::shared_ptr<libtorrent::socket_type>const& s, boost::system::error_code const& e )
session_impl::on_tick boost::system::error_code const& e )
session_impl::open_new_incoming_socks_connection ( )
session_impl::queue_check_torrent boost::shared_ptr<libtorrent::torrent>const& t )
session_impl::recalculate_optimistic_unchoke_slot ( )
session_impl::save_state ( libtorrent::entry& e, uint32_t flags, boost::mutex::scoped_lock& l ) const
session_impl::set_alert_dispatch boost::function<void(libtorrent::alert const&)>const& p1 )
session_impl::set_local_download_rate_limit int bytes_per_second )
session_impl::set_local_upload_rate_limit int bytes_per_second )
session_impl::setup_socket_buffers libtorrent::socket_type& s )
session_impl::start_dht ( )
session_impl::start_natpmp libtorrent::natpmp* n )
session_impl::start_upnp libtorrent::upnp* u )
session_impl::update_disk_thread_settings ( )

socks5_stream.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
socks_category [data]
socks_error_category::default_error_condition int ev ) const
socks_error_category::message int ev ) const
socks_error_category::name ( ) const
socks_error_category::~socks_error_category [in-charge-deleting] ( )
socks_error_category::~socks_error_category [in-charge] ( )

sp_counted_impl.hpp, libtorrent-rasterbar.so.6.0.0
namespace boost::detail
sp_counted_impl_p<std::string>::dispose ( )
sp_counted_impl_p<std::string>::get_deleter sp_typeinfo const& p1 )
sp_counted_impl_p<std::string>::~sp_counted_impl_p [in-charge-deleting] ( )
sp_counted_impl_p<std::string>::~sp_counted_impl_p [in-charge] ( )

stat.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
stat_channel::second_tick int tick_interval_ms )

storage.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
piece_manager::async_read_and_hash ( peer_request const& r, boost::function<void(int, disk_io_job const&)>const& handler, int priority )
piece_manager::queued_bytes ( ) const
storage_interface::readv ( file::iovec_t const* bufs, int slot, int offset, int num_bufs )
storage_interface::sparse_end int start ) const
storage_interface::writev ( file::iovec_t const* bufs, int slot, int offset, int num_bufs )

torrent.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
torrent::add_merkle_nodes ( std::map<int, big_number>const& n, int piece )
torrent::add_piece int piece, char const* data, int flags )
torrent::add_stats stat const& s )
torrent::add_tracker announce_entry const& url )
torrent::announce_with_tracker ( tracker_request::event_t e, address const& bind_interface )
torrent::block_bytes_wanted piece_block const& p ) const
torrent::bytes_done torrent_status& st ) const
torrent::connect_to_url_seed web_seed_entry const& url )
torrent::disconnect_all boost::system::error_code const& ec )
torrent::file_progress ( std::vector<long long>& fp, int flags ) const
torrent::files_checked boost::mutex::scoped_lock const& p1 )
torrent::files_checked_lock ( )
torrent::find_tracker tracker_request const& r )
torrent::flush_cache ( )
torrent::force_tracker_request ( )
torrent::force_tracker_request ptime p1 )
torrent::get_piece_to_super_seed bitfield const& p1 )
torrent::handle_disk_error ( disk_io_job const& j, peer_connection* c )
torrent::lsd_announce ( )
torrent::next_announce ( ) const
torrent::on_disk_read_complete int ret, disk_io_job const& j, peer_request r, torrent::read_piece_struct* rp )
torrent::on_disk_write_complete int ret, disk_io_job const& j, peer_request p )
torrent::on_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, web_seed_entry url, boost::asio::ip::tcp::endpoint proxy )
torrent::on_proxy_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, web_seed_entry url )
torrent::read_piece int piece )
torrent::retry_web_seed ( std::string const& url, web_seed_entry::type_t type, int retry )
torrent::second_tick ( stat& accumulator, int tick_interval_ms )
torrent::send_upload_only ( )
torrent::set_error ( boost::system::error_code const& ec, std::string const& file )
torrent::set_metadata ( char const* metadata_buf, int metadata_size )
torrent::set_piece_deadline int piece, int t, int flags )
torrent::set_tracker_login ( std::string const& name, std::string const& pw )
torrent::set_upload_mode bool b )
torrent::super_seeding bool on )
torrent::torrent [in-charge] ( aux::session_impl& ses, boost::asio::ip::tcp::endpoint const& net_interface, int block_size, int seq, add_torrent_params const& p )
torrent::torrent [not-in-charge] ( aux::session_impl& ses, boost::asio::ip::tcp::endpoint const& net_interface, int block_size, int seq, add_torrent_params const& p )
torrent::tracker_request_error ( tracker_request const& r, int response_code, std::string const& str, int retry_interval )
torrent::tracker_response ( tracker_request const& r, address const& tracker_ip, std::list<boost::asio::ip::address>const& ip_list, std::vector<peer_entry>& e, int interval, int min_interval, int complete, int incomplete, address const& external_ip )
torrent::update_sparse_piece_prio int piece, int cursor, int reverse_cursor )
torrent::we_have int index )
torrent::web_seeds web_seed_entry::type_t type ) const

torrent_handle.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
throw_invalid_handle ( )
torrent_handle::add_http_seed std::string const& url ) const
torrent_handle::add_piece int piece, char const* data, int flags ) const
torrent_handle::add_tracker announce_entry const& p1 ) const
torrent_handle::file_progress ( std::vector<long long>& progress, int flags ) const
torrent_handle::flush_cache ( ) const
torrent_handle::force_dht_announce ( ) const
torrent_handle::http_seeds ( ) const
torrent_handle::max_connections ( ) const
torrent_handle::max_uploads ( ) const
torrent_handle::read_piece int piece ) const
torrent_handle::remove_http_seed std::string const& url ) const
torrent_handle::set_metadata ( char const* metadata, int size ) const
torrent_handle::set_piece_deadline int index, int deadline, int flags ) const
torrent_handle::set_priority int prio ) const
torrent_handle::set_upload_mode bool b ) const
torrent_handle::super_seeding ( ) const
torrent_handle::super_seeding bool on ) const

torrent_info.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
announce_entry::min_announce_in ( ) const
announce_entry::next_announce_in ( ) const
torrent_info::add_merkle_nodes ( std::map<int, big_number>const& subtree, int piece )
torrent_info::build_merkle_list int piece ) const
torrent_info::parse_info_section ( lazy_entry const& e, boost::system::error_code& ex )
torrent_info::remap_files file_storage const& f )
torrent_info::torrent_info [in-charge] ( char const* buffer, int size, boost::system::error_code& ec )
torrent_info::torrent_info [in-charge] ( lazy_entry const& torrent_file, boost::system::error_code& ec )
torrent_info::torrent_info [in-charge] torrent_info const& t )
torrent_info::torrent_info [not-in-charge] ( char const* buffer, int size, boost::system::error_code& ec )
torrent_info::torrent_info [not-in-charge] ( lazy_entry const& torrent_file, boost::system::error_code& ec )
torrent_info::torrent_info [not-in-charge] torrent_info const& t )

tracker_manager.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
tracker_connection::fail int code, char const* msg, int interval, int min_interval )
tracker_connection::received_bytes int bytes )
tracker_connection::sent_bytes int bytes )
tracker_connection::tracker_connection [in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, boost::weak_ptr<request_callback> r )
tracker_connection::tracker_connection [not-in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, boost::weak_ptr<request_callback> r )
tracker_manager::abort_all_requests bool all )
tracker_manager::queue_request ( io_service& ios, connection_queue& cc, tracker_request r, std::string const& auth, boost::weak_ptr<request_callback> c )
tracker_manager::received_bytes int bytes )
tracker_manager::sent_bytes int bytes )

udp_socket.hpp, libtorrent-rasterbar.so.6.0.0
namespace libtorrent
rate_limited_udp_socket::close ( )
rate_limited_udp_socket::rate_limited_udp_socket [in-charge] ( io_service& ios, udp_socket::callback_t const& c, connection_queue& cc )
rate_limited_udp_socket::rate_limited_udp_socket [not-in-charge] ( io_service& ios, udp_socket::callback_t const& c, connection_queue& cc )
rate_limited_udp_socket::send ( boost::asio::ip::udp::endpoint const& ep, char const* p, int len, boost::system::error_code& ec, int flags )

to the top

Removed Symbols (55)


alert.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
alert_manager::alert_manager [in-charge] ( )
alert_manager::alert_manager [not-in-charge] ( )

entry.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
entry::print ( std::ostream& os, int indent ) const

error_code.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
libtorrent_category [data]

escape_string.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
isprint char c )
unescape_string std::string const& s )

policy.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
policy::connect_one_peer ( )
policy::connection_closed peer_connection const& c )
policy::erase_peer std::_Rb_tree_iterator<std::pair<boost::asio::ip::address const, policy::peer> > i )
policy::interested peer_connection& c )
policy::new_connection peer_connection& c )
policy::not_interested peer_connection& c )
policy::peer::peer [in-charge] ( boost::asio::ip::tcp::endpoint const& ip, policy::peer::connection_type t, int src )
policy::peer::peer [not-in-charge] ( boost::asio::ip::tcp::endpoint const& ip, policy::peer::connection_type t, int src )
policy::peer_from_tracker ( boost::asio::ip::tcp::endpoint const& remote, peer_id const& pid, int source, char flags )
policy::unchoked peer_connection& c )

stat.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
stat_channel::second_tick float tick_interval )

torrent.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
torrent::announce_with_tracker tracker_request::event_t e )
torrent::assign_bandwidth int channel, int amount, int blk )
torrent::bandwidth_queue_size int channel ) const
torrent::bytes_done ( ) const
torrent::connect_to_url_seed std::string const& url )
torrent::disconnect_all ( )
torrent::expire_bandwidth int channel, int amount )
torrent::file_progress std::vector<long long>& fp ) const
torrent::files_checked ( )
torrent::on_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, std::string url, boost::asio::ip::tcp::endpoint proxy )
torrent::on_proxy_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, std::string url )
torrent::perform_bandwidth_request int channel, boost::intrusive_ptr<peer_connection>const& p, int block_size, int priority )
torrent::request_bandwidth int channel, boost::intrusive_ptr<peer_connection>const& p, int max_block_size, int priority )
torrent::retry_url_seed std::string const& url )
torrent::second_tick ( stat& accumulator, float tick_interval )
torrent::set_error std::string const& msg )
torrent::set_metadata ( lazy_entry const& metadata, std::string& error )
torrent::tracker_request_error ( tracker_request const& r, int response_code, std::string const& str )
torrent::tracker_response ( tracker_request const& r, std::vector<peer_entry>& e, int interval, int complete, int incomplete, address const& external_ip )

torrent_handle.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
duplicate_torrent::what ( ) const
duplicate_torrent::~duplicate_torrent [in-charge-deleting] ( )
duplicate_torrent::~duplicate_torrent [in-charge] ( )
invalid_handle::what ( ) const
invalid_handle::~invalid_handle [in-charge-deleting] ( )
invalid_handle::~invalid_handle [in-charge] ( )
torrent_handle::file_progress std::vector<long long>& progress ) const
vtable for duplicate_torrent [data]
vtable for invalid_handle [data]

torrent_info.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
invalid_torrent_file::what ( ) const
invalid_torrent_file::~invalid_torrent_file [in-charge-deleting] ( )
invalid_torrent_file::~invalid_torrent_file [in-charge] ( )
torrent_info::parse_info_section ( lazy_entry const& e, std::string& error )
vtable for invalid_torrent_file [data]

tracker_manager.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
tracker_connection::fail int code, char const* msg )
tracker_connection::tracker_connection [in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, address bind_interface, boost::weak_ptr<request_callback> r )
tracker_connection::tracker_connection [not-in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, address bind_interface, boost::weak_ptr<request_callback> r )
tracker_manager::abort_all_requests ( )
tracker_manager::queue_request ( io_service& ios, connection_queue& cc, tracker_request r, std::string const& auth, address bind_infc, boost::weak_ptr<request_callback> c, ip_filter const* ipf )

to the top

Problems with Data Types, High Severity (18)


alert.hpp
namespace libtorrent
[+] class alert_manager (1)

bitfield.hpp
namespace libtorrent
[+] class bitfield (1)

piece_picker.hpp
namespace libtorrent
[+] class piece_picker (1)

policy.hpp
namespace libtorrent
[+] class policy (1)
[+] class policy::peer (3)

storage.hpp
namespace libtorrent
[+] class storage_interface (8)

torrent_info.hpp
namespace libtorrent
[+] class torrent_info (1)

tracker_manager.hpp
namespace libtorrent
[+] class tracker_connection (1)
[+] class tracker_request (1)

to the top

Problems with Symbols, High Severity (31)


alert.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] alert_manager::alert_manager [in-charge] ( ) (1)
[+] alert_manager::alert_manager [not-in-charge] ( ) (1)

escape_string.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] unescape_string std::string const& s ) (1)

piece_picker.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] piece_picker::distributed_copies ( ) const (1)

policy.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] policy::connect_one_peer ( ) (1)
[+] policy::connection_closed peer_connection const& c ) (1)
[+] policy::erase_peer std::_Rb_tree_iterator<std::pair<boost::asio::ip::address const, policy::peer> > i ) (1)
[+] policy::new_connection peer_connection& c ) (1)
[+] policy::peer::peer [in-charge] ( boost::asio::ip::tcp::endpoint const& ip, policy::peer::connection_type t, int src ) (1)
[+] policy::peer::peer [not-in-charge] ( boost::asio::ip::tcp::endpoint const& ip, policy::peer::connection_type t, int src ) (1)

stat.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] stat_channel::second_tick float tick_interval ) (1)

torrent.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] torrent::announce_with_tracker tracker_request::event_t e ) (1)
[+] torrent::bytes_done ( ) const (1)
[+] torrent::connect_to_url_seed std::string const& url ) (1)
[+] torrent::disconnect_all ( ) (1)
[+] torrent::file_progress std::vector<long long>& fp ) const (1)
[+] torrent::files_checked ( ) (1)
[+] torrent::on_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, std::string url, boost::asio::ip::tcp::endpoint proxy ) (1)
[+] torrent::on_proxy_name_lookup ( boost::system::error_code const& e, boost::asio::ip::basic_resolver<boost::asio::ip::tcp, boost::asio::ip::resolver_service<boost::asio::ip::tcp> >::iterator i, std::string url ) (1)
[+] torrent::second_tick ( stat& accumulator, float tick_interval ) (1)
[+] torrent::set_error std::string const& msg ) (1)
[+] torrent::set_metadata ( lazy_entry const& metadata, std::string& error ) (1)
[+] torrent::tracker_request_error ( tracker_request const& r, int response_code, std::string const& str ) (1)
[+] torrent::tracker_response ( tracker_request const& r, std::vector<peer_entry>& e, int interval, int complete, int incomplete, address const& external_ip ) (1)

torrent_handle.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] torrent_handle::file_progress std::vector<long long>& progress ) const (1)

torrent_info.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] torrent_info::parse_info_section ( lazy_entry const& e, std::string& error ) (1)

tracker_manager.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] tracker_connection::fail int code, char const* msg ) (1)
[+] tracker_connection::tracker_connection [not-in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, address bind_interface, boost::weak_ptr<request_callback> r ) (1)
[+] tracker_connection::tracker_connection [in-charge] ( tracker_manager& man, tracker_request const& req, io_service& ios, address bind_interface, boost::weak_ptr<request_callback> r ) (1)
[+] tracker_manager::abort_all_requests ( ) (1)
[+] tracker_manager::queue_request ( io_service& ios, connection_queue& cc, tracker_request r, std::string const& auth, address bind_infc, boost::weak_ptr<request_callback> c, ip_filter const* ipf ) (1)

to the top

Problems with Data Types, Medium Severity (36)


policy.hpp
namespace libtorrent
[+] class policy::peer (16)

session_settings.hpp
namespace libtorrent
[+] class session_settings (9)

torrent_handle.hpp
namespace libtorrent
[+] class torrent_status (9)

tracker_manager.hpp
namespace libtorrent
[+] class request_callback (2)

to the top

Problems with Symbols, Medium Severity (2)


torrent_handle.hpp, libtorrent-rasterbar.so.5.0.0
namespace libtorrent
[+] torrent_handle::trackers ( ) const (2)

to the top

Problems with Data Types, Low Severity (99)


alert.hpp
namespace libtorrent
[+] class alert_manager (2)

connection_queue.hpp
namespace libtorrent
[+] class connection_queue (2)

file_storage.hpp
namespace libtorrent
[+] class file_entry (7)

piece_picker.hpp
namespace libtorrent
[+] class piece_picker (1)

policy.hpp
namespace libtorrent
[+] class policy (2)
[+] class policy::peer (1)

session_settings.hpp
namespace libtorrent
[+] class session_settings (29)

storage.hpp
namespace libtorrent
[+] class piece_manager (6)
[+] class storage_interface (2)

time.hpp
namespace libtorrent
[+] class ptime (1)

torrent.hpp
namespace libtorrent
[+] class torrent (34)

torrent_handle.hpp
namespace libtorrent
[+] class torrent_status (5)

torrent_info.hpp
namespace libtorrent
[+] class torrent_info (3)

tracker_manager.hpp
namespace libtorrent
[+] class tracker_connection (2)
[+] class tracker_request (2)

to the top

Header Files (1)


torrent.hpp

to the top

Shared Libraries (1)


libtorrent-rasterbar.so.5.0.0

to the top




Generated on Sat Sep 3 17:17:07 2011 for libtorrent (Rasterbar) by ABI Compliance Checker 1.93.8  
A tool for checking backward binary compatibility of a shared C/C++ library API