use anyhow::{anyhow, Context, Result}; use futures::{io::BufWriter, AsyncRead, AsyncWrite}; use gpui::{executor, Task}; use parking_lot::{Mutex, RwLock}; use postage::{barrier, oneshot, prelude::Stream, sink::Sink}; use serde::{Deserialize, Serialize}; use serde_json::{json, value::RawValue, Value}; use smol::{ channel, io::{AsyncBufReadExt, AsyncReadExt, AsyncWriteExt, BufReader}, process::Command, }; use std::{ collections::HashMap, future::Future, io::Write, str::FromStr, sync::{ atomic::{AtomicBool, AtomicUsize, Ordering::SeqCst}, Arc, }, }; use std::{path::Path, process::Stdio}; use util::TryFutureExt; pub use lsp_types::*; const JSON_RPC_VERSION: &'static str = "2.0"; const CONTENT_LEN_HEADER: &'static str = "Content-Length: "; type NotificationHandler = Box; type ResponseHandler = Box)>; pub struct LanguageServer { next_id: AtomicUsize, outbound_tx: RwLock>>>, notification_handlers: Arc>>, response_handlers: Arc>>, executor: Arc, io_tasks: Mutex>, Task>)>>, initialized: barrier::Receiver, output_done_rx: Mutex>, } pub struct Subscription { method: &'static str, notification_handlers: Arc>>, } #[derive(Serialize, Deserialize)] struct Request<'a, T> { jsonrpc: &'a str, id: usize, method: &'a str, params: T, } #[derive(Serialize, Deserialize)] struct AnyResponse<'a> { id: usize, #[serde(default)] error: Option, #[serde(borrow)] result: Option<&'a RawValue>, } #[derive(Serialize, Deserialize)] struct Notification<'a, T> { #[serde(borrow)] jsonrpc: &'a str, #[serde(borrow)] method: &'a str, params: T, } #[derive(Deserialize)] struct AnyNotification<'a> { #[serde(borrow)] method: &'a str, #[serde(borrow)] params: &'a RawValue, } #[derive(Debug, Serialize, Deserialize)] struct Error { message: String, } impl LanguageServer { pub fn new( binary_path: &Path, root_path: &Path, background: Arc, ) -> Result> { let mut server = Command::new(binary_path) .stdin(Stdio::piped()) .stdout(Stdio::piped()) .stderr(Stdio::inherit()) .spawn()?; let stdin = server.stdin.take().unwrap(); let stdout = server.stdout.take().unwrap(); Self::new_internal(stdin, stdout, root_path, background) } fn new_internal( stdin: Stdin, stdout: Stdout, root_path: &Path, executor: Arc, ) -> Result> where Stdin: AsyncWrite + Unpin + Send + 'static, Stdout: AsyncRead + Unpin + Send + 'static, { let mut stdin = BufWriter::new(stdin); let mut stdout = BufReader::new(stdout); let (outbound_tx, outbound_rx) = channel::unbounded::>(); let notification_handlers = Arc::new(RwLock::new(HashMap::<_, NotificationHandler>::new())); let response_handlers = Arc::new(Mutex::new(HashMap::<_, ResponseHandler>::new())); let input_task = executor.spawn( { let notification_handlers = notification_handlers.clone(); let response_handlers = response_handlers.clone(); async move { let mut buffer = Vec::new(); loop { buffer.clear(); stdout.read_until(b'\n', &mut buffer).await?; stdout.read_until(b'\n', &mut buffer).await?; let message_len: usize = std::str::from_utf8(&buffer)? .strip_prefix(CONTENT_LEN_HEADER) .ok_or_else(|| anyhow!("invalid header"))? .trim_end() .parse()?; buffer.resize(message_len, 0); stdout.read_exact(&mut buffer).await?; if let Ok(AnyNotification { method, params }) = serde_json::from_slice(&buffer) { if let Some(handler) = notification_handlers.write().get_mut(method) { handler(params.get()); } else { log::info!( "unhandled notification {}:\n{}", method, serde_json::to_string_pretty( &Value::from_str(params.get()).unwrap() ) .unwrap() ); } } else if let Ok(AnyResponse { id, error, result }) = serde_json::from_slice(&buffer) { if let Some(handler) = response_handlers.lock().remove(&id) { if let Some(error) = error { handler(Err(error)); } else if let Some(result) = result { handler(Ok(result.get())); } else { handler(Ok("null")); } } } else { return Err(anyhow!( "failed to deserialize message:\n{}", std::str::from_utf8(&buffer)? )); } } } } .log_err(), ); let (output_done_tx, output_done_rx) = barrier::channel(); let output_task = executor.spawn( async move { let mut content_len_buffer = Vec::new(); while let Ok(message) = outbound_rx.recv().await { content_len_buffer.clear(); write!(content_len_buffer, "{}", message.len()).unwrap(); stdin.write_all(CONTENT_LEN_HEADER.as_bytes()).await?; stdin.write_all(&content_len_buffer).await?; stdin.write_all("\r\n\r\n".as_bytes()).await?; stdin.write_all(&message).await?; stdin.flush().await?; } drop(output_done_tx); Ok(()) } .log_err(), ); let (initialized_tx, initialized_rx) = barrier::channel(); let this = Arc::new(Self { notification_handlers, response_handlers, next_id: Default::default(), outbound_tx: RwLock::new(Some(outbound_tx)), executor: executor.clone(), io_tasks: Mutex::new(Some((input_task, output_task))), initialized: initialized_rx, output_done_rx: Mutex::new(Some(output_done_rx)), }); let root_uri = lsp_types::Url::from_file_path(root_path).map_err(|_| anyhow!("invalid root path"))?; executor .spawn({ let this = this.clone(); async move { this.init(root_uri).log_err().await; drop(initialized_tx); } }) .detach(); Ok(this) } async fn init(self: Arc, root_uri: lsp_types::Url) -> Result<()> { #[allow(deprecated)] let params = lsp_types::InitializeParams { process_id: Default::default(), root_path: Default::default(), root_uri: Some(root_uri), initialization_options: Default::default(), capabilities: lsp_types::ClientCapabilities { experimental: Some(json!({ "serverStatusNotification": true, })), window: Some(lsp_types::WindowClientCapabilities { work_done_progress: Some(true), ..Default::default() }), ..Default::default() }, trace: Default::default(), workspace_folders: Default::default(), client_info: Default::default(), locale: Default::default(), }; let this = self.clone(); let request = Self::request_internal::( &this.next_id, &this.response_handlers, this.outbound_tx.read().as_ref(), params, ); request.await?; Self::notify_internal::( this.outbound_tx.read().as_ref(), lsp_types::InitializedParams {}, )?; Ok(()) } pub fn shutdown(&self) -> Option>> { if let Some(tasks) = self.io_tasks.lock().take() { let response_handlers = self.response_handlers.clone(); let outbound_tx = self.outbound_tx.write().take(); let next_id = AtomicUsize::new(self.next_id.load(SeqCst)); let mut output_done = self.output_done_rx.lock().take().unwrap(); Some(async move { Self::request_internal::( &next_id, &response_handlers, outbound_tx.as_ref(), (), ) .await?; Self::notify_internal::(outbound_tx.as_ref(), ())?; drop(outbound_tx); output_done.recv().await; drop(tasks); Ok(()) }) } else { None } } pub fn on_notification(&self, mut f: F) -> Subscription where T: lsp_types::notification::Notification, F: 'static + Send + Sync + FnMut(T::Params), { let prev_handler = self.notification_handlers.write().insert( T::METHOD, Box::new( move |notification| match serde_json::from_str(notification) { Ok(notification) => f(notification), Err(err) => log::error!("error parsing notification {}: {}", T::METHOD, err), }, ), ); assert!( prev_handler.is_none(), "registered multiple handlers for the same notification" ); Subscription { method: T::METHOD, notification_handlers: self.notification_handlers.clone(), } } pub fn request( self: Arc, params: T::Params, ) -> impl Future> where T::Result: 'static + Send, { let this = self.clone(); async move { this.initialized.clone().recv().await; Self::request_internal::( &this.next_id, &this.response_handlers, this.outbound_tx.read().as_ref(), params, ) .await } } fn request_internal( next_id: &AtomicUsize, response_handlers: &Mutex>, outbound_tx: Option<&channel::Sender>>, params: T::Params, ) -> impl 'static + Future> where T::Result: 'static + Send, { let id = next_id.fetch_add(1, SeqCst); let message = serde_json::to_vec(&Request { jsonrpc: JSON_RPC_VERSION, id, method: T::METHOD, params, }) .unwrap(); let mut response_handlers = response_handlers.lock(); let (mut tx, mut rx) = oneshot::channel(); response_handlers.insert( id, Box::new(move |result| { let response = match result { Ok(response) => { serde_json::from_str(response).context("failed to deserialize response") } Err(error) => Err(anyhow!("{}", error.message)), }; let _ = tx.try_send(response); }), ); let send = outbound_tx .as_ref() .ok_or_else(|| { anyhow!("tried to send a request to a language server that has been shut down") }) .and_then(|outbound_tx| { outbound_tx.try_send(message)?; Ok(()) }); async move { send?; rx.recv().await.unwrap() } } pub fn notify( self: &Arc, params: T::Params, ) -> impl Future> { let this = self.clone(); async move { this.initialized.clone().recv().await; Self::notify_internal::(this.outbound_tx.read().as_ref(), params)?; Ok(()) } } fn notify_internal( outbound_tx: Option<&channel::Sender>>, params: T::Params, ) -> Result<()> { let message = serde_json::to_vec(&Notification { jsonrpc: JSON_RPC_VERSION, method: T::METHOD, params, }) .unwrap(); let outbound_tx = outbound_tx .as_ref() .ok_or_else(|| anyhow!("tried to notify a language server that has been shut down"))?; outbound_tx.try_send(message)?; Ok(()) } } impl Drop for LanguageServer { fn drop(&mut self) { if let Some(shutdown) = self.shutdown() { self.executor.spawn(shutdown).detach(); } } } impl Subscription { pub fn detach(mut self) { self.method = ""; } } impl Drop for Subscription { fn drop(&mut self) { self.notification_handlers.write().remove(self.method); } } #[cfg(any(test, feature = "test-support"))] pub struct FakeLanguageServer { buffer: Vec, stdin: smol::io::BufReader, stdout: smol::io::BufWriter, pub started: Arc, } #[cfg(any(test, feature = "test-support"))] pub struct RequestId { id: usize, _type: std::marker::PhantomData, } #[cfg(any(test, feature = "test-support"))] impl LanguageServer { pub async fn fake(executor: Arc) -> (Arc, FakeLanguageServer) { let stdin = async_pipe::pipe(); let stdout = async_pipe::pipe(); let mut fake = FakeLanguageServer { stdin: smol::io::BufReader::new(stdin.1), stdout: smol::io::BufWriter::new(stdout.0), buffer: Vec::new(), started: Arc::new(AtomicBool::new(true)), }; let server = Self::new_internal(stdin.0, stdout.1, Path::new("/"), executor).unwrap(); let (init_id, _) = fake.receive_request::().await; fake.respond(init_id, InitializeResult::default()).await; fake.receive_notification::() .await; (server, fake) } } #[cfg(any(test, feature = "test-support"))] impl FakeLanguageServer { pub async fn notify(&mut self, params: T::Params) { if !self.started.load(std::sync::atomic::Ordering::SeqCst) { panic!("can't simulate an LSP notification before the server has been started"); } let message = serde_json::to_vec(&Notification { jsonrpc: JSON_RPC_VERSION, method: T::METHOD, params, }) .unwrap(); self.send(message).await; } pub async fn respond<'a, T: request::Request>( &mut self, request_id: RequestId, result: T::Result, ) { let result = serde_json::to_string(&result).unwrap(); let message = serde_json::to_vec(&AnyResponse { id: request_id.id, error: None, result: Some(&RawValue::from_string(result).unwrap()), }) .unwrap(); self.send(message).await; } pub async fn receive_request(&mut self) -> (RequestId, T::Params) { loop { self.receive().await; if let Ok(request) = serde_json::from_slice::>(&self.buffer) { assert_eq!(request.method, T::METHOD); assert_eq!(request.jsonrpc, JSON_RPC_VERSION); return ( RequestId { id: request.id, _type: std::marker::PhantomData, }, request.params, ); } else { println!( "skipping message in fake language server {:?}", std::str::from_utf8(&self.buffer) ); } } } pub async fn receive_notification(&mut self) -> T::Params { self.receive().await; let notification = serde_json::from_slice::>(&self.buffer).unwrap(); assert_eq!(notification.method, T::METHOD); notification.params } pub async fn start_progress(&mut self, token: impl Into) { self.notify::(ProgressParams { token: NumberOrString::String(token.into()), value: ProgressParamsValue::WorkDone(WorkDoneProgress::Begin(Default::default())), }) .await; } pub async fn end_progress(&mut self, token: impl Into) { self.notify::(ProgressParams { token: NumberOrString::String(token.into()), value: ProgressParamsValue::WorkDone(WorkDoneProgress::End(Default::default())), }) .await; } async fn send(&mut self, message: Vec) { self.stdout .write_all(CONTENT_LEN_HEADER.as_bytes()) .await .unwrap(); self.stdout .write_all((format!("{}", message.len())).as_bytes()) .await .unwrap(); self.stdout.write_all("\r\n\r\n".as_bytes()).await.unwrap(); self.stdout.write_all(&message).await.unwrap(); self.stdout.flush().await.unwrap(); } async fn receive(&mut self) { self.buffer.clear(); self.stdin .read_until(b'\n', &mut self.buffer) .await .unwrap(); self.stdin .read_until(b'\n', &mut self.buffer) .await .unwrap(); let message_len: usize = std::str::from_utf8(&self.buffer) .unwrap() .strip_prefix(CONTENT_LEN_HEADER) .unwrap() .trim_end() .parse() .unwrap(); self.buffer.resize(message_len, 0); self.stdin.read_exact(&mut self.buffer).await.unwrap(); } } #[cfg(test)] mod tests { use super::*; use gpui::TestAppContext; use simplelog::SimpleLogger; use unindent::Unindent; use util::test::temp_tree; #[gpui::test] async fn test_basic(cx: TestAppContext) { let lib_source = r#" fn fun() { let hello = "world"; } "# .unindent(); let root_dir = temp_tree(json!({ "Cargo.toml": r#" [package] name = "temp" version = "0.1.0" edition = "2018" "#.unindent(), "src": { "lib.rs": &lib_source } })); let lib_file_uri = lsp_types::Url::from_file_path(root_dir.path().join("src/lib.rs")).unwrap(); let server = cx.read(|cx| { LanguageServer::new( Path::new("rust-analyzer"), root_dir.path(), cx.background().clone(), ) .unwrap() }); server.next_idle_notification().await; server .notify::( lsp_types::DidOpenTextDocumentParams { text_document: lsp_types::TextDocumentItem::new( lib_file_uri.clone(), "rust".to_string(), 0, lib_source, ), }, ) .await .unwrap(); let hover = server .request::(lsp_types::HoverParams { text_document_position_params: lsp_types::TextDocumentPositionParams { text_document: lsp_types::TextDocumentIdentifier::new(lib_file_uri), position: lsp_types::Position::new(1, 21), }, work_done_progress_params: Default::default(), }) .await .unwrap() .unwrap(); assert_eq!( hover.contents, lsp_types::HoverContents::Markup(lsp_types::MarkupContent { kind: lsp_types::MarkupKind::Markdown, value: "&str".to_string() }) ); } #[gpui::test] async fn test_fake(cx: TestAppContext) { SimpleLogger::init(log::LevelFilter::Info, Default::default()).unwrap(); let (server, mut fake) = LanguageServer::fake(cx.background()).await; let (message_tx, message_rx) = channel::unbounded(); let (diagnostics_tx, diagnostics_rx) = channel::unbounded(); server .on_notification::(move |params| { message_tx.try_send(params).unwrap() }) .detach(); server .on_notification::(move |params| { diagnostics_tx.try_send(params).unwrap() }) .detach(); server .notify::(DidOpenTextDocumentParams { text_document: TextDocumentItem::new( Url::from_str("file://a/b").unwrap(), "rust".to_string(), 0, "".to_string(), ), }) .await .unwrap(); assert_eq!( fake.receive_notification::() .await .text_document .uri .as_str(), "file://a/b" ); fake.notify::(ShowMessageParams { typ: MessageType::ERROR, message: "ok".to_string(), }) .await; fake.notify::(PublishDiagnosticsParams { uri: Url::from_str("file://b/c").unwrap(), version: Some(5), diagnostics: vec![], }) .await; assert_eq!(message_rx.recv().await.unwrap().message, "ok"); assert_eq!( diagnostics_rx.recv().await.unwrap().uri.as_str(), "file://b/c" ); drop(server); let (shutdown_request, _) = fake.receive_request::().await; fake.respond(shutdown_request, ()).await; fake.receive_notification::() .await; } impl LanguageServer { async fn next_idle_notification(self: &Arc) { let (tx, rx) = channel::unbounded(); let _subscription = self.on_notification::(move |params| { if params.quiescent { tx.try_send(()).unwrap(); } }); let _ = rx.recv().await; } } pub enum ServerStatusNotification {} impl lsp_types::notification::Notification for ServerStatusNotification { type Params = ServerStatusParams; const METHOD: &'static str = "experimental/serverStatus"; } #[derive(Deserialize, Serialize, PartialEq, Eq, Clone)] pub struct ServerStatusParams { pub quiescent: bool, } }