async-graphql/integrations/axum/src/subscription.rs

258 lines
8.8 KiB
Rust
Raw Normal View History

2021-08-21 21:43:20 +00:00
use std::borrow::Cow;
2021-11-12 04:58:32 +00:00
use std::convert::Infallible;
2021-08-01 09:44:28 +00:00
use std::future::Future;
2021-11-12 04:58:32 +00:00
use std::str::FromStr;
2021-08-01 09:44:28 +00:00
2021-11-12 04:58:32 +00:00
use async_graphql::futures_util::task::{Context, Poll};
use async_graphql::http::{WebSocketProtocols, WsMessage, ALL_WEBSOCKET_PROTOCOLS};
2021-08-01 09:44:28 +00:00
use async_graphql::{Data, ObjectType, Result, Schema, SubscriptionType};
2021-12-06 04:57:15 +00:00
use axum::body::{boxed, BoxBody, HttpBody};
use axum::extract::ws::{CloseFrame, Message};
2021-11-12 04:58:32 +00:00
use axum::extract::{FromRequest, RequestParts, WebSocketUpgrade};
use axum::http::{self, Request, Response, StatusCode};
use axum::response::IntoResponse;
use axum::Error;
2021-11-12 04:58:32 +00:00
use futures_util::future::{BoxFuture, Ready};
use futures_util::stream::{SplitSink, SplitStream};
use futures_util::{future, Sink, SinkExt, Stream, StreamExt};
2021-11-12 04:58:32 +00:00
use tower_service::Service;
2021-08-01 09:44:28 +00:00
2021-11-12 04:58:32 +00:00
/// A GraphQL protocol extractor.
///
/// It extract GraphQL protocol from `SEC_WEBSOCKET_PROTOCOL` header.
#[derive(Debug, Copy, Clone, PartialEq, Eq)]
pub struct GraphQLProtocol(WebSocketProtocols);
#[async_trait::async_trait]
impl<B: Send> FromRequest<B> for GraphQLProtocol {
type Rejection = StatusCode;
2021-08-01 09:44:28 +00:00
2021-11-12 04:58:32 +00:00
async fn from_request(req: &mut RequestParts<B>) -> Result<Self, Self::Rejection> {
req.headers()
.and_then(|headers| headers.get(http::header::SEC_WEBSOCKET_PROTOCOL))
.and_then(|value| value.to_str().ok())
.and_then(|protocols| {
protocols
.split(',')
.find_map(|p| WebSocketProtocols::from_str(p.trim()).ok())
})
.map(Self)
2021-11-12 13:25:39 +00:00
.ok_or(StatusCode::BAD_REQUEST)
2021-08-01 09:44:28 +00:00
}
2021-11-12 04:58:32 +00:00
}
2021-08-01 09:44:28 +00:00
2021-11-12 04:58:32 +00:00
/// A GraphQL subscription service.
pub struct GraphQLSubscription<Query, Mutation, Subscription> {
schema: Schema<Query, Mutation, Subscription>,
}
2021-11-13 00:11:26 +00:00
impl<Query, Mutation, Subscription> Clone for GraphQLSubscription<Query, Mutation, Subscription>
where
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
{
fn clone(&self) -> Self {
Self {
schema: self.schema.clone(),
}
}
}
impl<Query, Mutation, Subscription> GraphQLSubscription<Query, Mutation, Subscription>
where
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
{
2021-11-12 04:58:32 +00:00
/// Create a GraphQL subscription service.
pub fn new(schema: Schema<Query, Mutation, Subscription>) -> Self {
Self { schema }
2021-08-01 09:44:28 +00:00
}
2021-11-12 04:58:32 +00:00
}
2021-08-01 09:44:28 +00:00
2021-11-12 04:58:32 +00:00
impl<B, Query, Mutation, Subscription> Service<Request<B>>
for GraphQLSubscription<Query, Mutation, Subscription>
where
B: HttpBody + Send + 'static,
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
{
type Response = Response<BoxBody>;
type Error = Infallible;
type Future = BoxFuture<'static, Result<Self::Response, Self::Error>>;
fn poll_ready(&mut self, _cx: &mut Context<'_>) -> Poll<Result<(), Self::Error>> {
Poll::Ready(Ok(()))
}
fn call(&mut self, req: Request<B>) -> Self::Future {
let schema = self.schema.clone();
Box::pin(async move {
let mut parts = RequestParts::new(req);
let protocol = match GraphQLProtocol::from_request(&mut parts).await {
Ok(protocol) => protocol,
2021-12-06 04:57:15 +00:00
Err(err) => return Ok(err.into_response().map(boxed)),
2021-11-12 04:58:32 +00:00
};
let upgrade = match WebSocketUpgrade::from_request(&mut parts).await {
Ok(protocol) => protocol,
2021-12-06 04:57:15 +00:00
Err(err) => return Ok(err.into_response().map(boxed)),
2021-11-12 04:58:32 +00:00
};
let schema = schema.clone();
let resp = upgrade
.protocols(ALL_WEBSOCKET_PROTOCOLS)
.on_upgrade(move |stream| GraphQLWebSocket::new(stream, schema, protocol).serve());
2021-12-06 04:57:15 +00:00
Ok(resp.into_response().map(boxed))
2021-11-12 04:58:32 +00:00
})
2021-08-01 09:44:28 +00:00
}
}
2021-11-12 04:58:32 +00:00
type DefaultOnConnInitType = fn(serde_json::Value) -> Ready<async_graphql::Result<Data>>;
fn default_on_connection_init(_: serde_json::Value) -> Ready<async_graphql::Result<Data>> {
futures_util::future::ready(Ok(Data::default()))
}
/// A Websocket connection for GraphQL subscription.
pub struct GraphQLWebSocket<Sink, Stream, Query, Mutation, Subscription, OnConnInit> {
sink: Sink,
stream: Stream,
2021-08-01 09:44:28 +00:00
schema: Schema<Query, Mutation, Subscription>,
2021-11-12 04:58:32 +00:00
data: Data,
on_connection_init: OnConnInit,
protocol: GraphQLProtocol,
}
impl<S, Query, Mutation, Subscription>
GraphQLWebSocket<
SplitSink<S, Message>,
SplitStream<S>,
Query,
Mutation,
Subscription,
DefaultOnConnInitType,
>
2021-11-12 04:58:32 +00:00
where
S: Stream<Item = Result<Message, Error>> + Sink<Message>,
2021-11-12 04:58:32 +00:00
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
2021-08-01 09:44:28 +00:00
{
2021-11-12 04:58:32 +00:00
/// Create a [`GraphQLWebSocket`] object.
pub fn new(
stream: S,
schema: Schema<Query, Mutation, Subscription>,
protocol: GraphQLProtocol,
) -> Self {
let (sink, stream) = stream.split();
GraphQLWebSocket::new_with_pair(sink, stream, schema, protocol)
}
}
impl<Sink, Stream, Query, Mutation, Subscription>
GraphQLWebSocket<Sink, Stream, Query, Mutation, Subscription, DefaultOnConnInitType>
where
Sink: futures_util::sink::Sink<Message>,
Stream: futures_util::stream::Stream<Item = Result<Message, Error>>,
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
{
/// Create a [`GraphQLWebSocket`] object with sink and stream objects.
pub fn new_with_pair(
sink: Sink,
stream: Stream,
2021-11-12 04:58:32 +00:00
schema: Schema<Query, Mutation, Subscription>,
protocol: GraphQLProtocol,
) -> Self {
GraphQLWebSocket {
sink,
2021-11-12 04:58:32 +00:00
stream,
schema,
2021-11-12 04:58:32 +00:00
data: Data::default(),
on_connection_init: default_on_connection_init,
protocol,
}
}
2021-08-01 09:44:28 +00:00
}
impl<Sink, Stream, Query, Mutation, Subscription, OnConnInit, OnConnInitFut>
GraphQLWebSocket<Sink, Stream, Query, Mutation, Subscription, OnConnInit>
2021-11-12 04:58:32 +00:00
where
Sink: futures_util::sink::Sink<Message>,
Stream: futures_util::stream::Stream<Item = Result<Message, Error>>,
2021-08-01 09:44:28 +00:00
Query: ObjectType + 'static,
Mutation: ObjectType + 'static,
Subscription: SubscriptionType + 'static,
2021-11-12 04:58:32 +00:00
OnConnInit: Fn(serde_json::Value) -> OnConnInitFut + Send + Sync + 'static,
OnConnInitFut: Future<Output = async_graphql::Result<Data>> + Send + 'static,
2021-08-01 09:44:28 +00:00
{
2021-11-12 04:58:32 +00:00
/// Specify the initial subscription context data, usually you can get something from the
/// incoming request to create it.
#[must_use]
2021-11-12 04:58:32 +00:00
pub fn with_data(self, data: Data) -> Self {
Self { data, ..self }
}
/// Specify a callback function to be called when the connection is initialized.
///
/// You can get something from the payload of [`GQL_CONNECTION_INIT` message](https://github.com/apollographql/subscriptions-transport-ws/blob/master/PROTOCOL.md#gql_connection_init) to create [`Data`].
/// The data returned by this callback function will be merged with the data specified by [`with_data`].
pub fn on_connection_init<OnConnInit2, Fut>(
self,
callback: OnConnInit2,
) -> GraphQLWebSocket<Sink, Stream, Query, Mutation, Subscription, OnConnInit2>
2021-11-12 04:58:32 +00:00
where
OnConnInit2: Fn(serde_json::Value) -> Fut + Send + Sync + 'static,
Fut: Future<Output = async_graphql::Result<Data>> + Send + 'static,
{
GraphQLWebSocket {
sink: self.sink,
2021-11-12 04:58:32 +00:00
stream: self.stream,
schema: self.schema,
2021-11-12 04:58:32 +00:00
data: self.data,
on_connection_init: callback,
protocol: self.protocol,
}
}
/// Processing subscription requests.
pub async fn serve(self) {
let input = self
.stream
2021-11-12 04:58:32 +00:00
.take_while(|res| future::ready(res.is_ok()))
.map(Result::unwrap)
.filter_map(|msg| {
if let Message::Text(_) | Message::Binary(_) = msg {
future::ready(Some(msg))
} else {
future::ready(None)
}
})
.map(Message::into_data);
let stream =
2021-11-12 04:58:32 +00:00
async_graphql::http::WebSocket::new(self.schema.clone(), input, self.protocol.0)
.connection_data(self.data)
.on_connection_init(self.on_connection_init)
.map(|msg| match msg {
WsMessage::Text(text) => Message::Text(text),
WsMessage::Close(code, status) => Message::Close(Some(CloseFrame {
code,
reason: Cow::from(status),
})),
});
let sink = self.sink;
futures_util::pin_mut!(stream, sink);
2021-11-12 04:58:32 +00:00
while let Some(item) = stream.next().await {
let _ = sink.send(item).await;
}
2021-08-01 09:44:28 +00:00
}
}