diff options
35 files changed, 1089 insertions, 249 deletions
diff --git a/net/base/net_util.cc b/net/base/net_util.cc index c4f00be..2dd92c1 100644 --- a/net/base/net_util.cc +++ b/net/base/net_util.cc @@ -1606,6 +1606,11 @@ std::string IPAddressToStringWithPort(const IPAddressNumber& addr, return IPAddressToStringWithPort(&addr.front(), addr.size(), port); } +std::string IPAddressToPackedString(const IPAddressNumber& addr) { + return std::string(reinterpret_cast<const char *>(&addr.front()), + addr.size()); +} + std::string GetHostName() { #if defined(OS_WIN) EnsureWinsockInit(); diff --git a/net/base/net_util.h b/net/base/net_util.h index ecd7400..113c8e8 100644 --- a/net/base/net_util.h +++ b/net/base/net_util.h @@ -166,6 +166,9 @@ NET_EXPORT std::string IPAddressToString(const IPAddressNumber& addr); NET_EXPORT std::string IPAddressToStringWithPort( const IPAddressNumber& addr, uint16 port); +// Returns the address as a sequence of bytes in network-byte-order. +NET_EXPORT std::string IPAddressToPackedString(const IPAddressNumber& addr); + // Returns the hostname of the current system. Returns empty string on failure. NET_EXPORT std::string GetHostName(); diff --git a/net/net.gyp b/net/net.gyp index 04609c7..16206bc 100644 --- a/net/net.gyp +++ b/net/net.gyp @@ -784,6 +784,8 @@ 'quic/crypto/strike_register.h', 'quic/crypto/source_address_token.cc', 'quic/crypto/source_address_token.h', + 'quic/quic_ack_notifier.cc', + 'quic/quic_ack_notifier.h', 'quic/quic_alarm.cc', 'quic/quic_alarm.h', 'quic/quic_bandwidth.cc', @@ -1747,6 +1749,7 @@ 'quic/test_tools/simple_quic_framer.h', 'quic/test_tools/test_task_runner.cc', 'quic/test_tools/test_task_runner.h', + 'quic/quic_ack_notifier_test.cc', 'quic/quic_alarm_test.cc', 'quic/quic_bandwidth_test.cc', 'quic/quic_client_session_test.cc', diff --git a/net/quic/crypto/crypto_server_config.cc b/net/quic/crypto/crypto_server_config.cc index f270dde..c5caa8c 100644 --- a/net/quic/crypto/crypto_server_config.cc +++ b/net/quic/crypto/crypto_server_config.cc @@ -11,6 +11,7 @@ #include "base/strings/string_number_conversions.h" #include "crypto/hkdf.h" #include "crypto/secure_hash.h" +#include "net/base/net_util.h" #include "net/quic/crypto/aes_128_gcm_12_decrypter.h" #include "net/quic/crypto/aes_128_gcm_12_encrypter.h" #include "net/quic/crypto/cert_compressor.h" @@ -56,6 +57,7 @@ QuicCryptoServerConfig::QuicCryptoServerConfig( next_config_promotion_time_(QuicWallTime::Zero()), strike_register_lock_(), server_nonce_strike_register_lock_(), + strike_register_no_startup_period_(false), strike_register_max_entries_(1 << 10), strike_register_window_secs_(600), source_address_token_future_secs_(3600), @@ -636,6 +638,8 @@ QuicErrorCode QuicCryptoServerConfig::EvaluateClientHello( static_cast<uint32>(info->now.ToUNIXSeconds()), strike_register_window_secs_, orbit, + strike_register_no_startup_period_ ? + StrikeRegister::NO_STARTUP_PERIOD_NEEDED : StrikeRegister::DENY_REQUESTS_AT_STARTUP)); } @@ -908,6 +912,12 @@ void QuicCryptoServerConfig::set_replay_protection(bool on) { replay_protection_ = on; } +void QuicCryptoServerConfig::set_strike_register_no_startup_period() { + base::AutoLock auto_lock(strike_register_lock_); + DCHECK(!strike_register_.get()); + strike_register_no_startup_period_ = true; +} + void QuicCryptoServerConfig::set_strike_register_max_entries( uint32 max_entries) { base::AutoLock locker(strike_register_lock_); @@ -949,7 +959,7 @@ string QuicCryptoServerConfig::NewSourceAddressToken( QuicRandom* rand, QuicWallTime now) const { SourceAddressToken source_address_token; - source_address_token.set_ip(ip.ToString()); + source_address_token.set_ip(IPAddressToPackedString(ip.address())); source_address_token.set_timestamp(now.ToUNIXSeconds()); return source_address_token_boxer_.Box( @@ -972,7 +982,7 @@ bool QuicCryptoServerConfig::ValidateSourceAddressToken( return false; } - if (source_address_token.ip() != ip.ToString()) { + if (source_address_token.ip() != IPAddressToPackedString(ip.address())) { // It's for a different IP address. return false; } diff --git a/net/quic/crypto/crypto_server_config.h b/net/quic/crypto/crypto_server_config.h index 364c200..cc40cb0 100644 --- a/net/quic/crypto/crypto_server_config.h +++ b/net/quic/crypto/crypto_server_config.h @@ -155,6 +155,10 @@ class NET_EXPORT_PRIVATE QuicCryptoServerConfig { // request to be processed twice. void set_replay_protection(bool on); + // set_strike_register_no_startup_period configures the strike register to + // not have a startup period. + void set_strike_register_no_startup_period(); + // set_strike_register_max_entries sets the maximum number of entries that // the internal strike register will hold. If the strike register fills up // then the oldest entries (by the client's clock) will be dropped. @@ -351,6 +355,7 @@ class NET_EXPORT_PRIVATE QuicCryptoServerConfig { // These fields store configuration values. See the comments for their // respective setter functions. + bool strike_register_no_startup_period_; uint32 strike_register_max_entries_; uint32 strike_register_window_secs_; uint32 source_address_token_future_secs_; diff --git a/net/quic/crypto/source_address_token.cc b/net/quic/crypto/source_address_token.cc index d15afeb..b095e76 100644 --- a/net/quic/crypto/source_address_token.cc +++ b/net/quic/crypto/source_address_token.cc @@ -21,24 +21,36 @@ SourceAddressToken::~SourceAddressToken() { } string SourceAddressToken::SerializeAsString() const { - return ip_ + " " + base::Int64ToString(timestamp_); + string out; + out.push_back(ip_.size()); + out.append(ip_); + string time_str = base::Int64ToString(timestamp_); + out.push_back(time_str.size()); + out.append(time_str); + return out; } bool SourceAddressToken::ParseFromArray(const char* plaintext, size_t plaintext_length) { - string data(plaintext, plaintext_length); - vector<string> results; - base::SplitString(data, ' ', &results); - if (results.size() < 2) { + if (plaintext_length == 0) { + return false; + } + size_t ip_len = plaintext[0]; + if (plaintext_length <= 1 + ip_len) { + return false; + } + size_t time_len = plaintext[1 + ip_len]; + if (plaintext_length != 1 + ip_len + 1 + time_len) { return false; } + string time_str(&plaintext[1 + ip_len + 1], time_len); int64 timestamp; - if (!base::StringToInt64(results[1], ×tamp)) { + if (!base::StringToInt64(time_str, ×tamp)) { return false; } - ip_ = results[0]; + ip_.assign(&plaintext[1], ip_len); timestamp_ = timestamp; return true; } diff --git a/net/quic/quic_ack_notifier.cc b/net/quic/quic_ack_notifier.cc new file mode 100644 index 0000000..662b432d --- /dev/null +++ b/net/quic/quic_ack_notifier.cc @@ -0,0 +1,56 @@ +// Copyright 2013 The Chromium Authors. All rights reserved. +// Use of this source code is governed by a BSD-style license that can be +// found in the LICENSE file. + +#include "net/quic/quic_ack_notifier.h" + +namespace net { + +QuicAckNotifier::DelegateInterface::DelegateInterface() {} + +QuicAckNotifier::DelegateInterface::~DelegateInterface() {} + +QuicAckNotifier::QuicAckNotifier(DelegateInterface* delegate) + : delegate_(delegate) { + DCHECK(delegate_); +} + +QuicAckNotifier::~QuicAckNotifier() {} + +void QuicAckNotifier::AddSequenceNumber( + const QuicPacketSequenceNumber& sequence_number) { + sequence_numbers_.insert(sequence_number); +} + +void QuicAckNotifier::AddSequenceNumbers( + const SequenceNumberSet& sequence_numbers) { + for (SequenceNumberSet::const_iterator it = sequence_numbers.begin(); + it != sequence_numbers.end(); ++it) { + AddSequenceNumber(*it); + } +} + +bool QuicAckNotifier::OnAck(SequenceNumberSet sequence_numbers) { + // If the set of sequence numbers we are tracking is empty then this + // QuicAckNotifier should have already been deleted. + DCHECK(!sequence_numbers_.empty()); + + for (SequenceNumberSet::iterator it = sequence_numbers.begin(); + it != sequence_numbers.end(); ++it) { + sequence_numbers_.erase(*it); + if (sequence_numbers_.empty()) { + delegate_->OnAckNotification(); + return true; + } + } + return false; +} + +void QuicAckNotifier::UpdateSequenceNumber( + QuicPacketSequenceNumber old_sequence_number, + QuicPacketSequenceNumber new_sequence_number) { + sequence_numbers_.erase(old_sequence_number); + sequence_numbers_.insert(new_sequence_number); +} + +}; // namespace net diff --git a/net/quic/quic_ack_notifier.h b/net/quic/quic_ack_notifier.h new file mode 100644 index 0000000..8470681 --- /dev/null +++ b/net/quic/quic_ack_notifier.h @@ -0,0 +1,66 @@ +// Copyright 2013 The Chromium Authors. All rights reserved. +// Use of this source code is governed by a BSD-style license that can be +// found in the LICENSE file. + +#ifndef NET_QUIC_QUIC_ACK_NOTIFIER_H_ +#define NET_QUIC_QUIC_ACK_NOTIFIER_H_ + +#include "base/callback.h" +#include "net/quic/quic_protocol.h" + +namespace net { + +// Used to register with a QuicConnection for notification once a set of packets +// have all been ACKed. +// The connection informs this class of newly ACKed sequence numbers, and once +// we have seen ACKs for all the sequence numbers we are interested in, we +// trigger a call to a provided Closure. +class NET_EXPORT_PRIVATE QuicAckNotifier { + public: + class NET_EXPORT_PRIVATE DelegateInterface { + public: + DelegateInterface(); + virtual ~DelegateInterface(); + virtual void OnAckNotification() = 0; + }; + + explicit QuicAckNotifier(DelegateInterface* delegate); + virtual ~QuicAckNotifier(); + + // Register a sequence number that this AckNotifier should be interested in. + void AddSequenceNumber(const QuicPacketSequenceNumber& sequence_number); + + // Register a set of sequence numbers that this AckNotifier should be + // interested in. + void AddSequenceNumbers(const SequenceNumberSet& sequence_numbers); + + // Called by the QuicConnection on receipt of new ACK frames with a list of + // ACKed sequence numbers. + // Deletes any matching sequence numbers from the set of sequence numbers + // being tracked. If this set is now empty, call the stored delegate's + // OnAckNotification method. + // + // Returns true if the provided sequence_numbers caused the delegate to be + // called, false otherwise. + bool OnAck(SequenceNumberSet sequence_numbers); + + // If a packet is retransmitted by the connection it will be sent with a + // different sequence number. Updates our internal set of sequence_numbers to + // track the latest number. + void UpdateSequenceNumber(QuicPacketSequenceNumber old_sequence_number, + QuicPacketSequenceNumber new_sequence_number); + + private: + // The delegate's OnAckNotification() method will be called once we have been + // notified of ACKs for all the sequence numbers we are tracking. + // This is not owned by OnAckNotifier and must outlive it. + DelegateInterface* delegate_; + + // Set of sequence numbers this notifier is waiting to hear about. The + // delegate will not be called until this is an empty set. + SequenceNumberSet sequence_numbers_; +}; + +}; // namespace net + +#endif // NET_QUIC_QUIC_ACK_NOTIFIER_H_ diff --git a/net/quic/quic_ack_notifier_test.cc b/net/quic/quic_ack_notifier_test.cc new file mode 100644 index 0000000..aa1ebfa --- /dev/null +++ b/net/quic/quic_ack_notifier_test.cc @@ -0,0 +1,106 @@ +// Copyright 2013 The Chromium Authors. All rights reserved. +// Use of this source code is governed by a BSD-style license that can be +// found in the LICENSE file. + +#include "net/quic/quic_ack_notifier.h" + +#include "net/quic/test_tools/quic_test_utils.h" +#include "testing/gmock/include/gmock/gmock.h" +#include "testing/gtest/include/gtest/gtest.h" + +namespace net { +namespace test { +namespace { + +class QuicAckNotifierTest : public ::testing::Test { + protected: + virtual void SetUp() { + notifier_.reset(new QuicAckNotifier(&delegate_)); + + sequence_numbers_.insert(26); + sequence_numbers_.insert(99); + sequence_numbers_.insert(1234); + notifier_->AddSequenceNumbers(sequence_numbers_); + } + + SequenceNumberSet sequence_numbers_; + MockAckNotifierDelegate delegate_; + scoped_ptr<QuicAckNotifier> notifier_; +}; + +// Should trigger callback when we receive acks for all the registered seqnums. +TEST_F(QuicAckNotifierTest, TriggerCallback) { + EXPECT_CALL(delegate_, OnAckNotification()).Times(1); + EXPECT_TRUE(notifier_->OnAck(sequence_numbers_)); +} + +// Should trigger callback when we receive acks for all the registered seqnums, +// even though they are interspersed with other seqnums. +TEST_F(QuicAckNotifierTest, TriggerCallbackInterspersed) { + sequence_numbers_.insert(3); + sequence_numbers_.insert(55); + sequence_numbers_.insert(805); + + EXPECT_CALL(delegate_, OnAckNotification()).Times(1); + EXPECT_TRUE(notifier_->OnAck(sequence_numbers_)); +} + +// Should trigger callback when we receive acks for all the registered seqnums, +// even though they are split over multiple calls to OnAck. +TEST_F(QuicAckNotifierTest, TriggerCallbackMultipleCalls) { + SequenceNumberSet seqnums; + seqnums.insert(26); + EXPECT_CALL(delegate_, OnAckNotification()).Times(0); + EXPECT_FALSE(notifier_->OnAck(seqnums)); + + seqnums.clear(); + seqnums.insert(55); + seqnums.insert(9001); + seqnums.insert(99); + EXPECT_CALL(delegate_, OnAckNotification()).Times(0); + EXPECT_FALSE(notifier_->OnAck(seqnums)); + + seqnums.clear(); + seqnums.insert(1234); + EXPECT_CALL(delegate_, OnAckNotification()).Times(1); + EXPECT_TRUE(notifier_->OnAck(seqnums)); +} + +// Should not trigger callback if we never provide all the seqnums. +TEST_F(QuicAckNotifierTest, DoesNotTrigger) { + SequenceNumberSet different_seqnums; + different_seqnums.insert(14); + different_seqnums.insert(15); + different_seqnums.insert(16); + + // Should not trigger callback as not all packets have been seen. + EXPECT_CALL(delegate_, OnAckNotification()).Times(0); + EXPECT_FALSE(notifier_->OnAck(different_seqnums)); +} + +// Should trigger even after updating sequence numbers and receiving ACKs for +// new sequeunce numbers. +TEST_F(QuicAckNotifierTest, UpdateSeqNums) { + // Uninteresting sequeunce numbers shouldn't trigger callback. + SequenceNumberSet seqnums; + seqnums.insert(6); + seqnums.insert(7); + seqnums.insert(2000); + EXPECT_CALL(delegate_, OnAckNotification()).Times(0); + EXPECT_FALSE(notifier_->OnAck(seqnums)); + + // Update a couple of the sequence numbers (i.e. retransmitted packets) + notifier_->UpdateSequenceNumber(99, 3000); + notifier_->UpdateSequenceNumber(1234, 3001); + + seqnums.clear(); + seqnums.insert(26); // original, unchanged + seqnums.insert(3000); // updated + seqnums.insert(3001); // updated + EXPECT_CALL(delegate_, OnAckNotification()).Times(1); + EXPECT_TRUE(notifier_->OnAck(seqnums)); +} + +} // namespace +} // namespace test +} // namespace net diff --git a/net/quic/quic_client_session.cc b/net/quic/quic_client_session.cc index 2980611..ec87d77 100644 --- a/net/quic/quic_client_session.cc +++ b/net/quic/quic_client_session.cc @@ -230,6 +230,10 @@ int QuicClientSession::CryptoConnect(bool require_confirmation, return ERR_IO_PENDING; } +int QuicClientSession::GetNumSentClientHellos() const { + return crypto_stream_->num_sent_client_hellos(); +} + ReliableQuicStream* QuicClientSession::CreateIncomingReliableStream( QuicStreamId id) { DLOG(ERROR) << "Server push not supported"; diff --git a/net/quic/quic_client_session.h b/net/quic/quic_client_session.h index 29531ec..a5973b6 100644 --- a/net/quic/quic_client_session.h +++ b/net/quic/quic_client_session.h @@ -132,6 +132,11 @@ class NET_EXPORT_PRIVATE QuicClientSession : public QuicSession { base::WeakPtr<QuicClientSession> GetWeakPtr(); + // Returns the number of client hello messages that have been sent on the + // crypto stream. If the handshake has completed then this is one greater + // than the number of round-trips needed for the handshake. + int GetNumSentClientHellos() const; + protected: // QuicSession methods: virtual ReliableQuicStream* CreateIncomingReliableStream( diff --git a/net/quic/quic_connection.cc b/net/quic/quic_connection.cc index 5cc97c1..748821e 100644 --- a/net/quic/quic_connection.cc +++ b/net/quic/quic_connection.cc @@ -190,6 +190,7 @@ QuicConnection::QuicConnection(QuicGuid guid, } QuicConnection::~QuicConnection() { + STLDeleteElements(&ack_notifiers_); STLDeleteElements(&undecryptable_packets_); STLDeleteValues(&unacked_packets_); STLDeleteValues(&group_map_); @@ -456,6 +457,23 @@ void QuicConnection::ProcessAckFrame(const QuicAckFrame& incoming_ack) { HandleAckForSentFecPackets(incoming_ack, &acked_packets); if (acked_packets.size() > 0) { visitor_->OnAck(acked_packets); + + // Inform all the registered AckNotifiers of the new ACKs. + // TODO(rjshade): Make this more efficient by maintaining a mapping of + // <sequence number, set<AckNotifierList>> so that OnAck + // is only called on AckNotifiers that care about the + // packets being ACKed. + AckNotifierList::iterator it = ack_notifiers_.begin(); + while (it != ack_notifiers_.end()) { + if ((*it)->OnAck(acked_packets)) { + // The QuicAckNotifier has seen all the ACKs it was interested in, and + // has triggered its callback. No more use for it. + delete *it; + it = ack_notifiers_.erase(it); + } else { + ++it; + } + } } congestion_manager_.OnIncomingAckFrame(incoming_ack, time_of_last_received_packet_); @@ -821,6 +839,30 @@ QuicConsumedData QuicConnection::SendStreamData(QuicStreamId id, return consumed_data; } +QuicConsumedData QuicConnection::SendStreamDataAndNotifyWhenAcked( + QuicStreamId id, + StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier::DelegateInterface* delegate) { + // This notifier will be deleted in ProcessAckFrame once it has seen ACKs for + // all the consumed data (or below if no data was consumed). + QuicAckNotifier* notifier = new QuicAckNotifier(delegate); + QuicConsumedData consumed_data = + packet_generator_.ConsumeData(id, data, offset, fin, notifier); + + if (consumed_data.bytes_consumed > 0) { + // If some data was consumed, then the delegate should be registered for + // notification when the data is ACKed. + ack_notifiers_.push_back(notifier); + } else { + // No data was consumed, delete the notifier. + delete notifier; + } + + return consumed_data; +} + void QuicConnection::SendRstStream(QuicStreamId id, QuicRstStreamErrorCode error) { LOG(INFO) << "Sending RST_STREAM: " << id << " code: " << error; @@ -1062,14 +1104,23 @@ void QuicConnection::RetransmitPacket( // Remove info with old sequence number. unacked_packets_.erase(unacked_it); retransmission_map_.erase(retransmission_it); - DVLOG(1) << ENDPOINT << "Retransmitting unacked packet " << sequence_number - << " as " << serialized_packet.sequence_number; + DLOG(INFO) << ENDPOINT << "Retransmitting unacked packet " << sequence_number + << " as " << serialized_packet.sequence_number; DCHECK(unacked_packets_.empty() || unacked_packets_.rbegin()->first < serialized_packet.sequence_number); unacked_packets_.insert(make_pair(serialized_packet.sequence_number, unacked)); retransmission_map_.insert(make_pair(serialized_packet.sequence_number, retransmission_info)); + + // A notifier may be waiting to hear about ACKs for the original sequence + // number. Inform them that the sequence number has changed. + for (AckNotifierList::iterator notifier_it = ack_notifiers_.begin(); + notifier_it != ack_notifiers_.end(); ++notifier_it) { + (*notifier_it)->UpdateSequenceNumber(sequence_number, + serialized_packet.sequence_number); + } + if (debug_visitor_) { debug_visitor_->OnPacketRetransmitted(sequence_number, serialized_packet.sequence_number); diff --git a/net/quic/quic_connection.h b/net/quic/quic_connection.h index 08fffaa..a23ecf0 100644 --- a/net/quic/quic_connection.h +++ b/net/quic/quic_connection.h @@ -27,6 +27,7 @@ #include "net/base/ip_endpoint.h" #include "net/base/linked_hash_map.h" #include "net/quic/congestion_control/quic_congestion_manager.h" +#include "net/quic/quic_ack_notifier.h" #include "net/quic/quic_alarm.h" #include "net/quic/quic_blocked_writer_interface.h" #include "net/quic/quic_connection_stats.h" @@ -213,6 +214,16 @@ class NET_EXPORT_PRIVATE QuicConnection base::StringPiece data, QuicStreamOffset offset, bool fin); + // Same as above, except that the provided delegate will be informed once ACKs + // have been received for all the packets written. + // The |delegate| is not owned by the QuicConnection and must outlive it. + QuicConsumedData SendStreamDataAndNotifyWhenAcked( + QuicStreamId id, + base::StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier::DelegateInterface* delegate); + // Send a stream reset frame to the peer. virtual void SendRstStream(QuicStreamId id, QuicRstStreamErrorCode error); @@ -504,6 +515,7 @@ class NET_EXPORT_PRIVATE QuicConnection std::vector<RetransmissionTime>, RetransmissionTimeComparator> RetransmissionTimeouts; + typedef std::list<QuicAckNotifier*> AckNotifierList; // Sends a version negotiation packet to the peer. void SendVersionNegotiationPacket(); @@ -701,6 +713,12 @@ class NET_EXPORT_PRIVATE QuicConnection // This is checked later on validating a data or version negotiation packet. bool address_migrating_; + // On every ACK frame received by this connection, all the ack_notifiers_ will + // be told which sequeunce numbers were ACKed. + // Once a given QuicAckNotifier has seen all the sequence numbers it is + // interested in, it will be deleted, and removed from this list. + AckNotifierList ack_notifiers_; + DISALLOW_COPY_AND_ASSIGN(QuicConnection); }; diff --git a/net/quic/quic_connection_test.cc b/net/quic/quic_connection_test.cc index 6e4631b..e57e7ae 100644 --- a/net/quic/quic_connection_test.cc +++ b/net/quic/quic_connection_test.cc @@ -570,20 +570,27 @@ class QuicConnectionTest : public ::testing::Test { return ProcessDataPacket(number, 1, entropy_flag); } - // Sends an FEC packet that covers the packets that would have been sent. + // Processes an FEC packet that covers the packets that would have been + // received. size_t ProcessFecPacket(QuicPacketSequenceNumber number, QuicPacketSequenceNumber min_protected_packet, bool expect_revival, - bool entropy_flag) { + bool entropy_flag, + QuicPacket* packet) { if (expect_revival) { EXPECT_CALL(visitor_, OnPacket(_, _, _, _)).WillOnce(DoAll( SaveArg<2>(&revived_header_), Return(accept_packet_))); } // Construct the decrypted data packet so we can compute the correct - // redundancy. - scoped_ptr<QuicPacket> data_packet(ConstructDataPacket(number, 1, - !kEntropyFlag)); + // redundancy. If |packet| has been provided then use that, otherwise + // construct a default data packet. + scoped_ptr<QuicPacket> data_packet; + if (packet) { + data_packet.reset(packet); + } else { + data_packet.reset(ConstructDataPacket(number, 1, !kEntropyFlag)); + } header_.public_header.guid = guid_; header_.public_header.reset_flag = false; @@ -595,6 +602,7 @@ class QuicConnectionTest : public ::testing::Test { header_.fec_group = min_protected_packet; QuicFecData fec_data; fec_data.fec_group = header_.fec_group; + // Since all data packets in this test have the same payload, the // redundancy is either equal to that payload or the xor of that payload // with itself, depending on the number of packets. @@ -608,6 +616,7 @@ class QuicConnectionTest : public ::testing::Test { } } fec_data.redundancy = data_packet->FecProtectedData(); + scoped_ptr<QuicPacket> fec_packet( framer_.BuildFecPacket(header_, fec_data).packet); scoped_ptr<QuicEncryptedPacket> encrypted( @@ -1598,14 +1607,14 @@ TEST_F(QuicConnectionTest, DontLatchUnackedPacket) { TEST_F(QuicConnectionTest, ReviveMissingPacketAfterFecPacket) { // Don't send missing packet 1. - ProcessFecPacket(2, 1, true, !kEntropyFlag); + ProcessFecPacket(2, 1, true, !kEntropyFlag, NULL); EXPECT_FALSE(revived_header_.entropy_flag); } TEST_F(QuicConnectionTest, ReviveMissingPacketAfterDataPacketThenFecPacket) { ProcessFecProtectedPacket(1, false, kEntropyFlag); // Don't send missing packet 2. - ProcessFecPacket(3, 1, true, !kEntropyFlag); + ProcessFecPacket(3, 1, true, !kEntropyFlag, NULL); EXPECT_TRUE(revived_header_.entropy_flag); } @@ -1613,13 +1622,13 @@ TEST_F(QuicConnectionTest, ReviveMissingPacketAfterDataPacketsThenFecPacket) { ProcessFecProtectedPacket(1, false, !kEntropyFlag); // Don't send missing packet 2. ProcessFecProtectedPacket(3, false, !kEntropyFlag); - ProcessFecPacket(4, 1, true, kEntropyFlag); + ProcessFecPacket(4, 1, true, kEntropyFlag, NULL); EXPECT_TRUE(revived_header_.entropy_flag); } TEST_F(QuicConnectionTest, ReviveMissingPacketAfterDataPacket) { // Don't send missing packet 1. - ProcessFecPacket(3, 1, false, !kEntropyFlag); + ProcessFecPacket(3, 1, false, !kEntropyFlag, NULL); // out of order ProcessFecProtectedPacket(2, true, !kEntropyFlag); EXPECT_FALSE(revived_header_.entropy_flag); @@ -1628,7 +1637,7 @@ TEST_F(QuicConnectionTest, ReviveMissingPacketAfterDataPacket) { TEST_F(QuicConnectionTest, ReviveMissingPacketAfterDataPackets) { ProcessFecProtectedPacket(1, false, !kEntropyFlag); // Don't send missing packet 2. - ProcessFecPacket(6, 1, false, kEntropyFlag); + ProcessFecPacket(6, 1, false, kEntropyFlag, NULL); ProcessFecProtectedPacket(3, false, kEntropyFlag); ProcessFecProtectedPacket(4, false, kEntropyFlag); ProcessFecProtectedPacket(5, true, !kEntropyFlag); @@ -1899,7 +1908,7 @@ TEST_F(QuicConnectionTest, DontUpdateQuicCongestionFeedbackFrameForRevived) { // Process an FEC packet, and revive the missing data packet // but only contact the receive_algorithm once. EXPECT_CALL(*receive_algorithm_, RecordIncomingPacket(_, _, _, _)); - ProcessFecPacket(2, 1, true, !kEntropyFlag); + ProcessFecPacket(2, 1, true, !kEntropyFlag, NULL); } TEST_F(QuicConnectionTest, InitialTimeout) { @@ -2477,7 +2486,7 @@ TEST_F(QuicConnectionTest, CheckReceiveStats) { received_bytes += ProcessFecProtectedPacket(3, false, !kEntropyFlag); // Should be counted against dropped packets. received_bytes += ProcessDataPacket(3, 1, !kEntropyFlag); - received_bytes += ProcessFecPacket(4, 1, true, !kEntropyFlag); // Fec packet + received_bytes += ProcessFecPacket(4, 1, true, !kEntropyFlag, NULL); EXPECT_CALL(*send_algorithm_, SmoothedRtt()).WillOnce( Return(QuicTime::Delta::Zero())); @@ -2612,6 +2621,129 @@ TEST_F(QuicConnectionTest, ConnectionCloseWhenNothingPending) { EXPECT_EQ(1u, helper_->packets_write_attempts()); } +TEST_F(QuicConnectionTest, AckNotifierTriggerCallback) { + // Create a delegate which we expect to be called. + MockAckNotifierDelegate delegate; + EXPECT_CALL(delegate, OnAckNotification()).Times(1);; + + // Send some data, which will register the delegate to be notified. + connection_.SendStreamDataAndNotifyWhenAcked(1, "foo", 0, !kFin, &delegate); + + // Process an ACK from the server which should trigger the callback. + EXPECT_CALL(visitor_, OnAck(_)).Times(1); + EXPECT_CALL(*send_algorithm_, OnIncomingAck(_, _, _)).Times(1); + QuicAckFrame frame(1, QuicTime::Zero(), 0); + ProcessAckPacket(&frame, true); +} + +TEST_F(QuicConnectionTest, AckNotifierFailToTriggerCallback) { + // Create a delegate which we don't expect to be called. + MockAckNotifierDelegate delegate; + EXPECT_CALL(delegate, OnAckNotification()).Times(0);; + + EXPECT_CALL(visitor_, OnAck(_)).Times(1); + EXPECT_CALL(*send_algorithm_, OnIncomingAck(_, _, _)).Times(2); + EXPECT_CALL(*send_algorithm_, OnIncomingLoss(_)).Times(1); + + // Send some data, which will register the delegate to be notified. This will + // not be ACKed and so the delegate should never be called. + connection_.SendStreamDataAndNotifyWhenAcked(1, "foo", 0, !kFin, &delegate); + + // Send some other data which we will ACK. + connection_.SendStreamData(1, "foo", 0, !kFin); + connection_.SendStreamData(1, "bar", 0, !kFin); + + // Now we receive ACK for packets 2 and 3, but importantly missing packet 1 + // which we registered to be notified about. + QuicAckFrame frame(3, QuicTime::Zero(), 0); + frame.received_info.missing_packets.insert(1); + ProcessAckPacket(&frame, true); +} + +TEST_F(QuicConnectionTest, AckNotifierCallbackAfterRetransmission) { + // Create a delegate which we expect to be called. + MockAckNotifierDelegate delegate; + EXPECT_CALL(delegate, OnAckNotification()).Times(1);; + + // OnAck called twice: once with missing packet, once after retransmit. + EXPECT_CALL(visitor_, OnAck(_)).Times(2); + + // In total expect ACKs for all 4 packets. + EXPECT_CALL(*send_algorithm_, OnIncomingAck(_, _, _)).Times(4); + + // We will lose the second packet. + EXPECT_CALL(*send_algorithm_, OnIncomingLoss(_)).Times(1); + + // Send four packets, and register to be notified on ACK of packet 2. + connection_.SendStreamData(1, "foo", 0, !kFin); + connection_.SendStreamDataAndNotifyWhenAcked(1, "bar", 0, !kFin, &delegate); + connection_.SendStreamData(1, "baz", 0, !kFin); + connection_.SendStreamData(1, "qux", 0, !kFin); + + // Now we receive ACK for packets 1, 3, and 4. + QuicAckFrame frame(4, QuicTime::Zero(), 0); + frame.received_info.missing_packets.insert(2); + ProcessAckPacket(&frame, true); + + // Advance time to trigger RTO, for packet 2 (which should be retransmitted as + // packet 5). + EXPECT_CALL(*send_algorithm_, AbandoningPacket(2, _)).Times(1); + EXPECT_CALL(*send_algorithm_, SentPacket(_, _, _, _)).Times(1); + + clock_.AdvanceTime(DefaultRetransmissionTime()); + connection_.OnRetransmissionTimeout(); + + // Now we get an ACK for packet 5 (retransmitted packet 2), which should + // trigger the callback. + QuicAckFrame second_ack_frame(5, QuicTime::Zero(), 0); + ProcessAckPacket(&second_ack_frame, true); +} + +// TODO(rjshade): Add a similar test that FEC recovery on peer (and resulting +// ACK) triggers notification on our end. +TEST_F(QuicConnectionTest, AckNotifierCallbackAfterFECRecovery) { + EXPECT_CALL(visitor_, OnCanWrite()).Times(1).WillOnce(Return(true)); + + // Create a delegate which we expect to be called. + MockAckNotifierDelegate delegate; + EXPECT_CALL(delegate, OnAckNotification()).Times(1);; + + // Expect ACKs for 1 packet. + EXPECT_CALL(visitor_, OnAck(_)).Times(1); + EXPECT_CALL(*send_algorithm_, OnIncomingAck(_, _, _)).Times(1); + + // Send one packet, and register to be notified on ACK. + connection_.SendStreamDataAndNotifyWhenAcked(1, "foo", 0, !kFin, &delegate); + + // Ack packet gets dropped, but we receive an FEC packet that covers it. + // Should recover the Ack packet and trigger the notification callback. + QuicFrames frames; + + QuicAckFrame ack_frame(1, QuicTime::Zero(), 0); + frames.push_back(QuicFrame(&ack_frame)); + + // Dummy stream frame to satisfy expectations set elsewhere. + QuicFrame frame(&frame1_); + frames.push_back(frame); + + QuicPacketHeader ack_header; + ack_header.public_header.guid = guid_; + ack_header.public_header.reset_flag = false; + ack_header.public_header.version_flag = false; + ack_header.entropy_flag = !kEntropyFlag; + ack_header.fec_flag = true; + ack_header.packet_sequence_number = 42; + ack_header.is_in_fec_group = IN_FEC_GROUP; + ack_header.fec_group = 1; + + QuicPacket* packet = + framer_.BuildUnsizedDataPacket(ack_header, frames).packet; + + // Take the packet which contains the ACK frame, and construct and deliver an + // FEC packet which allows the ACK packet to be recovered. + ProcessFecPacket(2, 1, true, !kEntropyFlag, packet); +} + class MockQuicConnectionDebugVisitor : public QuicConnectionDebugVisitorInterface { public: diff --git a/net/quic/quic_crypto_client_stream.cc b/net/quic/quic_crypto_client_stream.cc index 585b293..a6ef6bc 100644 --- a/net/quic/quic_crypto_client_stream.cc +++ b/net/quic/quic_crypto_client_stream.cc @@ -152,7 +152,7 @@ void QuicCryptoClientStream::DoHandshakeLoop( crypto_config_->LookupOrCreate(server_hostname_); if (in != NULL) { - DVLOG(1) << "Client received: " << in->DebugString(); + DVLOG(1) << "Client: Received " << in->DebugString(); } for (;;) { @@ -172,7 +172,7 @@ void QuicCryptoClientStream::DoHandshakeLoop( crypto_config_->FillInchoateClientHello( server_hostname_, cached, &crypto_negotiated_params_, &out); next_state_ = STATE_RECV_REJ; - DVLOG(1) << "Client Sending: " << out.DebugString(); + DVLOG(1) << "Client: Sending " << out.DebugString(); SendHandshakeMessage(out); return; } @@ -200,7 +200,7 @@ void QuicCryptoClientStream::DoHandshakeLoop( cert_verify_result_.reset(); } next_state_ = STATE_RECV_SHLO; - DVLOG(1) << "Client Sending: " << out.DebugString(); + DVLOG(1) << "Client: Sending " << out.DebugString(); SendHandshakeMessage(out); // Be prepared to decrypt with the new server write key. session()->connection()->SetAlternativeDecrypter( diff --git a/net/quic/quic_framer.cc b/net/quic/quic_framer.cc index 6004e3b..4160ddc 100644 --- a/net/quic/quic_framer.cc +++ b/net/quic/quic_framer.cc @@ -20,6 +20,19 @@ namespace net { namespace { +// TODO(jri): Remove uses of QuicFrameTypeOld when +// QUIC versions < 10 are no longer supported. +enum QuicFrameTypeOld { + PADDING_FRAME_OLD = 0, + STREAM_FRAME_OLD, + ACK_FRAME_OLD, + CONGESTION_FEEDBACK_FRAME_OLD, + RST_STREAM_FRAME_OLD, + CONNECTION_CLOSE_FRAME_OLD, + GOAWAY_FRAME_OLD, + NUM_FRAME_TYPES_OLD +}; + // Mask to select the lowest 48 bits of a sequence number. const QuicPacketSequenceNumber k6ByteSequenceNumberMask = GG_UINT64_C(0x0000FFFFFFFFFFFF); @@ -33,8 +46,36 @@ const QuicPacketSequenceNumber k1ByteSequenceNumberMask = const QuicGuid k1ByteGuidMask = GG_UINT64_C(0x00000000000000FF); const QuicGuid k4ByteGuidMask = GG_UINT64_C(0x00000000FFFFFFFF); +// New Frame Types, QUIC v. >= 10: +// There are two interpretations for the Frame Type byte in the QUIC protocol, +// resulting in two Frame Types: Special Frame Types and Regular Frame Types. +// +// Regular Frame Types use the Frame Type byte simply. Currently defined +// Regular Frame Types are: +// Padding : 0b 00000000 (0x00) +// ResetStream : 0b 00000001 (0x01) +// ConnectionClose : 0b 00000010 (0x02) +// GoAway : 0b 00000011 (0x03) +// +// Special Frame Types encode both a Frame Type and corresponding flags +// all in the Frame Type byte. Currently defined Special Frame Types are: +// Stream : 0b 1xxxxxxx +// Ack : 0b 01xxxxxx +// CongestionFeedback : 0b 001xxxxx +// +// Semantics of the flag bits above (the x bits) depends on the frame type. + +// Masks to determine if the frame type is a special use +// and for specific special frame types. +const uint8 kQuicFrameTypeSpecialMask = 0xE0; // 0b 11100000 +const uint8 kQuicFrameTypeStreamMask = 0x80; +const uint8 kQuicFrameTypeAckMask = 0x40; +const uint8 kQuicFrameTypeCongestionFeedbackMask = 0x20; + // Mask to determine if it's a special frame type(Stream, Ack, or // Congestion Control) by checking if the first bit is 0, then shifting right. +// TODO(jri): Remove kQuicFrameType0BitMask constant from v. 10 onwards. +// Replaced by kQuicFrameTypeStream defined above. const uint8 kQuicFrameType0BitMask = 0x01; // Default frame type shift and mask. @@ -891,62 +932,16 @@ bool QuicFramer::ProcessFrameData() { return RaiseError(QUIC_INVALID_FRAME_DATA); } - if ((frame_type & kQuicFrameType0BitMask) == 0) { - QuicStreamFrame frame; - if (!ProcessStreamFrame(frame_type, &frame)) { - return RaiseError(QUIC_INVALID_STREAM_DATA); - } - if (!visitor_->OnStreamFrame(frame)) { - DLOG(INFO) << "Visitor asked to stop further processing."; - // Returning true since there was no parsing error. - return true; - } - continue; - } - - frame_type >>= 1; - if ((frame_type & kQuicFrameType0BitMask) == 0) { - QuicAckFrame frame; - if (!ProcessAckFrame(&frame)) { - return RaiseError(QUIC_INVALID_ACK_DATA); - } - if (!visitor_->OnAckFrame(frame)) { - DLOG(INFO) << "Visitor asked to stop further processing."; - // Returning true since there was no parsing error. - return true; - } - continue; - } - - frame_type >>= 1; - if ((frame_type & kQuicFrameType0BitMask) == 0) { - QuicCongestionFeedbackFrame frame; - if (!ProcessQuicCongestionFeedbackFrame(&frame)) { - return RaiseError(QUIC_INVALID_CONGESTION_FEEDBACK_DATA); - } - if (!visitor_->OnCongestionFeedbackFrame(frame)) { - DLOG(INFO) << "Visitor asked to stop further processing."; - // Returning true since there was no parsing error. - return true; - } - continue; - } - - frame_type >>= 1; - - switch (frame_type) { - // STREAM_FRAME, ACK_FRAME, and CONGESTION_FEEDBACK_FRAME are handled - // above. - case PADDING_FRAME: - // We're done with the packet - return true; - - case RST_STREAM_FRAME: { - QuicRstStreamFrame frame; - if (!ProcessRstStreamFrame(&frame)) { - return RaiseError(QUIC_INVALID_RST_STREAM_DATA); + // TODO(jri): Remove this entire if block when support for + // QUIC version < 10 removed. + if (version() < QUIC_VERSION_10) { + // Special frame type processing for QUIC version < 10. + if ((frame_type & kQuicFrameType0BitMask) == 0) { + QuicStreamFrame frame; + if (!ProcessStreamFrame(frame_type, &frame)) { + return RaiseError(QUIC_INVALID_STREAM_DATA); } - if (!visitor_->OnRstStreamFrame(frame)) { + if (!visitor_->OnStreamFrame(frame)) { DLOG(INFO) << "Visitor asked to stop further processing."; // Returning true since there was no parsing error. return true; @@ -954,19 +949,27 @@ bool QuicFramer::ProcessFrameData() { continue; } - case CONNECTION_CLOSE_FRAME: { - QuicConnectionCloseFrame frame; - if (!ProcessConnectionCloseFrame(&frame)) { - return RaiseError(QUIC_INVALID_CONNECTION_CLOSE_DATA); + frame_type >>= 1; + if ((frame_type & kQuicFrameType0BitMask) == 0) { + QuicAckFrame frame; + if (!ProcessAckFrame(&frame)) { + return RaiseError(QUIC_INVALID_ACK_DATA); } - - if (!visitor_->OnAckFrame(frame.ack_frame)) { + if (!visitor_->OnAckFrame(frame)) { DLOG(INFO) << "Visitor asked to stop further processing."; // Returning true since there was no parsing error. return true; } + continue; + } - if (!visitor_->OnConnectionCloseFrame(frame)) { + frame_type >>= 1; + if ((frame_type & kQuicFrameType0BitMask) == 0) { + QuicCongestionFeedbackFrame frame; + if (!ProcessQuicCongestionFeedbackFrame(&frame)) { + return RaiseError(QUIC_INVALID_CONGESTION_FEEDBACK_DATA); + } + if (!visitor_->OnCongestionFeedbackFrame(frame)) { DLOG(INFO) << "Visitor asked to stop further processing."; // Returning true since there was no parsing error. return true; @@ -974,23 +977,178 @@ bool QuicFramer::ProcessFrameData() { continue; } - case GOAWAY_FRAME: { - QuicGoAwayFrame goaway_frame; - if (!ProcessGoAwayFrame(&goaway_frame)) { - return RaiseError(QUIC_INVALID_GOAWAY_DATA); - } - if (!visitor_->OnGoAwayFrame(goaway_frame)) { - DLOG(INFO) << "Visitor asked to stop further processing."; - // Returning true since there was no parsing error. + frame_type >>= 1; + switch (frame_type) { + // STREAM_FRAME, ACK_FRAME, and CONGESTION_FEEDBACK_FRAME are handled + // above. + case PADDING_FRAME_OLD: + // We're done with the packet. return true; + + case RST_STREAM_FRAME_OLD: { + QuicRstStreamFrame frame; + if (!ProcessRstStreamFrame(&frame)) { + return RaiseError(QUIC_INVALID_RST_STREAM_DATA); + } + if (!visitor_->OnRstStreamFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; } - continue; + + case CONNECTION_CLOSE_FRAME_OLD: { + QuicConnectionCloseFrame frame; + if (!ProcessConnectionCloseFrame(&frame)) { + return RaiseError(QUIC_INVALID_CONNECTION_CLOSE_DATA); + } + + if (!visitor_->OnAckFrame(frame.ack_frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + + if (!visitor_->OnConnectionCloseFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + case GOAWAY_FRAME_OLD: { + QuicGoAwayFrame goaway_frame; + if (!ProcessGoAwayFrame(&goaway_frame)) { + return RaiseError(QUIC_INVALID_GOAWAY_DATA); + } + if (!visitor_->OnGoAwayFrame(goaway_frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + set_detailed_error("Illegal frame type."); + DLOG(WARNING) << "Illegal frame type: " + << static_cast<int>(frame_type); + return RaiseError(QUIC_INVALID_FRAME_DATA); } + } else { + // TODO(jri): Retain this else block when support for + // QUIC version < 10 removed. Remove above if block. + + // Special frame type processing for QUIC version >= 10 + if (frame_type & kQuicFrameTypeSpecialMask) { + // Stream Frame + if (frame_type & kQuicFrameTypeStreamMask) { + QuicStreamFrame frame; + if (!ProcessStreamFrame(frame_type, &frame)) { + return RaiseError(QUIC_INVALID_STREAM_DATA); + } + if (!visitor_->OnStreamFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } - set_detailed_error("Illegal frame type."); - DLOG(WARNING) << "Illegal frame type: " - << static_cast<int>(frame_type); - return RaiseError(QUIC_INVALID_FRAME_DATA); + // Ack Frame + if (frame_type & kQuicFrameTypeAckMask) { + QuicAckFrame frame; + if (!ProcessAckFrame(&frame)) { + return RaiseError(QUIC_INVALID_ACK_DATA); + } + if (!visitor_->OnAckFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + // Congestion Feedback Frame + if (frame_type & kQuicFrameTypeCongestionFeedbackMask) { + QuicCongestionFeedbackFrame frame; + if (!ProcessQuicCongestionFeedbackFrame(&frame)) { + return RaiseError(QUIC_INVALID_CONGESTION_FEEDBACK_DATA); + } + if (!visitor_->OnCongestionFeedbackFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + // This was a special frame type that did not match any + // of the known ones. Error. + set_detailed_error("Illegal frame type."); + DLOG(WARNING) << "Illegal frame type: " + << static_cast<int>(frame_type); + return RaiseError(QUIC_INVALID_FRAME_DATA); + } + + switch (frame_type) { + case PADDING_FRAME: + // We're done with the packet. + return true; + + case RST_STREAM_FRAME: { + QuicRstStreamFrame frame; + if (!ProcessRstStreamFrame(&frame)) { + return RaiseError(QUIC_INVALID_RST_STREAM_DATA); + } + if (!visitor_->OnRstStreamFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + case CONNECTION_CLOSE_FRAME: { + QuicConnectionCloseFrame frame; + if (!ProcessConnectionCloseFrame(&frame)) { + return RaiseError(QUIC_INVALID_CONNECTION_CLOSE_DATA); + } + + if (!visitor_->OnAckFrame(frame.ack_frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + + if (!visitor_->OnConnectionCloseFrame(frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + case GOAWAY_FRAME: { + QuicGoAwayFrame goaway_frame; + if (!ProcessGoAwayFrame(&goaway_frame)) { + return RaiseError(QUIC_INVALID_GOAWAY_DATA); + } + if (!visitor_->OnGoAwayFrame(goaway_frame)) { + DLOG(INFO) << "Visitor asked to stop further processing."; + // Returning true since there was no parsing error. + return true; + } + continue; + } + + default: + set_detailed_error("Illegal frame type."); + DLOG(WARNING) << "Illegal frame type: " + << static_cast<int>(frame_type); + return RaiseError(QUIC_INVALID_FRAME_DATA); + } } } @@ -999,7 +1157,15 @@ bool QuicFramer::ProcessFrameData() { bool QuicFramer::ProcessStreamFrame(uint8 frame_type, QuicStreamFrame* frame) { - uint8 stream_flags = frame_type >> 1; + uint8 stream_flags = frame_type; + + // TODO(jri): Remove if block after support for ver. < 10 removed. + if (version() < QUIC_VERSION_10) { + stream_flags >>= 1; + } else { + stream_flags &= ~kQuicFrameTypeStreamMask; + } + // Read from right to left: StreamID, Offset, Data Length, Fin. const uint8 stream_id_length = (stream_flags & kQuicStreamIDLengthMask) + 1; stream_flags >>= kQuicStreamIdShift; @@ -1547,22 +1713,44 @@ bool QuicFramer::AppendTypeByte(const QuicFrame& frame, type_byte <<= kQuicStreamIdShift; type_byte |= GetStreamIdSize(frame.stream_frame->stream_id) - 1; - type_byte <<= 1; // Leaves the last bit as a 0. + // TODO(jri): Remove if block when support for QUIC ver. < 10 removed. + if (version() < QUIC_VERSION_10) { + type_byte <<= 1; // Leaves the last bit as a 0. + } else { + type_byte |= kQuicFrameTypeStreamMask; // Set Stream Frame Type to 1. + } break; } case ACK_FRAME: { // TODO(ianswett): Use extra 5 bits in the ack framing. - type_byte = 0x01; + // TODO(jri): Remove if block when support for QUIC ver. < 10 removed. + if (version() < QUIC_VERSION_10) { + type_byte = 0x01; + } else { + type_byte = kQuicFrameTypeAckMask; + } break; } case CONGESTION_FEEDBACK_FRAME: { // TODO(ianswett): Use extra 5 bits in the congestion feedback framing. - type_byte = 0x03; + // TODO(jri): Remove if block when support for QUIC ver. < 10 removed. + if (version() < QUIC_VERSION_10) { + type_byte = 0x03; + } else { + type_byte = kQuicFrameTypeCongestionFeedbackMask; + } break; } default: - type_byte = - frame.type << kQuicDefaultFrameTypeShift | kQuicDefaultFrameTypeMask; + type_byte = frame.type; + // TODO(jri): Remove if block when support for QUIC ver. < 10 removed. + if (version() < QUIC_VERSION_10) { + if (type_byte > 0) { + type_byte += 3; + } + type_byte = (type_byte << kQuicDefaultFrameTypeShift) | + kQuicDefaultFrameTypeMask; + } break; } diff --git a/net/quic/quic_framer_test.cc b/net/quic/quic_framer_test.cc index 7e364de..b3bdbac 100644 --- a/net/quic/quic_framer_test.cc +++ b/net/quic/quic_framer_test.cc @@ -319,6 +319,18 @@ class QuicFramerTest : public ::testing::TestWithParam<QuicVersion> { framer_.set_version(version_); } + // Helper function to get unsigned char representation of digit in the + // units place of the current QUIC version number. + unsigned char GetQuicVersionDigitOnes() { + return static_cast<unsigned char> ('0' + version_%10); + } + + // Helper function to get unsigned char representation of digit in the + // tens place of the current QUIC version number. + unsigned char GetQuicVersionDigitTens() { + return static_cast<unsigned char> ('0' + (version_/10)%10); + } + bool CheckEncryption(QuicPacketSequenceNumber sequence_number, QuicPacket* packet) { if (sequence_number != encrypter_->sequence_number_) { @@ -425,20 +437,6 @@ class QuicFramerTest : public ::testing::TestWithParam<QuicVersion> { << " wire_sequence_number: " << wire_sequence_number; } - char LastCharOfVersion() { - switch (GetParam()) { - case QUIC_VERSION_7: - return '7'; - case QUIC_VERSION_8: - return '8'; - case QUIC_VERSION_9: - return '9'; - default: - CHECK(0) << "Invalid version"; - return 0; - } - } - test::TestEncrypter* encrypter_; test::TestDecrypter* decrypter_; QuicVersion version_; @@ -814,7 +812,7 @@ TEST_P(QuicFramerTest, PacketHeaderWithVersionFlag) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), // packet sequence number 0xBC, 0x9A, 0x78, 0x56, 0x34, 0x12, @@ -1040,23 +1038,10 @@ TEST_P(QuicFramerTest, InvalidPublicFlag) { // private flags 0x00, - // frame count - 0x01, - // frame type (stream frame) - 0x01, - // stream id - 0x04, 0x03, 0x02, 0x01, - // fin - 0x01, - // offset - 0x54, 0x76, 0x10, 0x32, - 0xDC, 0xFE, 0x98, 0xBA, - // data length - 0x0c, 0x00, - // data - 'h', 'e', 'l', 'l', - 'o', ' ', 'w', 'o', - 'r', 'l', 'd', '!', + // frame type (padding) + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; CheckProcessingFails(packet, arraysize(packet), @@ -1072,30 +1057,17 @@ TEST_P(QuicFramerTest, InvalidPublicFlagWithMatchingVersions) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), // packet sequence number 0xBC, 0x9A, 0x78, 0x56, 0x34, 0x12, // private flags 0x00, - // frame count - 0x01, - // frame type (stream frame) - 0x01, - // stream id - 0x04, 0x03, 0x02, 0x01, - // fin - 0x01, - // offset - 0x54, 0x76, 0x10, 0x32, - 0xDC, 0xFE, 0x98, 0xBA, - // data length - 0x0c, 0x00, - // data - 'h', 'e', 'l', 'l', - 'o', ' ', 'w', 'o', - 'r', 'l', 'd', '!', + // frame type (padding) + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; CheckProcessingFails(packet, arraysize(packet), @@ -1119,7 +1091,9 @@ TEST_P(QuicFramerTest, LargePublicFlagWithMismatchedVersions) { 0x00, // frame type (padding frame) - 0x07, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; QuicEncryptedPacket encrypted(AsChars(packet), arraysize(packet), false); EXPECT_TRUE(framer_.ProcessPacket(encrypted)); @@ -1142,23 +1116,10 @@ TEST_P(QuicFramerTest, InvalidPrivateFlag) { // private flags 0x10, - // frame count - 0x01, - // frame type (stream frame) - 0x01, - // stream id - 0x04, 0x03, 0x02, 0x01, - // fin - 0x01, - // offset - 0x54, 0x76, 0x10, 0x32, - 0xDC, 0xFE, 0x98, 0xBA, - // data length - 0x0c, 0x00, - // data - 'h', 'e', 'l', 'l', - 'o', ' ', 'w', 'o', - 'r', 'l', 'd', '!', + // frame type (padding) + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; CheckProcessingFails(packet, arraysize(packet), @@ -1202,14 +1163,20 @@ TEST_P(QuicFramerTest, PaddingFrame) { 0x00, // frame type (padding frame) - 0x07, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), // Ignored data (which in this case is a stream frame) - 0x01, + // frame type (stream frame with fin) + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), + // stream id 0x04, 0x03, 0x02, 0x01, - 0x01, + // offset 0x54, 0x76, 0x10, 0x32, 0xDC, 0xFE, 0x98, 0xBA, + // data length 0x0c, 0x00, + // data 'h', 'e', 'l', 'l', 'o', ' ', 'w', 'o', 'r', 'l', 'd', '!', @@ -1245,7 +1212,8 @@ TEST_P(QuicFramerTest, StreamFrame) { 0x00, // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -1293,7 +1261,8 @@ TEST_P(QuicFramerTest, StreamFrame3ByteStreamId) { 0x00, // frame type (stream frame with fin) - 0xFC, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFC : 0xFE), // stream id 0x04, 0x03, 0x02, // offset @@ -1316,7 +1285,7 @@ TEST_P(QuicFramerTest, StreamFrame3ByteStreamId) { ASSERT_EQ(1u, visitor_.stream_frames_.size()); EXPECT_EQ(0u, visitor_.ack_frames_.size()); - EXPECT_EQ(static_cast<uint64>(0x00020304), + EXPECT_EQ(GG_UINT64_C(0x00020304), visitor_.stream_frames_[0]->stream_id); EXPECT_TRUE(visitor_.stream_frames_[0]->fin); EXPECT_EQ(GG_UINT64_C(0xBA98FEDC32107654), @@ -1342,7 +1311,8 @@ TEST_P(QuicFramerTest, StreamFrame2ByteStreamId) { 0x00, // frame type (stream frame with fin) - 0xFA, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFA : 0xFD), // stream id 0x04, 0x03, // offset @@ -1391,7 +1361,8 @@ TEST_P(QuicFramerTest, StreamFrame1ByteStreamId) { 0x00, // frame type (stream frame with fin) - 0xF8, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xF8 : 0xFC), // stream id 0x04, // offset @@ -1434,7 +1405,7 @@ TEST_P(QuicFramerTest, StreamFrameWithVersion) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), // packet sequence number 0xBC, 0x9A, 0x78, 0x56, 0x34, 0x12, @@ -1442,7 +1413,8 @@ TEST_P(QuicFramerTest, StreamFrameWithVersion) { 0x00, // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -1494,7 +1466,8 @@ TEST_P(QuicFramerTest, RejectPacket) { 0x00, // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -1522,7 +1495,8 @@ TEST_P(QuicFramerTest, RejectPacket) { TEST_P(QuicFramerTest, RevivedStreamFrame) { unsigned char payload[] = { // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -1591,7 +1565,8 @@ TEST_P(QuicFramerTest, StreamFrameInFecGroup) { 0x02, // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -1643,7 +1618,8 @@ TEST_P(QuicFramerTest, AckFrame) { 0x00, // frame type (ack frame) - static_cast<unsigned char>(0x01), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x01 : 0x40), // entropy hash of sent packets till least awaiting - 1. 0xAB, // least packet sequence number awaiting an ack @@ -1736,7 +1712,8 @@ TEST_P(QuicFramerTest, CongestionFeedbackFrameTCP) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (tcp) 0x00, // ack_frame.feedback.tcp.accumulated_number_of_lost_packets @@ -1793,7 +1770,8 @@ TEST_P(QuicFramerTest, CongestionFeedbackFrameInterArrival) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (inter arrival) 0x01, // accumulated_number_of_lost_packets @@ -1889,7 +1867,8 @@ TEST_P(QuicFramerTest, CongestionFeedbackFrameFixRate) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (fix rate) 0x02, // bitrate_in_bytes_per_second; @@ -1941,7 +1920,8 @@ TEST_P(QuicFramerTest, CongestionFeedbackFrameInvalidFeedback) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (invalid) 0x03, }; @@ -1966,7 +1946,8 @@ TEST_P(QuicFramerTest, RstStreamFrame) { 0x00, // frame type (rst stream frame) - static_cast<unsigned char>(0x27), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x27 : 0x01), // stream id 0x04, 0x03, 0x02, 0x01, // error code @@ -2025,7 +2006,8 @@ TEST_P(QuicFramerTest, ConnectionCloseFrame) { 0x00, // frame type (connection close frame) - static_cast<unsigned char>(0x2F), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x2F : 0x02), // error code 0x11, 0x00, 0x00, 0x00, @@ -2112,7 +2094,8 @@ TEST_P(QuicFramerTest, GoAwayFrame) { 0x00, // frame type (go away frame) - static_cast<unsigned char>(0x37), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x37 : 0x03), // error code 0x09, 0x00, 0x00, 0x00, // stream id @@ -2219,7 +2202,7 @@ TEST_P(QuicFramerTest, VersionNegotiationPacket) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), 'Q', '2', '.', '0', }; @@ -2312,7 +2295,9 @@ TEST_P(QuicFramerTest, BuildPaddingFramePacket) { 0x00, // frame type (padding frame) - static_cast<unsigned char>(0x07), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; uint64 header_size = @@ -2357,7 +2342,9 @@ TEST_P(QuicFramerTest, Build4ByteSequenceNumberPaddingFramePacket) { 0x00, // frame type (padding frame) - static_cast<unsigned char>(0x07), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; uint64 header_size = @@ -2402,7 +2389,9 @@ TEST_P(QuicFramerTest, Build2ByteSequenceNumberPaddingFramePacket) { 0x00, // frame type (padding frame) - static_cast<unsigned char>(0x07), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; uint64 header_size = @@ -2447,7 +2436,9 @@ TEST_P(QuicFramerTest, Build1ByteSequenceNumberPaddingFramePacket) { 0x00, // frame type (padding frame) - static_cast<unsigned char>(0x07), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x07 : 0x00), + 0x00, 0x00, 0x00, 0x00 }; uint64 header_size = @@ -2496,7 +2487,8 @@ TEST_P(QuicFramerTest, BuildStreamFramePacket) { 0x01, // frame type (stream frame with fin and no length) - 0xBE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xBE : 0xDF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -2543,7 +2535,7 @@ TEST_P(QuicFramerTest, BuildStreamFramePacketWithVersionFlag) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), // packet sequence number 0xBC, 0x9A, 0x78, 0x56, 0x34, 0x12, @@ -2551,7 +2543,8 @@ TEST_P(QuicFramerTest, BuildStreamFramePacketWithVersionFlag) { 0x01, // frame type (stream frame with fin and no length) - 0xBE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xBE : 0xDF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -2586,7 +2579,7 @@ TEST_P(QuicFramerTest, BuildVersionNegotiationPacket) { 0x10, 0x32, 0x54, 0x76, 0x98, 0xBA, 0xDC, 0xFE, // version tag - 'Q', '0', '0', LastCharOfVersion(), + 'Q', '0', GetQuicVersionDigitTens(), GetQuicVersionDigitOnes(), }; QuicVersionVector versions; @@ -2634,7 +2627,8 @@ TEST_P(QuicFramerTest, BuildAckFramePacket) { 0x01, // frame type (ack frame) - static_cast<unsigned char>(0x01), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x01 : 0x40), // entropy hash of sent packets till least awaiting - 1. 0x14, // least packet sequence number awaiting an ack @@ -2694,7 +2688,8 @@ TEST_P(QuicFramerTest, BuildCongestionFeedbackFramePacketTCP) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (TCP) 0x00, // accumulated number of lost packets @@ -2753,7 +2748,8 @@ TEST_P(QuicFramerTest, BuildCongestionFeedbackFramePacketInterArrival) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (inter arrival) 0x01, // accumulated_number_of_lost_packets @@ -2816,7 +2812,8 @@ TEST_P(QuicFramerTest, BuildCongestionFeedbackFramePacketFixRate) { 0x00, // frame type (congestion feedback frame) - 0x03, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x03 : 0x20), // congestion feedback type (fix rate) 0x02, // bitrate_in_bytes_per_second; @@ -2882,7 +2879,8 @@ TEST_P(QuicFramerTest, BuildRstFramePacket) { 0x00, // frame type (rst stream frame) - static_cast<unsigned char>(0x27), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x27 : 0x01), // stream id 0x04, 0x03, 0x02, 0x01, // error code @@ -2945,7 +2943,8 @@ TEST_P(QuicFramerTest, BuildCloseFramePacket) { 0x01, // frame type (connection close frame) - static_cast<unsigned char>(0x2F), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x2F : 0x02), // error code 0x08, 0x07, 0x06, 0x05, // error details length @@ -3016,7 +3015,8 @@ TEST_P(QuicFramerTest, BuildGoAwayPacket) { 0x01, // frame type (go away frame) - static_cast<unsigned char>(0x37), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x37 : 0x03), // error code 0x08, 0x07, 0x06, 0x05, // stream id @@ -3357,7 +3357,8 @@ TEST_P(QuicFramerTest, EntropyFlagTest) { 0x01, // frame type (stream frame with fin and no length) - 0xBE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xBE : 0xDF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -3394,7 +3395,8 @@ TEST_P(QuicFramerTest, FecEntropyTest) { 0xFF, // frame type (stream frame with fin and no length) - 0xBE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xBE : 0xDF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -3429,7 +3431,8 @@ TEST_P(QuicFramerTest, StopPacketProcessing) { 0x01, // frame type (stream frame with fin) - 0xFE, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0xFE : 0xFF), // stream id 0x04, 0x03, 0x02, 0x01, // offset @@ -3443,7 +3446,8 @@ TEST_P(QuicFramerTest, StopPacketProcessing) { 'r', 'l', 'd', '!', // frame type (ack frame) - 0x02, + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x01 : 0x40), // entropy hash of sent packets till least awaiting - 1. 0x14, // least packet sequence number awaiting an ack @@ -3488,7 +3492,8 @@ TEST_P(QuicFramerTest, ConnectionCloseWithInvalidAck) { 0x00, // frame type (connection close frame) - static_cast<unsigned char>(0x2F), + static_cast<unsigned char>( + GetParam() < QUIC_VERSION_10 ? 0x2F : 0x02), // error code 0x11, 0x00, 0x00, 0x00, // error details length diff --git a/net/quic/quic_packet_creator.cc b/net/quic/quic_packet_creator.cc index 387cd37..e1d0e21 100644 --- a/net/quic/quic_packet_creator.cc +++ b/net/quic/quic_packet_creator.cc @@ -6,6 +6,7 @@ #include "base/logging.h" #include "net/quic/crypto/quic_random.h" +#include "net/quic/quic_ack_notifier.h" #include "net/quic/quic_fec_group.h" #include "net/quic/quic_utils.h" @@ -30,7 +31,7 @@ QuicPacketCreator::QuicPacketCreator(QuicGuid guid, send_version_in_packet_(!is_server), sequence_number_length_(options_.send_sequence_number_length), packet_size_(0) { - framer_->set_fec_builder(this); + framer_->set_fec_builder(reinterpret_cast<QuicFecBuilderInterface*>(this)); } QuicPacketCreator::~QuicPacketCreator() { @@ -138,6 +139,23 @@ size_t QuicPacketCreator::CreateStreamFrame(QuicStreamId id, return bytes_consumed; } +size_t QuicPacketCreator::CreateStreamFrameWithNotifier( + QuicStreamId id, + StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier* notifier, + QuicFrame* frame) { + size_t bytes_consumed = CreateStreamFrame(id, data, offset, fin, frame); + + // The frame keeps track of the QuicAckNotifier until it is serialized into + // a packet. At that point the notifier is informed of the sequence number + // of the packet that this frame was eventually sent in. + frame->stream_frame->notifier = notifier; + + return bytes_consumed; +} + SerializedPacket QuicPacketCreator::ReserializeAllFrames( const QuicFrames& frames, QuicSequenceNumberLength original_length) { @@ -215,8 +233,19 @@ SerializedPacket QuicPacketCreator::SerializePacket() { QuicPacketHeader header; FillPacketHeader(fec_group_number_, false, false, &header); - SerializedPacket serialized = framer_->BuildDataPacket( - header, queued_frames_, PacketSize()); + SerializedPacket serialized = + framer_->BuildDataPacket(header, queued_frames_, packet_size_); + + // Run through all the included frames and if any of them have an AckNotifier + // registered, then inform the AckNotifier that it should be interested in + // this packet's sequence number. + for (QuicFrames::iterator it = queued_frames_.begin(); + it != queued_frames_.end(); ++it) { + if (it->type == STREAM_FRAME && it->stream_frame->notifier != NULL) { + it->stream_frame->notifier->AddSequenceNumber(serialized.sequence_number); + } + } + packet_size_ = 0; queued_frames_.clear(); serialized.retransmittable_frames = queued_retransmittable_frames_.release(); diff --git a/net/quic/quic_packet_creator.h b/net/quic/quic_packet_creator.h index e4fc2e7..0e0a8c7 100644 --- a/net/quic/quic_packet_creator.h +++ b/net/quic/quic_packet_creator.h @@ -23,6 +23,7 @@ namespace test { class QuicPacketCreatorPeer; } +class QuicAckNotifier; class QuicRandom; class NET_EXPORT_PRIVATE QuicPacketCreator : public QuicFecBuilderInterface { @@ -89,6 +90,17 @@ class NET_EXPORT_PRIVATE QuicPacketCreator : public QuicFecBuilderInterface { bool fin, QuicFrame* frame); + // As above, but keeps track of an QuicAckNotifier that should be called when + // the packet that contains this stream frame is ACKed. + // The |notifier| is not owned by the QuicPacketGenerator and must outlive the + // generated packet. + size_t CreateStreamFrameWithNotifier(QuicStreamId id, + base::StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier* notifier, + QuicFrame* frame); + // Serializes all frames into a single packet. All frames must fit into a // single packet. Also, sets the entropy hash of the serialized packet to a // random bool and returns that value as a member of SerializedPacket. diff --git a/net/quic/quic_packet_generator.cc b/net/quic/quic_packet_generator.cc index c684cda..41161eb 100644 --- a/net/quic/quic_packet_generator.cc +++ b/net/quic/quic_packet_generator.cc @@ -12,6 +12,8 @@ using base::StringPiece; namespace net { +class QuicAckNotifier; + QuicPacketGenerator::QuicPacketGenerator(DelegateInterface* delegate, DebugDelegateInterface* debug_delegate, QuicPacketCreator* creator) @@ -60,7 +62,6 @@ void QuicPacketGenerator::SetShouldSendAck(bool also_send_feedback) { SendQueuedFrames(); } - void QuicPacketGenerator::AddControlFrame(const QuicFrame& frame) { queued_control_frames_.push_back(frame); SendQueuedFrames(); @@ -70,6 +71,14 @@ QuicConsumedData QuicPacketGenerator::ConsumeData(QuicStreamId id, StringPiece data, QuicStreamOffset offset, bool fin) { + return ConsumeData(id, data, offset, fin, NULL); +} + +QuicConsumedData QuicPacketGenerator::ConsumeData(QuicStreamId id, + StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier* notifier) { IsHandshake handshake = id == kCryptoStreamId ? IS_HANDSHAKE : NOT_HANDSHAKE; // The caller should have flushed pending frames before sending handshake // messages. @@ -82,8 +91,15 @@ QuicConsumedData QuicPacketGenerator::ConsumeData(QuicStreamId id, while (delegate_->CanWrite(NOT_RETRANSMISSION, HAS_RETRANSMITTABLE_DATA, handshake)) { QuicFrame frame; - size_t bytes_consumed = packet_creator_->CreateStreamFrame( + size_t bytes_consumed; + if (notifier != NULL) { + // We want to track which packet this stream frame ends up in. + bytes_consumed = packet_creator_->CreateStreamFrameWithNotifier( + id, data, offset + total_bytes_consumed, fin, notifier, &frame); + } else { + bytes_consumed = packet_creator_->CreateStreamFrame( id, data, offset + total_bytes_consumed, fin, &frame); + } bool success = AddFrame(frame); DCHECK(success); diff --git a/net/quic/quic_packet_generator.h b/net/quic/quic_packet_generator.h index f61e6e4..75472a1 100644 --- a/net/quic/quic_packet_generator.h +++ b/net/quic/quic_packet_generator.h @@ -57,6 +57,8 @@ namespace net { +class QuicAckNotifier; + class NET_EXPORT_PRIVATE QuicPacketGenerator { public: class NET_EXPORT_PRIVATE DelegateInterface { @@ -90,11 +92,24 @@ class NET_EXPORT_PRIVATE QuicPacketGenerator { void SetShouldSendAck(bool also_send_feedback); void AddControlFrame(const QuicFrame& frame); + + // Given some data, may consume part or all of it and pass it to the packet + // creator to be serialized into packets. If not in batch mode, these packets + // will also be sent during this call. QuicConsumedData ConsumeData(QuicStreamId id, base::StringPiece data, QuicStreamOffset offset, bool fin); + // As above, but attaches a QuicAckNotifier to any created stream frames, + // which will be called once the frame is ACKed by the peer. + // The QuicAckNotifier is owned by the QuicConnection. + QuicConsumedData ConsumeData(QuicStreamId id, + base::StringPiece data, + QuicStreamOffset offset, + bool fin, + QuicAckNotifier* notifier); + // Indicates whether batch mode is currently enabled. bool InBatchMode(); // Disables flushing. @@ -121,6 +136,7 @@ class NET_EXPORT_PRIVATE QuicPacketGenerator { bool AddNextPendingFrame(); bool AddFrame(const QuicFrame& frame); + void SerializeAndSendPacket(); DelegateInterface* delegate_; diff --git a/net/quic/quic_protocol.cc b/net/quic/quic_protocol.cc index 3134542..cbd4cad 100644 --- a/net/quic/quic_protocol.cc +++ b/net/quic/quic_protocol.cc @@ -102,7 +102,8 @@ QuicStreamFrame::QuicStreamFrame(QuicStreamId stream_id, : stream_id(stream_id), fin(fin), offset(offset), - data(data) { + data(data), + notifier(NULL) { } uint32 MakeQuicTag(char a, char b, char c, char d) { @@ -126,6 +127,8 @@ QuicTag QuicVersionToQuicTag(const QuicVersion version) { return MakeQuicTag('Q', '0', '0', '8'); case QUIC_VERSION_9: return MakeQuicTag('Q', '0', '0', '9'); + case QUIC_VERSION_10: + return MakeQuicTag('Q', '0', '1', '0'); default: // This shold be an ERROR because we should never attempt to convert an // invalid QuicVersion to be written to the wire. @@ -138,6 +141,7 @@ QuicVersion QuicTagToQuicVersion(const QuicTag version_tag) { const QuicTag quic_tag_v7 = MakeQuicTag('Q', '0', '0', '7'); const QuicTag quic_tag_v8 = MakeQuicTag('Q', '0', '0', '8'); const QuicTag quic_tag_v9 = MakeQuicTag('Q', '0', '0', '9'); + const QuicTag quic_tag_v10 = MakeQuicTag('Q', '0', '1', '0'); if (version_tag == quic_tag_v7) { return QUIC_VERSION_7; @@ -145,6 +149,8 @@ QuicVersion QuicTagToQuicVersion(const QuicTag version_tag) { return QUIC_VERSION_8; } else if (version_tag == quic_tag_v9) { return QUIC_VERSION_9; + } else if (version_tag == quic_tag_v10) { + return QUIC_VERSION_10; } else { // Reading from the client so this should not be considered an ERROR. DLOG(INFO) << "Unsupported QuicTag version: " @@ -162,6 +168,7 @@ string QuicVersionToString(const QuicVersion version) { RETURN_STRING_LITERAL(QUIC_VERSION_7); RETURN_STRING_LITERAL(QUIC_VERSION_8); RETURN_STRING_LITERAL(QUIC_VERSION_9); + RETURN_STRING_LITERAL(QUIC_VERSION_10); default: return "QUIC_VERSION_UNSUPPORTED"; } @@ -414,6 +421,21 @@ void RetransmittableFrames::set_encryption_level(EncryptionLevel level) { encryption_level_ = level; } +SerializedPacket::SerializedPacket( + QuicPacketSequenceNumber sequence_number, + QuicSequenceNumberLength sequence_number_length, + QuicPacket* packet, + QuicPacketEntropyHash entropy_hash, + RetransmittableFrames* retransmittable_frames) + : sequence_number(sequence_number), + sequence_number_length(sequence_number_length), + packet(packet), + entropy_hash(entropy_hash), + retransmittable_frames(retransmittable_frames) { +} + +SerializedPacket::~SerializedPacket() {} + ostream& operator<<(ostream& os, const QuicEncryptedPacket& s) { os << s.length() << "-byte data"; return os; diff --git a/net/quic/quic_protocol.h b/net/quic/quic_protocol.h index b443827..75f6f58 100644 --- a/net/quic/quic_protocol.h +++ b/net/quic/quic_protocol.h @@ -27,6 +27,7 @@ namespace net { using ::operator<<; +class QuicAckNotifier; class QuicPacket; struct QuicPacketHeader; @@ -99,12 +100,12 @@ enum IsHandshake { enum QuicFrameType { PADDING_FRAME = 0, - STREAM_FRAME, - ACK_FRAME, - CONGESTION_FEEDBACK_FRAME, RST_STREAM_FRAME, CONNECTION_CLOSE_FRAME, GOAWAY_FRAME, + STREAM_FRAME, + ACK_FRAME, + CONGESTION_FEEDBACK_FRAME, NUM_FRAME_TYPES }; @@ -190,7 +191,8 @@ enum QuicVersion { QUIC_VERSION_7 = 7, QUIC_VERSION_8 = 8, - QUIC_VERSION_9 = 9, // Current version. + QUIC_VERSION_9 = 9, + QUIC_VERSION_10 = 10, // Current version. }; // This vector contains QUIC versions which we currently support. @@ -198,7 +200,7 @@ enum QuicVersion { // element, with subsequent elements in descending order (versions can be // skipped as necessary). static const QuicVersion kSupportedQuicVersions[] = - {QUIC_VERSION_9}; + {QUIC_VERSION_10, QUIC_VERSION_9}; typedef std::vector<QuicVersion> QuicVersionVector; @@ -474,6 +476,10 @@ struct NET_EXPORT_PRIVATE QuicStreamFrame { bool fin; QuicStreamOffset offset; // Location of this data in the stream. base::StringPiece data; + + // If this is set, then when this packet is ACKed the AckNotifier will be + // informed. + QuicAckNotifier* notifier; }; // TODO(ianswett): Re-evaluate the trade-offs of hash_set vs set when framing @@ -829,28 +835,24 @@ struct NET_EXPORT_PRIVATE SerializedPacket { QuicSequenceNumberLength sequence_number_length, QuicPacket* packet, QuicPacketEntropyHash entropy_hash, - RetransmittableFrames* retransmittable_frames) - : sequence_number(sequence_number), - sequence_number_length(sequence_number_length), - packet(packet), - entropy_hash(entropy_hash), - retransmittable_frames(retransmittable_frames) {} + RetransmittableFrames* retransmittable_frames); + ~SerializedPacket(); QuicPacketSequenceNumber sequence_number; QuicSequenceNumberLength sequence_number_length; QuicPacket* packet; QuicPacketEntropyHash entropy_hash; RetransmittableFrames* retransmittable_frames; + + // If set, these will be called when this packet is ACKed by the peer. + std::set<QuicAckNotifier*> notifiers; }; // A struct for functions which consume data payloads and fins. -// The first member of the pair indicates bytes consumed. -// The second member of the pair indicates if an incoming fin was consumed. struct QuicConsumedData { QuicConsumedData(size_t bytes_consumed, bool fin_consumed) : bytes_consumed(bytes_consumed), fin_consumed(fin_consumed) {} - // By default, gtest prints the raw bytes of an object. The bool data // member causes this object to have padding bytes, which causes the // default gtest object printer to read uninitialize memory. So we need @@ -858,7 +860,10 @@ struct QuicConsumedData { NET_EXPORT_PRIVATE friend std::ostream& operator<<( std::ostream& os, const QuicConsumedData& s); + // How many bytes were consumed. size_t bytes_consumed; + + // True if an incoming fin was consumed. bool fin_consumed; }; diff --git a/net/quic/quic_session.cc b/net/quic/quic_session.cc index db7203d..5b7dc38 100644 --- a/net/quic/quic_session.cc +++ b/net/quic/quic_session.cc @@ -428,12 +428,13 @@ ReliableQuicStream* QuicSession::GetIncomingReliableStream( connection()->SendConnectionClose(QUIC_INVALID_STREAM_ID); return NULL; } - if (largest_peer_created_stream_id_ != 0) { - for (QuicStreamId id = largest_peer_created_stream_id_ + 2; - id < stream_id; - id += 2) { - implicitly_created_streams_.insert(id); - } + if (largest_peer_created_stream_id_ == 0) { + largest_peer_created_stream_id_= 1; + } + for (QuicStreamId id = largest_peer_created_stream_id_ + 2; + id < stream_id; + id += 2) { + implicitly_created_streams_.insert(id); } largest_peer_created_stream_id_ = stream_id; } diff --git a/net/quic/quic_session_test.cc b/net/quic/quic_session_test.cc index ec79f67..b7953ae 100644 --- a/net/quic/quic_session_test.cc +++ b/net/quic/quic_session_test.cc @@ -176,6 +176,15 @@ TEST_F(QuicSessionTest, IsClosedStreamDefault) { } } +TEST_F(QuicSessionTest, ImplicitlyCreatedStreams) { + ASSERT_TRUE(session_.GetIncomingReliableStream(7) != NULL); + // Both 3 and 5 should be implicitly created. + EXPECT_FALSE(session_.IsClosedStream(3)); + EXPECT_FALSE(session_.IsClosedStream(5)); + ASSERT_TRUE(session_.GetIncomingReliableStream(5) != NULL); + ASSERT_TRUE(session_.GetIncomingReliableStream(3) != NULL); +} + TEST_F(QuicSessionTest, IsClosedStreamLocallyCreated) { TestStream* stream2 = session_.CreateOutgoingReliableStream(); EXPECT_EQ(2u, stream2->id()); diff --git a/net/quic/test_tools/quic_connection_peer.cc b/net/quic/test_tools/quic_connection_peer.cc index 610c505..c168313 100644 --- a/net/quic/test_tools/quic_connection_peer.cc +++ b/net/quic/test_tools/quic_connection_peer.cc @@ -127,6 +127,12 @@ void QuicConnectionPeer::SetSelfAddress(QuicConnection* connection, } // static +void QuicConnectionPeer::SetPeerAddress(QuicConnection* connection, + const IPEndPoint& peer_address) { + connection->peer_address_ = peer_address; +} + +// static void QuicConnectionPeer::SwapCrypters(QuicConnection* connection, QuicFramer* framer) { framer->SwapCryptersForTest(&connection->framer_); diff --git a/net/quic/test_tools/quic_connection_peer.h b/net/quic/test_tools/quic_connection_peer.h index 20dbc21..13ff14d 100644 --- a/net/quic/test_tools/quic_connection_peer.h +++ b/net/quic/test_tools/quic_connection_peer.h @@ -78,6 +78,9 @@ class QuicConnectionPeer { static void SetSelfAddress(QuicConnection* connection, const IPEndPoint& self_address); + static void SetPeerAddress(QuicConnection* connection, + const IPEndPoint& peer_address); + static void SwapCrypters(QuicConnection* connection, QuicFramer* framer); static void SetMaxPacketsPerRetransmissionAlarm(QuicConnection* connection, diff --git a/net/quic/test_tools/quic_test_utils.cc b/net/quic/test_tools/quic_test_utils.cc index 39571bc..9381e05 100644 --- a/net/quic/test_tools/quic_test_utils.cc +++ b/net/quic/test_tools/quic_test_utils.cc @@ -284,6 +284,12 @@ MockSendAlgorithm::MockSendAlgorithm() { MockSendAlgorithm::~MockSendAlgorithm() { } +MockAckNotifierDelegate::MockAckNotifierDelegate() { +} + +MockAckNotifierDelegate::~MockAckNotifierDelegate() { +} + namespace { string HexDumpWithMarks(const char* data, int length, diff --git a/net/quic/test_tools/quic_test_utils.h b/net/quic/test_tools/quic_test_utils.h index 843e485..a90b212 100644 --- a/net/quic/test_tools/quic_test_utils.h +++ b/net/quic/test_tools/quic_test_utils.h @@ -366,6 +366,14 @@ class TestDecompressorVisitor : public QuicSpdyDecompressor::Visitor { bool error_; }; +class MockAckNotifierDelegate : public QuicAckNotifier::DelegateInterface { + public: + MockAckNotifierDelegate(); + virtual ~MockAckNotifierDelegate(); + + MOCK_METHOD0(OnAckNotification, void()); +}; + } // namespace test } // namespace net diff --git a/net/tools/quic/end_to_end_test.cc b/net/tools/quic/end_to_end_test.cc index c256d61..9ad6649 100644 --- a/net/tools/quic/end_to_end_test.cc +++ b/net/tools/quic/end_to_end_test.cc @@ -61,13 +61,18 @@ void GenerateBody(string* body, int length) { // Simple wrapper class to run server in a thread. class ServerThread : public base::SimpleThread { public: - explicit ServerThread(IPEndPoint address, const QuicConfig& config) + ServerThread(IPEndPoint address, + const QuicConfig& config, + bool strike_register_no_startup_period) : SimpleThread("server_thread"), listening_(true, false), quit_(true, false), server_(config), address_(address), port_(0) { + if (strike_register_no_startup_period) { + server_.SetStrikeRegisterNoStartupPeriod(); + } } virtual ~ServerThread() { } @@ -116,7 +121,8 @@ class EndToEndTest : public ::testing::TestWithParam<QuicVersion> { protected: EndToEndTest() : server_hostname_("example.com"), - server_started_(false) { + server_started_(false), + strike_register_no_startup_period_(false) { net::IPAddressNumber ip; CHECK(net::ParseIPLiteralToNumber("127.0.0.1", &ip)); server_address_ = IPEndPoint(ip, 0); @@ -154,7 +160,8 @@ class EndToEndTest : public ::testing::TestWithParam<QuicVersion> { } void StartServer() { - server_thread_.reset(new ServerThread(server_address_, server_config_)); + server_thread_.reset(new ServerThread(server_address_, server_config_, + strike_register_no_startup_period_)); server_thread_->Start(); server_thread_->listening()->Wait(); server_address_ = IPEndPoint(server_address_.address(), @@ -210,6 +217,7 @@ class EndToEndTest : public ::testing::TestWithParam<QuicVersion> { QuicConfig client_config_; QuicConfig server_config_; QuicVersion version_; + bool strike_register_no_startup_period_; }; // Run all end to end tests with all supported versions. @@ -442,6 +450,9 @@ TEST_P(EndToEndTest, LargePost) { } TEST_P(EndToEndTest, LargePostZeroRTTFailure) { + // Have the server accept 0-RTT without waiting a startup period. + strike_register_no_startup_period_ = true; + // Send a request and then disconnect. This prepares the client to attempt // a 0-RTT handshake for the next request. ASSERT_TRUE(Initialize()); @@ -454,14 +465,15 @@ TEST_P(EndToEndTest, LargePostZeroRTTFailure) { request.AddBody(body, true); EXPECT_EQ(kFooResponseBody, client_->SendCustomSynchronousRequest(request)); + EXPECT_EQ(2, client_->client()->session()->GetNumSentClientHellos()); client_->Disconnect(); // The 0-RTT handshake should succeed. - // TODO(wtc): figure out why this 0-RTT handshake takes 1 RTT. client_->Connect(); ASSERT_TRUE(client_->client()->connected()); EXPECT_EQ(kFooResponseBody, client_->SendCustomSynchronousRequest(request)); + EXPECT_EQ(1, client_->client()->session()->GetNumSentClientHellos()); client_->Disconnect(); @@ -472,6 +484,7 @@ TEST_P(EndToEndTest, LargePostZeroRTTFailure) { client_->Connect(); ASSERT_TRUE(client_->client()->connected()); EXPECT_EQ(kFooResponseBody, client_->SendCustomSynchronousRequest(request)); + EXPECT_EQ(2, client_->client()->session()->GetNumSentClientHellos()); } // TODO(ianswett): Enable once b/9295090 is fixed. diff --git a/net/tools/quic/quic_client_session.cc b/net/tools/quic/quic_client_session.cc index c41df67..f993908 100644 --- a/net/tools/quic/quic_client_session.cc +++ b/net/tools/quic/quic_client_session.cc @@ -55,6 +55,10 @@ bool QuicClientSession::CryptoConnect() { return crypto_stream_.CryptoConnect(); } +int QuicClientSession::GetNumSentClientHellos() const { + return crypto_stream_.num_sent_client_hellos(); +} + ReliableQuicStream* QuicClientSession::CreateIncomingReliableStream( QuicStreamId id) { DLOG(ERROR) << "Server push not supported"; diff --git a/net/tools/quic/quic_client_session.h b/net/tools/quic/quic_client_session.h index f51aeea..a73d721 100644 --- a/net/tools/quic/quic_client_session.h +++ b/net/tools/quic/quic_client_session.h @@ -39,6 +39,11 @@ class QuicClientSession : public QuicSession { // handshake is started successfully. bool CryptoConnect(); + // Returns the number of client hello messages that have been sent on the + // crypto stream. If the handshake has completed then this is one greater + // than the number of round-trips needed for the handshake. + int GetNumSentClientHellos() const; + protected: // QuicSession methods: virtual ReliableQuicStream* CreateIncomingReliableStream( diff --git a/net/tools/quic/quic_server.h b/net/tools/quic/quic_server.h index 142d1d1..90863ce 100644 --- a/net/tools/quic/quic_server.h +++ b/net/tools/quic/quic_server.h @@ -18,8 +18,6 @@ namespace net { -class QuicCryptoServerConfig; - namespace tools { class QuicDispatcher; @@ -67,6 +65,10 @@ class QuicServer : public EpollCallbackInterface { const IPEndPoint& server_address, const IPEndPoint& client_address); + void SetStrikeRegisterNoStartupPeriod() { + crypto_config_.set_strike_register_no_startup_period(); + } + bool overflow_supported() { return overflow_supported_; } int packets_dropped() { return packets_dropped_; } diff --git a/net/tools/quic/test_tools/quic_test_utils.cc b/net/tools/quic/test_tools/quic_test_utils.cc index 95f1fb2..481a57f 100644 --- a/net/tools/quic/test_tools/quic_test_utils.cc +++ b/net/tools/quic/test_tools/quic_test_utils.cc @@ -76,6 +76,12 @@ QuicCryptoStream* TestSession::GetCryptoStream() { return crypto_stream_; } +MockAckNotifierDelegate::MockAckNotifierDelegate() { +} + +MockAckNotifierDelegate::~MockAckNotifierDelegate() { +} + } // namespace test } // namespace tools } // namespace net diff --git a/net/tools/quic/test_tools/quic_test_utils.h b/net/tools/quic/test_tools/quic_test_utils.h index d18556b..ba33c8b 100644 --- a/net/tools/quic/test_tools/quic_test_utils.h +++ b/net/tools/quic/test_tools/quic_test_utils.h @@ -103,6 +103,14 @@ class TestSession : public QuicSession { DISALLOW_COPY_AND_ASSIGN(TestSession); }; +class MockAckNotifierDelegate : public QuicAckNotifier::DelegateInterface { + public: + MockAckNotifierDelegate(); + virtual ~MockAckNotifierDelegate(); + + MOCK_METHOD0(OnAckNotification, void()); +}; + } // namespace test } // namespace tools } // namespace net |