mz_sql_server_util/
lib.rs

1// Copyright Materialize, Inc. and contributors. All rights reserved.
2//
3// Use of this software is governed by the Business Source License
4// included in the LICENSE file.
5//
6// As of the Change Date specified in that file, in accordance with
7// the Business Source License, use of this software will be governed
8// by the Apache License, Version 2.0.
9
10use std::any::Any;
11use std::borrow::Cow;
12use std::future::IntoFuture;
13use std::pin::Pin;
14use std::sync::Arc;
15
16use anyhow::Context;
17use derivative::Derivative;
18use futures::future::BoxFuture;
19use futures::{FutureExt, Stream, StreamExt, TryStreamExt};
20use mz_ore::result::ResultExt;
21use mz_repr::SqlScalarType;
22use smallvec::{SmallVec, smallvec};
23use tiberius::ToSql;
24use tokio::net::TcpStream;
25use tokio::sync::mpsc::{UnboundedReceiver, UnboundedSender};
26use tokio::sync::oneshot;
27use tokio_util::compat::{Compat, TokioAsyncWriteCompatExt};
28
29pub mod cdc;
30pub mod config;
31pub mod desc;
32pub mod inspect;
33
34pub use config::Config;
35pub use desc::{ProtoSqlServerColumnDesc, ProtoSqlServerTableDesc};
36
37use crate::cdc::Lsn;
38use crate::config::TunnelConfig;
39use crate::desc::SqlServerColumnDecodeType;
40
41/// Higher level wrapper around a [`tiberius::Client`] that models transaction
42/// management like other database clients.
43#[derive(Debug)]
44pub struct Client {
45    tx: UnboundedSender<Request>,
46    // The configuration used to create this client.
47    config: Config,
48}
49// While a Client could implement Clone, it's not obvious how multiple Clients
50// using the same SQL Server connection would interact, so ban it for now.
51static_assertions::assert_not_impl_all!(Client: Clone);
52
53impl Client {
54    /// Connect to the specified SQL Server instance, returning a [`Client`]
55    /// that can be used to query it and a [`Connection`] that must be polled
56    /// to send and receive results.
57    ///
58    /// TODO(sql_server2): Maybe return a `ClientBuilder` here that implements
59    /// IntoFuture and does the default good thing of moving the `Connection`
60    /// into a tokio task? And a `.raw()` option that will instead return both
61    /// the Client and Connection for manual polling.
62    pub async fn connect(config: Config) -> Result<Self, SqlServerError> {
63        // Setup our tunnelling and return any resources that need to be kept
64        // alive for the duration of the connection.
65        let (tcp, resources): (_, Option<Box<dyn Any + Send + Sync>>) = match &config.tunnel {
66            TunnelConfig::Direct => {
67                let tcp = TcpStream::connect(config.inner.get_addr())
68                    .await
69                    .context("direct")?;
70                (tcp, None)
71            }
72            TunnelConfig::Ssh {
73                config: ssh_config,
74                manager,
75                timeout,
76                host,
77                port,
78            } => {
79                // N.B. If this tunnel is dropped it will close so we need to
80                // keep it alive for the duration of the connection.
81                let tunnel = manager
82                    .connect(ssh_config.clone(), host, *port, *timeout, config.in_task)
83                    .await?;
84                let tcp = TcpStream::connect(tunnel.local_addr())
85                    .await
86                    .context("ssh tunnel")?;
87
88                (tcp, Some(Box::new(tunnel)))
89            }
90            TunnelConfig::AwsPrivatelink {
91                connection_id,
92                port,
93            } => {
94                let privatelink_host = mz_cloud_resources::vpc_endpoint_name(*connection_id);
95                let mut privatelink_addrs =
96                    tokio::net::lookup_host((privatelink_host.clone(), 0)).await?;
97
98                let Some(mut addr) = privatelink_addrs.next() else {
99                    return Err(SqlServerError::InvariantViolated(format!(
100                        "aws privatelink: no addresses found for host {:?}",
101                        privatelink_host
102                    )));
103                };
104
105                addr.set_port(port.clone());
106
107                let tcp = TcpStream::connect(addr)
108                    .await
109                    .context(format!("aws privatelink {:?}", addr))?;
110
111                (tcp, None)
112            }
113        };
114
115        tcp.set_nodelay(true)?;
116
117        let (client, connection) = Self::connect_raw(config, tcp, resources).await?;
118        mz_ore::task::spawn(|| "sql-server-client-connection", async move {
119            connection.await
120        });
121
122        Ok(client)
123    }
124
125    /// Create a new Client instance with the same configuration that created
126    /// this configuration.
127    pub async fn new_connection(&self) -> Result<Self, SqlServerError> {
128        Self::connect(self.config.clone()).await
129    }
130
131    pub async fn connect_raw(
132        config: Config,
133        tcp: tokio::net::TcpStream,
134        resources: Option<Box<dyn Any + Send + Sync>>,
135    ) -> Result<(Self, Connection), SqlServerError> {
136        let client = tiberius::Client::connect(config.inner.clone(), tcp.compat_write()).await?;
137        let (tx, rx) = tokio::sync::mpsc::unbounded_channel();
138
139        // TODO(sql_server2): Add a lot more logging here like the Postgres and MySQL clients have.
140
141        Ok((
142            Client { tx, config },
143            Connection {
144                rx,
145                client,
146                _resources: resources,
147            },
148        ))
149    }
150
151    /// Executes SQL statements in SQL Server, returning the number of rows effected.
152    ///
153    /// Passthrough method for [`tiberius::Client::execute`].
154    ///
155    /// Note: The returned [`Future`] does not need to be awaited for the query
156    /// to be sent.
157    ///
158    /// [`Future`]: std::future::Future
159    pub async fn execute<'a>(
160        &mut self,
161        query: impl Into<Cow<'a, str>>,
162        params: &[&dyn ToSql],
163    ) -> Result<SmallVec<[u64; 1]>, SqlServerError> {
164        let (tx, rx) = tokio::sync::oneshot::channel();
165
166        let params = params
167            .iter()
168            .map(|p| OwnedColumnData::from(p.to_sql()))
169            .collect();
170        let kind = RequestKind::Execute {
171            query: query.into().to_string(),
172            params,
173        };
174        self.tx
175            .send(Request { tx, kind })
176            .context("sending request")?;
177
178        let response = rx.await.context("channel")??;
179        match response {
180            Response::Execute { rows_affected } => Ok(rows_affected),
181            other @ Response::Rows(_) | other @ Response::RowStream { .. } => {
182                Err(SqlServerError::ProgrammingError(format!(
183                    "expected Response::Execute, got {other:?}"
184                )))
185            }
186        }
187    }
188
189    /// Executes SQL statements in SQL Server, returning the resulting rows.
190    ///
191    /// Passthrough method for [`tiberius::Client::query`].
192    ///
193    /// Note: The returned [`Future`] does not need to be awaited for the query
194    /// to be sent.
195    ///
196    /// [`Future`]: std::future::Future
197    pub async fn query<'a>(
198        &mut self,
199        query: impl Into<Cow<'a, str>>,
200        params: &[&dyn tiberius::ToSql],
201    ) -> Result<SmallVec<[tiberius::Row; 1]>, SqlServerError> {
202        let (tx, rx) = tokio::sync::oneshot::channel();
203
204        let params = params
205            .iter()
206            .map(|p| OwnedColumnData::from(p.to_sql()))
207            .collect();
208        let kind = RequestKind::Query {
209            query: query.into().to_string(),
210            params,
211        };
212        self.tx
213            .send(Request { tx, kind })
214            .context("sending request")?;
215
216        let response = rx.await.context("channel")??;
217        match response {
218            Response::Rows(rows) => Ok(rows),
219            other @ Response::Execute { .. } | other @ Response::RowStream { .. } => Err(
220                SqlServerError::ProgrammingError(format!("expected Response::Rows, got {other:?}")),
221            ),
222        }
223    }
224
225    /// Executes SQL statements in SQL Server, returning a [`Stream`] of
226    /// resulting rows.
227    ///
228    /// Passthrough method for [`tiberius::Client::query`].
229    pub fn query_streaming<'c, 'q, Q>(
230        &'c mut self,
231        query: Q,
232        params: &[&dyn tiberius::ToSql],
233    ) -> impl Stream<Item = Result<tiberius::Row, SqlServerError>> + Send + use<'c, Q>
234    where
235        Q: Into<Cow<'q, str>>,
236    {
237        let (tx, rx) = tokio::sync::oneshot::channel();
238        let params = params
239            .iter()
240            .map(|p| OwnedColumnData::from(p.to_sql()))
241            .collect();
242        let kind = RequestKind::QueryStreamed {
243            query: query.into().to_string(),
244            params,
245        };
246
247        // Make our initial request which will return a Stream of Rows.
248        let request_future = async move {
249            self.tx
250                .send(Request { tx, kind })
251                .context("sending request")?;
252
253            let response = rx.await.context("channel")??;
254            match response {
255                Response::RowStream { stream } => {
256                    Ok(tokio_stream::wrappers::ReceiverStream::new(stream))
257                }
258                other @ Response::Execute { .. } | other @ Response::Rows(_) => {
259                    Err(SqlServerError::ProgrammingError(format!(
260                        "expected Response::Rows, got {other:?}"
261                    )))
262                }
263            }
264        };
265
266        // "flatten" our initial request into the returned stream.
267        futures::stream::once(request_future).try_flatten()
268    }
269
270    /// Executes multiple queries, delimited with `;` and return multiple
271    /// result sets; one for each query.
272    ///
273    /// Passthrough method for [`tiberius::Client::simple_query`].
274    ///
275    /// Note: The returned [`Future`] does not need to be awaited for the query
276    /// to be sent.
277    ///
278    /// [`Future`]: std::future::Future
279    pub async fn simple_query<'a>(
280        &mut self,
281        query: impl Into<Cow<'a, str>>,
282    ) -> Result<SmallVec<[tiberius::Row; 1]>, SqlServerError> {
283        let (tx, rx) = tokio::sync::oneshot::channel();
284        let kind = RequestKind::SimpleQuery {
285            query: query.into().to_string(),
286        };
287        self.tx
288            .send(Request { tx, kind })
289            .context("sending request")?;
290
291        let response = rx.await.context("channel")??;
292        match response {
293            Response::Rows(rows) => Ok(rows),
294            other @ Response::Execute { .. } | other @ Response::RowStream { .. } => Err(
295                SqlServerError::ProgrammingError(format!("expected Response::Rows, got {other:?}")),
296            ),
297        }
298    }
299
300    /// Starts a transaction which is automatically rolled back on drop.
301    ///
302    /// To commit or rollback the transaction, see [`Transaction::commit`] and
303    /// [`Transaction::rollback`] respectively.
304    pub async fn transaction(&mut self) -> Result<Transaction<'_>, SqlServerError> {
305        Transaction::new(self).await
306    }
307
308    /// Sets the transaction isolation level for the current session.
309    pub async fn set_transaction_isolation(
310        &mut self,
311        level: TransactionIsolationLevel,
312    ) -> Result<(), SqlServerError> {
313        let query = format!("SET TRANSACTION ISOLATION LEVEL {}", level.as_str());
314        self.simple_query(query).await?;
315        Ok(())
316    }
317
318    /// Returns the current transaction isolation level for the current session.
319    pub async fn get_transaction_isolation(
320        &mut self,
321    ) -> Result<TransactionIsolationLevel, SqlServerError> {
322        const QUERY: &str = "SELECT transaction_isolation_level FROM sys.dm_exec_sessions where session_id = @@SPID;";
323        let rows = self.simple_query(QUERY).await?;
324        match &rows[..] {
325            [row] => {
326                let val: i16 = row
327                    .try_get(0)
328                    .context("getting 0th column")?
329                    .ok_or_else(|| anyhow::anyhow!("no 0th column?"))?;
330                let level = TransactionIsolationLevel::try_from_sql_server(val)?;
331                Ok(level)
332            }
333            other => Err(SqlServerError::InvariantViolated(format!(
334                "expected one row, got {other:?}"
335            ))),
336        }
337    }
338
339    /// Return a [`CdcStream`] that can be used to track changes for the specified
340    /// `capture_instances`.
341    ///
342    /// [`CdcStream`]: crate::cdc::CdcStream
343    pub fn cdc<I, M>(&mut self, capture_instances: I, metrics: M) -> crate::cdc::CdcStream<'_, M>
344    where
345        I: IntoIterator,
346        I::Item: Into<Arc<str>>,
347        M: SqlServerCdcMetrics,
348    {
349        let instances = capture_instances
350            .into_iter()
351            .map(|i| (i.into(), None))
352            .collect();
353        crate::cdc::CdcStream::new(self, instances, metrics)
354    }
355}
356
357/// A stream of [`tiberius::Row`]s.
358pub type RowStream<'a> =
359    Pin<Box<dyn Stream<Item = Result<tiberius::Row, SqlServerError>> + Send + 'a>>;
360
361#[derive(Debug)]
362pub struct Transaction<'a> {
363    client: &'a mut Client,
364    closed: bool,
365}
366
367impl<'a> Transaction<'a> {
368    async fn new(client: &'a mut Client) -> Result<Self, SqlServerError> {
369        let results = client
370            .simple_query("BEGIN TRANSACTION")
371            .await
372            .context("begin")?;
373        if !results.is_empty() {
374            Err(SqlServerError::InvariantViolated(format!(
375                "expected empty result from BEGIN TRANSACTION. Got: {results:?}"
376            )))
377        } else {
378            Ok(Transaction {
379                client,
380                closed: false,
381            })
382        }
383    }
384
385    /// Creates a savepoint via `SAVE TRANSACTION` with the provided name.
386    /// Creating a savepoint forces a write to the transaction log, which will associate an
387    /// [`Lsn`] with the current transaction.
388    ///
389    /// The savepoint name must follow rules for SQL Server identifiers
390    /// - starts with letter or underscore
391    /// - only contains letters, digits, and underscores
392    /// - no reserved words
393    /// - 32 char max
394    pub async fn create_savepoint(&mut self, savepoint_name: &str) -> Result<(), SqlServerError> {
395        // Limit the name checks to prevent sending a potentially dangerous string to the SQL Server.
396        // We prefer the server do the majority of the validation.
397        if savepoint_name.is_empty()
398            || !savepoint_name
399                .chars()
400                .all(|c| c.is_alphanumeric() || c == '_')
401        {
402            Err(SqlServerError::ProgrammingError(format!(
403                "Invalid savepoint name: '{savepoint_name}"
404            )))?;
405        }
406
407        let stmt = format!("SAVE TRANSACTION [{savepoint_name}]");
408        let _result = self.client.simple_query(stmt).await?;
409        Ok(())
410    }
411
412    /// Retrieve the [`Lsn`] associated with the current session.
413    ///
414    /// MS SQL Server will not assign an [`Lsn`] until a write is performed (e.g. via `SAVE TRANSACTION`).
415    pub async fn get_lsn(&mut self) -> Result<Lsn, SqlServerError> {
416        static CURRENT_LSN_QUERY: &str = "SELECT dt.database_transaction_most_recent_savepoint_lsn \
417            FROM sys.dm_tran_database_transactions dt \
418            JOIN sys.dm_tran_current_transaction ct \
419                ON ct.transaction_id = dt.transaction_id \
420            WHERE dt.database_transaction_most_recent_savepoint_lsn IS NOT NULL";
421        let result = self.client.simple_query(CURRENT_LSN_QUERY).await?;
422        crate::inspect::parse_numeric_lsn(&result)
423    }
424
425    /// Lock the provided table to prevent writes but allow reads, uses `(TABLOCK, HOLDLOCK)`.
426    ///
427    /// This will set the transaction isolation level to `READ COMMITTED` and then obtain the
428    /// lock using a `SELECT` statement that will not read any data from the table.
429    /// The lock is released after transaction commit or rollback.
430    pub async fn lock_table_shared(
431        &mut self,
432        schema: &str,
433        table: &str,
434    ) -> Result<(), SqlServerError> {
435        // Locks in MS SQL server do not behave the same way under all isolation levels. In testing,
436        // it has been observed that if the isolation level is SNAPSHOT, these locks are ineffective.
437        static SET_READ_COMMITTED: &str = "SET TRANSACTION ISOLATION LEVEL READ COMMITTED;";
438        // This query probably seems odd, but there is no LOCK command in MS SQL. Locks are specified
439        // in SELECT using the WITH keyword.  This query does not need to return any rows to lock the table,
440        // hence the 1=0, which is something short that always evaluates to false in this universe.
441        let query = format!(
442            "{SET_READ_COMMITTED}\nSELECT * FROM [{schema}].[{table}] WITH (TABLOCK, HOLDLOCK) WHERE 1=0;"
443        );
444        let _result = self.client.simple_query(query).await?;
445        Ok(())
446    }
447
448    /// See [`Client::execute`].
449    pub async fn execute<'q>(
450        &mut self,
451        query: impl Into<Cow<'q, str>>,
452        params: &[&dyn ToSql],
453    ) -> Result<SmallVec<[u64; 1]>, SqlServerError> {
454        self.client.execute(query, params).await
455    }
456
457    /// See [`Client::query`].
458    pub async fn query<'q>(
459        &mut self,
460        query: impl Into<Cow<'q, str>>,
461        params: &[&dyn tiberius::ToSql],
462    ) -> Result<SmallVec<[tiberius::Row; 1]>, SqlServerError> {
463        self.client.query(query, params).await
464    }
465
466    /// See [`Client::query_streaming`]
467    pub fn query_streaming<'c, 'q, Q>(
468        &'c mut self,
469        query: Q,
470        params: &[&dyn tiberius::ToSql],
471    ) -> impl Stream<Item = Result<tiberius::Row, SqlServerError>> + Send + use<'c, Q>
472    where
473        Q: Into<Cow<'q, str>>,
474    {
475        self.client.query_streaming(query, params)
476    }
477
478    /// See [`Client::simple_query`].
479    pub async fn simple_query<'q>(
480        &mut self,
481        query: impl Into<Cow<'q, str>>,
482    ) -> Result<SmallVec<[tiberius::Row; 1]>, SqlServerError> {
483        self.client.simple_query(query).await
484    }
485
486    /// Rollback the [`Transaction`].
487    pub async fn rollback(mut self) -> Result<(), SqlServerError> {
488        static ROLLBACK_QUERY: &str = "ROLLBACK TRANSACTION";
489        // N.B. Mark closed _before_ running the query. This prevents us from
490        // double closing the transaction if this query itself fails.
491        self.closed = true;
492        self.client.simple_query(ROLLBACK_QUERY).await?;
493        Ok(())
494    }
495
496    /// Commit the [`Transaction`].
497    pub async fn commit(mut self) -> Result<(), SqlServerError> {
498        static COMMIT_QUERY: &str = "COMMIT TRANSACTION";
499        // N.B. Mark closed _before_ running the query. This prevents us from
500        // double closing the transaction if this query itself fails.
501        self.closed = true;
502        self.client.simple_query(COMMIT_QUERY).await?;
503        Ok(())
504    }
505}
506
507impl Drop for Transaction<'_> {
508    fn drop(&mut self) {
509        // Internally the query is synchronously sent down a channel, and the response is what
510        // we await. In other words, we don't need to `.await` here for the query to be run.
511        if !self.closed {
512            let _fut = self.client.simple_query("ROLLBACK TRANSACTION");
513        }
514    }
515}
516
517/// Transaction isolation levels defined by Microsoft's SQL Server.
518///
519/// See: <https://learn.microsoft.com/en-us/sql/t-sql/statements/set-transaction-isolation-level-transact-sql>
520#[derive(Debug, PartialEq, Eq)]
521pub enum TransactionIsolationLevel {
522    ReadUncommitted,
523    ReadCommitted,
524    RepeatableRead,
525    Snapshot,
526    Serializable,
527}
528
529impl TransactionIsolationLevel {
530    /// Return the string representation of a transaction isolation level.
531    fn as_str(&self) -> &'static str {
532        match self {
533            TransactionIsolationLevel::ReadUncommitted => "READ UNCOMMITTED",
534            TransactionIsolationLevel::ReadCommitted => "READ COMMITTED",
535            TransactionIsolationLevel::RepeatableRead => "REPEATABLE READ",
536            TransactionIsolationLevel::Snapshot => "SNAPSHOT",
537            TransactionIsolationLevel::Serializable => "SERIALIZABLE",
538        }
539    }
540
541    /// Try to parse a [`TransactionIsolationLevel`] from the value returned from SQL Server.
542    fn try_from_sql_server(val: i16) -> Result<TransactionIsolationLevel, anyhow::Error> {
543        let level = match val {
544            1 => TransactionIsolationLevel::ReadUncommitted,
545            2 => TransactionIsolationLevel::ReadCommitted,
546            3 => TransactionIsolationLevel::RepeatableRead,
547            4 => TransactionIsolationLevel::Serializable,
548            5 => TransactionIsolationLevel::Snapshot,
549            x => anyhow::bail!("unknown level {x}"),
550        };
551        Ok(level)
552    }
553}
554
555#[derive(Derivative)]
556#[derivative(Debug)]
557enum Response {
558    Execute {
559        rows_affected: SmallVec<[u64; 1]>,
560    },
561    Rows(SmallVec<[tiberius::Row; 1]>),
562    RowStream {
563        #[derivative(Debug = "ignore")]
564        stream: tokio::sync::mpsc::Receiver<Result<tiberius::Row, SqlServerError>>,
565    },
566}
567
568#[derive(Debug)]
569struct Request {
570    tx: oneshot::Sender<Result<Response, SqlServerError>>,
571    kind: RequestKind,
572}
573
574#[derive(Derivative)]
575#[derivative(Debug)]
576enum RequestKind {
577    Execute {
578        query: String,
579        #[derivative(Debug = "ignore")]
580        params: SmallVec<[OwnedColumnData; 4]>,
581    },
582    Query {
583        query: String,
584        #[derivative(Debug = "ignore")]
585        params: SmallVec<[OwnedColumnData; 4]>,
586    },
587    QueryStreamed {
588        query: String,
589        #[derivative(Debug = "ignore")]
590        params: SmallVec<[OwnedColumnData; 4]>,
591    },
592    SimpleQuery {
593        query: String,
594    },
595}
596
597pub struct Connection {
598    /// Other end of the channel that [`Client`] holds.
599    rx: UnboundedReceiver<Request>,
600    /// Actual client that we use to send requests.
601    client: tiberius::Client<Compat<TcpStream>>,
602    /// Resources (e.g. SSH tunnel) that need to be held open for the life of this connection.
603    _resources: Option<Box<dyn Any + Send + Sync>>,
604}
605
606impl Connection {
607    async fn run(mut self) {
608        while let Some(Request { tx, kind }) = self.rx.recv().await {
609            tracing::trace!(?kind, "processing SQL Server query");
610            let result = Connection::handle_request(&mut self.client, kind).await;
611            let (response, maybe_extra_work) = match result {
612                Ok((response, work)) => (Ok(response), work),
613                Err(err) => (Err(err), None),
614            };
615
616            // We don't care if our listener for this query has gone away.
617            let _ = tx.send(response);
618
619            // After we handle a request there might still be something in-flight
620            // that we need to continue driving, e.g. when the response is a
621            // Stream of Rows.
622            if let Some(extra_work) = maybe_extra_work {
623                extra_work.await;
624            }
625        }
626        tracing::debug!("channel closed, SQL Server InnerClient shutting down");
627    }
628
629    async fn handle_request<'c>(
630        client: &'c mut tiberius::Client<Compat<TcpStream>>,
631        kind: RequestKind,
632    ) -> Result<(Response, Option<BoxFuture<'c, ()>>), SqlServerError> {
633        match kind {
634            RequestKind::Execute { query, params } => {
635                #[allow(clippy::as_conversions)]
636                let params: SmallVec<[&dyn ToSql; 4]> =
637                    params.iter().map(|x| x as &dyn ToSql).collect();
638                let result = client.execute(query, &params[..]).await?;
639
640                match result.rows_affected() {
641                    rows_affected => {
642                        let response = Response::Execute {
643                            rows_affected: rows_affected.into(),
644                        };
645                        Ok((response, None))
646                    }
647                }
648            }
649            RequestKind::Query { query, params } => {
650                #[allow(clippy::as_conversions)]
651                let params: SmallVec<[&dyn ToSql; 4]> =
652                    params.iter().map(|x| x as &dyn ToSql).collect();
653                let result = client.query(query, params.as_slice()).await?;
654
655                let mut results = result.into_results().await.context("into results")?;
656                if results.is_empty() {
657                    Ok((Response::Rows(smallvec![]), None))
658                } else if results.len() == 1 {
659                    // TODO(sql_server3): Don't use `into_results()` above, instead directly
660                    // push onto a SmallVec to avoid the heap allocations.
661                    let rows = results.pop().expect("checked len").into();
662                    Ok((Response::Rows(rows), None))
663                } else {
664                    Err(SqlServerError::ProgrammingError(format!(
665                        "Query only supports 1 statement, got {}",
666                        results.len()
667                    )))
668                }
669            }
670            RequestKind::QueryStreamed { query, params } => {
671                #[allow(clippy::as_conversions)]
672                let params: SmallVec<[&dyn ToSql; 4]> =
673                    params.iter().map(|x| x as &dyn ToSql).collect();
674                let result = client.query(query, params.as_slice()).await?;
675
676                // ~~ Rust Lifetimes ~~
677                //
678                // What's going on here, why do we have some extra channel and
679                // this 'work' future?
680                //
681                // Remember, we run the actual `tiberius::Client` in a separate
682                // `tokio::task` and the `mz::Client` sends query requests via
683                // a channel, this allows us to "automatically" manage
684                // transactions.
685                //
686                // But the returned `QueryStream` from a `tiberius::Client` has
687                // a lifetime associated with said client running in this
688                // separate task. Thus we cannot send the `QueryStream` back to
689                // the `mz::Client` because the lifetime of these two clients
690                // is not linked at all. The fix is to create a separate owned
691                // channel and return the receiving end, while this work future
692                // pulls events off the `QueryStream` and sends them over the
693                // channel we just returned.
694                let (tx, rx) = tokio::sync::mpsc::channel(256);
695                let work = Box::pin(async move {
696                    let mut stream = result.into_row_stream();
697                    while let Some(result) = stream.next().await {
698                        if let Err(err) = tx.send(result.err_into()).await {
699                            tracing::warn!(?err, "SQL Server row stream receiver went away");
700                        }
701                    }
702                    tracing::info!("SQL Server row stream complete");
703                });
704
705                Ok((Response::RowStream { stream: rx }, Some(work)))
706            }
707            RequestKind::SimpleQuery { query } => {
708                let result = client.simple_query(query).await?;
709
710                let mut results = result.into_results().await.context("into results")?;
711                if results.is_empty() {
712                    Ok((Response::Rows(smallvec![]), None))
713                } else if results.len() == 1 {
714                    // TODO(sql_server3): Don't use `into_results()` above, instead directly
715                    // push onto a SmallVec to avoid the heap allocations.
716                    let rows = results.pop().expect("checked len").into();
717                    Ok((Response::Rows(rows), None))
718                } else {
719                    Err(SqlServerError::ProgrammingError(format!(
720                        "Simple query only supports 1 statement, got {}",
721                        results.len()
722                    )))
723                }
724            }
725        }
726    }
727}
728
729impl IntoFuture for Connection {
730    type Output = ();
731    type IntoFuture = BoxFuture<'static, Self::Output>;
732
733    fn into_future(self) -> Self::IntoFuture {
734        self.run().boxed()
735    }
736}
737
738/// Owned version of [`tiberius::ColumnData`] that can be more easily sent
739/// across threads or through a channel.
740#[derive(Debug)]
741enum OwnedColumnData {
742    U8(Option<u8>),
743    I16(Option<i16>),
744    I32(Option<i32>),
745    I64(Option<i64>),
746    F32(Option<f32>),
747    F64(Option<f64>),
748    Bit(Option<bool>),
749    String(Option<String>),
750    Guid(Option<uuid::Uuid>),
751    Binary(Option<Vec<u8>>),
752    Numeric(Option<tiberius::numeric::Numeric>),
753    Xml(Option<tiberius::xml::XmlData>),
754    DateTime(Option<tiberius::time::DateTime>),
755    SmallDateTime(Option<tiberius::time::SmallDateTime>),
756    Time(Option<tiberius::time::Time>),
757    Date(Option<tiberius::time::Date>),
758    DateTime2(Option<tiberius::time::DateTime2>),
759    DateTimeOffset(Option<tiberius::time::DateTimeOffset>),
760}
761
762impl<'a> From<tiberius::ColumnData<'a>> for OwnedColumnData {
763    fn from(value: tiberius::ColumnData<'a>) -> Self {
764        match value {
765            tiberius::ColumnData::U8(inner) => OwnedColumnData::U8(inner),
766            tiberius::ColumnData::I16(inner) => OwnedColumnData::I16(inner),
767            tiberius::ColumnData::I32(inner) => OwnedColumnData::I32(inner),
768            tiberius::ColumnData::I64(inner) => OwnedColumnData::I64(inner),
769            tiberius::ColumnData::F32(inner) => OwnedColumnData::F32(inner),
770            tiberius::ColumnData::F64(inner) => OwnedColumnData::F64(inner),
771            tiberius::ColumnData::Bit(inner) => OwnedColumnData::Bit(inner),
772            tiberius::ColumnData::String(inner) => {
773                OwnedColumnData::String(inner.map(|s| s.to_string()))
774            }
775            tiberius::ColumnData::Guid(inner) => OwnedColumnData::Guid(inner),
776            tiberius::ColumnData::Binary(inner) => {
777                OwnedColumnData::Binary(inner.map(|b| b.to_vec()))
778            }
779            tiberius::ColumnData::Numeric(inner) => OwnedColumnData::Numeric(inner),
780            tiberius::ColumnData::Xml(inner) => OwnedColumnData::Xml(inner.map(|x| x.into_owned())),
781            tiberius::ColumnData::DateTime(inner) => OwnedColumnData::DateTime(inner),
782            tiberius::ColumnData::SmallDateTime(inner) => OwnedColumnData::SmallDateTime(inner),
783            tiberius::ColumnData::Time(inner) => OwnedColumnData::Time(inner),
784            tiberius::ColumnData::Date(inner) => OwnedColumnData::Date(inner),
785            tiberius::ColumnData::DateTime2(inner) => OwnedColumnData::DateTime2(inner),
786            tiberius::ColumnData::DateTimeOffset(inner) => OwnedColumnData::DateTimeOffset(inner),
787        }
788    }
789}
790
791impl tiberius::ToSql for OwnedColumnData {
792    fn to_sql(&self) -> tiberius::ColumnData<'_> {
793        match self {
794            OwnedColumnData::U8(inner) => tiberius::ColumnData::U8(*inner),
795            OwnedColumnData::I16(inner) => tiberius::ColumnData::I16(*inner),
796            OwnedColumnData::I32(inner) => tiberius::ColumnData::I32(*inner),
797            OwnedColumnData::I64(inner) => tiberius::ColumnData::I64(*inner),
798            OwnedColumnData::F32(inner) => tiberius::ColumnData::F32(*inner),
799            OwnedColumnData::F64(inner) => tiberius::ColumnData::F64(*inner),
800            OwnedColumnData::Bit(inner) => tiberius::ColumnData::Bit(*inner),
801            OwnedColumnData::String(inner) => {
802                tiberius::ColumnData::String(inner.as_deref().map(Cow::Borrowed))
803            }
804            OwnedColumnData::Guid(inner) => tiberius::ColumnData::Guid(*inner),
805            OwnedColumnData::Binary(inner) => {
806                tiberius::ColumnData::Binary(inner.as_deref().map(Cow::Borrowed))
807            }
808            OwnedColumnData::Numeric(inner) => tiberius::ColumnData::Numeric(*inner),
809            OwnedColumnData::Xml(inner) => {
810                tiberius::ColumnData::Xml(inner.as_ref().map(Cow::Borrowed))
811            }
812            OwnedColumnData::DateTime(inner) => tiberius::ColumnData::DateTime(*inner),
813            OwnedColumnData::SmallDateTime(inner) => tiberius::ColumnData::SmallDateTime(*inner),
814            OwnedColumnData::Time(inner) => tiberius::ColumnData::Time(*inner),
815            OwnedColumnData::Date(inner) => tiberius::ColumnData::Date(*inner),
816            OwnedColumnData::DateTime2(inner) => tiberius::ColumnData::DateTime2(*inner),
817            OwnedColumnData::DateTimeOffset(inner) => tiberius::ColumnData::DateTimeOffset(*inner),
818        }
819    }
820}
821
822impl<'a, T: tiberius::ToSql> From<&'a T> for OwnedColumnData {
823    fn from(value: &'a T) -> Self {
824        OwnedColumnData::from(value.to_sql())
825    }
826}
827
828#[derive(Debug, thiserror::Error)]
829pub enum SqlServerError {
830    #[error(transparent)]
831    SqlServer(#[from] tiberius::error::Error),
832    #[error(transparent)]
833    CdcError(#[from] crate::cdc::CdcError),
834    #[error("expected column '{0}' to be present")]
835    MissingColumn(&'static str),
836    #[error("sql server client encountered I/O error: {0}")]
837    IO(#[from] tokio::io::Error),
838    #[error("found invalid data in the column '{column_name}': {error}")]
839    InvalidData { column_name: String, error: String },
840    #[error("got back a null value when querying for the LSN")]
841    NullLsn,
842    #[error("invalid SQL Server system setting '{name}'. Expected '{expected}'. Got '{actual}'.")]
843    InvalidSystemSetting {
844        name: String,
845        expected: String,
846        actual: String,
847    },
848    #[error("invariant was violated: {0}")]
849    InvariantViolated(String),
850    #[error(transparent)]
851    Generic(#[from] anyhow::Error),
852    #[error("programming error! {0}")]
853    ProgrammingError(String),
854    #[error(
855        "insufficient permissions for tables [{tables}] or capture instances [{capture_instances}]"
856    )]
857    AuthorizationError {
858        tables: String,
859        capture_instances: String,
860    },
861}
862
863/// Errors returned from decoding SQL Server rows.
864///
865/// **PLEASE READ**
866///
867/// The string representation of this error type is **durably stored** in a source and thus this
868/// error type needs to be **stable** across releases. For example, if in v11 of Materialize we
869/// fail to decode `Row(["foo bar"])` from SQL Server, we will record the error in the source's
870/// Persist shard. If in v12 of Materialize the user deletes the `Row(["foo bar"])` from their
871/// upstream instance, we need to perfectly retract the error we previously committed.
872///
873/// This means be **very** careful when changing this type.
874#[derive(Debug, thiserror::Error)]
875pub enum SqlServerDecodeError {
876    #[error("column '{column_name}' was invalid when getting as type '{as_type}'")]
877    InvalidColumn {
878        column_name: String,
879        as_type: &'static str,
880    },
881    #[error("found invalid data in the column '{column_name}': {error}")]
882    InvalidData { column_name: String, error: String },
883    #[error("can't decode {sql_server_type:?} as {mz_type:?}")]
884    Unsupported {
885        sql_server_type: SqlServerColumnDecodeType,
886        mz_type: SqlScalarType,
887    },
888}
889
890impl SqlServerDecodeError {
891    fn invalid_timestamp(name: &str, error: mz_repr::adt::timestamp::TimestampError) -> Self {
892        // These error messages need to remain stable, do not change them.
893        let error = match error {
894            mz_repr::adt::timestamp::TimestampError::OutOfRange => "out of range",
895        };
896        SqlServerDecodeError::InvalidData {
897            column_name: name.to_string(),
898            error: error.to_string(),
899        }
900    }
901
902    fn invalid_date(name: &str, error: mz_repr::adt::date::DateError) -> Self {
903        // These error messages need to remain stable, do not change them.
904        let error = match error {
905            mz_repr::adt::date::DateError::OutOfRange => "out of range",
906        };
907        SqlServerDecodeError::InvalidData {
908            column_name: name.to_string(),
909            error: error.to_string(),
910        }
911    }
912
913    fn invalid_char(name: &str, expected_chars: usize, found_chars: usize) -> Self {
914        SqlServerDecodeError::InvalidData {
915            column_name: name.to_string(),
916            error: format!("expected {expected_chars} chars found {found_chars}"),
917        }
918    }
919
920    fn invalid_varchar(name: &str, max_chars: usize, found_chars: usize) -> Self {
921        SqlServerDecodeError::InvalidData {
922            column_name: name.to_string(),
923            error: format!("expected max {max_chars} chars found {found_chars}"),
924        }
925    }
926
927    fn invalid_column(name: &str, as_type: &'static str) -> Self {
928        SqlServerDecodeError::InvalidColumn {
929            column_name: name.to_string(),
930            as_type,
931        }
932    }
933}
934
935/// Quotes the provided string using '[]' to match SQL Server `QUOTENAME` function. This form
936/// of quotes is unaffected by the SQL Server setting `SET QUOTED_IDENTIFIER`.
937///
938/// See:
939/// - <https://learn.microsoft.com/en-us/sql/t-sql/functions/quotename-transact-sql?view=sql-server-ver17>
940/// - <https://learn.microsoft.com/en-us/sql/t-sql/statements/set-quoted-identifier-transact-sql?view=sql-server-ver17>
941pub fn quote_identifier(ident: &str) -> String {
942    let mut quoted = ident.replace(']', "]]");
943    quoted.insert(0, '[');
944    quoted.push(']');
945    quoted
946}
947
948pub trait SqlServerCdcMetrics {
949    /// Called before the table lock is aquired
950    fn snapshot_table_lock_start(&self, table_name: &str);
951    /// Called after the table lock is released
952    fn snapshot_table_lock_end(&self, table_name: &str);
953}
954
955/// A simple implementation of [`SqlServerCdcMetrics`] that uses the tracing framework to log
956/// the start and end conditions.
957pub struct LoggingSqlServerCdcMetrics;
958
959impl SqlServerCdcMetrics for LoggingSqlServerCdcMetrics {
960    fn snapshot_table_lock_start(&self, table_name: &str) {
961        tracing::info!("snapshot_table_lock_start: {table_name}");
962    }
963
964    fn snapshot_table_lock_end(&self, table_name: &str) {
965        tracing::info!("snapshot_table_lock_end: {table_name}");
966    }
967}
968
969#[cfg(test)]
970mod test {
971    use super::*;
972
973    #[mz_ore::test]
974    fn test_sql_server_escaping() {
975        assert_eq!("[]", &quote_identifier(""));
976        assert_eq!("[]]]", &quote_identifier("]"));
977        assert_eq!("[a]", &quote_identifier("a"));
978        assert_eq!("[cost(]]\u{00A3})]", &quote_identifier("cost(]\u{00A3})"));
979        assert_eq!("[[g[o[o]][]", &quote_identifier("[g[o[o]["));
980    }
981}