Files
platform-external-webrtc/p2p/client/basicportallocator.cc
Qingsi Wang 625efe6dfe Use also the related address in redundancy detection for candidates from
the any-address/wildcard ports.

A TURN server can allocate different IPs for different allocation
requests from the same network interface, and a relayed candidate from a
wildcard port is not considered duplicate with another relayed candidate
using the same network interface in the current redundancy detection, if
their mapped addresses (as the "related address" for relayed candidates)
are different. Extra candidates would then be surfaced to the
application unnecessarily.

Bug: webrtc:9469
Change-Id: I504fde3b70cd727ef6ad4517072dcf37328a8380
Reviewed-on: https://webrtc-review.googlesource.com/86181
Commit-Queue: Qingsi Wang <qingsi@webrtc.org>
Reviewed-by: Steve Anton <steveanton@webrtc.org>
Reviewed-by: Qingsi Wang <qingsi@webrtc.org>
Cr-Commit-Position: refs/heads/master@{#24108}
2018-07-25 22:18:38 +00:00

1827 lines
66 KiB
C++

/*
* Copyright 2004 The WebRTC Project Authors. All rights reserved.
*
* Use of this source code is governed by a BSD-style license
* that can be found in the LICENSE file in the root of the source
* tree. An additional intellectual property rights grant can be found
* in the file PATENTS. All contributing project authors may
* be found in the AUTHORS file in the root of the source tree.
*/
#include "p2p/client/basicportallocator.h"
#include <algorithm>
#include <functional>
#include <set>
#include <string>
#include <vector>
#include "p2p/base/basicpacketsocketfactory.h"
#include "p2p/base/port.h"
#include "p2p/base/relayport.h"
#include "p2p/base/stunport.h"
#include "p2p/base/tcpport.h"
#include "p2p/base/turnport.h"
#include "p2p/base/udpport.h"
#include "rtc_base/checks.h"
#include "rtc_base/helpers.h"
#include "rtc_base/ipaddress.h"
#include "rtc_base/logging.h"
#include "system_wrappers/include/metrics.h"
using rtc::CreateRandomId;
namespace {
enum {
MSG_CONFIG_START,
MSG_CONFIG_READY,
MSG_ALLOCATE,
MSG_ALLOCATION_PHASE,
MSG_SEQUENCEOBJECTS_CREATED,
MSG_CONFIG_STOP,
MSG_SIGNAL_ANY_ADDRESS_PORTS,
};
const int PHASE_UDP = 0;
const int PHASE_RELAY = 1;
const int PHASE_TCP = 2;
const int kNumPhases = 3;
// Gets protocol priority: UDP > TCP > SSLTCP == TLS.
int GetProtocolPriority(cricket::ProtocolType protocol) {
switch (protocol) {
case cricket::PROTO_UDP:
return 2;
case cricket::PROTO_TCP:
return 1;
case cricket::PROTO_SSLTCP:
case cricket::PROTO_TLS:
return 0;
default:
RTC_NOTREACHED();
return 0;
}
}
// Gets address family priority: IPv6 > IPv4 > Unspecified.
int GetAddressFamilyPriority(int ip_family) {
switch (ip_family) {
case AF_INET6:
return 2;
case AF_INET:
return 1;
default:
RTC_NOTREACHED();
return 0;
}
}
// Returns positive if a is better, negative if b is better, and 0 otherwise.
int ComparePort(const cricket::Port* a, const cricket::Port* b) {
int a_protocol = GetProtocolPriority(a->GetProtocol());
int b_protocol = GetProtocolPriority(b->GetProtocol());
int cmp_protocol = a_protocol - b_protocol;
if (cmp_protocol != 0) {
return cmp_protocol;
}
int a_family = GetAddressFamilyPriority(a->Network()->GetBestIP().family());
int b_family = GetAddressFamilyPriority(b->Network()->GetBestIP().family());
return a_family - b_family;
}
struct NetworkFilter {
using Predicate = std::function<bool(rtc::Network*)>;
NetworkFilter(Predicate pred, const std::string& description)
: pred(pred), description(description) {}
Predicate pred;
const std::string description;
};
using NetworkList = rtc::NetworkManager::NetworkList;
void FilterNetworks(NetworkList* networks, NetworkFilter filter) {
auto start_to_remove =
std::remove_if(networks->begin(), networks->end(), filter.pred);
if (start_to_remove == networks->end()) {
return;
}
RTC_LOG(INFO) << "Filtered out " << filter.description << " networks:";
for (auto it = start_to_remove; it != networks->end(); ++it) {
RTC_LOG(INFO) << (*it)->ToString();
}
networks->erase(start_to_remove, networks->end());
}
bool IsAnyAddressPort(const cricket::Port* port) {
return rtc::IPIsAny(port->Network()->GetBestIP());
}
} // namespace
namespace cricket {
const uint32_t DISABLE_ALL_PHASES =
PORTALLOCATOR_DISABLE_UDP | PORTALLOCATOR_DISABLE_TCP |
PORTALLOCATOR_DISABLE_STUN | PORTALLOCATOR_DISABLE_RELAY;
// BasicPortAllocator
BasicPortAllocator::BasicPortAllocator(
rtc::NetworkManager* network_manager,
rtc::PacketSocketFactory* socket_factory,
webrtc::TurnCustomizer* customizer,
RelayPortFactoryInterface* relay_port_factory)
: network_manager_(network_manager), socket_factory_(socket_factory) {
InitRelayPortFactory(relay_port_factory);
RTC_DCHECK(relay_port_factory_ != nullptr);
RTC_DCHECK(network_manager_ != nullptr);
RTC_DCHECK(socket_factory_ != nullptr);
SetConfiguration(ServerAddresses(), std::vector<RelayServerConfig>(), 0,
false, customizer);
Construct();
}
BasicPortAllocator::BasicPortAllocator(rtc::NetworkManager* network_manager)
: network_manager_(network_manager), socket_factory_(nullptr) {
InitRelayPortFactory(nullptr);
RTC_DCHECK(relay_port_factory_ != nullptr);
RTC_DCHECK(network_manager_ != nullptr);
Construct();
}
BasicPortAllocator::BasicPortAllocator(rtc::NetworkManager* network_manager,
rtc::PacketSocketFactory* socket_factory,
const ServerAddresses& stun_servers)
: network_manager_(network_manager), socket_factory_(socket_factory) {
InitRelayPortFactory(nullptr);
RTC_DCHECK(relay_port_factory_ != nullptr);
RTC_DCHECK(socket_factory_ != nullptr);
SetConfiguration(stun_servers, std::vector<RelayServerConfig>(), 0, false,
nullptr);
Construct();
}
BasicPortAllocator::BasicPortAllocator(
rtc::NetworkManager* network_manager,
const ServerAddresses& stun_servers,
const rtc::SocketAddress& relay_address_udp,
const rtc::SocketAddress& relay_address_tcp,
const rtc::SocketAddress& relay_address_ssl)
: network_manager_(network_manager), socket_factory_(nullptr) {
InitRelayPortFactory(nullptr);
RTC_DCHECK(relay_port_factory_ != nullptr);
RTC_DCHECK(network_manager_ != nullptr);
std::vector<RelayServerConfig> turn_servers;
RelayServerConfig config(RELAY_GTURN);
if (!relay_address_udp.IsNil()) {
config.ports.push_back(ProtocolAddress(relay_address_udp, PROTO_UDP));
}
if (!relay_address_tcp.IsNil()) {
config.ports.push_back(ProtocolAddress(relay_address_tcp, PROTO_TCP));
}
if (!relay_address_ssl.IsNil()) {
config.ports.push_back(ProtocolAddress(relay_address_ssl, PROTO_SSLTCP));
}
if (!config.ports.empty()) {
turn_servers.push_back(config);
}
SetConfiguration(stun_servers, turn_servers, 0, false, nullptr);
Construct();
}
void BasicPortAllocator::Construct() {
allow_tcp_listen_ = true;
}
void BasicPortAllocator::OnIceRegathering(PortAllocatorSession* session,
IceRegatheringReason reason) {
// If the session has not been taken by an active channel, do not report the
// metric.
for (auto& allocator_session : pooled_sessions()) {
if (allocator_session.get() == session) {
return;
}
}
RTC_HISTOGRAM_ENUMERATION("WebRTC.PeerConnection.IceRegatheringReason",
static_cast<int>(reason),
static_cast<int>(IceRegatheringReason::MAX_VALUE));
}
BasicPortAllocator::~BasicPortAllocator() {
CheckRunOnValidThreadIfInitialized();
// Our created port allocator sessions depend on us, so destroy our remaining
// pooled sessions before anything else.
DiscardCandidatePool();
}
void BasicPortAllocator::SetNetworkIgnoreMask(int network_ignore_mask) {
// TODO(phoglund): implement support for other types than loopback.
// See https://code.google.com/p/webrtc/issues/detail?id=4288.
// Then remove set_network_ignore_list from NetworkManager.
CheckRunOnValidThreadIfInitialized();
network_ignore_mask_ = network_ignore_mask;
}
PortAllocatorSession* BasicPortAllocator::CreateSessionInternal(
const std::string& content_name,
int component,
const std::string& ice_ufrag,
const std::string& ice_pwd) {
CheckRunOnValidThreadAndInitialized();
PortAllocatorSession* session = new BasicPortAllocatorSession(
this, content_name, component, ice_ufrag, ice_pwd);
session->SignalIceRegathering.connect(this,
&BasicPortAllocator::OnIceRegathering);
return session;
}
void BasicPortAllocator::AddTurnServer(const RelayServerConfig& turn_server) {
CheckRunOnValidThreadAndInitialized();
std::vector<RelayServerConfig> new_turn_servers = turn_servers();
new_turn_servers.push_back(turn_server);
SetConfiguration(stun_servers(), new_turn_servers, candidate_pool_size(),
prune_turn_ports(), turn_customizer());
}
void BasicPortAllocator::InitRelayPortFactory(
RelayPortFactoryInterface* relay_port_factory) {
if (relay_port_factory != nullptr) {
relay_port_factory_ = relay_port_factory;
} else {
default_relay_port_factory_.reset(new TurnPortFactory());
relay_port_factory_ = default_relay_port_factory_.get();
}
}
// BasicPortAllocatorSession
BasicPortAllocatorSession::BasicPortAllocatorSession(
BasicPortAllocator* allocator,
const std::string& content_name,
int component,
const std::string& ice_ufrag,
const std::string& ice_pwd)
: PortAllocatorSession(content_name,
component,
ice_ufrag,
ice_pwd,
allocator->flags()),
allocator_(allocator),
network_thread_(nullptr),
socket_factory_(allocator->socket_factory()),
allocation_started_(false),
network_manager_started_(false),
allocation_sequences_created_(false),
prune_turn_ports_(allocator->prune_turn_ports()) {
allocator_->network_manager()->SignalNetworksChanged.connect(
this, &BasicPortAllocatorSession::OnNetworksChanged);
allocator_->network_manager()->StartUpdating();
}
BasicPortAllocatorSession::~BasicPortAllocatorSession() {
allocator_->network_manager()->StopUpdating();
if (network_thread_ != nullptr)
network_thread_->Clear(this);
for (uint32_t i = 0; i < sequences_.size(); ++i) {
// AllocationSequence should clear it's map entry for turn ports before
// ports are destroyed.
sequences_[i]->Clear();
}
std::vector<PortData>::iterator it;
for (it = ports_.begin(); it != ports_.end(); it++)
delete it->port();
for (uint32_t i = 0; i < configs_.size(); ++i)
delete configs_[i];
for (uint32_t i = 0; i < sequences_.size(); ++i)
delete sequences_[i];
}
BasicPortAllocator* BasicPortAllocatorSession::allocator() {
return allocator_;
}
void BasicPortAllocatorSession::SetCandidateFilter(uint32_t filter) {
if (filter == candidate_filter_) {
return;
}
// We assume the filter will only change from "ALL" to something else.
RTC_DCHECK(candidate_filter_ == CF_ALL);
candidate_filter_ = filter;
for (PortData& port : ports_) {
if (!port.has_pairable_candidate()) {
continue;
}
const auto& candidates = port.port()->Candidates();
// Setting a filter may cause a ready port to become non-ready
// if it no longer has any pairable candidates.
if (!std::any_of(candidates.begin(), candidates.end(),
[this, &port](const Candidate& candidate) {
return CandidatePairable(candidate, port.port());
})) {
port.set_has_pairable_candidate(false);
}
}
}
void BasicPortAllocatorSession::StartGettingPorts() {
network_thread_ = rtc::Thread::Current();
state_ = SessionState::GATHERING;
if (!socket_factory_) {
owned_socket_factory_.reset(
new rtc::BasicPacketSocketFactory(network_thread_));
socket_factory_ = owned_socket_factory_.get();
}
network_thread_->Post(RTC_FROM_HERE, this, MSG_CONFIG_START);
RTC_LOG(LS_INFO) << "Start getting ports with prune_turn_ports "
<< (prune_turn_ports_ ? "enabled" : "disabled");
}
void BasicPortAllocatorSession::StopGettingPorts() {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
ClearGettingPorts();
// Note: this must be called after ClearGettingPorts because both may set the
// session state and we should set the state to STOPPED.
state_ = SessionState::STOPPED;
}
void BasicPortAllocatorSession::ClearGettingPorts() {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
network_thread_->Clear(this, MSG_ALLOCATE);
for (uint32_t i = 0; i < sequences_.size(); ++i) {
sequences_[i]->Stop();
}
network_thread_->Post(RTC_FROM_HERE, this, MSG_CONFIG_STOP);
state_ = SessionState::CLEARED;
}
bool BasicPortAllocatorSession::IsGettingPorts() {
return state_ == SessionState::GATHERING;
}
bool BasicPortAllocatorSession::IsCleared() const {
return state_ == SessionState::CLEARED;
}
bool BasicPortAllocatorSession::IsStopped() const {
return state_ == SessionState::STOPPED;
}
std::vector<rtc::Network*> BasicPortAllocatorSession::GetFailedNetworks() {
std::vector<rtc::Network*> networks = GetNetworks();
// A network interface may have both IPv4 and IPv6 networks. Only if
// neither of the networks has any connections, the network interface
// is considered failed and need to be regathered on.
std::set<std::string> networks_with_connection;
for (const PortData& data : ports_) {
Port* port = data.port();
if (!port->connections().empty()) {
networks_with_connection.insert(port->Network()->name());
}
}
networks.erase(
std::remove_if(networks.begin(), networks.end(),
[networks_with_connection](rtc::Network* network) {
// If a network does not have any connection, it is
// considered failed.
return networks_with_connection.find(network->name()) !=
networks_with_connection.end();
}),
networks.end());
return networks;
}
void BasicPortAllocatorSession::RegatherOnFailedNetworks() {
// Find the list of networks that have no connection.
std::vector<rtc::Network*> failed_networks = GetFailedNetworks();
if (failed_networks.empty()) {
return;
}
RTC_LOG(LS_INFO) << "Regather candidates on failed networks";
// Mark a sequence as "network failed" if its network is in the list of failed
// networks, so that it won't be considered as equivalent when the session
// regathers ports and candidates.
for (AllocationSequence* sequence : sequences_) {
if (!sequence->network_failed() &&
std::find(failed_networks.begin(), failed_networks.end(),
sequence->network()) != failed_networks.end()) {
sequence->set_network_failed();
}
}
bool disable_equivalent_phases = true;
Regather(failed_networks, disable_equivalent_phases,
IceRegatheringReason::NETWORK_FAILURE);
}
void BasicPortAllocatorSession::RegatherOnAllNetworks() {
std::vector<rtc::Network*> networks = GetNetworks();
if (networks.empty()) {
return;
}
RTC_LOG(LS_INFO) << "Regather candidates on all networks";
// We expect to generate candidates that are equivalent to what we have now.
// Force DoAllocate to generate them instead of skipping.
bool disable_equivalent_phases = false;
Regather(networks, disable_equivalent_phases,
IceRegatheringReason::OCCASIONAL_REFRESH);
}
void BasicPortAllocatorSession::Regather(
const std::vector<rtc::Network*>& networks,
bool disable_equivalent_phases,
IceRegatheringReason reason) {
// Remove ports from being used locally and send signaling to remove
// the candidates on the remote side.
std::vector<PortData*> ports_to_prune = GetUnprunedPorts(networks);
if (!ports_to_prune.empty()) {
RTC_LOG(LS_INFO) << "Prune " << ports_to_prune.size() << " ports";
PrunePortsAndSignalCandidatesRemoval(ports_to_prune);
}
if (allocation_started_ && network_manager_started_ && !IsStopped()) {
SignalIceRegathering(this, reason);
DoAllocate(disable_equivalent_phases);
}
}
void BasicPortAllocatorSession::SetStunKeepaliveIntervalForReadyPorts(
const absl::optional<int>& stun_keepalive_interval) {
auto ports = ReadyPorts();
for (PortInterface* port : ports) {
// The port type and protocol can be used to identify different subclasses
// of Port in the current implementation. Note that a TCPPort has the type
// LOCAL_PORT_TYPE but uses the protocol PROTO_TCP.
if (port->Type() == STUN_PORT_TYPE ||
(port->Type() == LOCAL_PORT_TYPE && port->GetProtocol() == PROTO_UDP)) {
static_cast<UDPPort*>(port)->set_stun_keepalive_delay(
stun_keepalive_interval);
}
}
}
std::vector<PortInterface*> BasicPortAllocatorSession::ReadyPorts() const {
std::vector<PortInterface*> ret;
for (const PortData& data : ports_) {
if (data.ready()) {
ret.push_back(data.port());
}
}
return ret;
}
std::vector<Candidate> BasicPortAllocatorSession::ReadyCandidates() const {
std::vector<Candidate> candidates;
for (const PortData& data : ports_) {
if (!data.ready()) {
continue;
}
GetCandidatesFromPort(data, &candidates);
}
return candidates;
}
void BasicPortAllocatorSession::GetCandidatesFromPort(
const PortData& data,
std::vector<Candidate>* candidates) const {
RTC_CHECK(candidates != nullptr);
for (const Candidate& candidate : data.port()->Candidates()) {
if (!CheckCandidateFilter(candidate)) {
continue;
}
candidates->push_back(SanitizeRelatedAddress(candidate));
}
}
Candidate BasicPortAllocatorSession::SanitizeRelatedAddress(
const Candidate& c) const {
Candidate copy = c;
// If adapter enumeration is disabled or host candidates are disabled,
// clear the raddr of STUN candidates to avoid local address leakage.
bool filter_stun_related_address =
((flags() & PORTALLOCATOR_DISABLE_ADAPTER_ENUMERATION) &&
(flags() & PORTALLOCATOR_DISABLE_DEFAULT_LOCAL_CANDIDATE)) ||
!(candidate_filter_ & CF_HOST);
// If the candidate filter doesn't allow reflexive addresses, empty TURN raddr
// to avoid reflexive address leakage.
bool filter_turn_related_address = !(candidate_filter_ & CF_REFLEXIVE);
if ((c.type() == STUN_PORT_TYPE && filter_stun_related_address) ||
(c.type() == RELAY_PORT_TYPE && filter_turn_related_address)) {
copy.set_related_address(
rtc::EmptySocketAddressWithFamily(copy.address().family()));
}
return copy;
}
bool BasicPortAllocatorSession::CandidatesAllocationDone() const {
// Done only if all required AllocationSequence objects
// are created.
if (!allocation_sequences_created_) {
return false;
}
// Check that all port allocation sequences are complete (not running).
if (std::any_of(sequences_.begin(), sequences_.end(),
[](const AllocationSequence* sequence) {
return sequence->state() == AllocationSequence::kRunning;
})) {
return false;
}
// If all allocated ports are no longer gathering, session must have got all
// expected candidates. Session will trigger candidates allocation complete
// signal.
return std::none_of(ports_.begin(), ports_.end(),
[](const PortData& port) { return port.inprogress(); });
}
void BasicPortAllocatorSession::OnMessage(rtc::Message* message) {
switch (message->message_id) {
case MSG_CONFIG_START:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
GetPortConfigurations();
break;
case MSG_CONFIG_READY:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
OnConfigReady(static_cast<PortConfiguration*>(message->pdata));
break;
case MSG_ALLOCATE:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
OnAllocate();
break;
case MSG_SEQUENCEOBJECTS_CREATED:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
OnAllocationSequenceObjectsCreated();
break;
case MSG_CONFIG_STOP:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
OnConfigStop();
break;
case MSG_SIGNAL_ANY_ADDRESS_PORTS:
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
SignalAnyAddressPortsAndCandidatesReadyIfNotRedundant();
break;
default:
RTC_NOTREACHED();
}
}
void BasicPortAllocatorSession::UpdateIceParametersInternal() {
for (PortData& port : ports_) {
port.port()->set_content_name(content_name());
port.port()->SetIceParameters(component(), ice_ufrag(), ice_pwd());
}
}
void BasicPortAllocatorSession::GetPortConfigurations() {
PortConfiguration* config =
new PortConfiguration(allocator_->stun_servers(), username(), password());
for (const RelayServerConfig& turn_server : allocator_->turn_servers()) {
config->AddRelay(turn_server);
}
ConfigReady(config);
}
void BasicPortAllocatorSession::ConfigReady(PortConfiguration* config) {
network_thread_->Post(RTC_FROM_HERE, this, MSG_CONFIG_READY, config);
}
// Adds a configuration to the list.
void BasicPortAllocatorSession::OnConfigReady(PortConfiguration* config) {
if (config) {
configs_.push_back(config);
}
AllocatePorts();
}
void BasicPortAllocatorSession::OnConfigStop() {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
// If any of the allocated ports have not completed the candidates allocation,
// mark those as error. Since session doesn't need any new candidates
// at this stage of the allocation, it's safe to discard any new candidates.
bool send_signal = false;
for (std::vector<PortData>::iterator it = ports_.begin(); it != ports_.end();
++it) {
if (it->inprogress()) {
// Updating port state to error, which didn't finish allocating candidates
// yet.
it->set_error();
send_signal = true;
}
}
// Did we stop any running sequences?
for (std::vector<AllocationSequence*>::iterator it = sequences_.begin();
it != sequences_.end() && !send_signal; ++it) {
if ((*it)->state() == AllocationSequence::kStopped) {
send_signal = true;
}
}
// If we stopped anything that was running, send a done signal now.
if (send_signal) {
FireAllocationStatusSignalsIfNeeded();
}
}
void BasicPortAllocatorSession::AllocatePorts() {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
network_thread_->Post(RTC_FROM_HERE, this, MSG_ALLOCATE);
}
void BasicPortAllocatorSession::OnAllocate() {
if (network_manager_started_ && !IsStopped()) {
bool disable_equivalent_phases = true;
DoAllocate(disable_equivalent_phases);
}
allocation_started_ = true;
}
std::vector<rtc::Network*> BasicPortAllocatorSession::GetNetworks() {
std::vector<rtc::Network*> networks;
rtc::NetworkManager* network_manager = allocator_->network_manager();
RTC_DCHECK(network_manager != nullptr);
// If the network permission state is BLOCKED, we just act as if the flag has
// been passed in.
if (network_manager->enumeration_permission() ==
rtc::NetworkManager::ENUMERATION_BLOCKED) {
set_flags(flags() | PORTALLOCATOR_DISABLE_ADAPTER_ENUMERATION);
}
// If adapter enumeration is disabled, we'll just bind to any address
// instead of a specific NIC. This is to ensure that WebRTC traffic is routed
// by the OS in the same way that HTTP traffic would be, and no additional
// local or public IPs are leaked during ICE processing.
//
// Even when adapter enumeration is enabled, we still bind to the "any"
// address as a fallback, since this may potentially reveal network
// interfaces that weren't otherwise accessible. Note that the candidates
// gathered by binding to the "any" address won't be surfaced to the
// application if they're determined to be redundant (if they have the same
// address as a candidate gathered by binding to an interface explicitly).
if (!(flags() & PORTALLOCATOR_DISABLE_ADAPTER_ENUMERATION)) {
network_manager->GetNetworks(&networks);
}
network_manager->GetAnyAddressNetworks(&networks);
// Filter out link-local networks if needed.
if (flags() & PORTALLOCATOR_DISABLE_LINK_LOCAL_NETWORKS) {
NetworkFilter link_local_filter(
[](rtc::Network* network) { return IPIsLinkLocal(network->prefix()); },
"link-local");
FilterNetworks(&networks, link_local_filter);
}
// Do some more filtering, depending on the network ignore mask and "disable
// costly networks" flag.
NetworkFilter ignored_filter(
[this](rtc::Network* network) {
return allocator_->network_ignore_mask() & network->type();
},
"ignored");
FilterNetworks(&networks, ignored_filter);
if (flags() & PORTALLOCATOR_DISABLE_COSTLY_NETWORKS) {
uint16_t lowest_cost = rtc::kNetworkCostMax;
for (rtc::Network* network : networks) {
// Don't determine the lowest cost from a link-local or any address
// network. On iOS, a device connected to the computer will get a
// link-local network for communicating with the computer, however this
// network can't be used to connect to a peer outside the network.
if (rtc::IPIsLinkLocal(network->GetBestIP()) ||
rtc::IPIsAny(network->GetBestIP())) {
continue;
}
lowest_cost = std::min<uint16_t>(lowest_cost, network->GetCost());
}
NetworkFilter costly_filter(
[lowest_cost](rtc::Network* network) {
return network->GetCost() > lowest_cost + rtc::kNetworkCostLow;
},
"costly");
FilterNetworks(&networks, costly_filter);
}
// Lastly, if we have a limit for the number of IPv6 network interfaces (by
// default, it's 5), remove networks to ensure that limit is satisfied.
//
// TODO(deadbeef): Instead of just taking the first N arbitrary IPv6
// networks, we could try to choose a set that's "most likely to work". It's
// hard to define what that means though; it's not just "lowest cost".
// Alternatively, we could just focus on making our ICE pinging logic smarter
// such that this filtering isn't necessary in the first place.
int ipv6_networks = 0;
for (auto it = networks.begin(); it != networks.end();) {
if ((*it)->prefix().family() == AF_INET6) {
if (ipv6_networks >= allocator_->max_ipv6_networks()) {
it = networks.erase(it);
continue;
} else {
++ipv6_networks;
}
}
++it;
}
return networks;
}
// For each network, see if we have a sequence that covers it already. If not,
// create a new sequence to create the appropriate ports.
void BasicPortAllocatorSession::DoAllocate(bool disable_equivalent) {
bool done_signal_needed = false;
std::vector<rtc::Network*> networks = GetNetworks();
if (networks.empty()) {
RTC_LOG(LS_WARNING)
<< "Machine has no networks; no ports will be allocated";
done_signal_needed = true;
} else {
RTC_LOG(LS_INFO) << "Allocate ports on " << networks.size() << " networks";
PortConfiguration* config = configs_.empty() ? nullptr : configs_.back();
for (uint32_t i = 0; i < networks.size(); ++i) {
uint32_t sequence_flags = flags();
if ((sequence_flags & DISABLE_ALL_PHASES) == DISABLE_ALL_PHASES) {
// If all the ports are disabled we should just fire the allocation
// done event and return.
done_signal_needed = true;
break;
}
if (!config || config->relays.empty()) {
// No relay ports specified in this config.
sequence_flags |= PORTALLOCATOR_DISABLE_RELAY;
}
if (!(sequence_flags & PORTALLOCATOR_ENABLE_IPV6) &&
networks[i]->GetBestIP().family() == AF_INET6) {
// Skip IPv6 networks unless the flag's been set.
continue;
}
if (!(sequence_flags & PORTALLOCATOR_ENABLE_IPV6_ON_WIFI) &&
networks[i]->GetBestIP().family() == AF_INET6 &&
networks[i]->type() == rtc::ADAPTER_TYPE_WIFI) {
// Skip IPv6 Wi-Fi networks unless the flag's been set.
continue;
}
if (disable_equivalent) {
// Disable phases that would only create ports equivalent to
// ones that we have already made.
DisableEquivalentPhases(networks[i], config, &sequence_flags);
if ((sequence_flags & DISABLE_ALL_PHASES) == DISABLE_ALL_PHASES) {
// New AllocationSequence would have nothing to do, so don't make it.
continue;
}
}
AllocationSequence* sequence =
new AllocationSequence(this, networks[i], config, sequence_flags);
sequence->SignalPortAllocationComplete.connect(
this, &BasicPortAllocatorSession::OnPortAllocationComplete);
sequence->Init();
sequence->Start();
sequences_.push_back(sequence);
done_signal_needed = true;
}
}
if (done_signal_needed) {
network_thread_->Post(RTC_FROM_HERE, this, MSG_SEQUENCEOBJECTS_CREATED);
}
// If adapter enumeration is enabled, then we prefer binding to individual
// network adapters, only using ports bound to the "any" address (0.0.0.0) if
// they reveal an interface not otherwise accessible. Normally these will be
// surfaced when candidate allocation completes, but sometimes candidate
// allocation can take a long time, if a STUN transaction times out for
// instance. So as a backup, we'll surface these ports/candidates after
// |kMaxWaitMsBeforeSignalingAnyAddressPortsAndCandidates| passes.
if (!(flags() & PORTALLOCATOR_DISABLE_ADAPTER_ENUMERATION)) {
network_thread_->PostDelayed(
RTC_FROM_HERE, kMaxWaitMsBeforeSignalingAnyAddressPortsAndCandidates,
this, MSG_SIGNAL_ANY_ADDRESS_PORTS);
}
}
void BasicPortAllocatorSession::OnNetworksChanged() {
std::vector<rtc::Network*> networks = GetNetworks();
std::vector<rtc::Network*> failed_networks;
for (AllocationSequence* sequence : sequences_) {
// Mark the sequence as "network failed" if its network is not in
// |networks|.
if (!sequence->network_failed() &&
std::find(networks.begin(), networks.end(), sequence->network()) ==
networks.end()) {
sequence->OnNetworkFailed();
failed_networks.push_back(sequence->network());
}
}
std::vector<PortData*> ports_to_prune = GetUnprunedPorts(failed_networks);
if (!ports_to_prune.empty()) {
RTC_LOG(LS_INFO) << "Prune " << ports_to_prune.size()
<< " ports because their networks were gone";
PrunePortsAndSignalCandidatesRemoval(ports_to_prune);
}
if (allocation_started_ && !IsStopped()) {
if (network_manager_started_) {
// If the network manager has started, it must be regathering.
SignalIceRegathering(this, IceRegatheringReason::NETWORK_CHANGE);
}
bool disable_equivalent_phases = true;
DoAllocate(disable_equivalent_phases);
}
if (!network_manager_started_) {
RTC_LOG(LS_INFO) << "Network manager has started";
network_manager_started_ = true;
}
}
void BasicPortAllocatorSession::DisableEquivalentPhases(
rtc::Network* network,
PortConfiguration* config,
uint32_t* flags) {
for (uint32_t i = 0; i < sequences_.size() &&
(*flags & DISABLE_ALL_PHASES) != DISABLE_ALL_PHASES;
++i) {
sequences_[i]->DisableEquivalentPhases(network, config, flags);
}
}
void BasicPortAllocatorSession::AddAllocatedPort(Port* port,
AllocationSequence* seq,
bool prepare_address) {
if (!port)
return;
RTC_LOG(LS_INFO) << "Adding allocated port for " << content_name();
port->set_content_name(content_name());
port->set_component(component());
port->set_generation(generation());
if (allocator_->proxy().type != rtc::PROXY_NONE)
port->set_proxy(allocator_->user_agent(), allocator_->proxy());
port->set_send_retransmit_count_attribute(
(flags() & PORTALLOCATOR_ENABLE_STUN_RETRANSMIT_ATTRIBUTE) != 0);
PortData data(port, seq);
ports_.push_back(data);
port->SignalCandidateReady.connect(
this, &BasicPortAllocatorSession::OnCandidateReady);
port->SignalPortComplete.connect(this,
&BasicPortAllocatorSession::OnPortComplete);
port->SignalDestroyed.connect(this,
&BasicPortAllocatorSession::OnPortDestroyed);
port->SignalPortError.connect(this, &BasicPortAllocatorSession::OnPortError);
RTC_LOG(LS_INFO) << port->ToString() << ": Added port to allocator";
if (prepare_address)
port->PrepareAddress();
}
void BasicPortAllocatorSession::OnAllocationSequenceObjectsCreated() {
allocation_sequences_created_ = true;
// Send candidate allocation complete signal if we have no sequences.
FireAllocationStatusSignalsIfNeeded();
}
void BasicPortAllocatorSession::OnCandidateReady(Port* port,
const Candidate& c) {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
PortData* data = FindPort(port);
RTC_DCHECK(data != nullptr);
RTC_LOG(LS_INFO) << port->ToString()
<< ": Gathered candidate: " << c.ToSensitiveString();
// Discarding any candidate signal if port allocation status is
// already done with gathering.
if (!data->inprogress()) {
RTC_LOG(LS_WARNING)
<< "Discarding candidate because port is already done gathering.";
return;
}
// Mark that the port has a pairable candidate, either because we have a
// usable candidate from the port, or simply because the port is bound to the
// any address and therefore has no host candidate. This will trigger the port
// to start creating candidate pairs (connections) and issue connectivity
// checks. If port has already been marked as having a pairable candidate,
// do nothing here.
// Note: We should check whether any candidates may become ready after this
// because there we will check whether the candidate is generated by the ready
// ports, which may include this port.
bool pruned = false;
if (CandidatePairable(c, port) && !data->has_pairable_candidate()) {
data->set_has_pairable_candidate(true);
if (prune_turn_ports_ && port->Type() == RELAY_PORT_TYPE) {
pruned = PruneTurnPorts(port);
}
// If the current port is not pruned yet, SignalPortReady.
if (!data->pruned()) {
port->KeepAliveUntilPruned();
// We postpone the signaling of any address ports to when the candidates
// allocation is done or the candidate allocation process has start for
// more than kMaxWaitMsBeforeSignalingAnyAddressPortsAndCandidates, and
// we check whether they are redundant or not (in
// SignalAnyAddressPortsAndCandidatesReadyIfNotRedundant). Otherwise,
// connectivity checks will be sent from these possibly redundant ports,
// likely also resulting in "prflx" candidate pairs being created on the
// other side if not pruned in time. The signaling of any address ports
// that are not redundant happens in
// SignalAnyAddressPortsAndCandidatesReadyIfNotRedundant.
//
// If adapter enumeration is disabled, these "any" address ports
// are all we'll get, so we can signal them immediately.
//
// Same logic applies to candidates below.
if (!IsAnyAddressPort(port) ||
(flags() & PORTALLOCATOR_DISABLE_ADAPTER_ENUMERATION)) {
RTC_LOG(INFO) << port->ToString() << ": Port ready.";
SignalPortReady(this, port);
data->set_signaled();
}
}
}
if (data->ready() && CheckCandidateFilter(c)) {
// See comment above about why we delay signaling candidates from "any
// address" ports.
//
// For candidates gathered after the any address port is signaled, we will
// not perform the redundancy check anymore. Note that late candiates
// gathered from the any address port should be a srflx candidate from a
// late STUN binding response.
if (data->signaled()) {
std::vector<Candidate> candidates;
candidates.push_back(SanitizeRelatedAddress(c));
SignalCandidatesReady(this, candidates);
} else {
RTC_LOG(INFO) << "Candidate not signaled yet because it is from the "
"any address port: "
<< c.ToSensitiveString();
}
} else {
RTC_LOG(LS_INFO) << "Discarding candidate because it doesn't match filter.";
}
// If we have pruned any port, maybe need to signal port allocation done.
if (pruned) {
FireAllocationStatusSignalsIfNeeded();
}
}
Port* BasicPortAllocatorSession::GetBestTurnPortForNetwork(
const std::string& network_name) const {
Port* best_turn_port = nullptr;
for (const PortData& data : ports_) {
if (data.port()->Network()->name() == network_name &&
data.port()->Type() == RELAY_PORT_TYPE && data.ready() &&
(!best_turn_port || ComparePort(data.port(), best_turn_port) > 0)) {
best_turn_port = data.port();
}
}
return best_turn_port;
}
bool BasicPortAllocatorSession::PruneTurnPorts(Port* newly_pairable_turn_port) {
// Note: We determine the same network based only on their network names. So
// if an IPv4 address and an IPv6 address have the same network name, they
// are considered the same network here.
const std::string& network_name = newly_pairable_turn_port->Network()->name();
Port* best_turn_port = GetBestTurnPortForNetwork(network_name);
// |port| is already in the list of ports, so the best port cannot be nullptr.
RTC_CHECK(best_turn_port != nullptr);
bool pruned = false;
std::vector<PortData*> ports_to_prune;
for (PortData& data : ports_) {
if (data.port()->Network()->name() == network_name &&
data.port()->Type() == RELAY_PORT_TYPE && !data.pruned() &&
ComparePort(data.port(), best_turn_port) < 0) {
pruned = true;
if (data.port() != newly_pairable_turn_port) {
// These ports will be pruned in PrunePortsAndSignalCandidatesRemoval.
ports_to_prune.push_back(&data);
} else {
data.Prune();
}
}
}
if (!ports_to_prune.empty()) {
RTC_LOG(LS_INFO) << "Prune " << ports_to_prune.size()
<< " low-priority TURN ports";
PrunePortsAndSignalCandidatesRemoval(ports_to_prune);
}
return pruned;
}
void BasicPortAllocatorSession::PruneAllPorts() {
for (PortData& data : ports_) {
data.Prune();
}
}
void BasicPortAllocatorSession::OnPortComplete(Port* port) {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
RTC_LOG(LS_INFO) << port->ToString()
<< ": Port completed gathering candidates.";
PortData* data = FindPort(port);
RTC_DCHECK(data != nullptr);
// Ignore any late signals.
if (!data->inprogress()) {
return;
}
// Moving to COMPLETE state.
data->set_complete();
// Send candidate allocation complete signal if this was the last port.
FireAllocationStatusSignalsIfNeeded();
}
void BasicPortAllocatorSession::OnPortError(Port* port) {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
RTC_LOG(LS_INFO) << port->ToString()
<< ": Port encountered error while gathering candidates.";
PortData* data = FindPort(port);
RTC_DCHECK(data != nullptr);
// We might have already given up on this port and stopped it.
if (!data->inprogress()) {
return;
}
// SignalAddressError is currently sent from StunPort/TurnPort.
// But this signal itself is generic.
data->set_error();
// Send candidate allocation complete signal if this was the last port.
FireAllocationStatusSignalsIfNeeded();
}
bool BasicPortAllocatorSession::CheckCandidateFilter(const Candidate& c) const {
uint32_t filter = candidate_filter_;
// When binding to any address, before sending packets out, the getsockname
// returns all 0s, but after sending packets, it'll be the NIC used to
// send. All 0s is not a valid ICE candidate address and should be filtered
// out.
if (c.address().IsAnyIP()) {
return false;
}
if (c.type() == RELAY_PORT_TYPE) {
return ((filter & CF_RELAY) != 0);
} else if (c.type() == STUN_PORT_TYPE) {
return ((filter & CF_REFLEXIVE) != 0);
} else if (c.type() == LOCAL_PORT_TYPE) {
if ((filter & CF_REFLEXIVE) && !c.address().IsPrivateIP()) {
// We allow host candidates if the filter allows server-reflexive
// candidates and the candidate is a public IP. Because we don't generate
// server-reflexive candidates if they have the same IP as the host
// candidate (i.e. when the host candidate is a public IP), filtering to
// only server-reflexive candidates won't work right when the host
// candidates have public IPs.
return true;
}
return ((filter & CF_HOST) != 0);
}
return false;
}
bool BasicPortAllocatorSession::CandidatePairable(const Candidate& c,
const Port* port) const {
bool candidate_signalable = CheckCandidateFilter(c);
// When device enumeration is disabled (to prevent non-default IP addresses
// from leaking), we ping from some local candidates even though we don't
// signal them. However, if host candidates are also disabled (for example, to
// prevent even default IP addresses from leaking), we still don't want to
// ping from them, even if device enumeration is disabled. Thus, we check for
// both device enumeration and host candidates being disabled.
bool candidate_has_any_address = c.address().IsAnyIP();
bool can_ping_from_candidate =
(port->SharedSocket() || c.protocol() == TCP_PROTOCOL_NAME);
bool host_candidates_disabled = !(candidate_filter_ & CF_HOST);
return candidate_signalable ||
(candidate_has_any_address && can_ping_from_candidate &&
!host_candidates_disabled);
}
void BasicPortAllocatorSession::OnPortAllocationComplete(
AllocationSequence* seq) {
// Send candidate allocation complete signal if all ports are done.
FireAllocationStatusSignalsIfNeeded();
}
void BasicPortAllocatorSession::FireAllocationStatusSignalsIfNeeded() {
if (CandidatesAllocationDone()) {
// Now that allocation is done, we can surface any ports bound to the "any"
// address if they're not redundant (if they don't have the same address as
// a port bound to a specific interface). We don't surface them as soon as
// they're gathered because we may not know yet whether they're redundant.
//
// This also happens after a timeout of 2 seconds (see comment in
// DoAllocate); if allocation completes first we clear that timer since
// it's not needed.
network_thread_->Clear(this, MSG_SIGNAL_ANY_ADDRESS_PORTS);
SignalAnyAddressPortsAndCandidatesReadyIfNotRedundant();
if (pooled()) {
RTC_LOG(LS_INFO) << "All candidates gathered for pooled session.";
} else {
RTC_LOG(LS_INFO) << "All candidates gathered for " << content_name()
<< ":" << component() << ":" << generation();
}
SignalCandidatesAllocationDone(this);
}
}
// We detect the redundancy in any address ports as follows:
//
// 1. Delay the signaling of all any address ports and candidates gathered from
// these ports, which happens in OnCandidateReady.
//
// 2. For all non-any address ports, collect the IPs of their candidates
// (ignoring "active" TCP candidates, since no sockets are created for them
// until a connection is made and there's no guarantee they'll work).
//
// 3. For each any address port, compare their candidates to the existing IPs
// collected from step 2, and this port can be signaled if it has candidates
// with unseen IPs.
void BasicPortAllocatorSession::
SignalAnyAddressPortsAndCandidatesReadyIfNotRedundant() {
// Note that this is called either when allocation completes, or after a
// timeout, so some ports may still be waiting for STUN transactions to
// finish.
//
// First, get a list of all "any address" ports that have not yet been
// signaled, and a list of candidate IP addresses from all other ports.
std::vector<PortData*> maybe_signalable_any_address_ports;
std::set<rtc::IPAddress> ips_from_non_any_address_ports;
for (PortData& port_data : ports_) {
if (!port_data.ready()) {
continue;
}
if (IsAnyAddressPort(port_data.port())) {
if (!port_data.signaled()) {
maybe_signalable_any_address_ports.push_back(&port_data);
}
} else {
for (const Candidate& c : port_data.port()->Candidates()) {
// If the port of the candidate is |DISCARD_PORT| (9), this is an
// "active" TCP candidate and it doesn't mean we actually bound a
// socket to this address, so ignore it.
if (c.address().port() != DISCARD_PORT) {
ips_from_non_any_address_ports.insert(c.address().ipaddr());
if (port_data.port()->Type() == RELAY_PORT_TYPE) {
// The related address of a relay candidate is the server reflexive
// address obtained from the TURN allocation response.
ips_from_non_any_address_ports.insert(c.related_address().ipaddr());
}
}
}
}
}
// Now signal "any" address ports that have a unique address, and prune any
// that don't.
std::vector<PortData*> signalable_any_address_ports;
std::vector<PortData*> prunable_any_address_ports;
std::vector<Candidate> signalable_candidates_from_any_address_ports;
for (PortData* port_data : maybe_signalable_any_address_ports) {
bool port_signalable = false;
for (const Candidate& c : port_data->port()->Candidates()) {
if (!CandidatePairable(c, port_data->port()) ||
ips_from_non_any_address_ports.count(c.address().ipaddr()) ||
ips_from_non_any_address_ports.count(c.related_address().ipaddr())) {
continue;
}
// Even when a port is bound to the "any" address, it should normally
// still have an associated IP (determined by calling "connect" and then
// "getsockaddr"). Though sometimes even this fails (meaning |is_any_ip|
// will be true), and thus we have no way of knowing whether the port is
// redundant or not. In that case, we'll use the port if we have
// *no* ports bound to specific addresses. This is needed for corner
// cases such as bugs.webrtc.org/7798.
bool is_any_ip = rtc::IPIsAny(c.address().ipaddr());
if (is_any_ip && !ips_from_non_any_address_ports.empty()) {
continue;
}
port_signalable = true;
// Still need to check the candidiate filter and sanitize the related
// address before signaling the candidate itself.
if (CheckCandidateFilter(c)) {
signalable_candidates_from_any_address_ports.push_back(
SanitizeRelatedAddress(c));
}
}
if (port_signalable) {
signalable_any_address_ports.push_back(port_data);
} else {
prunable_any_address_ports.push_back(port_data);
}
}
PrunePorts(prunable_any_address_ports);
for (PortData* port_data : signalable_any_address_ports) {
RTC_LOG(INFO) << port_data->port()->ToString() << ": Port ready.";
SignalPortReady(this, port_data->port());
port_data->set_signaled();
}
RTC_LOG(INFO) << "Signaling candidates from the any address ports.";
SignalCandidatesReady(this, signalable_candidates_from_any_address_ports);
}
void BasicPortAllocatorSession::OnPortDestroyed(
PortInterface* port) {
RTC_DCHECK(rtc::Thread::Current() == network_thread_);
for (std::vector<PortData>::iterator iter = ports_.begin();
iter != ports_.end(); ++iter) {
if (port == iter->port()) {
ports_.erase(iter);
RTC_LOG(LS_INFO) << port->ToString() << ": Removed port from allocator ("
<< static_cast<int>(ports_.size()) << " remaining)";
return;
}
}
RTC_NOTREACHED();
}
BasicPortAllocatorSession::PortData* BasicPortAllocatorSession::FindPort(
Port* port) {
for (std::vector<PortData>::iterator it = ports_.begin(); it != ports_.end();
++it) {
if (it->port() == port) {
return &*it;
}
}
return nullptr;
}
std::vector<BasicPortAllocatorSession::PortData*>
BasicPortAllocatorSession::GetUnprunedPorts(
const std::vector<rtc::Network*>& networks) {
std::vector<PortData*> unpruned_ports;
for (PortData& port : ports_) {
if (!port.pruned() &&
std::find(networks.begin(), networks.end(),
port.sequence()->network()) != networks.end()) {
unpruned_ports.push_back(&port);
}
}
return unpruned_ports;
}
std::vector<Candidate> BasicPortAllocatorSession::PrunePorts(
const std::vector<PortData*>& port_data_list) {
std::vector<PortInterface*> pruned_ports;
std::vector<Candidate> removed_candidates;
for (PortData* data : port_data_list) {
// Prune the port so that it may be destroyed.
data->Prune();
pruned_ports.push_back(data->port());
if (data->has_pairable_candidate()) {
GetCandidatesFromPort(*data, &removed_candidates);
// Mark the port as having no pairable candidates so that its candidates
// won't be removed multiple times.
data->set_has_pairable_candidate(false);
}
}
if (!pruned_ports.empty()) {
SignalPortsPruned(this, pruned_ports);
}
return removed_candidates;
}
void BasicPortAllocatorSession::PrunePortsAndSignalCandidatesRemoval(
const std::vector<PortData*>& port_data_list) {
std::vector<Candidate> removed_candidates = PrunePorts(port_data_list);
if (!removed_candidates.empty()) {
RTC_LOG(LS_INFO) << "Removed " << removed_candidates.size()
<< " candidates";
SignalCandidatesRemoved(this, removed_candidates);
}
}
// AllocationSequence
AllocationSequence::AllocationSequence(BasicPortAllocatorSession* session,
rtc::Network* network,
PortConfiguration* config,
uint32_t flags)
: session_(session),
network_(network),
config_(config),
state_(kInit),
flags_(flags),
udp_socket_(),
udp_port_(nullptr),
phase_(0) {}
void AllocationSequence::Init() {
if (IsFlagSet(PORTALLOCATOR_ENABLE_SHARED_SOCKET)) {
udp_socket_.reset(session_->socket_factory()->CreateUdpSocket(
rtc::SocketAddress(network_->GetBestIP(), 0),
session_->allocator()->min_port(), session_->allocator()->max_port()));
if (udp_socket_) {
udp_socket_->SignalReadPacket.connect(this,
&AllocationSequence::OnReadPacket);
}
// Continuing if |udp_socket_| is null, as local TCP and RelayPort using
// TCP are next available options to setup a communication channel.
}
}
void AllocationSequence::Clear() {
udp_port_ = nullptr;
relay_ports_.clear();
}
void AllocationSequence::OnNetworkFailed() {
RTC_DCHECK(!network_failed_);
network_failed_ = true;
// Stop the allocation sequence if its network failed.
Stop();
}
AllocationSequence::~AllocationSequence() {
session_->network_thread()->Clear(this);
}
void AllocationSequence::DisableEquivalentPhases(rtc::Network* network,
PortConfiguration* config,
uint32_t* flags) {
if (network_failed_) {
// If the network of this allocation sequence has ever become failed,
// it won't be equivalent to the new network.
return;
}
if (!((network == network_) && (previous_best_ip_ == network->GetBestIP()))) {
// Different network setup; nothing is equivalent.
return;
}
// Else turn off the stuff that we've already got covered.
// Every config implicitly specifies local, so turn that off right away if we
// already have a port of the corresponding type. Look for a port that
// matches this AllocationSequence's network, is the right protocol, and
// hasn't encountered an error.
// TODO(deadbeef): This doesn't take into account that there may be another
// AllocationSequence that's ABOUT to allocate a UDP port, but hasn't yet.
// This can happen if, say, there's a network change event right before an
// application-triggered ICE restart. Hopefully this problem will just go
// away if we get rid of the gathering "phases" though, which is planned.
if (std::any_of(session_->ports_.begin(), session_->ports_.end(),
[this](const BasicPortAllocatorSession::PortData& p) {
return p.port()->Network() == network_ &&
p.port()->GetProtocol() == PROTO_UDP && !p.error();
})) {
*flags |= PORTALLOCATOR_DISABLE_UDP;
}
if (std::any_of(session_->ports_.begin(), session_->ports_.end(),
[this](const BasicPortAllocatorSession::PortData& p) {
return p.port()->Network() == network_ &&
p.port()->GetProtocol() == PROTO_TCP && !p.error();
})) {
*flags |= PORTALLOCATOR_DISABLE_TCP;
}
if (config_ && config) {
if (config_->StunServers() == config->StunServers()) {
// Already got this STUN servers covered.
*flags |= PORTALLOCATOR_DISABLE_STUN;
}
if (!config_->relays.empty()) {
// Already got relays covered.
// NOTE: This will even skip a _different_ set of relay servers if we
// were to be given one, but that never happens in our codebase. Should
// probably get rid of the list in PortConfiguration and just keep a
// single relay server in each one.
*flags |= PORTALLOCATOR_DISABLE_RELAY;
}
}
}
void AllocationSequence::Start() {
state_ = kRunning;
session_->network_thread()->Post(RTC_FROM_HERE, this, MSG_ALLOCATION_PHASE);
// Take a snapshot of the best IP, so that when DisableEquivalentPhases is
// called next time, we enable all phases if the best IP has since changed.
previous_best_ip_ = network_->GetBestIP();
}
void AllocationSequence::Stop() {
// If the port is completed, don't set it to stopped.
if (state_ == kRunning) {
state_ = kStopped;
session_->network_thread()->Clear(this, MSG_ALLOCATION_PHASE);
}
}
void AllocationSequence::OnMessage(rtc::Message* msg) {
RTC_DCHECK(rtc::Thread::Current() == session_->network_thread());
RTC_DCHECK(msg->message_id == MSG_ALLOCATION_PHASE);
const char* const PHASE_NAMES[kNumPhases] = {"Udp", "Relay", "Tcp"};
// Perform all of the phases in the current step.
RTC_LOG(LS_INFO) << network_->ToString()
<< ": Allocation Phase=" << PHASE_NAMES[phase_];
switch (phase_) {
case PHASE_UDP:
CreateUDPPorts();
CreateStunPorts();
break;
case PHASE_RELAY:
CreateRelayPorts();
break;
case PHASE_TCP:
CreateTCPPorts();
state_ = kCompleted;
break;
default:
RTC_NOTREACHED();
}
if (state() == kRunning) {
++phase_;
session_->network_thread()->PostDelayed(RTC_FROM_HERE,
session_->allocator()->step_delay(),
this, MSG_ALLOCATION_PHASE);
} else {
// If all phases in AllocationSequence are completed, no allocation
// steps needed further. Canceling pending signal.
session_->network_thread()->Clear(this, MSG_ALLOCATION_PHASE);
SignalPortAllocationComplete(this);
}
}
void AllocationSequence::CreateUDPPorts() {
if (IsFlagSet(PORTALLOCATOR_DISABLE_UDP)) {
RTC_LOG(LS_VERBOSE) << "AllocationSequence: UDP ports disabled, skipping.";
return;
}
// TODO(mallinath) - Remove UDPPort creating socket after shared socket
// is enabled completely.
UDPPort* port = nullptr;
bool emit_local_candidate_for_anyaddress =
!IsFlagSet(PORTALLOCATOR_DISABLE_DEFAULT_LOCAL_CANDIDATE);
if (IsFlagSet(PORTALLOCATOR_ENABLE_SHARED_SOCKET) && udp_socket_) {
port = UDPPort::Create(
session_->network_thread(), session_->socket_factory(), network_,
udp_socket_.get(), session_->username(), session_->password(),
session_->allocator()->origin(), emit_local_candidate_for_anyaddress,
session_->allocator()->stun_candidate_keepalive_interval());
} else {
port = UDPPort::Create(
session_->network_thread(), session_->socket_factory(), network_,
session_->allocator()->min_port(), session_->allocator()->max_port(),
session_->username(), session_->password(),
session_->allocator()->origin(), emit_local_candidate_for_anyaddress,
session_->allocator()->stun_candidate_keepalive_interval());
}
if (port) {
// If shared socket is enabled, STUN candidate will be allocated by the
// UDPPort.
if (IsFlagSet(PORTALLOCATOR_ENABLE_SHARED_SOCKET)) {
udp_port_ = port;
port->SignalDestroyed.connect(this, &AllocationSequence::OnPortDestroyed);
// If STUN is not disabled, setting stun server address to port.
if (!IsFlagSet(PORTALLOCATOR_DISABLE_STUN)) {
if (config_ && !config_->StunServers().empty()) {
RTC_LOG(LS_INFO)
<< "AllocationSequence: UDPPort will be handling the "
"STUN candidate generation.";
port->set_server_addresses(config_->StunServers());
}
}
}
session_->AddAllocatedPort(port, this, true);
}
}
void AllocationSequence::CreateTCPPorts() {
if (IsFlagSet(PORTALLOCATOR_DISABLE_TCP)) {
RTC_LOG(LS_VERBOSE) << "AllocationSequence: TCP ports disabled, skipping.";
return;
}
Port* port = TCPPort::Create(
session_->network_thread(), session_->socket_factory(), network_,
session_->allocator()->min_port(), session_->allocator()->max_port(),
session_->username(), session_->password(),
session_->allocator()->allow_tcp_listen());
if (port) {
session_->AddAllocatedPort(port, this, true);
// Since TCPPort is not created using shared socket, |port| will not be
// added to the dequeue.
}
}
void AllocationSequence::CreateStunPorts() {
if (IsFlagSet(PORTALLOCATOR_DISABLE_STUN)) {
RTC_LOG(LS_VERBOSE) << "AllocationSequence: STUN ports disabled, skipping.";
return;
}
if (IsFlagSet(PORTALLOCATOR_ENABLE_SHARED_SOCKET)) {
return;
}
if (!(config_ && !config_->StunServers().empty())) {
RTC_LOG(LS_WARNING)
<< "AllocationSequence: No STUN server configured, skipping.";
return;
}
StunPort* port = StunPort::Create(
session_->network_thread(), session_->socket_factory(), network_,
session_->allocator()->min_port(), session_->allocator()->max_port(),
session_->username(), session_->password(), config_->StunServers(),
session_->allocator()->origin(),
session_->allocator()->stun_candidate_keepalive_interval());
if (port) {
session_->AddAllocatedPort(port, this, true);
// Since StunPort is not created using shared socket, |port| will not be
// added to the dequeue.
}
}
void AllocationSequence::CreateRelayPorts() {
if (IsFlagSet(PORTALLOCATOR_DISABLE_RELAY)) {
RTC_LOG(LS_VERBOSE)
<< "AllocationSequence: Relay ports disabled, skipping.";
return;
}
// If BasicPortAllocatorSession::OnAllocate left relay ports enabled then we
// ought to have a relay list for them here.
RTC_DCHECK(config_);
RTC_DCHECK(!config_->relays.empty());
if (!(config_ && !config_->relays.empty())) {
RTC_LOG(LS_WARNING)
<< "AllocationSequence: No relay server configured, skipping.";
return;
}
for (RelayServerConfig& relay : config_->relays) {
if (relay.type == RELAY_GTURN) {
CreateGturnPort(relay);
} else if (relay.type == RELAY_TURN) {
CreateTurnPort(relay);
} else {
RTC_NOTREACHED();
}
}
}
void AllocationSequence::CreateGturnPort(const RelayServerConfig& config) {
// TODO(mallinath) - Rename RelayPort to GTurnPort.
RelayPort* port = RelayPort::Create(
session_->network_thread(), session_->socket_factory(), network_,
session_->allocator()->min_port(), session_->allocator()->max_port(),
config_->username, config_->password);
if (port) {
// Since RelayPort is not created using shared socket, |port| will not be
// added to the dequeue.
// Note: We must add the allocated port before we add addresses because
// the latter will create candidates that need name and preference
// settings. However, we also can't prepare the address (normally
// done by AddAllocatedPort) until we have these addresses. So we
// wait to do that until below.
session_->AddAllocatedPort(port, this, false);
// Add the addresses of this protocol.
PortList::const_iterator relay_port;
for (relay_port = config.ports.begin(); relay_port != config.ports.end();
++relay_port) {
port->AddServerAddress(*relay_port);
port->AddExternalAddress(*relay_port);
}
// Start fetching an address for this port.
port->PrepareAddress();
}
}
void AllocationSequence::CreateTurnPort(const RelayServerConfig& config) {
PortList::const_iterator relay_port;
for (relay_port = config.ports.begin(); relay_port != config.ports.end();
++relay_port) {
// Skip UDP connections to relay servers if it's disallowed.
if (IsFlagSet(PORTALLOCATOR_DISABLE_UDP_RELAY) &&
relay_port->proto == PROTO_UDP) {
continue;
}
// Do not create a port if the server address family is known and does
// not match the local IP address family.
int server_ip_family = relay_port->address.ipaddr().family();
int local_ip_family = network_->GetBestIP().family();
if (server_ip_family != AF_UNSPEC && server_ip_family != local_ip_family) {
RTC_LOG(LS_INFO)
<< "Server and local address families are not compatible. "
"Server address: "
<< relay_port->address.ipaddr().ToString()
<< " Local address: " << network_->GetBestIP().ToString();
continue;
}
CreateRelayPortArgs args;
args.network_thread = session_->network_thread();
args.socket_factory = session_->socket_factory();
args.network = network_;
args.username = session_->username();
args.password = session_->password();
args.server_address = &(*relay_port);
args.config = &config;
args.origin = session_->allocator()->origin();
args.turn_customizer = session_->allocator()->turn_customizer();
std::unique_ptr<cricket::Port> port;
// Shared socket mode must be enabled only for UDP based ports. Hence
// don't pass shared socket for ports which will create TCP sockets.
// TODO(mallinath) - Enable shared socket mode for TURN ports. Disabled
// due to webrtc bug https://code.google.com/p/webrtc/issues/detail?id=3537
if (IsFlagSet(PORTALLOCATOR_ENABLE_SHARED_SOCKET) &&
relay_port->proto == PROTO_UDP && udp_socket_) {
port = session_->allocator()->relay_port_factory()->Create(
args, udp_socket_.get());
if (!port) {
RTC_LOG(LS_WARNING) << "Failed to create relay port with "
<< args.server_address->address.ToString();
continue;
}
relay_ports_.push_back(port.get());
// Listen to the port destroyed signal, to allow AllocationSequence to
// remove entrt from it's map.
port->SignalDestroyed.connect(this, &AllocationSequence::OnPortDestroyed);
} else {
port = session_->allocator()->relay_port_factory()->Create(
args, session_->allocator()->min_port(),
session_->allocator()->max_port());
if (!port) {
RTC_LOG(LS_WARNING) << "Failed to create relay port with "
<< args.server_address->address.ToString();
continue;
}
}
RTC_DCHECK(port != nullptr);
session_->AddAllocatedPort(port.release(), this, true);
}
}
void AllocationSequence::OnReadPacket(rtc::AsyncPacketSocket* socket,
const char* data,
size_t size,
const rtc::SocketAddress& remote_addr,
const rtc::PacketTime& packet_time) {
RTC_DCHECK(socket == udp_socket_.get());
bool turn_port_found = false;
// Try to find the TurnPort that matches the remote address. Note that the
// message could be a STUN binding response if the TURN server is also used as
// a STUN server. We don't want to parse every message here to check if it is
// a STUN binding response, so we pass the message to TurnPort regardless of
// the message type. The TurnPort will just ignore the message since it will
// not find any request by transaction ID.
for (auto* port : relay_ports_) {
if (port->CanHandleIncomingPacketsFrom(remote_addr)) {
if (port->HandleIncomingPacket(socket, data, size, remote_addr,
packet_time)) {
return;
}
turn_port_found = true;
}
}
if (udp_port_) {
const ServerAddresses& stun_servers = udp_port_->server_addresses();
// Pass the packet to the UdpPort if there is no matching TurnPort, or if
// the TURN server is also a STUN server.
if (!turn_port_found ||
stun_servers.find(remote_addr) != stun_servers.end()) {
RTC_DCHECK(udp_port_->SharedSocket());
udp_port_->HandleIncomingPacket(socket, data, size, remote_addr,
packet_time);
}
}
}
void AllocationSequence::OnPortDestroyed(PortInterface* port) {
if (udp_port_ == port) {
udp_port_ = nullptr;
return;
}
auto it = std::find(relay_ports_.begin(), relay_ports_.end(), port);
if (it != relay_ports_.end()) {
relay_ports_.erase(it);
} else {
RTC_LOG(LS_ERROR) << "Unexpected OnPortDestroyed for nonexistent port.";
RTC_NOTREACHED();
}
}
// PortConfiguration
PortConfiguration::PortConfiguration(const rtc::SocketAddress& stun_address,
const std::string& username,
const std::string& password)
: stun_address(stun_address), username(username), password(password) {
if (!stun_address.IsNil())
stun_servers.insert(stun_address);
}
PortConfiguration::PortConfiguration(const ServerAddresses& stun_servers,
const std::string& username,
const std::string& password)
: stun_servers(stun_servers), username(username), password(password) {
if (!stun_servers.empty())
stun_address = *(stun_servers.begin());
}
PortConfiguration::~PortConfiguration() = default;
ServerAddresses PortConfiguration::StunServers() {
if (!stun_address.IsNil() &&
stun_servers.find(stun_address) == stun_servers.end()) {
stun_servers.insert(stun_address);
}
// Every UDP TURN server should also be used as a STUN server.
ServerAddresses turn_servers = GetRelayServerAddresses(RELAY_TURN, PROTO_UDP);
for (const rtc::SocketAddress& turn_server : turn_servers) {
if (stun_servers.find(turn_server) == stun_servers.end()) {
stun_servers.insert(turn_server);
}
}
return stun_servers;
}
void PortConfiguration::AddRelay(const RelayServerConfig& config) {
relays.push_back(config);
}
bool PortConfiguration::SupportsProtocol(const RelayServerConfig& relay,
ProtocolType type) const {
PortList::const_iterator relay_port;
for (relay_port = relay.ports.begin(); relay_port != relay.ports.end();
++relay_port) {
if (relay_port->proto == type)
return true;
}
return false;
}
bool PortConfiguration::SupportsProtocol(RelayType turn_type,
ProtocolType type) const {
for (size_t i = 0; i < relays.size(); ++i) {
if (relays[i].type == turn_type && SupportsProtocol(relays[i], type))
return true;
}
return false;
}
ServerAddresses PortConfiguration::GetRelayServerAddresses(
RelayType turn_type,
ProtocolType type) const {
ServerAddresses servers;
for (size_t i = 0; i < relays.size(); ++i) {
if (relays[i].type == turn_type && SupportsProtocol(relays[i], type)) {
servers.insert(relays[i].ports.front().address);
}
}
return servers;
}
} // namespace cricket