mirror of
https://github.com/librespot-org/librespot.git
synced 2024-12-18 17:11:53 +00:00
Rework session keep-alive logic (#1359)
we don't really know what the server expects and how quickly it usually reacts, so add some safety margin to avoid timing out too early
This commit is contained in:
parent
f43ed29970
commit
ed766d2b2a
3 changed files with 276 additions and 156 deletions
1
Cargo.lock
generated
1
Cargo.lock
generated
|
@ -1777,6 +1777,7 @@ dependencies = [
|
||||||
"once_cell",
|
"once_cell",
|
||||||
"parking_lot",
|
"parking_lot",
|
||||||
"pbkdf2",
|
"pbkdf2",
|
||||||
|
"pin-project-lite",
|
||||||
"priority-queue",
|
"priority-queue",
|
||||||
"protobuf",
|
"protobuf",
|
||||||
"quick-xml",
|
"quick-xml",
|
||||||
|
|
|
@ -44,6 +44,7 @@ num-traits = "0.2"
|
||||||
once_cell = "1"
|
once_cell = "1"
|
||||||
parking_lot = { version = "0.12", features = ["deadlock_detection"] }
|
parking_lot = { version = "0.12", features = ["deadlock_detection"] }
|
||||||
pbkdf2 = { version = "0.12", default-features = false, features = ["hmac"] }
|
pbkdf2 = { version = "0.12", default-features = false, features = ["hmac"] }
|
||||||
|
pin-project-lite = "0.2"
|
||||||
priority-queue = "2.0"
|
priority-queue = "2.0"
|
||||||
protobuf = "3.5"
|
protobuf = "3.5"
|
||||||
quick-xml = { version = "0.36.1", features = ["serialize"] }
|
quick-xml = { version = "0.36.1", features = ["serialize"] }
|
||||||
|
|
|
@ -12,14 +12,18 @@ use std::{
|
||||||
use byteorder::{BigEndian, ByteOrder};
|
use byteorder::{BigEndian, ByteOrder};
|
||||||
use bytes::Bytes;
|
use bytes::Bytes;
|
||||||
use futures_core::TryStream;
|
use futures_core::TryStream;
|
||||||
use futures_util::{future, ready, StreamExt, TryStreamExt};
|
use futures_util::StreamExt;
|
||||||
use librespot_protocol::authentication::AuthenticationType;
|
use librespot_protocol::authentication::AuthenticationType;
|
||||||
use num_traits::FromPrimitive;
|
use num_traits::FromPrimitive;
|
||||||
use once_cell::sync::OnceCell;
|
use once_cell::sync::OnceCell;
|
||||||
use parking_lot::RwLock;
|
use parking_lot::RwLock;
|
||||||
|
use pin_project_lite::pin_project;
|
||||||
use quick_xml::events::Event;
|
use quick_xml::events::Event;
|
||||||
use thiserror::Error;
|
use thiserror::Error;
|
||||||
use tokio::{sync::mpsc, time::Instant};
|
use tokio::{
|
||||||
|
sync::mpsc,
|
||||||
|
time::{sleep, Duration as TokioDuration, Instant as TokioInstant, Sleep},
|
||||||
|
};
|
||||||
use tokio_stream::wrappers::UnboundedReceiverStream;
|
use tokio_stream::wrappers::UnboundedReceiverStream;
|
||||||
|
|
||||||
use crate::{
|
use crate::{
|
||||||
|
@ -82,7 +86,6 @@ struct SessionData {
|
||||||
time_delta: i64,
|
time_delta: i64,
|
||||||
invalid: bool,
|
invalid: bool,
|
||||||
user_data: UserData,
|
user_data: UserData,
|
||||||
last_ping: Option<Instant>,
|
|
||||||
}
|
}
|
||||||
|
|
||||||
struct SessionInternal {
|
struct SessionInternal {
|
||||||
|
@ -240,6 +243,8 @@ impl Session {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
// This channel serves as a buffer for packets and serializes access to the TcpStream, such
|
||||||
|
// that `self.send_packet` can return immediately and needs no additional synchronization.
|
||||||
let (tx_connection, rx_connection) = mpsc::unbounded_channel();
|
let (tx_connection, rx_connection) = mpsc::unbounded_channel();
|
||||||
self.0
|
self.0
|
||||||
.tx_connection
|
.tx_connection
|
||||||
|
@ -250,17 +255,20 @@ impl Session {
|
||||||
let sender_task = UnboundedReceiverStream::new(rx_connection)
|
let sender_task = UnboundedReceiverStream::new(rx_connection)
|
||||||
.map(Ok)
|
.map(Ok)
|
||||||
.forward(sink);
|
.forward(sink);
|
||||||
let receiver_task = DispatchTask(stream, self.weak());
|
let session_weak = self.weak();
|
||||||
let timeout_task = Session::session_timeout(self.weak());
|
|
||||||
|
|
||||||
tokio::spawn(async move {
|
tokio::spawn(async move {
|
||||||
let result = future::try_join3(sender_task, receiver_task, timeout_task).await;
|
if let Err(e) = sender_task.await {
|
||||||
|
|
||||||
if let Err(e) = result {
|
|
||||||
error!("{}", e);
|
error!("{}", e);
|
||||||
|
if let Some(session) = session_weak.try_upgrade() {
|
||||||
|
if !session.is_invalid() {
|
||||||
|
session.shutdown();
|
||||||
|
}
|
||||||
|
}
|
||||||
}
|
}
|
||||||
});
|
});
|
||||||
|
|
||||||
|
tokio::spawn(DispatchTask::new(self.weak(), stream));
|
||||||
|
|
||||||
Ok(())
|
Ok(())
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -302,33 +310,6 @@ impl Session {
|
||||||
.get_or_init(|| TokenProvider::new(self.weak()))
|
.get_or_init(|| TokenProvider::new(self.weak()))
|
||||||
}
|
}
|
||||||
|
|
||||||
/// Returns an error, when we haven't received a ping for too long (2 minutes),
|
|
||||||
/// which means that we silently lost connection to Spotify servers.
|
|
||||||
async fn session_timeout(session: SessionWeak) -> io::Result<()> {
|
|
||||||
// pings are sent every 2 minutes and a 5 second margin should be fine
|
|
||||||
const SESSION_TIMEOUT: Duration = Duration::from_secs(125);
|
|
||||||
|
|
||||||
while let Some(session) = session.try_upgrade() {
|
|
||||||
if session.is_invalid() {
|
|
||||||
break;
|
|
||||||
}
|
|
||||||
let last_ping = session.0.data.read().last_ping.unwrap_or_else(Instant::now);
|
|
||||||
if last_ping.elapsed() >= SESSION_TIMEOUT {
|
|
||||||
session.shutdown();
|
|
||||||
// TODO: Optionally reconnect (with cached/last credentials?)
|
|
||||||
return Err(io::Error::new(
|
|
||||||
io::ErrorKind::TimedOut,
|
|
||||||
"session lost connection to server",
|
|
||||||
));
|
|
||||||
}
|
|
||||||
// drop the strong reference before sleeping
|
|
||||||
drop(session);
|
|
||||||
// a potential timeout cannot occur at least until SESSION_TIMEOUT after the last_ping
|
|
||||||
tokio::time::sleep_until(last_ping + SESSION_TIMEOUT).await;
|
|
||||||
}
|
|
||||||
Ok(())
|
|
||||||
}
|
|
||||||
|
|
||||||
pub fn time_delta(&self) -> i64 {
|
pub fn time_delta(&self) -> i64 {
|
||||||
self.0.data.read().time_delta
|
self.0.data.read().time_delta
|
||||||
}
|
}
|
||||||
|
@ -361,96 +342,6 @@ impl Session {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
fn dispatch(&self, cmd: u8, data: Bytes) -> Result<(), Error> {
|
|
||||||
use PacketType::*;
|
|
||||||
|
|
||||||
let packet_type = FromPrimitive::from_u8(cmd);
|
|
||||||
let cmd = match packet_type {
|
|
||||||
Some(cmd) => cmd,
|
|
||||||
None => {
|
|
||||||
trace!("Ignoring unknown packet {:x}", cmd);
|
|
||||||
return Err(SessionError::Packet(cmd).into());
|
|
||||||
}
|
|
||||||
};
|
|
||||||
|
|
||||||
match packet_type {
|
|
||||||
Some(Ping) => {
|
|
||||||
let server_timestamp = BigEndian::read_u32(data.as_ref()) as i64;
|
|
||||||
let timestamp = SystemTime::now()
|
|
||||||
.duration_since(UNIX_EPOCH)
|
|
||||||
.unwrap_or(Duration::ZERO)
|
|
||||||
.as_secs() as i64;
|
|
||||||
|
|
||||||
{
|
|
||||||
let mut data = self.0.data.write();
|
|
||||||
data.time_delta = server_timestamp.saturating_sub(timestamp);
|
|
||||||
data.last_ping = Some(Instant::now());
|
|
||||||
}
|
|
||||||
|
|
||||||
self.debug_info();
|
|
||||||
self.send_packet(Pong, vec![0, 0, 0, 0])
|
|
||||||
}
|
|
||||||
Some(CountryCode) => {
|
|
||||||
let country = String::from_utf8(data.as_ref().to_owned())?;
|
|
||||||
info!("Country: {:?}", country);
|
|
||||||
self.0.data.write().user_data.country = country;
|
|
||||||
Ok(())
|
|
||||||
}
|
|
||||||
Some(StreamChunkRes) | Some(ChannelError) => self.channel().dispatch(cmd, data),
|
|
||||||
Some(AesKey) | Some(AesKeyError) => self.audio_key().dispatch(cmd, data),
|
|
||||||
Some(MercuryReq) | Some(MercurySub) | Some(MercuryUnsub) | Some(MercuryEvent) => {
|
|
||||||
self.mercury().dispatch(cmd, data)
|
|
||||||
}
|
|
||||||
Some(ProductInfo) => {
|
|
||||||
let data = std::str::from_utf8(&data)?;
|
|
||||||
let mut reader = quick_xml::Reader::from_str(data);
|
|
||||||
|
|
||||||
let mut buf = Vec::new();
|
|
||||||
let mut current_element = String::new();
|
|
||||||
let mut user_attributes: UserAttributes = HashMap::new();
|
|
||||||
|
|
||||||
loop {
|
|
||||||
match reader.read_event_into(&mut buf) {
|
|
||||||
Ok(Event::Start(ref element)) => {
|
|
||||||
std::str::from_utf8(element)?.clone_into(&mut current_element)
|
|
||||||
}
|
|
||||||
Ok(Event::End(_)) => {
|
|
||||||
current_element = String::new();
|
|
||||||
}
|
|
||||||
Ok(Event::Text(ref value)) => {
|
|
||||||
if !current_element.is_empty() {
|
|
||||||
let _ = user_attributes
|
|
||||||
.insert(current_element.clone(), value.unescape()?.to_string());
|
|
||||||
}
|
|
||||||
}
|
|
||||||
Ok(Event::Eof) => break,
|
|
||||||
Ok(_) => (),
|
|
||||||
Err(e) => warn!(
|
|
||||||
"Error parsing XML at position {}: {:?}",
|
|
||||||
reader.buffer_position(),
|
|
||||||
e
|
|
||||||
),
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
trace!("Received product info: {:#?}", user_attributes);
|
|
||||||
Self::check_catalogue(&user_attributes);
|
|
||||||
|
|
||||||
self.0.data.write().user_data.attributes = user_attributes;
|
|
||||||
Ok(())
|
|
||||||
}
|
|
||||||
Some(PongAck)
|
|
||||||
| Some(SecretBlock)
|
|
||||||
| Some(LegacyWelcome)
|
|
||||||
| Some(UnknownDataAllZeros)
|
|
||||||
| Some(LicenseVersion) => Ok(()),
|
|
||||||
_ => {
|
|
||||||
trace!("Ignoring {:?} packet with data {:#?}", cmd, data);
|
|
||||||
Err(SessionError::Packet(cmd as u8).into())
|
|
||||||
}
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
pub fn send_packet(&self, cmd: PacketType, data: Vec<u8>) -> Result<(), Error> {
|
pub fn send_packet(&self, cmd: PacketType, data: Vec<u8>) -> Result<(), Error> {
|
||||||
match self.0.tx_connection.get() {
|
match self.0.tx_connection.get() {
|
||||||
Some(tx) => Ok(tx.send((cmd as u8, data))?),
|
Some(tx) => Ok(tx.send((cmd as u8, data))?),
|
||||||
|
@ -614,50 +505,277 @@ impl Drop for SessionInternal {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
struct DispatchTask<S>(S, SessionWeak)
|
#[derive(Clone, Copy, Default, Debug, PartialEq)]
|
||||||
|
enum KeepAliveState {
|
||||||
|
#[default]
|
||||||
|
// Expecting a Ping from the server, either after startup or after a PongAck.
|
||||||
|
ExpectingPing,
|
||||||
|
|
||||||
|
// We need to send a Pong at the given time.
|
||||||
|
PendingPong,
|
||||||
|
|
||||||
|
// We just sent a Pong and wait for it be ACK'd.
|
||||||
|
ExpectingPongAck,
|
||||||
|
}
|
||||||
|
|
||||||
|
const INITIAL_PING_TIMEOUT: TokioDuration = TokioDuration::from_secs(20);
|
||||||
|
const PING_TIMEOUT: TokioDuration = TokioDuration::from_secs(80); // 60s expected + 20s buffer
|
||||||
|
const PONG_DELAY: TokioDuration = TokioDuration::from_secs(60);
|
||||||
|
const PONG_ACK_TIMEOUT: TokioDuration = TokioDuration::from_secs(20);
|
||||||
|
|
||||||
|
impl KeepAliveState {
|
||||||
|
fn debug(&self, sleep: &Sleep) {
|
||||||
|
let delay = sleep
|
||||||
|
.deadline()
|
||||||
|
.checked_duration_since(TokioInstant::now())
|
||||||
|
.map(|t| t.as_secs_f64())
|
||||||
|
.unwrap_or(f64::INFINITY);
|
||||||
|
|
||||||
|
trace!("keep-alive state: {:?}, timeout in {:.1}", self, delay);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
pin_project! {
|
||||||
|
struct DispatchTask<S>
|
||||||
|
where
|
||||||
|
S: TryStream<Ok = (u8, Bytes)>
|
||||||
|
{
|
||||||
|
session: SessionWeak,
|
||||||
|
keep_alive_state: KeepAliveState,
|
||||||
|
#[pin]
|
||||||
|
stream: S,
|
||||||
|
#[pin]
|
||||||
|
timeout: Sleep,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl<S> PinnedDrop for DispatchTask<S>
|
||||||
|
where
|
||||||
|
S: TryStream<Ok = (u8, Bytes)>
|
||||||
|
{
|
||||||
|
fn drop(_this: Pin<&mut Self>) {
|
||||||
|
debug!("drop Dispatch");
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl<S> DispatchTask<S>
|
||||||
where
|
where
|
||||||
S: TryStream<Ok = (u8, Bytes)> + Unpin;
|
S: TryStream<Ok = (u8, Bytes)>,
|
||||||
|
{
|
||||||
|
fn new(session: SessionWeak, stream: S) -> Self {
|
||||||
|
Self {
|
||||||
|
session,
|
||||||
|
keep_alive_state: KeepAliveState::ExpectingPing,
|
||||||
|
stream,
|
||||||
|
timeout: sleep(INITIAL_PING_TIMEOUT),
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
fn dispatch(
|
||||||
|
mut self: Pin<&mut Self>,
|
||||||
|
session: &Session,
|
||||||
|
cmd: u8,
|
||||||
|
data: Bytes,
|
||||||
|
) -> Result<(), Error> {
|
||||||
|
use KeepAliveState::*;
|
||||||
|
use PacketType::*;
|
||||||
|
|
||||||
|
let packet_type = FromPrimitive::from_u8(cmd);
|
||||||
|
let cmd = match packet_type {
|
||||||
|
Some(cmd) => cmd,
|
||||||
|
None => {
|
||||||
|
trace!("Ignoring unknown packet {:x}", cmd);
|
||||||
|
return Err(SessionError::Packet(cmd).into());
|
||||||
|
}
|
||||||
|
};
|
||||||
|
|
||||||
|
match packet_type {
|
||||||
|
Some(Ping) => {
|
||||||
|
trace!("Received Ping");
|
||||||
|
if self.keep_alive_state != ExpectingPing {
|
||||||
|
warn!("Received unexpected Ping from server")
|
||||||
|
}
|
||||||
|
let mut this = self.as_mut().project();
|
||||||
|
*this.keep_alive_state = PendingPong;
|
||||||
|
this.timeout
|
||||||
|
.as_mut()
|
||||||
|
.reset(TokioInstant::now() + PONG_DELAY);
|
||||||
|
this.keep_alive_state.debug(&this.timeout);
|
||||||
|
|
||||||
|
let server_timestamp = BigEndian::read_u32(data.as_ref()) as i64;
|
||||||
|
let timestamp = SystemTime::now()
|
||||||
|
.duration_since(UNIX_EPOCH)
|
||||||
|
.unwrap_or(Duration::ZERO)
|
||||||
|
.as_secs() as i64;
|
||||||
|
{
|
||||||
|
let mut data = session.0.data.write();
|
||||||
|
data.time_delta = server_timestamp.saturating_sub(timestamp);
|
||||||
|
}
|
||||||
|
|
||||||
|
session.debug_info();
|
||||||
|
|
||||||
|
Ok(())
|
||||||
|
}
|
||||||
|
Some(PongAck) => {
|
||||||
|
trace!("Received PongAck");
|
||||||
|
if self.keep_alive_state != ExpectingPongAck {
|
||||||
|
warn!("Received unexpected PongAck from server")
|
||||||
|
}
|
||||||
|
let mut this = self.as_mut().project();
|
||||||
|
*this.keep_alive_state = ExpectingPing;
|
||||||
|
this.timeout
|
||||||
|
.as_mut()
|
||||||
|
.reset(TokioInstant::now() + PING_TIMEOUT);
|
||||||
|
this.keep_alive_state.debug(&this.timeout);
|
||||||
|
|
||||||
|
Ok(())
|
||||||
|
}
|
||||||
|
Some(CountryCode) => {
|
||||||
|
let country = String::from_utf8(data.as_ref().to_owned())?;
|
||||||
|
info!("Country: {:?}", country);
|
||||||
|
session.0.data.write().user_data.country = country;
|
||||||
|
Ok(())
|
||||||
|
}
|
||||||
|
Some(StreamChunkRes) | Some(ChannelError) => session.channel().dispatch(cmd, data),
|
||||||
|
Some(AesKey) | Some(AesKeyError) => session.audio_key().dispatch(cmd, data),
|
||||||
|
Some(MercuryReq) | Some(MercurySub) | Some(MercuryUnsub) | Some(MercuryEvent) => {
|
||||||
|
session.mercury().dispatch(cmd, data)
|
||||||
|
}
|
||||||
|
Some(ProductInfo) => {
|
||||||
|
let data = std::str::from_utf8(&data)?;
|
||||||
|
let mut reader = quick_xml::Reader::from_str(data);
|
||||||
|
|
||||||
|
let mut buf = Vec::new();
|
||||||
|
let mut current_element = String::new();
|
||||||
|
let mut user_attributes: UserAttributes = HashMap::new();
|
||||||
|
|
||||||
|
loop {
|
||||||
|
match reader.read_event_into(&mut buf) {
|
||||||
|
Ok(Event::Start(ref element)) => {
|
||||||
|
std::str::from_utf8(element)?.clone_into(&mut current_element)
|
||||||
|
}
|
||||||
|
Ok(Event::End(_)) => {
|
||||||
|
current_element = String::new();
|
||||||
|
}
|
||||||
|
Ok(Event::Text(ref value)) => {
|
||||||
|
if !current_element.is_empty() {
|
||||||
|
let _ = user_attributes
|
||||||
|
.insert(current_element.clone(), value.unescape()?.to_string());
|
||||||
|
}
|
||||||
|
}
|
||||||
|
Ok(Event::Eof) => break,
|
||||||
|
Ok(_) => (),
|
||||||
|
Err(e) => warn!(
|
||||||
|
"Error parsing XML at position {}: {:?}",
|
||||||
|
reader.buffer_position(),
|
||||||
|
e
|
||||||
|
),
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
trace!("Received product info: {:#?}", user_attributes);
|
||||||
|
Session::check_catalogue(&user_attributes);
|
||||||
|
|
||||||
|
session.0.data.write().user_data.attributes = user_attributes;
|
||||||
|
Ok(())
|
||||||
|
}
|
||||||
|
Some(SecretBlock)
|
||||||
|
| Some(LegacyWelcome)
|
||||||
|
| Some(UnknownDataAllZeros)
|
||||||
|
| Some(LicenseVersion) => Ok(()),
|
||||||
|
_ => {
|
||||||
|
trace!("Ignoring {:?} packet with data {:#?}", cmd, data);
|
||||||
|
Err(SessionError::Packet(cmd as u8).into())
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
impl<S> Future for DispatchTask<S>
|
impl<S> Future for DispatchTask<S>
|
||||||
where
|
where
|
||||||
S: TryStream<Ok = (u8, Bytes)> + Unpin,
|
S: TryStream<Ok = (u8, Bytes), Error = std::io::Error>,
|
||||||
<S as TryStream>::Ok: std::fmt::Debug,
|
<S as TryStream>::Ok: std::fmt::Debug,
|
||||||
{
|
{
|
||||||
type Output = Result<(), S::Error>;
|
type Output = Result<(), S::Error>;
|
||||||
|
|
||||||
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
||||||
let session = match self.1.try_upgrade() {
|
use KeepAliveState::*;
|
||||||
|
|
||||||
|
let session = match self.session.try_upgrade() {
|
||||||
Some(session) => session,
|
Some(session) => session,
|
||||||
None => return Poll::Ready(Ok(())),
|
None => return Poll::Ready(Ok(())),
|
||||||
};
|
};
|
||||||
|
|
||||||
|
// Process all messages that are immediately ready
|
||||||
loop {
|
loop {
|
||||||
let (cmd, data) = match ready!(self.0.try_poll_next_unpin(cx)) {
|
match self.as_mut().project().stream.try_poll_next(cx) {
|
||||||
Some(Ok(t)) => t,
|
Poll::Ready(Some(Ok((cmd, data)))) => {
|
||||||
None => {
|
let result = self.as_mut().dispatch(&session, cmd, data);
|
||||||
|
if let Err(e) = result {
|
||||||
|
debug!("could not dispatch command: {}", e);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
Poll::Ready(None) => {
|
||||||
warn!("Connection to server closed.");
|
warn!("Connection to server closed.");
|
||||||
session.shutdown();
|
session.shutdown();
|
||||||
return Poll::Ready(Ok(()));
|
return Poll::Ready(Ok(()));
|
||||||
}
|
}
|
||||||
Some(Err(e)) => {
|
Poll::Ready(Some(Err(e))) => {
|
||||||
error!("Connection to server closed.");
|
error!("Connection to server closed.");
|
||||||
session.shutdown();
|
session.shutdown();
|
||||||
return Poll::Ready(Err(e));
|
return Poll::Ready(Err(e));
|
||||||
}
|
}
|
||||||
};
|
Poll::Pending => break,
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
if let Err(e) = session.dispatch(cmd, data) {
|
// Handle the keep-alive sequence, returning an error when we haven't received a
|
||||||
debug!("could not dispatch command: {}", e);
|
// Ping/PongAck for too long.
|
||||||
|
//
|
||||||
|
// The expected keepalive sequence is
|
||||||
|
// - Server: Ping
|
||||||
|
// - wait 60s
|
||||||
|
// - Client: Pong
|
||||||
|
// - Server: PongAck
|
||||||
|
// - wait 60s
|
||||||
|
// - repeat
|
||||||
|
//
|
||||||
|
// This means that we silently lost connection to Spotify servers if
|
||||||
|
// - we don't receive Ping immediately after connecting,
|
||||||
|
// - we don't receive a Ping 60s after the last PongAck or
|
||||||
|
// - we don't receive a PongAck immediately after our Pong.
|
||||||
|
//
|
||||||
|
// Currently, we add a safety margin of 20s to these expected deadlines.
|
||||||
|
let mut this = self.as_mut().project();
|
||||||
|
if let Poll::Ready(()) = this.timeout.as_mut().poll(cx) {
|
||||||
|
match this.keep_alive_state {
|
||||||
|
ExpectingPing | ExpectingPongAck => {
|
||||||
|
if !session.is_invalid() {
|
||||||
|
session.shutdown();
|
||||||
|
}
|
||||||
|
// TODO: Optionally reconnect (with cached/last credentials?)
|
||||||
|
return Poll::Ready(Err(io::Error::new(
|
||||||
|
io::ErrorKind::TimedOut,
|
||||||
|
format!(
|
||||||
|
"session lost connection to server ({:?})",
|
||||||
|
this.keep_alive_state
|
||||||
|
),
|
||||||
|
)));
|
||||||
|
}
|
||||||
|
PendingPong => {
|
||||||
|
trace!("Sending Pong");
|
||||||
|
// TODO: Ideally, this should flush the `Framed<TcpStream> as Sink`
|
||||||
|
// before starting the timeout.
|
||||||
|
let _ = session.send_packet(PacketType::Pong, vec![0, 0, 0, 0]);
|
||||||
|
*this.keep_alive_state = ExpectingPongAck;
|
||||||
|
this.timeout
|
||||||
|
.as_mut()
|
||||||
|
.reset(TokioInstant::now() + PONG_ACK_TIMEOUT);
|
||||||
|
this.keep_alive_state.debug(&this.timeout);
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
}
|
|
||||||
|
Poll::Pending
|
||||||
impl<S> Drop for DispatchTask<S>
|
|
||||||
where
|
|
||||||
S: TryStream<Ok = (u8, Bytes)> + Unpin,
|
|
||||||
{
|
|
||||||
fn drop(&mut self) {
|
|
||||||
debug!("drop Dispatch");
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
Loading…
Reference in a new issue