/* * 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 #include #include #include "pc/channel.h" #include "absl/memory/memory.h" #include "api/call/audio_sink.h" #include "media/base/mediaconstants.h" #include "media/base/rtputils.h" #include "modules/rtp_rtcp/source/rtp_packet_received.h" #include "rtc_base/bind.h" #include "rtc_base/byteorder.h" #include "rtc_base/checks.h" #include "rtc_base/copyonwritebuffer.h" #include "rtc_base/dscp.h" #include "rtc_base/logging.h" #include "rtc_base/networkroute.h" #include "rtc_base/trace_event.h" // Adding 'nogncheck' to disable the gn include headers check to support modular // WebRTC build targets. #include "media/engine/webrtcvoiceengine.h" // nogncheck #include "p2p/base/packettransportinternal.h" #include "pc/channelmanager.h" #include "pc/rtpmediautils.h" namespace cricket { using rtc::Bind; using webrtc::SdpType; namespace { struct SendPacketMessageData : public rtc::MessageData { rtc::CopyOnWriteBuffer packet; rtc::PacketOptions options; }; } // namespace enum { MSG_SEND_RTP_PACKET = 1, MSG_SEND_RTCP_PACKET, MSG_READYTOSENDDATA, MSG_DATARECEIVED, MSG_FIRSTPACKETRECEIVED, }; static void SafeSetError(const std::string& message, std::string* error_desc) { if (error_desc) { *error_desc = message; } } static bool ValidPacket(bool rtcp, const rtc::CopyOnWriteBuffer* packet) { // Check the packet size. We could check the header too if needed. return packet && IsValidRtpRtcpPacketSize(rtcp, packet->size()); } template void RtpParametersFromMediaDescription( const MediaContentDescriptionImpl* desc, const RtpHeaderExtensions& extensions, RtpParameters* params) { // TODO(pthatcher): Remove this once we're sure no one will give us // a description without codecs. Currently the ORTC implementation is relying // on this. if (desc->has_codecs()) { params->codecs = desc->codecs(); } // TODO(pthatcher): See if we really need // rtp_header_extensions_set() and remove it if we don't. if (desc->rtp_header_extensions_set()) { params->extensions = extensions; } params->rtcp.reduced_size = desc->rtcp_reduced_size(); } template void RtpSendParametersFromMediaDescription( const MediaContentDescriptionImpl* desc, const RtpHeaderExtensions& extensions, RtpSendParameters* send_params) { RtpParametersFromMediaDescription(desc, extensions, send_params); send_params->max_bandwidth_bps = desc->bandwidth(); } BaseChannel::BaseChannel(rtc::Thread* worker_thread, rtc::Thread* network_thread, rtc::Thread* signaling_thread, std::unique_ptr media_channel, const std::string& content_name, bool srtp_required, rtc::CryptoOptions crypto_options) : worker_thread_(worker_thread), network_thread_(network_thread), signaling_thread_(signaling_thread), content_name_(content_name), srtp_required_(srtp_required), crypto_options_(crypto_options), media_channel_(std::move(media_channel)) { RTC_DCHECK_RUN_ON(worker_thread_); demuxer_criteria_.mid = content_name; RTC_LOG(LS_INFO) << "Created channel for " << content_name; } BaseChannel::~BaseChannel() { TRACE_EVENT0("webrtc", "BaseChannel::~BaseChannel"); RTC_DCHECK_RUN_ON(worker_thread_); // Eats any outstanding messages or packets. worker_thread_->Clear(&invoker_); worker_thread_->Clear(this); // We must destroy the media channel before the transport channel, otherwise // the media channel may try to send on the dead transport channel. NULLing // is not an effective strategy since the sends will come on another thread. media_channel_.reset(); RTC_LOG(LS_INFO) << "Destroyed channel: " << content_name_; } bool BaseChannel::ConnectToRtpTransport() { RTC_DCHECK(rtp_transport_); if (!RegisterRtpDemuxerSink()) { return false; } rtp_transport_->SignalReadyToSend.connect( this, &BaseChannel::OnTransportReadyToSend); rtp_transport_->SignalRtcpPacketReceived.connect( this, &BaseChannel::OnRtcpPacketReceived); rtp_transport_->SignalNetworkRouteChanged.connect( this, &BaseChannel::OnNetworkRouteChanged); rtp_transport_->SignalWritableState.connect(this, &BaseChannel::OnWritableState); rtp_transport_->SignalSentPacket.connect(this, &BaseChannel::SignalSentPacket_n); return true; } void BaseChannel::DisconnectFromRtpTransport() { RTC_DCHECK(rtp_transport_); rtp_transport_->UnregisterRtpDemuxerSink(this); rtp_transport_->SignalReadyToSend.disconnect(this); rtp_transport_->SignalRtcpPacketReceived.disconnect(this); rtp_transport_->SignalNetworkRouteChanged.disconnect(this); rtp_transport_->SignalWritableState.disconnect(this); rtp_transport_->SignalSentPacket.disconnect(this); } void BaseChannel::Init_w(webrtc::RtpTransportInternal* rtp_transport) { RTC_DCHECK_RUN_ON(worker_thread_); network_thread_->Invoke( RTC_FROM_HERE, [this, rtp_transport] { SetRtpTransport(rtp_transport); }); // Both RTP and RTCP channels should be set, we can call SetInterface on // the media channel and it can set network options. media_channel_->SetInterface(this); } void BaseChannel::Deinit() { RTC_DCHECK(worker_thread_->IsCurrent()); media_channel_->SetInterface(NULL); // Packets arrive on the network thread, processing packets calls virtual // functions, so need to stop this process in Deinit that is called in // derived classes destructor. network_thread_->Invoke(RTC_FROM_HERE, [&] { FlushRtcpMessages_n(); if (rtp_transport_) { DisconnectFromRtpTransport(); } // Clear pending read packets/messages. network_thread_->Clear(&invoker_); network_thread_->Clear(this); }); } bool BaseChannel::SetRtpTransport(webrtc::RtpTransportInternal* rtp_transport) { if (rtp_transport == rtp_transport_) { return true; } if (!network_thread_->IsCurrent()) { return network_thread_->Invoke(RTC_FROM_HERE, [this, rtp_transport] { return SetRtpTransport(rtp_transport); }); } if (rtp_transport_) { DisconnectFromRtpTransport(); } rtp_transport_ = rtp_transport; if (rtp_transport_) { RTC_DCHECK(rtp_transport_->rtp_packet_transport()); transport_name_ = rtp_transport_->rtp_packet_transport()->transport_name(); if (!ConnectToRtpTransport()) { RTC_LOG(LS_ERROR) << "Failed to connect to the new RtpTransport."; return false; } OnTransportReadyToSend(rtp_transport_->IsReadyToSend()); UpdateWritableState_n(); // Set the cached socket options. for (const auto& pair : socket_options_) { rtp_transport_->rtp_packet_transport()->SetOption(pair.first, pair.second); } if (rtp_transport_->rtcp_packet_transport()) { for (const auto& pair : rtcp_socket_options_) { rtp_transport_->rtp_packet_transport()->SetOption(pair.first, pair.second); } } } return true; } bool BaseChannel::Enable(bool enable) { worker_thread_->Invoke( RTC_FROM_HERE, Bind(enable ? &BaseChannel::EnableMedia_w : &BaseChannel::DisableMedia_w, this)); return true; } bool BaseChannel::AddRecvStream(const StreamParams& sp) { demuxer_criteria_.ssrcs.insert(sp.first_ssrc()); if (!RegisterRtpDemuxerSink()) { return false; } return InvokeOnWorker(RTC_FROM_HERE, Bind(&BaseChannel::AddRecvStream_w, this, sp)); } bool BaseChannel::RemoveRecvStream(uint32_t ssrc) { demuxer_criteria_.ssrcs.erase(ssrc); if (!RegisterRtpDemuxerSink()) { return false; } return InvokeOnWorker( RTC_FROM_HERE, Bind(&BaseChannel::RemoveRecvStream_w, this, ssrc)); } bool BaseChannel::AddSendStream(const StreamParams& sp) { return InvokeOnWorker( RTC_FROM_HERE, Bind(&MediaChannel::AddSendStream, media_channel(), sp)); } bool BaseChannel::RemoveSendStream(uint32_t ssrc) { return InvokeOnWorker( RTC_FROM_HERE, Bind(&MediaChannel::RemoveSendStream, media_channel(), ssrc)); } bool BaseChannel::SetLocalContent(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "BaseChannel::SetLocalContent"); return InvokeOnWorker( RTC_FROM_HERE, Bind(&BaseChannel::SetLocalContent_w, this, content, type, error_desc)); } bool BaseChannel::SetRemoteContent(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "BaseChannel::SetRemoteContent"); return InvokeOnWorker( RTC_FROM_HERE, Bind(&BaseChannel::SetRemoteContent_w, this, content, type, error_desc)); } bool BaseChannel::IsReadyToReceiveMedia_w() const { // Receive data if we are enabled and have local content, return enabled() && webrtc::RtpTransceiverDirectionHasRecv(local_content_direction_); } bool BaseChannel::IsReadyToSendMedia_w() const { // Need to access some state updated on the network thread. return network_thread_->Invoke( RTC_FROM_HERE, Bind(&BaseChannel::IsReadyToSendMedia_n, this)); } bool BaseChannel::IsReadyToSendMedia_n() const { // Send outgoing data if we are enabled, have local and remote content, // and we have had some form of connectivity. return enabled() && webrtc::RtpTransceiverDirectionHasRecv(remote_content_direction_) && webrtc::RtpTransceiverDirectionHasSend(local_content_direction_) && was_ever_writable(); } bool BaseChannel::SendPacket(rtc::CopyOnWriteBuffer* packet, const rtc::PacketOptions& options) { return SendPacket(false, packet, options); } bool BaseChannel::SendRtcp(rtc::CopyOnWriteBuffer* packet, const rtc::PacketOptions& options) { return SendPacket(true, packet, options); } int BaseChannel::SetOption(SocketType type, rtc::Socket::Option opt, int value) { return network_thread_->Invoke( RTC_FROM_HERE, Bind(&BaseChannel::SetOption_n, this, type, opt, value)); } int BaseChannel::SetOption_n(SocketType type, rtc::Socket::Option opt, int value) { RTC_DCHECK(network_thread_->IsCurrent()); RTC_DCHECK(rtp_transport_); rtc::PacketTransportInternal* transport = nullptr; switch (type) { case ST_RTP: transport = rtp_transport_->rtp_packet_transport(); socket_options_.push_back( std::pair(opt, value)); break; case ST_RTCP: transport = rtp_transport_->rtcp_packet_transport(); rtcp_socket_options_.push_back( std::pair(opt, value)); break; } return transport ? transport->SetOption(opt, value) : -1; } void BaseChannel::OnWritableState(bool writable) { RTC_DCHECK(network_thread_->IsCurrent()); if (writable) { ChannelWritable_n(); } else { ChannelNotWritable_n(); } } void BaseChannel::OnNetworkRouteChanged( absl::optional network_route) { RTC_DCHECK(network_thread_->IsCurrent()); rtc::NetworkRoute new_route; if (network_route) { new_route = *(network_route); } // Note: When the RTCP-muxing is not enabled, RTCP transport and RTP transport // use the same transport name and MediaChannel::OnNetworkRouteChanged cannot // work correctly. Intentionally leave it broken to simplify the code and // encourage the users to stop using non-muxing RTCP. invoker_.AsyncInvoke(RTC_FROM_HERE, worker_thread_, [=] { media_channel_->OnNetworkRouteChanged(transport_name_, new_route); }); } void BaseChannel::OnTransportReadyToSend(bool ready) { invoker_.AsyncInvoke(RTC_FROM_HERE, worker_thread_, [=] { media_channel_->OnReadyToSend(ready); }); } bool BaseChannel::SendPacket(bool rtcp, rtc::CopyOnWriteBuffer* packet, const rtc::PacketOptions& options) { // SendPacket gets called from MediaEngine, on a pacer or an encoder thread. // If the thread is not our network thread, we will post to our network // so that the real work happens on our network. This avoids us having to // synchronize access to all the pieces of the send path, including // SRTP and the inner workings of the transport channels. // The only downside is that we can't return a proper failure code if // needed. Since UDP is unreliable anyway, this should be a non-issue. if (!network_thread_->IsCurrent()) { // Avoid a copy by transferring the ownership of the packet data. int message_id = rtcp ? MSG_SEND_RTCP_PACKET : MSG_SEND_RTP_PACKET; SendPacketMessageData* data = new SendPacketMessageData; data->packet = std::move(*packet); data->options = options; network_thread_->Post(RTC_FROM_HERE, this, message_id, data); return true; } TRACE_EVENT0("webrtc", "BaseChannel::SendPacket"); // Now that we are on the correct thread, ensure we have a place to send this // packet before doing anything. (We might get RTCP packets that we don't // intend to send.) If we've negotiated RTCP mux, send RTCP over the RTP // transport. if (!rtp_transport_ || !rtp_transport_->IsWritable(rtcp)) { return false; } // Protect ourselves against crazy data. if (!ValidPacket(rtcp, packet)) { RTC_LOG(LS_ERROR) << "Dropping outgoing " << content_name_ << " " << RtpRtcpStringLiteral(rtcp) << " packet: wrong size=" << packet->size(); return false; } if (!srtp_active()) { if (srtp_required_) { // The audio/video engines may attempt to send RTCP packets as soon as the // streams are created, so don't treat this as an error for RTCP. // See: https://bugs.chromium.org/p/webrtc/issues/detail?id=6809 if (rtcp) { return false; } // However, there shouldn't be any RTP packets sent before SRTP is set up // (and SetSend(true) is called). RTC_LOG(LS_ERROR) << "Can't send outgoing RTP packet when SRTP is inactive" << " and crypto is required"; RTC_NOTREACHED(); return false; } std::string packet_type = rtcp ? "RTCP" : "RTP"; RTC_LOG(LS_WARNING) << "Sending an " << packet_type << " packet without encryption."; } // Bon voyage. return rtcp ? rtp_transport_->SendRtcpPacket(packet, options, PF_SRTP_BYPASS) : rtp_transport_->SendRtpPacket(packet, options, PF_SRTP_BYPASS); } void BaseChannel::OnRtpPacket(const webrtc::RtpPacketReceived& parsed_packet) { // Reconstruct the PacketTime from the |parsed_packet|. // RtpPacketReceived.arrival_time_ms = (PacketTime + 500) / 1000; // Note: The |not_before| field is always 0 here. This field is not currently // used, so it should be fine. int64_t timestamp = -1; if (parsed_packet.arrival_time_ms() > 0) { timestamp = parsed_packet.arrival_time_ms() * 1000; } rtc::PacketTime packet_time(timestamp, /*not_before=*/0); OnPacketReceived(/*rtcp=*/false, parsed_packet.Buffer(), packet_time); } void BaseChannel::UpdateRtpHeaderExtensionMap( const RtpHeaderExtensions& header_extensions) { RTC_DCHECK(rtp_transport_); // Update the header extension map on network thread in case there is data // race. // TODO(zhihuang): Add an rtc::ThreadChecker make sure to RtpTransport won't // be accessed from different threads. // // NOTE: This doesn't take the BUNDLE case in account meaning the RTP header // extension maps are not merged when BUNDLE is enabled. This is fine because // the ID for MID should be consistent among all the RTP transports. network_thread_->Invoke(RTC_FROM_HERE, [this, &header_extensions] { rtp_transport_->UpdateRtpHeaderExtensionMap(header_extensions); }); } bool BaseChannel::RegisterRtpDemuxerSink() { RTC_DCHECK(rtp_transport_); return network_thread_->Invoke(RTC_FROM_HERE, [this] { return rtp_transport_->RegisterRtpDemuxerSink(demuxer_criteria_, this); }); } void BaseChannel::OnRtcpPacketReceived(rtc::CopyOnWriteBuffer* packet, const rtc::PacketTime& packet_time) { OnPacketReceived(/*rtcp=*/true, *packet, packet_time); } void BaseChannel::OnPacketReceived(bool rtcp, const rtc::CopyOnWriteBuffer& packet, const rtc::PacketTime& packet_time) { if (!has_received_packet_ && !rtcp) { has_received_packet_ = true; signaling_thread()->Post(RTC_FROM_HERE, this, MSG_FIRSTPACKETRECEIVED); } if (!srtp_active() && srtp_required_) { // Our session description indicates that SRTP is required, but we got a // packet before our SRTP filter is active. This means either that // a) we got SRTP packets before we received the SDES keys, in which case // we can't decrypt it anyway, or // b) we got SRTP packets before DTLS completed on both the RTP and RTCP // transports, so we haven't yet extracted keys, even if DTLS did // complete on the transport that the packets are being sent on. It's // really good practice to wait for both RTP and RTCP to be good to go // before sending media, to prevent weird failure modes, so it's fine // for us to just eat packets here. This is all sidestepped if RTCP mux // is used anyway. RTC_LOG(LS_WARNING) << "Can't process incoming " << RtpRtcpStringLiteral(rtcp) << " packet when SRTP is inactive and crypto is required"; return; } invoker_.AsyncInvoke( RTC_FROM_HERE, worker_thread_, Bind(&BaseChannel::ProcessPacket, this, rtcp, packet, packet_time)); } void BaseChannel::ProcessPacket(bool rtcp, const rtc::CopyOnWriteBuffer& packet, const rtc::PacketTime& packet_time) { RTC_DCHECK(worker_thread_->IsCurrent()); // Need to copy variable because OnRtcpReceived/OnPacketReceived // requires non-const pointer to buffer. This doesn't memcpy the actual data. rtc::CopyOnWriteBuffer data(packet); if (rtcp) { media_channel_->OnRtcpReceived(&data, packet_time); } else { media_channel_->OnPacketReceived(&data, packet_time); } } void BaseChannel::EnableMedia_w() { RTC_DCHECK(worker_thread_ == rtc::Thread::Current()); if (enabled_) return; RTC_LOG(LS_INFO) << "Channel enabled"; enabled_ = true; UpdateMediaSendRecvState_w(); } void BaseChannel::DisableMedia_w() { RTC_DCHECK(worker_thread_ == rtc::Thread::Current()); if (!enabled_) return; RTC_LOG(LS_INFO) << "Channel disabled"; enabled_ = false; UpdateMediaSendRecvState_w(); } void BaseChannel::UpdateWritableState_n() { if (rtp_transport_->IsWritable(/*rtcp=*/true) && rtp_transport_->IsWritable(/*rtcp=*/false)) { ChannelWritable_n(); } else { ChannelNotWritable_n(); } } void BaseChannel::ChannelWritable_n() { RTC_DCHECK(network_thread_->IsCurrent()); if (writable_) { return; } RTC_LOG(LS_INFO) << "Channel writable (" << content_name_ << ")" << (was_ever_writable_ ? "" : " for the first time"); was_ever_writable_ = true; writable_ = true; UpdateMediaSendRecvState(); } void BaseChannel::ChannelNotWritable_n() { RTC_DCHECK(network_thread_->IsCurrent()); if (!writable_) return; RTC_LOG(LS_INFO) << "Channel not writable (" << content_name_ << ")"; writable_ = false; UpdateMediaSendRecvState(); } bool BaseChannel::AddRecvStream_w(const StreamParams& sp) { RTC_DCHECK(worker_thread() == rtc::Thread::Current()); return media_channel()->AddRecvStream(sp); } bool BaseChannel::RemoveRecvStream_w(uint32_t ssrc) { RTC_DCHECK(worker_thread() == rtc::Thread::Current()); return media_channel()->RemoveRecvStream(ssrc); } bool BaseChannel::UpdateLocalStreams_w(const std::vector& streams, SdpType type, std::string* error_desc) { // Check for streams that have been removed. bool ret = true; for (StreamParamsVec::const_iterator it = local_streams_.begin(); it != local_streams_.end(); ++it) { if (it->has_ssrcs() && !GetStreamBySsrc(streams, it->first_ssrc())) { if (!media_channel()->RemoveSendStream(it->first_ssrc())) { std::ostringstream desc; desc << "Failed to remove send stream with ssrc " << it->first_ssrc() << "."; SafeSetError(desc.str(), error_desc); ret = false; } } } // Check for new streams. for (StreamParamsVec::const_iterator it = streams.begin(); it != streams.end(); ++it) { if (it->has_ssrcs() && !GetStreamBySsrc(local_streams_, it->first_ssrc())) { if (media_channel()->AddSendStream(*it)) { RTC_LOG(LS_INFO) << "Add send stream ssrc: " << it->ssrcs[0]; } else { std::ostringstream desc; desc << "Failed to add send stream ssrc: " << it->first_ssrc(); SafeSetError(desc.str(), error_desc); ret = false; } } } local_streams_ = streams; return ret; } bool BaseChannel::UpdateRemoteStreams_w( const std::vector& streams, SdpType type, std::string* error_desc) { // Check for streams that have been removed. bool ret = true; for (StreamParamsVec::const_iterator it = remote_streams_.begin(); it != remote_streams_.end(); ++it) { // If we no longer have an unsignaled stream, we would like to remove // the unsignaled stream params that are cached. if ((!it->has_ssrcs() && !HasStreamWithNoSsrcs(streams)) || !GetStreamBySsrc(streams, it->first_ssrc())) { if (RemoveRecvStream_w(it->first_ssrc())) { RTC_LOG(LS_INFO) << "Remove remote ssrc: " << it->first_ssrc(); } else { std::ostringstream desc; desc << "Failed to remove remote stream with ssrc " << it->first_ssrc() << "."; SafeSetError(desc.str(), error_desc); ret = false; } } } demuxer_criteria_.ssrcs.clear(); // Check for new streams. for (StreamParamsVec::const_iterator it = streams.begin(); it != streams.end(); ++it) { // We allow a StreamParams with an empty list of SSRCs, in which case the // MediaChannel will cache the parameters and use them for any unsignaled // stream received later. if ((!it->has_ssrcs() && !HasStreamWithNoSsrcs(remote_streams_)) || !GetStreamBySsrc(remote_streams_, it->first_ssrc())) { if (AddRecvStream_w(*it)) { RTC_LOG(LS_INFO) << "Add remote ssrc: " << it->first_ssrc(); } else { std::ostringstream desc; desc << "Failed to add remote stream ssrc: " << it->first_ssrc(); SafeSetError(desc.str(), error_desc); ret = false; } } // Update the receiving SSRCs. demuxer_criteria_.ssrcs.insert(it->ssrcs.begin(), it->ssrcs.end()); } // Re-register the sink to update the receiving ssrcs. RegisterRtpDemuxerSink(); remote_streams_ = streams; return ret; } RtpHeaderExtensions BaseChannel::GetFilteredRtpHeaderExtensions( const RtpHeaderExtensions& extensions) { RTC_DCHECK(rtp_transport_); if (crypto_options_.enable_encrypted_rtp_header_extensions) { RtpHeaderExtensions filtered; auto pred = [](const webrtc::RtpExtension& extension) { return !extension.encrypt; }; std::copy_if(extensions.begin(), extensions.end(), std::back_inserter(filtered), pred); return filtered; } return webrtc::RtpExtension::FilterDuplicateNonEncrypted(extensions); } void BaseChannel::OnMessage(rtc::Message* pmsg) { TRACE_EVENT0("webrtc", "BaseChannel::OnMessage"); switch (pmsg->message_id) { case MSG_SEND_RTP_PACKET: case MSG_SEND_RTCP_PACKET: { RTC_DCHECK(network_thread_->IsCurrent()); SendPacketMessageData* data = static_cast(pmsg->pdata); bool rtcp = pmsg->message_id == MSG_SEND_RTCP_PACKET; SendPacket(rtcp, &data->packet, data->options); delete data; break; } case MSG_FIRSTPACKETRECEIVED: { SignalFirstPacketReceived(this); break; } } } void BaseChannel::AddHandledPayloadType(int payload_type) { demuxer_criteria_.payload_types.insert(static_cast(payload_type)); } void BaseChannel::FlushRtcpMessages_n() { // Flush all remaining RTCP messages. This should only be called in // destructor. RTC_DCHECK(network_thread_->IsCurrent()); rtc::MessageList rtcp_messages; network_thread_->Clear(this, MSG_SEND_RTCP_PACKET, &rtcp_messages); for (const auto& message : rtcp_messages) { network_thread_->Send(RTC_FROM_HERE, this, MSG_SEND_RTCP_PACKET, message.pdata); } } void BaseChannel::SignalSentPacket_n(const rtc::SentPacket& sent_packet) { RTC_DCHECK(network_thread_->IsCurrent()); invoker_.AsyncInvoke( RTC_FROM_HERE, worker_thread_, rtc::Bind(&BaseChannel::SignalSentPacket_w, this, sent_packet)); } void BaseChannel::SignalSentPacket_w(const rtc::SentPacket& sent_packet) { RTC_DCHECK(worker_thread_->IsCurrent()); SignalSentPacket(sent_packet); } VoiceChannel::VoiceChannel(rtc::Thread* worker_thread, rtc::Thread* network_thread, rtc::Thread* signaling_thread, // TODO(nisse): Delete unused argument. MediaEngineInterface* /* media_engine */, std::unique_ptr media_channel, const std::string& content_name, bool srtp_required, rtc::CryptoOptions crypto_options) : BaseChannel(worker_thread, network_thread, signaling_thread, std::move(media_channel), content_name, srtp_required, crypto_options) {} VoiceChannel::~VoiceChannel() { TRACE_EVENT0("webrtc", "VoiceChannel::~VoiceChannel"); // this can't be done in the base class, since it calls a virtual DisableMedia_w(); Deinit(); } void BaseChannel::UpdateMediaSendRecvState() { RTC_DCHECK(network_thread_->IsCurrent()); invoker_.AsyncInvoke( RTC_FROM_HERE, worker_thread_, Bind(&BaseChannel::UpdateMediaSendRecvState_w, this)); } void VoiceChannel::UpdateMediaSendRecvState_w() { // Render incoming data if we're the active call, and we have the local // content. We receive data on the default channel and multiplexed streams. bool recv = IsReadyToReceiveMedia_w(); media_channel()->SetPlayout(recv); // Send outgoing data if we're the active call, we have the remote content, // and we have had some form of connectivity. bool send = IsReadyToSendMedia_w(); media_channel()->SetSend(send); RTC_LOG(LS_INFO) << "Changing voice state, recv=" << recv << " send=" << send; } bool VoiceChannel::SetLocalContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "VoiceChannel::SetLocalContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting local voice description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find audio content in local description.", error_desc); return false; } const AudioContentDescription* audio = content->as_audio(); RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(audio->rtp_header_extensions()); UpdateRtpHeaderExtensionMap(rtp_header_extensions); AudioRecvParameters recv_params = last_recv_params_; RtpParametersFromMediaDescription(audio, rtp_header_extensions, &recv_params); if (!media_channel()->SetRecvParameters(recv_params)) { SafeSetError("Failed to set local audio description recv parameters.", error_desc); return false; } for (const AudioCodec& codec : audio->codecs()) { AddHandledPayloadType(codec.id); } // Need to re-register the sink to update the handled payload. if (!RegisterRtpDemuxerSink()) { RTC_LOG(LS_ERROR) << "Failed to set up audio demuxing."; return false; } last_recv_params_ = recv_params; // TODO(pthatcher): Move local streams into AudioSendParameters, and // only give it to the media channel once we have a remote // description too (without a remote description, we won't be able // to send them anyway). if (!UpdateLocalStreams_w(audio->streams(), type, error_desc)) { SafeSetError("Failed to set local audio description streams.", error_desc); return false; } set_local_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } bool VoiceChannel::SetRemoteContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "VoiceChannel::SetRemoteContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting remote voice description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find audio content in remote description.", error_desc); return false; } const AudioContentDescription* audio = content->as_audio(); RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(audio->rtp_header_extensions()); AudioSendParameters send_params = last_send_params_; RtpSendParametersFromMediaDescription(audio, rtp_header_extensions, &send_params); send_params.mid = content_name(); bool parameters_applied = media_channel()->SetSendParameters(send_params); if (!parameters_applied) { SafeSetError("Failed to set remote audio description send parameters.", error_desc); return false; } last_send_params_ = send_params; // TODO(pthatcher): Move remote streams into AudioRecvParameters, // and only give it to the media channel once we have a local // description too (without a local description, we won't be able to // recv them anyway). if (!UpdateRemoteStreams_w(audio->streams(), type, error_desc)) { SafeSetError("Failed to set remote audio description streams.", error_desc); return false; } set_remote_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } VideoChannel::VideoChannel(rtc::Thread* worker_thread, rtc::Thread* network_thread, rtc::Thread* signaling_thread, std::unique_ptr media_channel, const std::string& content_name, bool srtp_required, rtc::CryptoOptions crypto_options) : BaseChannel(worker_thread, network_thread, signaling_thread, std::move(media_channel), content_name, srtp_required, crypto_options) {} VideoChannel::~VideoChannel() { TRACE_EVENT0("webrtc", "VideoChannel::~VideoChannel"); // this can't be done in the base class, since it calls a virtual DisableMedia_w(); Deinit(); } void VideoChannel::UpdateMediaSendRecvState_w() { // Send outgoing data if we're the active call, we have the remote content, // and we have had some form of connectivity. bool send = IsReadyToSendMedia_w(); if (!media_channel()->SetSend(send)) { RTC_LOG(LS_ERROR) << "Failed to SetSend on video channel"; // TODO(gangji): Report error back to server. } RTC_LOG(LS_INFO) << "Changing video state, send=" << send; } void VideoChannel::FillBitrateInfo(BandwidthEstimationInfo* bwe_info) { InvokeOnWorker(RTC_FROM_HERE, Bind(&VideoMediaChannel::FillBitrateInfo, media_channel(), bwe_info)); } bool VideoChannel::SetLocalContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "VideoChannel::SetLocalContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting local video description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find video content in local description.", error_desc); return false; } const VideoContentDescription* video = content->as_video(); RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(video->rtp_header_extensions()); UpdateRtpHeaderExtensionMap(rtp_header_extensions); VideoRecvParameters recv_params = last_recv_params_; RtpParametersFromMediaDescription(video, rtp_header_extensions, &recv_params); if (!media_channel()->SetRecvParameters(recv_params)) { SafeSetError("Failed to set local video description recv parameters.", error_desc); return false; } for (const VideoCodec& codec : video->codecs()) { AddHandledPayloadType(codec.id); } // Need to re-register the sink to update the handled payload. if (!RegisterRtpDemuxerSink()) { RTC_LOG(LS_ERROR) << "Failed to set up video demuxing."; return false; } last_recv_params_ = recv_params; // TODO(pthatcher): Move local streams into VideoSendParameters, and // only give it to the media channel once we have a remote // description too (without a remote description, we won't be able // to send them anyway). if (!UpdateLocalStreams_w(video->streams(), type, error_desc)) { SafeSetError("Failed to set local video description streams.", error_desc); return false; } set_local_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } bool VideoChannel::SetRemoteContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "VideoChannel::SetRemoteContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting remote video description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find video content in remote description.", error_desc); return false; } const VideoContentDescription* video = content->as_video(); RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(video->rtp_header_extensions()); VideoSendParameters send_params = last_send_params_; RtpSendParametersFromMediaDescription(video, rtp_header_extensions, &send_params); if (video->conference_mode()) { send_params.conference_mode = true; } send_params.mid = content_name(); bool parameters_applied = media_channel()->SetSendParameters(send_params); if (!parameters_applied) { SafeSetError("Failed to set remote video description send parameters.", error_desc); return false; } last_send_params_ = send_params; // TODO(pthatcher): Move remote streams into VideoRecvParameters, // and only give it to the media channel once we have a local // description too (without a local description, we won't be able to // recv them anyway). if (!UpdateRemoteStreams_w(video->streams(), type, error_desc)) { SafeSetError("Failed to set remote video description streams.", error_desc); return false; } set_remote_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } RtpDataChannel::RtpDataChannel(rtc::Thread* worker_thread, rtc::Thread* network_thread, rtc::Thread* signaling_thread, std::unique_ptr media_channel, const std::string& content_name, bool srtp_required, rtc::CryptoOptions crypto_options) : BaseChannel(worker_thread, network_thread, signaling_thread, std::move(media_channel), content_name, srtp_required, crypto_options) {} RtpDataChannel::~RtpDataChannel() { TRACE_EVENT0("webrtc", "RtpDataChannel::~RtpDataChannel"); // this can't be done in the base class, since it calls a virtual DisableMedia_w(); Deinit(); } void RtpDataChannel::Init_w(webrtc::RtpTransportInternal* rtp_transport) { BaseChannel::Init_w(rtp_transport); media_channel()->SignalDataReceived.connect(this, &RtpDataChannel::OnDataReceived); media_channel()->SignalReadyToSend.connect( this, &RtpDataChannel::OnDataChannelReadyToSend); } bool RtpDataChannel::SendData(const SendDataParams& params, const rtc::CopyOnWriteBuffer& payload, SendDataResult* result) { return InvokeOnWorker( RTC_FROM_HERE, Bind(&DataMediaChannel::SendData, media_channel(), params, payload, result)); } bool RtpDataChannel::CheckDataChannelTypeFromContent( const DataContentDescription* content, std::string* error_desc) { bool is_sctp = ((content->protocol() == kMediaProtocolSctp) || (content->protocol() == kMediaProtocolDtlsSctp)); // It's been set before, but doesn't match. That's bad. if (is_sctp) { SafeSetError("Data channel type mismatch. Expected RTP, got SCTP.", error_desc); return false; } return true; } bool RtpDataChannel::SetLocalContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "RtpDataChannel::SetLocalContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting local data description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find data content in local description.", error_desc); return false; } const DataContentDescription* data = content->as_data(); if (!CheckDataChannelTypeFromContent(data, error_desc)) { return false; } RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(data->rtp_header_extensions()); DataRecvParameters recv_params = last_recv_params_; RtpParametersFromMediaDescription(data, rtp_header_extensions, &recv_params); if (!media_channel()->SetRecvParameters(recv_params)) { SafeSetError("Failed to set remote data description recv parameters.", error_desc); return false; } for (const DataCodec& codec : data->codecs()) { AddHandledPayloadType(codec.id); } // Need to re-register the sink to update the handled payload. if (!RegisterRtpDemuxerSink()) { RTC_LOG(LS_ERROR) << "Failed to set up data demuxing."; return false; } last_recv_params_ = recv_params; // TODO(pthatcher): Move local streams into DataSendParameters, and // only give it to the media channel once we have a remote // description too (without a remote description, we won't be able // to send them anyway). if (!UpdateLocalStreams_w(data->streams(), type, error_desc)) { SafeSetError("Failed to set local data description streams.", error_desc); return false; } set_local_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } bool RtpDataChannel::SetRemoteContent_w(const MediaContentDescription* content, SdpType type, std::string* error_desc) { TRACE_EVENT0("webrtc", "RtpDataChannel::SetRemoteContent_w"); RTC_DCHECK_RUN_ON(worker_thread()); RTC_LOG(LS_INFO) << "Setting remote data description"; RTC_DCHECK(content); if (!content) { SafeSetError("Can't find data content in remote description.", error_desc); return false; } const DataContentDescription* data = content->as_data(); // If the remote data doesn't have codecs, it must be empty, so ignore it. if (!data->has_codecs()) { return true; } if (!CheckDataChannelTypeFromContent(data, error_desc)) { return false; } RtpHeaderExtensions rtp_header_extensions = GetFilteredRtpHeaderExtensions(data->rtp_header_extensions()); RTC_LOG(LS_INFO) << "Setting remote data description"; DataSendParameters send_params = last_send_params_; RtpSendParametersFromMediaDescription(data, rtp_header_extensions, &send_params); if (!media_channel()->SetSendParameters(send_params)) { SafeSetError("Failed to set remote data description send parameters.", error_desc); return false; } last_send_params_ = send_params; // TODO(pthatcher): Move remote streams into DataRecvParameters, // and only give it to the media channel once we have a local // description too (without a local description, we won't be able to // recv them anyway). if (!UpdateRemoteStreams_w(data->streams(), type, error_desc)) { SafeSetError("Failed to set remote data description streams.", error_desc); return false; } set_remote_content_direction(content->direction()); UpdateMediaSendRecvState_w(); return true; } void RtpDataChannel::UpdateMediaSendRecvState_w() { // Render incoming data if we're the active call, and we have the local // content. We receive data on the default channel and multiplexed streams. bool recv = IsReadyToReceiveMedia_w(); if (!media_channel()->SetReceive(recv)) { RTC_LOG(LS_ERROR) << "Failed to SetReceive on data channel"; } // Send outgoing data if we're the active call, we have the remote content, // and we have had some form of connectivity. bool send = IsReadyToSendMedia_w(); if (!media_channel()->SetSend(send)) { RTC_LOG(LS_ERROR) << "Failed to SetSend on data channel"; } // Trigger SignalReadyToSendData asynchronously. OnDataChannelReadyToSend(send); RTC_LOG(LS_INFO) << "Changing data state, recv=" << recv << " send=" << send; } void RtpDataChannel::OnMessage(rtc::Message* pmsg) { switch (pmsg->message_id) { case MSG_READYTOSENDDATA: { DataChannelReadyToSendMessageData* data = static_cast(pmsg->pdata); ready_to_send_data_ = data->data(); SignalReadyToSendData(ready_to_send_data_); delete data; break; } case MSG_DATARECEIVED: { DataReceivedMessageData* data = static_cast(pmsg->pdata); SignalDataReceived(data->params, data->payload); delete data; break; } default: BaseChannel::OnMessage(pmsg); break; } } void RtpDataChannel::OnDataReceived(const ReceiveDataParams& params, const char* data, size_t len) { DataReceivedMessageData* msg = new DataReceivedMessageData(params, data, len); signaling_thread()->Post(RTC_FROM_HERE, this, MSG_DATARECEIVED, msg); } void RtpDataChannel::OnDataChannelReadyToSend(bool writable) { // This is usded for congestion control to indicate that the stream is ready // to send by the MediaChannel, as opposed to OnReadyToSend, which indicates // that the transport channel is ready. signaling_thread()->Post(RTC_FROM_HERE, this, MSG_READYTOSENDDATA, new DataChannelReadyToSendMessageData(writable)); } } // namespace cricket