SQL Server 2022: What The Heck Is sp_copy_data_in_batches?

Make It Or Not


I’m gonna be honest with you, dear reader, because without honesty we’ve got nothing.

Except lies — which you know — those can be comforting sometimes. Hm. I’ll have to think about that one for a bit.

While digging through to find new stuff in SQL Server 2022, this stored procedure caught my eye.

If you try to get the text of it, you get told off. It’s All Internal© as they say on the tubes.

EXEC sp_helptext 
    'sp_copy_data_in_batches';

Well, okay. But we can try to get it working on our own. Usually I use this method to figure out what parameters a new thing requires to run.

Not this time!

Trial And Error


What I usually do is stick NULL or DEFAULT after the EXEC to to see what comes back. Sometimes using a number or something makes sense too, but whatever.

This at least helps you figure out:

  • Number of parameters
  • Expected data types
  • Parameter NULLability
  • Etc. and whenceforth

Eventually, I figured out that sp_copy_data_in_batches requires two strings, and that it expects those strings to exist as tables.

The final command that ended up working was this. Note that there is no third parameter at present to specify a batch size.

sp_copy_data_in_batches 
    N'dbo.art', 
    N'dbo.fart';

Path To Existence


This, of course, depends on two tables existing that match those names.

CREATE TABLE dbo.art(id int NOT NULL PRIMARY KEY);
CREATE TABLE dbo.fart(id int NOT NULL PRIMARY KEY);

One thing to note here is that you don’t need a primary key to do this, but the table definitions do need to match exactly or else you’ll get this error:

Msg 37486, Level 16, State 2, Procedure sp_copy_data_in_batches, Line 1 [Batch Start Line 63]
'sp_copy_data_in_batches' failed because column 'id' does not have the same collation, 
nullability, sparse, ANSI_PADDING, vardecimal, identity or generated always attribute, CLR type 
or schema collection in tables '[dbo].[art]' and '[dbo].[fart]'.

Because GENERATE_SERIES is still a bit rough around the edges, I’m gonna do this the old fashioned way, which turns out a bit faster.

INSERT 
    dbo.art WITH(TABLOCK)
(
    id
)
SELECT TOP (10000000)
    id = 
        ROW_NUMBER() OVER 
        (
            ORDER BY 1/0
        )
FROM sys.messages AS m
CROSS JOIN sys.messages AS m2;

Behind The Scenes


I sort of expected to run some before and after stuff, and see the count slowly increment, but the query plan for sp_copy_data_in_batches just showed this:

SQL Server Query Plan
wink wink

I’m not really sure what the batching is here.

Also, this is an online index operation, so perhaps it won’t work in Standard Edition. If there even is a Standard Edition anymore?

Has anyone heard from Standard Edition lately?

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

SQL Server 2022: GENERATE_SERIES Causes Parallel Deadlocks In A Transaction

Many Times!


These table valued functions of the built-in variety have this problem.

This one is no exception. Well, it does throw an exception. But you know.

That’s not exceptional.

DROP TABLE IF EXISTS
    dbo.select_into;

BEGIN TRAN

SELECT
    id = 
        gs.value
INTO dbo.select_into
FROM GENERATE_SERIES
     (
         START = 1, 
         STOP = 10000000
     ) AS gs
OPTION(MAXDOP 8);

COMMIT;

If you run the above code, you’ll get this error:

Msg 1205, Level 13, State 78, Line 105
Transaction (Process ID 70) was deadlocked on lock | communication buffer resources with another process and has been chosen as the deadlock victim. Rerun the transaction.
SQL Server Error
pilot program

Like the issues I outlined in yesterday’s post, I do hope these get fixed before go-live.

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

SQL Server 2022 GENERATE_SERIES: Some Notes At Release Time

Yep, I know

a great post
great post, psychic

It’s the first public CTP. Things will change. Things will get better. Think about the rich history of Microsoft fixing stuff immediately, like with adding an ordinal position to STRING_SPLIT.

That came out in SQL Server 2016, and uh… Wait, they just added the ordinal position in SQL Server 2022. There were two major versions in between that function getting released and any improvements.

With that in mind, I’m extending as much generosity of spirit to improvements to the function at hand: GENERATE_SERIES.

Quite a while back, I blogged about how much I’d love to have this as a function. We… sort of got it. It doesn’t do dates natively, but you can work around some of that with date functions.

In this post, I want to go over some of the disappointing performance issues I found when testing this function out.

Single Threaded In A Parallel Plan


First up, reading streaming results from the function is single threaded. That isn’t necessarily bad on its own, but can result in annoying performance issues when you have to distribute a large number of rows.

If you have to ask what the purpose or use case for 10 million rows is, it’s your fault that SQL Server doesn’t scale.

Got it? Yours, and yours alone.

DROP TABLE IF EXISTS
    dbo.art_aux;

CREATE TABLE 
    dbo.art_aux
(
    id int NOT NULL PRIMARY KEY CLUSTERED
);

The first way we’re going to try this is with a simple one column table that has a primary key/clustered index on it.

Of course, we won’t expect a parallel insert into the table itself because of that index, but that’s okay. For now.

INSERT INTO
    dbo.art_aux WITH(TABLOCK)
(
    id
)
SELECT
    gs.value
FROM GENERATE_SERIES
     (
         START = 1, 
         STOP = 10000000
     ) AS gs
OPTION(MAXDOP 8);

The query plan for this insert looks about like so:

SQL Server Query Plan
sup with that

I’m only including the plan cost here to compare it to the serial plan later, and to understand the per-operator cost percentage breakdown.

It’s worth noting that the Distribute Streams operator uses Round Robin partitioning to put rows onto threads. That seems an odd choice here, since Round Robin partitioning pushes packets across exchanges.

For a function that produces streaming integers, it would make more sense to use Demand partitioning which only pulls single rows across exchanges. Waiting for Round Robin to fill up packets with integers seems a poor choice, here.

Then we get to the Sort, which Microsoft has promised to fix in a future CTP. Hopefully that happens! But it may not help with the order preserving Gather Streams leading up to the Insert.

SQL Server Query Plan
preservatives

It seems a bit odd ordered data from the Sort would hamstring the Gather Streams operator’s ability to do its thing, but what do I know?

I’m just a bouncer, after all.

But The Serial Plan


Using the same setup, let’s make that plan run at MAXDOP 1.

INSERT INTO
    dbo.art_aux WITH(TABLOCK)
(
    id
)
SELECT
    gs.value
FROM GENERATE_SERIES
     (
         START = 1, 
         STOP = 10000000
     ) AS gs
OPTION(MAXDOP 1);

You might expect this to run substantially slower to generate and insert 10,000,000 rows, but it ends up being nearly three full seconds faster.

Comparing the query cost here (1048.11) vs. the cost of the parallel plan above (418.551), it’s easy to understand why a parallel plan was chosen.

It didn’t work out so well, though, in this case.

SQL Server Query Plan
cereal

With no need to distribute 10,000,000 rows out to 8 threads, sort the data, and then gather the 8 threads back to one while preserving that sorted order, we can rely on the serial sort operator to produce and feed rows in index-order to the table.

Hopefully that will continue to be the case once Microsoft addresses the Sort being present there in the first place. That would knock a second or so off the the overall runtime.

Into A Heap


Taking the index out of the picture and inserting into a heap does two things:

But it also… Well, let’s just see what happens. And talk about it. Query plans need talk therapy, too. I’m their therapist.

DROP TABLE IF EXISTS
    dbo.art_aux;

CREATE TABLE 
    dbo.art_aux
(
    id int NOT NULL
);
SQL Server Query Plan
hmmmmm

The Eager Table Spool here is for halloween protection, I’d wager. Why we need it is a bit of a mystery, since we’re guaranteed to get a unique, ever-increasing series of numbers from the function. On a single thread.

Performance is terrible here because spooling ten million rows is an absolute disaster under any circumstance.

With this challenge in mind, I tried to get a plan here that would go parallel and avoid the spool.

Well, mission accomplished. Sort of.

Crash And Burn


One thing we can do is use SELECT INTO rather than relying on INSERT SELECT WITH (TABLOCK) to do try to get it. There are many restrictions on the latter method.

SELECT
    id = 
        gs.value
INTO dbo.select_into
FROM GENERATE_SERIES
     (
         START = 1, 
         STOP = 10000000
     ) AS gs
OPTION(MAXDOP 8);

This doesn’t make things better:

SQL Server Query Plan
four minutes!

This strategy clearly didn’t work out.

Bummer.

Again, I’d say most of the issue is from Round Robin partitioning on the Distribute Streams.

Finish Him


The initial version of GENERATE_SERIES is a bit rough around the edges, and I hope some of these issues get fixed.

And, like, faster than issues with STRING_SPLIT did, because it took a really long time to get that worked on.

And that was with a dozen or so MVPs griping about it the whole time.

But there’s an even bigger problem with it that we’ll look at tomorrow, where it won’t get lost in all this stuff.

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New Extended Events Stuff In SQL Server 2022

I am a heading


Some events:

event_name
memory_grant_feedback_percentile_grant
memory_grant_feedback_persistence_update
parameter_sensitive_plan_optimization
process_killed
query_optimizer_nullable_scalar_agg_iv_update
spinlock_backoff
sql_exit_invoked
tsql_feature_usage_tracking

A bunch of stuff:

package_name event_name description
qds automatic_tuning_query_check_ignored Fired when APRC decides to not track a query that is marked as ignored
qds automatic_tuning_wtest_details Fired when APRC performs Welch test based regression detection
qds ce_feedback_hints_lookup_failed Fired when error occurs during CE Feedback hints lookup.
qds query_store_clear_db_oversize_flag Fired when QDS is clearing DB oversize flag.
qds query_store_clear_message_queues Fired when query store clears the message queue
qds query_store_generate_showplan_with_replay_script_failure Fired when Query Store failed to update a query plan because the generation of showplan (which contains a Replay Script) failed.
qds query_store_hints_application_failed Fired if application of Query Store hints failed.
qds query_store_hints_application_persist_failure_failed Fired if last_failure_reason and failure_count in sys.query_store_query_hints failed to update.
qds query_store_hints_application_success Fired if application of Query Store hints succeeded.
qds query_store_hints_lookup_failed Fired if there is a failure during the lookup for whether a query has any hints set in Query Store. Query hints, if any, will not be applied.
qds query_store_messaging_failures Diagnostic information for QDS messaging components.
qds query_store_persist_feedback_quick_lock_failures This XEvent is fired when we fail to acquire quick shared db lock during feedback persistence.
qds query_store_secondary_guid_creation_failure
qds query_store_update_plan_with_replay_script Fired when the existing Showplan in QDS is updated with a Showplan with Replay Script
qds query_store_user_plan_removal Fired when plan is removed with SP sp_query_store_remove_plan.
qds query_store_user_query_removal Fired when query is removed with SP sp_query_store_remove_query.
sqlclr clr_forced_yield SQL CLR quantum punishment ocurred.
sqlos cpu_starvation_stats_ring_buffer_recorded CPU starvation stats ring buffer recorded
sqlos sos_direct_shrink_no_progress Fire if Direct Shrink does not make progress within specified timer period
sqlos sos_operate_set_target_task_list Lock acquire failure when doing insert/delete
SQLSatellite job_object_trace Fired for launchpad job object trace events.
SQLSatellite management_session_creation Fired when a new library or language management session is created.
sqlserver aad_build_federated_context Occurs when we attempt to build federated context.
sqlserver aad_signing_key_refresh Occurs when we attempt to refresh signing keys from Azure Active Directory, to update the in-memory cache.
sqlserver add_file_in_master Occurs when the file manager added file metadata in the master database segment.
sqlserver add_file_rollback Occurs when add file action is rolled back.
sqlserver adr_sweep_for_skip_pages_finished The ADR sweep for skipped pages in ADR finished.
sqlserver adr_sweep_timed_out The ADR sweep for skipped pages timed out.
sqlserver all_files_created Occurs when all database files has already been formatted on disk for an ADD FILE DDL statement.
sqlserver allocation_page_update_stats Allocation page (PFS/GAM/SGAM) statistics.
sqlserver ascending_leading_column_flipped The sort type of the leading column flipped from/to ascending?
sqlserver async_read_page_count_bucket Emit page counts map for rbio async read requests.
sqlserver attention Indicates that a cancel operation, client-interrupt request, or broken client connection has occurred. Be aware that cancel operations can also occur as the result of implementing data access driver time-outs, aborted.
sqlserver auth_fw_cache_lookup_failure This event is generated when the xodbc cache firewall lookup fails.
sqlserver auth_fw_cache_lookup_success This event is generated when the xodbc cache firewall lookup succeeds.
sqlserver autostats_update_async_low_priority_status This XEvent is fired when auto asynchronous statistics is triggered in low priority mode.
sqlserver autostats_update_blocking_readers This XEvent is fired to reproduce a blocking scenario when an auto statistics update thread waits to acquire a Sch-M lock on stats metadata object which subsequently blocks readers (select queries on that table for instance). This XEvent is used primarily for unit testing.
sqlserver azure_active_directory_service_failure Occurs when we encounter a failure in AzureActiveDirectoryService layer, when performing MSODS lookup during Login and Create Login/User workflow.
sqlserver backup_between_data_and_log Used for signaling the point in a full/diff backup after the data copy is finished but before the log copy has started.
sqlserver blob_access_pattern Blobs access pattern
sqlserver blob_trace_backtrack Search blob trace for the problem blob handle lifetime
sqlserver btree_retraversal_count In every 2 hours interval,stats data of BTree re-traversal count is emitted
sqlserver buffer_pool_flush_cache_start Fired when Buffer Pool starts flushing dirty buffers.
sqlserver buffer_pool_flush_io_throttle Fire when Buffer Pool throttles flushing dirty pages. This event is fired very frequently when IO throttling is occurring.
sqlserver buffer_pool_flush_io_throttle_status Fired when Buffer Pool is flushing dirty pages. This event reports the status of IO throttling.
sqlserver buffer_pool_scan_start Fired when Buffer Pool scan starts.
sqlserver buffer_pool_scan_stats Buffer Pool Scan Statistics.
sqlserver buffer_pool_scan_task_complete Fired when Buffer Pool scan parallel task completes.
sqlserver buffer_pool_scan_task_error Fired when Buffer Pool scan parallel task encounters an error.
sqlserver buffer_pool_scan_task_start Fired when Buffer Pool scan parallel task starts.
sqlserver cdc_cleanup_job_status Change data capture cleanup job status. Returns information every 5 minutes.
sqlserver cdc_ddl_session CDC DDL Handling Session Information
sqlserver cdc_log_throttle Occurs when primary log gets full because of CDC/Repl and needs to be throttled.
sqlserver cdc_log_throttle_manager CDC Log I/O throttling manager events (create, delete, error)
sqlserver cdc_scheduler CDC Scheduler Information
sqlserver certificate_report Certificate info.
sqlserver column_store_fast_string_equals Info about fast string search
sqlserver column_store_index_deltastore_add_column A columnstore deltastore rowgroup was rewritten from adding a column.
sqlserver column_store_index_deltastore_alter_column A columnstore deltastore rowgroup was rewritten from altering a column.
sqlserver column_store_qualified_rowgroup_stats Info about row group elimination and qualification in columnstore scan.
sqlserver columnstore_flush_as_deltastore_fido Shows column store index build information when remaining rows in the current rowgroup have been flushed into deltastore.
sqlserver columnstore_index_additional_memory_fraction Shows column store index addtional memory fraction information during columnstore index build.
sqlserver columnstore_index_adjust_required_memory Shows column store memory information when the required memory is adjusted to zero.
sqlserver columnstore_index_bucketization_cleanup_task_fail Shows column store index build information when a bucketization failed to clean up a task related objects.
sqlserver columnstore_index_bucketization_create_dataset Shows column store index build information when a bucketization insertion created a dataset.
sqlserver columnstore_index_bucketization_create_task Shows column store index build information when a bucketization process is about to finish.
sqlserver columnstore_index_bucketization_create_task_from_multiple_cells Shows column store index build information when a bucketization process has created one or more tasks from multiple cells.
sqlserver columnstore_index_bucketization_drop_worktable Shows column store index build information when a bucketization dropped a worktable.
sqlserver columnstore_index_bucketization_end_index_build Shows column store index build information when a bucketization process is about to create a task.
sqlserver columnstore_index_bucketization_enqueue_all_tables Shows column store index build information when a bucketization process has enqueued all remaining worktables.
sqlserver columnstore_index_bucketization_first_row_received Shows column store index build information when a bucketization insertion thread received the first row.
sqlserver columnstore_index_bucketization_get_or_create_worktable Shows column store index build information when a bucketization insertion created a worktable.
sqlserver columnstore_index_bucketization_init_index_build Shows column store index build information when a bucketization process is initialized.
sqlserver columnstore_index_bucketization_insert_fail Shows column store index build information when a bucketization process has failed.
sqlserver columnstore_index_bucketization_insert_into_columnstore_fail Shows column store index build information when a bucketization insertion into a columnstore segment has failed.
sqlserver columnstore_index_bucketization_insert_into_worktable_fail Shows column store index build information when a bucketization insertion into a worktable has failed.
sqlserver columnstore_index_bucketization_process_task Shows column store index build information when a bucketization process task is finished.
sqlserver columnstore_index_bucketization_process_task_about_to_flush_last_row Shows column store index build information when a bucketization task flushed the last row into columnstore index builder.
sqlserver columnstore_index_bucketization_process_task_fail Shows column store index build information when a bucketization process task has failed.
sqlserver columnstore_index_bucketization_process_task_start Shows column store index build information when a bucketization process task is started.
sqlserver columnstore_index_bucketization_reached_end_index_build Shows column store index build information when a bucketization process is reached to the end of index build, but has not finished its work yet.
sqlserver columnstore_index_bucketization_rows_received Shows column store index build information when a bucketization insertion thread received rows.
sqlserver columnstore_index_bulk_insert_acquire_memory_grant_attempt_timeout Shows column store memory information when an attempt of the memory grant request of columnstore bulk insert times out.
sqlserver columnstore_index_clear_bulk_insert_flag Shows rowset information when the columnstore bulk insert flag is cleared.
sqlserver columnstore_index_convert_bulk_insert_to_trickle_insert Shows column store memory information when the memory grant request of columnstore bulk insert times out.
sqlserver columnstore_object_manager_read_retry Retry read from azure blobk blob on sbs read failure.
sqlserver columnstore_tuple_mover_exclusion_lock_timeout The tuple mover timed out trying to acquire a lock to compress a row group.
sqlserver columnstore_tuple_mover_worker_stealing Columnstore tuple mover worker stealing.
sqlserver compute_readable_secondary_wait_for_redo_for_debugging When a query gets a page from the future, it waits for redo to catchup. Emitted without predicates
sqlserver compute_secondary_permanent_fault
sqlserver concurrent_gam_update_stats Concurrent GAM Update stats.
sqlserver connection_attempt_failure_system_error Connection attempt metrics
sqlserver connection_attempt_failure_user_error Connection attempt user error metrics
sqlserver connection_attempt_success Connection attempt success metrics
sqlserver cpu_vectorization_levels Event containing details of CPU vectorization level(s).
sqlserver create_acr_cache_store When an Access Check Result cache store is created.
sqlserver create_file_tracing Tracing during the different steps of FileCreation.
sqlserver csv_column_statistics Aggregate details of processing a column for one file.
sqlserver csv_decompression_statistics Decompression time and memory utilized if the input file is compressed.
sqlserver csv_input_file Details of a CSV input file processed by OpenRowset
sqlserver csv_rejected_rows Aggregate details for a error type of rejected rows.
sqlserver csv_row_statistics Aggregate details of processing rows for one file.
sqlserver csv_shallow_parse Aggregate details for shallow parsing logic used in calculating file splits.
sqlserver customer_connection_failure Connection failure metrics
sqlserver customer_connection_failure_firewall_error Connection blocked by firewall
sqlserver customer_connection_failure_user_error Connections failed due to user error
sqlserver customer_connection_success Connection successful metrics
sqlserver dac_login_information Occurs when an internal DAC session is established/disconnected with sqlserver
sqlserver data_export_profile Reports aggregated stats about data exported to an external file. Distinct event per each file and each processing thread.
sqlserver data_retention_cleanup_completed Occurs when cleanup process of table with data retention policy ends.
sqlserver data_retention_cleanup_exception Occurs cleanup process of table with retention policy fails.
sqlserver data_retention_cleanup_started Occurs when cleanup process of table with data retention policy starts.
sqlserver data_retention_cleanup_task_exception Occurs when then background (parent) task for data retention based cleanup fails due to an exception.
sqlserver data_retention_task_completed Occurs when background task for cleanup of tables with retention policy ends.
sqlserver data_retention_task_exception Occurs when background task for cleanup of tables with retention policy fails outside of retention cleanup process specific to table.
sqlserver data_retention_task_started Occurs when background task for cleanup of tables with retention policy starts.
sqlserver data_virtualization_failed_query Fired when OPENROWSET or query against external table or external file format fails during parsing.
sqlserver data_virtualization_query Fired on compile for every query targeting external data sources.
sqlserver database_file_growing Occurs when any of the data or log files for a database is about to grow.
sqlserver database_recovery_complete Occurs when database recovery has completed.
sqlserver database_xml_deadlock_report_mdm Emit a metric when a deadlock report for a victim is produced.
sqlserver db_fw_cache_expire_begin This event is generated when the task that cleans the DB firewall cache begins.
sqlserver db_fw_cache_expire_end This event is generated when the task that cleans the DB firewall cache ends.
sqlserver db_fw_cache_lookup_failure This event is generated when the DB firewall lookup fails.
sqlserver db_fw_cache_lookup_success This event is generated when the DB firewall lookup success.
sqlserver db_fw_cache_update_begin This event is generated when the task that updates the DB firewall cache begins.
sqlserver db_fw_cache_update_end This event is generated when the task that updates the DB firewall cache ends.
sqlserver deadlock_callstack Print callstack of thread within deadlock graph.
sqlserver deferred_au_deallocation_to_next_run Dropping of allocation unti marked for deferred drop is delayed to the next run.
sqlserver delta_migration_failure Delta Migration Failure XEvents
sqlserver delta_migration_information Delta Migration Informational XEvents
sqlserver delta_migration_task_end Delta Migration Task End XEvents
sqlserver delta_migration_task_start Delta Migration Task Start XEvents
sqlserver dop_feedback_eligible_query Reports when a query plan becomes eligible for dop feedback
sqlserver dop_feedback_provided Reports DOP feedback provided data for a query
sqlserver dop_feedback_reverted This reports when a DOP feedback is reverted
sqlserver dop_feedback_validation Reports when the validation occurs for the query runtime stats against baseline or previous feedback stats
sqlserver drop_file_committed Occurs when drop file action is committed.
sqlserver drop_file_prepared Occurs when the file is prepared to be dropped.
sqlserver drop_file_rollback Occurs when drop file action is rolled back.
sqlserver dw_backup_app_lock_end DW Backup App Lock End XEvents
sqlserver dw_backup_app_lock_start DW Backup App Lock Begin XEvents
sqlserver dw_large_text_store DW large text store for fragmented text blobs.
sqlserver ests_request_attempt Occurs when an ESTS or ESTS-R request is submitted in order to acquire a token for AKV or Storage operations.
sqlserver exec_plpgsql Shows PLPGSQL statements sent to PostgreSQL server during Exec External Language statement
sqlserver ext_table_extr_operation External Table Extractor event. Should encapsulate resolving file and schema (and possible initialization).
sqlserver external_policy_pulltask_finished XEvent for policy pull finish
sqlserver external_policy_pulltask_retries XEvent for policy pull retries diagnostics
sqlserver external_policy_pulltask_started XEvent for policy pull start
sqlserver external_rest_endpoint_error_winhttp_calls Fired when a winhttp API call fails without stopping the execution
sqlserver external_rest_endpoint_summary Fired for each execution of sp_invoke_external_rest_endpoint.
sqlserver external_runtime_execution_stats Publishes consolidated stats collected during external endpoint invocation
sqlserver external_table_stats_creation Fires after computing external table stats.
sqlserver extractor_scan_memory_grant Summary of an Exteranl Extractor operation memory grant.
sqlserver extractor_scan_summary Summary of an Exteranl Extractor operation.
sqlserver failed_compilation Collect the compilation information for errored out or failed compilations.
sqlserver failure_injection_during_backup_device_restoring Used for testing restore hang if an exception is thrown on one backup stream but other streams are marked as completed
sqlserver fedauth_ddl Occurs when someone executes CREATE USER/LOGIN FROM Windows; ALTER USER/LOGIN WindowsPrincipal WITH NAME; in SAWAv2 and its not a Backslash login/user.
sqlserver fedauth_execute_as Execute as DDL events for AD Auth user.
sqlserver fedauth_ticket_service_cache_timer_activity Logged during the routine cleanup of cache containing federated contexts.
sqlserver fedauth_ticket_service_failure Occurs when we encounter a failure in FedAuthTicketService layer, when authenticating the fedauth ticket/token or when doing group expansion.
sqlserver fedauth_ticket_service_success Logged during the success of federated authentication, including group expansion if applicable.
sqlserver fedauth_webtoken Logs some important claim information found in the token.
sqlserver fedauth_webtoken_failure Occurs when we encounter a failure in FedAuthTicketService layer, when authenticating the fedauth ticket/token or when doing group expansion.
sqlserver ffv_obtained_validation_bitmap Foreign file validator obtained a copy of the validation bitmap as part of establishing a new snapshot pair.
sqlserver fido_clone_update_filter_ctx_on_dir_change FIDO clone trace during scan
sqlserver fido_fcs_md_read_ahead_perf_metric FIDO Fcs metadata read ahead perf metric.
sqlserver fido_glm_rowset_cleanup FIDO GLM ROwset cleanup
sqlserver fido_glm_rowset_operation FIDO GLM Rowset operation.
sqlserver fido_glm_rowset_serialization_error FIDO Metadata Rowset update error.
sqlserver fido_lock_manager_message FIDO LM log trace.
sqlserver fido_multi_step_ddl_operation FIDO DDL step for multi-step DDL operation.
sqlserver fido_rm_transaction_abort FIDO RM abort trace.
sqlserver fido_rm_transaction_begin FIDO RM begin trace.
sqlserver fido_rm_transaction_commit FIDO RM commit trace.
sqlserver fido_rowgroup_lineage Fido xevent to establish rowgroup lineage.
sqlserver fido_scanner_end_database Fido scanner end database scan.
sqlserver fido_scanner_percent_complete Fido scanner percent completed.
sqlserver fido_scanner_start_database Fido scanner start database scan.
sqlserver fido_scanner_trace_print Fido scanner debug trace.
sqlserver fido_temp_db_events FIDO Temp DB Trace.
sqlserver fido_temp_table_mapping FIDO temp table name mapping
sqlserver fido_tm_transaction_abort FIDO TM abort trace.
sqlserver fido_tm_transaction_begin FIDO TM begin trace.
sqlserver fido_tm_transaction_commit FIDO TM commit trace.
sqlserver fido_transaction FIDO transaction trace.
sqlserver fido_transaction_message FIDO TM log trace.
sqlserver file_added_in_database Occurs when a database file is added into the database segment.
sqlserver find_and_kill_tm_blocking_table_drop Find and kill the background tuple mover task if it blocks the drop.
sqlserver foreign_log_apply_suspended Indicates that the foreign log apply thread is suspended with a trace flag.
sqlserver foreign_redo_hash
sqlserver foreign_redo_old_bsn_corruption
sqlserver foreign_redo_rbpex_page_dirtied Fired when a page from covering RBPEX is to be dirtied during foreign redo.
sqlserver fulltext_crawl_log Reports fulltext crawl log.
sqlserver global_query_extractor_begin Global Query extractor execution start.
sqlserver global_query_extractor_cancel Global Query extractor execution canceled.
sqlserver global_query_extractor_end Global Query extractor execution completed successfully.
sqlserver global_query_extractor_fail Global Query extractor execution failed with error.
sqlserver hadr_chimera_send_request_to_MS_long_retry Alert for long retries when sending notification request to control ring
sqlserver hadr_db_manager_qds_msg QDS messages sent between replicas.
sqlserver hadr_hybrid_subscription_auth_failure Log ucs subscription authentication failure for hybrid link.
sqlserver hadr_hybrid_subscription_auth_long_retry Log ucs subscription authentication retry info for hybrid link.
sqlserver hadr_hybrid_subscription_auth_success Log ucs subscription authentication success for hybrid link.
sqlserver hadr_transport_dump_extended_recovery_forks_message Use this event to help trace HADR extended recovery forks messages.
sqlserver hadr_undo_of_redo_pages_processing_stats Pages processing stats
sqlserver hadr_undo_of_redo_parallel_page_requesting_first_missing_page First missing page id in parallel page request buffer.
sqlserver hadr_undo_of_redo_parallel_page_requesting_notification Requesting page in parallel for Undo of Redo enabled.
sqlserver hardware_error_rbpex_invalidate_page Tracks invalidating rbpex page after detecting a hardware error on the page.
sqlserver heap_access_pattern Emit statistics related to heap access patterns.
sqlserver hotpagetracker_bucket_aggregation_ended Indicates that aggregating hit counts into the snapshot bucket at given position in the bucket list ended.
sqlserver hotpagetracker_bucket_aggregation_started Indicates that aggregating hit counts into the snapshot bucket at given position in the bucket list started.
sqlserver hotpagetracker_page_list_receive_failed Indicates that the new primary compute has NOT received the list of hot pages it requested from a page server.
sqlserver hotpagetracker_page_list_receive_succeeded Indicates that the new primary compute has received the list of hot pages it requested from a page server.
sqlserver hotpagetracker_pageseed_candidate A page that the new primary compute will seed into its RBPEX for a given file.
sqlserver hotpagetracker_pageseed_failed Indicates that the new primary compute has failed to queue all the hot pages to seed onto its RBPEX for a given file.
sqlserver hotpagetracker_pageseed_queued Indicates that the new primary compute has queued all the hot pages to seed onto its RBPEX for a given file.
sqlserver hyperscale_no_pushdown QP pushdown not available.
sqlserver hyperscale_pushdown_aggregated_stats Aggregated stats for a single execution of a single QP pushdown operator.
sqlserver hyperscale_pushdown_completed QP pushdown queue completed.
sqlserver hyperscale_pushdown_memory_change QP pushdown memory reservation change.
sqlserver hyperscale_pushdown_request_completed QP pushdown request completed.
sqlserver hyperscale_pushdown_request_starting QP pushdown request starting.
sqlserver hyperscale_pushdown_resource_pool_failure Failures related to obtaining resource pool for pushdown queries
sqlserver hyperscale_pushdown_skipped QP pushdown skipped at runtime.
sqlserver hyperscale_pushdown_starting QP pushdown queue created.
sqlserver hyperscale_pushdown_stats QP pushdown statistics that are periodically emitted.
sqlserver iam_page_range_cache_stats IAM Page range cache stats
sqlserver increment_paused_write_ios_count Increments the number of write IOs paused.
sqlserver index_corruption_detected Reports names,id of related database when index corruption is detected
sqlserver index_stats_inconsistency_event Indicate we did some repair logic for the index stats cache
sqlserver kerberos_to_jwt_service_failure Occurs when we encounter error in Kerberos ticket to JSON Web token conversion through ESTS AAD endpoint.
sqlserver large_non_adr_transactions The number of records and/or bytes of log for a non-ADR transaction exceeds the current threshold.
sqlserver ledger_digest_upload_failed Uploading a digest of the database ledger failed.
sqlserver ledger_digest_upload_failed_mdm Emit a metric when a ledger digest fails to be uploaded.
sqlserver ledger_digest_upload_success Uploading a digest of the database ledger succeeded.
sqlserver ledger_digest_upload_success_mdm Emit a metric when a ledger digest is successfully uploaded.
sqlserver ledger_generate_digest Ledger digest generated
sqlserver ledger_settings Ledger settings
sqlserver ledger_table_verification_completed Ledger table verification operation completed.
sqlserver ledger_table_verification_started Ledger table verification operation started.
sqlserver ledger_transaction_count Ledger transaction
sqlserver ledger_verification_completed Ledger verification operation completed.
sqlserver ledger_verification_started Ledger verification operation started.
sqlserver ledger_view_query_count Ledger view query
sqlserver lock_manager_init Stats during init of lock manager
sqlserver locking_qp_stats Emit QP statistics related to locking.
sqlserver locking_stats Emit statistics related to locking.
sqlserver log_block_header_failover_info Print failover info stored in log block header during LC flush
sqlserver log_lease_skip_same_vlf Indicates that the request to the log leasing service for the same vlf is skipped
sqlserver log_pool_cache_miss_aggregation Aggregated outout of log pool miss.
sqlserver log_production_stats_mdm Aggregated statistics about log production, emitted periodically.
sqlserver log_redo_stats
sqlserver long_compilation_progress Collect the compilation progress information for long-running compilations.
sqlserver management_service_operation_failed Management Service operation failed.
sqlserver management_service_operation_started Management service operation started.
sqlserver management_service_operation_succeeded Management service operation succeeded.
sqlserver maxdop_feedback_received
sqlserver memory_grant_feedback_percentile_grant Occurs at intervals when percentile grant is enabled
sqlserver memory_grant_feedback_persistence_invalid Occurs when persisted memory grant feedback can not be used due to inconsistency with current plan.
sqlserver memory_grant_feedback_persistence_update Occurs when memory grant feedback is persisted to QDS.
sqlserver metadata_change Tracking metadata change which may affect query performance.
sqlserver modify_file_name Occurs when the file manager started to modify a database file name.
sqlserver modify_file_operation Occurs when the file manager modified the property of a database file.
sqlserver native_shuffle_nullability_mismatch Reports a NULL value in a native shuffle QTable column declared with NOT NULL in the schema.
sqlserver oiblob_cleanup_begin_batch Occurs when cleanup for a single batch has started for online index build with LOBs.
sqlserver oiblob_cleanup_end_batch Occurs when cleanup for a single batch has finished for online index build with LOBs.
sqlserver oledb_provider_initialized Occurs when SQL Server initializes an OLEDB provider for a distributed query or remote stored procedure. Use this event to monitor OLEDB provider initialization. This event will be triggered once when a particular provider is initialized. It is also used for reporting type of mapping used for linked servers.
sqlserver online_index_ddl_tx_info Log record- and transaction-related info about the non-CTR ONLINE_INDEX_DDL transaction.
sqlserver openrowset_bulk_file_resolvement Occurs when updating resolved files within openrowset bulk statement.
sqlserver openrowset_bulk_schema_inference Occurs during schema inference in openrowset bulk statement.
sqlserver openrowset_cardinality_query Fires after executing internal sampled cardinality estimation query.
sqlserver openrowset_stats_cleanup Fires at the start and after stats table cleanup finishes.
sqlserver openrowset_stats_cleanup_all Fires at the start and after stats table truncation finishes.
sqlserver openrowset_stats_creation Fires after computing openrowset stats.
sqlserver openrowset_stats_loading Fires after loading openrowset stats.
sqlserver openrowset_stats_row_reading_failed Fires when reading of openrowset stats/cardinality row from the openrowset stats table fails.
sqlserver openrowset_stats_stale_detection Fires after algorithm for stale stats detection finishes.
sqlserver openrowset_table_level_stats Fires after computing openrowset or external table stats on table level.
sqlserver opt_replay_delete_ors_allocated_memory Fired when the memory allocated for replay script (ORS) is successfully deleted.
sqlserver opt_replay_exception_info Collect exception info about Optimization Replay’s failure.
sqlserver override_max_supported_db_version_to_1 Used for mock downgrade max supported db version to 1
sqlserver page_compression_cache_init_complete Occurs after page compression cache is initialized during decompression
sqlserver page_covering_rbpex_repair Tracks the repair of pages in covering RBPEX
sqlserver page_encryption_prewrite_complete Occurs after page has been compressed in-memory before being flushed
sqlserver parameter_sensitive_plan_optimization This event is fired when a query uses Parameter Sensitive Plan (PSP) Optimization feature.
sqlserver parameter_sensitive_plan_optimization_skipped_reason Occurs when the parameter sensitive plan feature is skipped. Use this event to monitor the reason why parameter sensitive plan optimization is skipped.
sqlserver parameter_sensitive_plan_testing Fired when parameter sensitive plan is tested.
sqlserver partition_elimination_mapping Fires when pruned data source is added to the list of reduced sources.
sqlserver partition_elimination_routine Fires when partition elimination routine gets called.
sqlserver pesto_rename_sbs_blob_fail Failed to update the sbs blob id with new GUID during the Pesto consoliate rowgroup copy blob
sqlserver pfs_file_share_stats PFS file share stats collected periodically from GetShareStats api
sqlserver pfs_observed_transition_to_secondary Emitted when observed DB replica role transition during evaluation period for PFS dynamic scaling
sqlserver pfs_rest_action PFS REST API call action.
sqlserver pfs_scaling_signal Output signal for PFS Dynamic Scaling
sqlserver polaris_background_task_exception Unexpected exceptions during execution of Polaris background task.
sqlserver polaris_billing_data_scanned Billing report – data size read through external extractors. Distinct event per each file and each processing thread.
sqlserver polaris_billing_data_scanned_csv Billing report – data size read through native CSV reader. Distinct event per each file.
sqlserver polaris_billing_data_written Billing report – Reports data written.
sqlserver polaris_billing_distributed_queries_executed Fires when VDW distributed computation was executed.
sqlserver polaris_billing_estimated_data_scanned Billing report – Estimated data scanned during query compilation phase.
sqlserver polaris_billing_exception Unexpected exceptions during data_export or distributed_move operations.
sqlserver polaris_billing_exception_managed_data Unexpected billing exception.
sqlserver polaris_billing_native_shuffle_data_moved Billing report – Reports data moved by native shuffle.
sqlserver polaris_billing_verification_distributed_queries_executed Fires when VDW distributed computation was executed. Should be used only for billing verification.
sqlserver polaris_budget_limit_exception Unexpected exceptions during SQL On-Demand budget limit related operations.
sqlserver polaris_configuration_background_task Configuration state changes for background tasks.
sqlserver polaris_configuration_budget_limit_change Configuration changes for SQL On-Demand budget limit.
sqlserver polaris_configuration_budget_limit_snapshot Daily configuration snapshot for SQL On-Demand budget limit.
sqlserver polaris_created_in_memory_resource_group Fired when Polaris background tasks resource group is initialized.
sqlserver polaris_current_state_of_data_processed Reports status about internal query that is calculating current state of data processed in SQL On Demand.
sqlserver polaris_error_classification_failed Is fired when ErrorClassificationOverrideRules setting is invalid.
sqlserver polaris_exception_query_not_billed Unexpected exceptions during billing related system operations.
sqlserver polaris_executed_requests_history
sqlserver polaris_executed_requests_history_cleanup Reports status about retention cleanup on master.sys.polaris_executed_requests_history and master.sys.polaris_executed_requests_text tables.
sqlserver polaris_executed_requests_retention_period Reports retention period used for master.sys.polaris_executed_requests_history and master.sys.polaris_executed_requests_text tables.
sqlserver polaris_failed_to_find_resource_group Fired when Polaris background tasks resource group is not initialized.
sqlserver polaris_internal_metrics_distributed_query_history_tables Fires after write to distributed query history tables fail.
sqlserver polaris_internal_tsql_query_status Reports status about Polaris internal T-SQL query.
sqlserver polaris_metrics_connections Fires after login to Polaris frontend is finished.
sqlserver polaris_metrics_data_processed Fires after data is processed.
sqlserver polaris_metrics_login_rh Fires Resource Health signal after login to Polaris frontend is finished.
sqlserver polaris_metrics_queries Fires after distributed query result is returned.
sqlserver polaris_metrics_query_rh Fires Resource Health signal after distributed query on Polaris finishes.
sqlserver polaris_rejected_rows_aggregations Reports status of rejected rows aggregation processing
sqlserver polaris_rejected_rows_exception Unexpected exceptions during rejected rows processing.
sqlserver polaris_rejected_rows_exception_details Details of overwritten query response exception
sqlserver polaris_unexpected_switch_value Is fired when unexpected switch value is encountered.
sqlserver polaris_write_distributed_query_history_exception Unexpected exceptions during data ingestion into polaris history tables
sqlserver predict_error PREDICT error
sqlserver predict_onnx_log ONNX log message
sqlserver private_vdw_client_batch_submitted Fires when query to SQL FE is submitted and log to Pii table.
sqlserver private_vdw_sql_statement_compiled Fires when a sql statement in SQL FE is compiled and log to Pii table.
sqlserver private_vdw_sql_statement_starting Fires when a sql statement is started in SQL FE and log to Pii table.
sqlserver query_abort Indicates that a cancel operation, client-interrupt request, or broken client connection was received, triggering abort.
sqlserver query_antipattern Occurs when a a query antipattern is present and can potentially affect performance.
sqlserver query_ce_feedback_telemetry Reports query feedback information
sqlserver query_feedback_analysis Reports query feedback analysis details
sqlserver query_feedback_validation Reports query feedback pre validation data
sqlserver query_optimizer_nullable_scalar_agg_iv_update Occurs when scalar indexed view with nullable aggregates is being created or updated.
sqlserver query_optimizer_optimize_insert Occurs when the query optimizer checks an optimization of insert is possible.
sqlserver query_post_execution_stats Occurs after a SQL statement is executed. This event contains stats on query execution and uses lightweight profiling infrastructure but does not have showplan xml. This event is fired only when Query Store is enabled and Query Store is tracking the query.
sqlserver query_store_hadron_transport_failures When QDS cannot process a message correctly this XEvent is emitted with diagnostic information.
sqlserver query_with_parameter_sensitivity This event is fired when a query is discovered to have parameter sensitivity. This telemetry will help us in identifying queries that are parameter sensitive and how skewed the columns involved in the query are. This is for internal analysis only.
sqlserver rbpex_compute_zone_hotness
sqlserver rbpex_deferring_remote_io RBPEX deferred remote I/O due to pending file growth.
sqlserver rbpex_eviction_run_profile
sqlserver rbpex_force_copy_pages_failure Event to force copy pages failure during RBPEX seeding.
sqlserver rbpex_grow_fail_reporting_max_size RBPEX grow has been failing continuously and now we are reporting max RBPEX file size as part of IDSU.
sqlserver rbpex_incremental_grow Tracks rbpex grow when utilization exceeds threshold.
sqlserver rbpex_is_file_growth_supported Occurs when RBPEX/WB checks if file growth can be deferred
sqlserver rbpex_parallel_seeding_timing Rbpex parallel seeding timing info.
sqlserver rbpex_pause_exclusive_phase Rbpex pause segment functionality test, exclusive phase wait.
sqlserver rbpex_peer_seed Records RBPEX peer seed activity.
sqlserver rbpex_physical_grow Rbpex physical growth succeeded
sqlserver rbpex_physical_shrink Rbpex Physical shrink not allowed to proceed
sqlserver rbpex_seed_thread_start Event to report start of seed thread.
sqlserver rbpex_seeding_catchup_retry Fired before attempting to retry segment catchup operation from blob during rbpex seeding.
sqlserver rbpex_seeding_segment_copy_retry Fired before attempting to retry segment copy operation from snapshot during rbpex seeding.
sqlserver rbpex_seeding_snapshot_created Fired when a snapshot is created for page server seeding.
sqlserver rbpex_seg_seed_copy_page Event to report dirty pages being copied during seeding.
sqlserver rbpex_shrinkmgr_grow Records RBPEX growth activity.
sqlserver rbpex_shrinkmgr_shrink Rbpex shrink info.
sqlserver rbpex_shrinkmgr_shrink_assert_error Rbpex shrink assertions errors
sqlserver rbpex_shrinkmgr_shrink_started
sqlserver reclaim_dropped_column_space_begin Occurs when reclaim space for dropped LOB columns has started.
sqlserver reclaim_dropped_column_space_end Occurs when reclaim space for dropped LOB columns has finished.
sqlserver recovery_catch_checkpoint Dirty pages will be written to advance the oldest page LSN and catch up with the current LSN. This event is only applicable to databases where indirect checkpoint is enabled.
sqlserver recovery_force_flush_checkpoint Dirty pages will be written to advance the oldest page LSN and catch up with the target log distance. This event is only applicable to databases where indirect checkpoint is enabled.
sqlserver recovery_indirect_checkpoint_end Checkpoint has ended. This event is only applicable to databases where indirect checkpoint is enabled.
sqlserver recovery_simple_log_truncate Dirty pages will be written to help log truncation of the simple-recovery database. This event is only applicable to databases where indirect checkpoint is enabled.
sqlserver remove_remote_file_redo_operation_completed RemoveFileFromRemoteReplicas Operation Completed
sqlserver remove_remote_file_redo_operation_failed RemoveFileFromRemoteReplicas Operation Failed
sqlserver remove_remote_file_redo_operation_started RemoveFileFromRemoteReplicas Operation Started
sqlserver repl_error This event will be fired from replication code when an error occurs.
sqlserver repl_logscan_session This event captures log scan operations telemetry through Replication and Change Data Capture (CDC) phases 1 through 7.Returns session transactions as they are processed.
sqlserver repl_metadata_change This event will be fired from replication code on changes related to replication metadata.
sqlserver repldone_session ReplDone Information
sqlserver required_memory_grant_too_big Keep the related data when the requested memory is greater than the available memory (right before throwing an exception)
sqlserver resource_governor_classifier_changed Occurs when Resource Governor classifier function is changed.
sqlserver resource_governor_reconfigure_classifier_details Shows classifier data before and after rg reconfigure.
sqlserver resource_governor_resource_pool_definition_changed Occurs when resource pool definition changes.
sqlserver resource_governor_workload_group_definition_changed Occurs when workload group definition changes.
sqlserver restore_rollfoward_complete RestoreRedoMachine::Rollforward function telemetry details.
sqlserver resumable_index_auto_abort Occurs when the resumable index has been paused for longer than the auto abort threshold.
sqlserver rowgroup_consolidation_append_blob Append columnstore data to existing rowgroup blob
sqlserver rowgroup_consolidation_copy_blob Copy the existing Roco file to another blob, update columnstore metadata and cache entries with new blob id
sqlserver rowgroup_consolidation_create_and_write_rowgroup_blob Flush a consolidated rowgroup blob
sqlserver rowgroup_consolidation_flush_rowgroup_blob_fail Attempted to flush a chunk of columnstore rowgroup data to block blob and failed.
sqlserver rpc_completed Occurs when a remote procedure call has completed.
sqlserver security_cache_recreate_login_token Recreate a login token and cache it(for existing sessions) after the security token caches have been invalidated.
sqlserver security_cache_ring_buffer Security Cache ring buffer telemetry.
sqlserver security_context_token_cleanup When a security context token is deleted.
sqlserver send_segment_io_data send segment access information
sqlserver send_segment_io_data_v2 # of IOs on a segment (simulated).
sqlserver send_segment_io_data_v2_heartbeat Whether segment IOs are being tracked (simulated).
sqlserver session_fedauth_failure Occurs when a session is attempting to set a fed auth token in an unsupported scenario.
sqlserver set_partial_log_backup_checkpoint_lsn_to_null Used for setting the partialLogBackupCkptLsn to NullLSN
sqlserver shallow_scan_in_view_enabled Indicates that shallow metadata checks are enabled early during view binding, for earlier failure detection.
sqlserver socket_dup_event This event is for Socket Duplication steps at SQL or Xlog side.
sqlserver sp_cloud_update_sys_databases_post_termination_completed Spec proc sp_cloud_update_sys_databases_post_termination completed (with or without error).
sqlserver sp_statement_completed Occurs when a statement inside a stored procedure has completed.
sqlserver sp_statement_starting Occurs when a statement inside a stored procedure has started.
sqlserver spexec_batch_compilation_serialization This event will be emitted when the spexec batch compilation serialization occurs
sqlserver spills_to_tempdb Spills to tempdb, which were caused by any query. Only fires off when spills exceeds (predefined threshold * MaxTempdbDbMaxSizeinMB)
sqlserver sql_statement_completed Occurs when a Transact-SQL statement has completed.
sqlserver sql_syms_publishing Fires during metadata publishing to SyMS.
sqlserver sql_syms_publishing_exception Fires when metadata publishing to SyMS hits exception.
sqlserver sql_syms_publishing_http_request Fires on metadata publishing HTTP requests to SyMS.
sqlserver sr_tx_count XEvent that indicates a Serializable Transaction info
sqlserver srb_backup_sync_message Backup Sync messages sent during backup on secondary replica.
sqlserver srb_clear_diff_map_succeeded Backup Info message sent from primary to secondary to signal that diff map was cleared and provide a new checkpoint LSN.
sqlserver srb_commit_diff_backup Backup Info message sent from secondary to primary to signal that diff backup finished and that lock should be released on primary.
sqlserver srb_commit_full_backup Backup Info message sent from secondary to primary to signal that full backup finished and to provide neccessary information.
sqlserver srb_database_diff_backup_start_ack Backup Info message sent from primary to secondary to acknowledge diff backup request.
sqlserver srb_database_full_backup_start_ack Backup Info message sent from primary to secondary to acknowledge full backup request.
sqlserver srb_force_checkpoint_succeeded Backup Info message sent from primary to secondary to signal that checkpoint was executed and provide a new checkpoint LSN.
sqlserver srb_log_backup_info Backup Info messages sent during log backup on secondary replica.
sqlserver stale_user_tx_page_cleanup_element_removal Telemetry regarding how many stale elements were removed from the user transaction page cleanup hash table by version cleaner.
sqlserver startup_phase_telemetry Startup phase telemetry details .
sqlserver storage_engine_performance_counters Performance counter data produced by StoragePerfCountersRecord function
sqlserver summarized_oom_snapshot Out-of-memory (OOM) summary snapshot
sqlserver suppress_errors Alter statement execution
sqlserver synapse_link_addfilesnapshotendentry Called after a data export file is added to snapshot_end manifest entry
sqlserver synapse_link_buffering_row_data Synapse Link Buffering Row Data
sqlserver synapse_link_capture_throttling Synapse Link Capture Cycles Throttling
sqlserver synapse_link_db_enable Synapse Link enable events
sqlserver synapse_link_end_data_snapshot Called in LandingZoneParquetExporter at the end of successful data snapshot functionality
sqlserver synapse_link_error Error events from Synapse Link components
sqlserver synapse_link_info Synapse Link info
sqlserver synapse_link_library Synapse Link Call Back Events
sqlserver synapse_link_perf Synapse Link performance
sqlserver synapse_link_scheduler Synapse Link Scheduler Information
sqlserver synapse_link_start_data_snapshot Called in LandingZoneParquetExporter at the beginning of data snapshot functionality
sqlserver synapse_link_totalsnapshotcount Called when all files have been added a snapshot end entry
sqlserver synapse_link_trace Synapse Link trace
sqlserver synapse_sql_pool_metrics_login Fires after login to Synapse SQL Pool frontend completes.
sqlserver synapse_sql_pool_metrics_query Fires after Synapse SQL Pool query finishes.
sqlserver tail_log_cache_buffer_refcounter_change Occurs along with a tail log cache buffer’s reference counter being incremented or decremented.
sqlserver tail_log_cache_miss Occurs when a log consumer attempts to lookup a block from the tail log cache but fails to find it.
sqlserver toad_cell_tuning_metrics Toad cell tuning metrics event.
sqlserver toad_delete_bitmap_tuning_metrics Toad delete bitmap tuning metrics event.
sqlserver toad_delta_force_tuning_metrics Toad delta force tuning metrics event.
sqlserver toad_discovery Toad work discovery event.
sqlserver toad_exception Exception channel for the background toad tasks.
sqlserver toad_memory_pressure_notification Toad memory pressure notification event.
sqlserver toad_memory_semaphore_request Toad memory semaphore request event.
sqlserver toad_occi_tuning_metrics Toad OCCI tuning metrics event.
sqlserver toad_star_cell_tuning_metrics Toad star cell tuning metrics event.
sqlserver toad_tuning_zone_circuit_breaker Toad tuning zone circuit breaker event.
sqlserver toad_work_execution Toad work execution event.
sqlserver tsql_feature_usage_tracking Track usage of t-sql features in queries for the database
sqlserver user_token_cache_hit Successfully retrieved a user token from the cache.
sqlserver user_token_cache_miss When unable to retrieve a user token from the cache.
sqlserver user_token_cleanup When a user token is deleted.
sqlserver user_tx_page_cleanup_progress Emit various data about user transaction page cleanup progress.
sqlserver user_tx_page_cleanup_stats Emit statistics related to user transaction page cleanup hash table.
sqlserver vdw_annotations Collect annotations from queries.
sqlserver vdw_backend_cancel_query_feedback Fired by the VDW backend when query feedback submission is canceled.
sqlserver vdw_backend_prepare_query_feedback Fired by the VDW backend when preparing query feedback submission.
sqlserver vdw_backend_query_feedback_rpc Fired by the VDW backend to report query feedback status.
sqlserver vdw_backend_submit_query_feedback Fired by the VDW backend when query feedback submission occures.
sqlserver vdw_cancel_query_completion Fired by the VDW SQL FE when query completed notification submission is canceled.
sqlserver vdw_cetas_drop_ext_table_metadata Fires if the DML part of a CETAS fails in pre-Gen3 Polaris.
sqlserver vdw_client_batch_cancelled Fires when query to SQL FE is cancelled.
sqlserver vdw_client_batch_completed Fires when query to SQL FE is completed.
sqlserver vdw_client_batch_submitted Fires when query to SQL FE is submitted.
sqlserver vdw_distributed_computation_error Fires when returning error or warning reported by code related to VDW distributed computation.
sqlserver vdw_distributed_computation_rpc Fires when RPC for VDW distributed computation was requested.
sqlserver vdw_distributed_query_cleanup_exception Unexpected exception during cleanup of VDW distributed operator.
sqlserver vdw_distributed_query_metrics Fired by the VDW backend to report collected metrics when going out of sp_executesql_metrics scope.
sqlserver vdw_file_format_parser_version_usage Fired by the VDW frontend during resolve operation of parser version for provided format.
sqlserver vdw_file_level_sampling Fired by the VDW backend instance for OPENROWSET(BULK) queries that use TABLESAMPLE clause.
sqlserver vdw_logical_file_splits Emits information related to logical file splits.
sqlserver vdw_logical_file_splits_memo_generation Emits information related to logical file splits after memo generation.
sqlserver vdw_prepare_query_completion Fired by the VDW SQL FE when preparing query completed notification submission.
sqlserver vdw_query_completion_rpc Fired by the VDW SQL FE to notify ES FE that the query is completed.
sqlserver vdw_sp_drop_storage_location Fired by the VDW frontend from stored procedure sp_drop_storage_location.
sqlserver vdw_sql_statement_compiled Fires when a sql statement in SQL FE is compiled.
sqlserver vdw_sql_statement_completed Fires when a sql statement is completed in SQL FE.
sqlserver vdw_sql_statement_fido_transaction SQL FE statement and fido transaction trace.
sqlserver vdw_sql_statement_starting Fires when a sql statement is started in SQL FE.
sqlserver vdw_statement_execution Fires when VDW query execution starts or completed.
sqlserver vdw_submit_query_completion Fired by the VDW SQL FE when query completed notification submission occures.
sqlserver vdw_wildcard_expansion Fired by the VDW frontend when wildcard expansion was requested.
sqlserver vdw_wildcard_list_directory_stats Fired by the VDW frontend when wildcard expansion was requested. Contains information about each list directory call in WCE.
sqlserver version_cleaner_worker_stealing Version cleaner worker stealing.
sqlserver vldb_geodr_applied_throttling
sqlserver vldb_geodr_throttling_stat
sqlserver vm_msi_access_token_retrieval Request access token for Azure virutal machine MSI.
sqlserver volume_entity_stats latency histogram for volume entity.
sqlserver volume_traffic_policer_stats Reports stats on conforming and non-conforming IOs in terms of IOPS and Bandwidth governances
sqlserver wait_for_redo_lsn_to_catchup_pagestats In every 5 minutes interval,stats data of RedoPageType and RedoLocation is emitted
sqlserver wait_for_redo_lsn_to_catchup_stats In every 5 minutes interval,stats data of waitforlsn is emitted
sqlserver wb_checkpoint_failed_ios Logs failed ios during WB checkpoint.
sqlserver wb_checkpoint_metadata Traces foreign log state for write behind checkpoint progress.
sqlserver wb_checkpoint_progress Monitors progress of write behind checkpoint.
sqlserver wb_checkpoint_report_file_size This xevent is fired when rbpex write behind checkpoint handle physical file growth.
sqlserver wb_checkpoint_skip_file_growth This xevent is fired when rbpex write behind checkpoint abort deferred physical file growth.
sqlserver wb_recovery_progress Write behind recovery stats.
sqlserver wb_throttle_info Monitors info determining write behind throttling.
sqlserver webtoken_generator_failure Occurs when we encounter a failure during JWT creation with JSONWebTokenGenerator class.
sqlserver wildcard_expansion Fired by the SQL frontend when wildcard expansion was requested.
sqlserver worker_migration_stats Shows the number of worker migrations for a particular task.
sqlserver xact_outcome_list_cleanup_completed XEvent used to indicate that outcome list cleanup (via specproc) has completed.
sqlserver xact_outcome_list_cleanup_performed XEvent used to indicate that outcome list cleanup was performed on a database.
sqlserver xact_outcome_list_cleanup_starting XEvent used to indicate that outcome list cleanup (via specproc) is starting.
sqlserver xact_outcome_status Periodically fired XEvent to indicate current count of xact outcomes in the outcome list.
sqlserver xfile_storage_file_operation_metrics Storage file operation metrics.
sqlserver xfile_stream_reader_operation_metrics Stream reader operation metrics.
sqlserver xio_lease_action Lease request to Windows Azure Storage.
sqlserver xio_lease_action_sensitive Lease request to Windows Azure Storage. Contains PII data.
sqlserver xio_read_complete_sensitive Read complete from Windows Azure Storage response. Sensitive data.
sqlserver xio_request_reissue_finished_first Event fired when request which was reissued finishes before original request.
sqlserver xio_request_reissue_read_stats Contains information about data read with reissuing of long requests.
sqlserver xio_request_retry_finished_first Request that was part of parallel retry due to long request duration time finished first.
sqlserver xio_request_retry_finished_first_sensitive Request that was part of parallel retry due to long request duration time finished first. Contains PII data.
sqlserver xml_compression_telemetry Xml Compression telemetry collected per query
sqlserver xodbc_cache_get_federated_user_info_cache_bypass Occurs when a federated user cache lookup request bypasses the cache and executes a DB query.
sqlserver xodbc_cache_get_federated_user_info_failure Occurs when a remote authentication request to logical master failed to query for federated user info.
sqlserver xodbc_cache_update_federated_user_info_cache_entry Occurs when a federated user, has a name that matches object ID, and the name is updated with the correct value during login.
sqlserver xstore_aad_token_failure Occurs when we encounter a failure in XStoreAADTokenCache layer, when performing refresh to the AAD token
sqlserver xstore_create_physical_file Creating physical XStore file has been attempted with the options below.
sqlserver xstore_create_physical_file_sensitive Creating physical XStore file has been attempted with the options below. Contains sensitive data
sqlserver xstore_io_throttling_storage_account_removed XStore I/O throttling handler has removed storage account.
sqlserver xtp_db_page_allocation_state_change Indicates that the state of page allocations for the database is changed, from allowed to disallowed or vice versa.
sqlserver xtp_open_existing_database Indicates the XTP open existing database progress.
ucs ucs_connection_stats UCS transport connection periodic statistics
ucs ucs_task_count UCS task manager task count number
ucs ucs_transmitter_block_send_transport_not_ready UCS transmitter block send if transport not in ready state
ucs ucs_transmitter_destination_init UCS transmitter destination initiation
ucs ucs_transmitter_notify_destination_status_change_event UCS transmitter destination notifed of stream status change
ucs ucs_transmitter_send_backoff_to_be_added UCS transmitter service failed send enough times that a backoff will be added
ucs ucs_transmitter_send_stats UCS transmitter service stats on send for each index
ucs ucs_transmitter_skip_transport_reconnection_check UCS transmitter destination skipping check for transport reconnects
ucs ucs_transmitter_skip_transport_stream_reconnection UCS transmitter destination skipping transport reconnect due to recheck
ucs ucs_transmitter_transport_reconnect UCS transmitter destination submitted a transport stream reconnect request due to the transport stream being disconnected
ucs ucs_transmitter_transport_reconnect_all_check UCS transmitter destination check to see if we need to reconnect all transport streams due to ip/port or dns names of connection targets being different
XeSqlFido fido_catalog_get_buckets FIDO Physical Catalog Get Buckets.
XeSqlFido fido_catalog_get_cache_version FIDO Physical Catalog Cache Get.
XeSqlFido fido_catalog_sync FIDO Physical Catalog Sync Event.
XeSqlFido fido_catalog_update_cache_version FIDO Physical Catalog Cache Update.
XeSqlFido fido_catalog_update_version FIDO Physical Catalog Update Server version.
XeSqlFido fido_catalog_version FIDO Physical Catalog Get Server version.
XeSqlFido fido_clone_inherited_directory_info FIDO clone inherited directory info.
XeSqlFido fido_clone_reference_info FIDO clone reference info.
XeSqlFido fido_fork_entries FIDO fork entries
XeSqlFido fido_garbage_collection_drop_blob_info FIDO Garbage Collection dropped blob info
XeSqlFido fido_garbage_collection_task FIDO Garbage Collection task
XeSqlFido fido_garbage_collection_task_end FIDO Garbage Collection Task End XEvents
XeSqlFido fido_garbage_collection_task_failure FIDO Garbage Collection task failed
XeSqlFido fido_garbage_collection_task_start FIDO Garbage Collection Task Start XEvents
XeSqlFido fido_glm_alter_txn_operation FIDO GLM Alter Txn operation.
XeSqlFido fido_glm_backup FIDO GLM Server Backup.
XeSqlFido fido_glm_client_sync FIDO GLM Client Sync.
XeSqlFido fido_glm_execute_ddl_cached FIDO GLM Execute DDL from Cache.
XeSqlFido fido_glm_glog_truncate FIDO GLog truncation.
XeSqlFido fido_glm_pit_db_create FIDO PIT DB Create.
XeSqlFido fido_glm_pit_db_create_failed FIDO GLM PIT DB create failed.
XeSqlFido fido_glm_pit_db_drop FIDO PIT DB destroyed.
XeSqlFido fido_glm_pit_db_drop_fail FIDO PIT DB drop failed.
XeSqlFido fido_glm_restore FIDO GLM Client Restore.
XeSqlFido fido_glm_send_ucs_request FIDO GLM Send UCS request.
XeSqlFido fido_glm_send_ucs_response FIDO GLM Send UCS response.
XeSqlFido fido_indexstore_stats FIDO index store stats message.
XeSqlFido fido_lock_manager_trace FIDO LM message.
XeSqlFido fido_log_trace FIDO log trace.
XeSqlFido fido_log_trace_sensitive FIDO PII log trace.
XeSqlFido fido_metadata_cleanup FIDO GLMS cleanup
XeSqlFido fido_perf_metric FIDO perf metric.
XeSqlFido fido_rowgroup_visibility_info FIDO Is Rowgroup visible.
XeSqlFido fido_rowset_blob_directory FIDO rowset blob directory.
XeSqlFido fido_rsc_version_tracking_task FIDO RSC Version Tracking Task
XeSqlFido fido_rsc_version_tracking_task_end FIDO RSC Version Tracking Task End XEvents
XeSqlFido fido_rsc_version_tracking_task_failure FIDO RSC Version Tracking Task failed
XeSqlFido fido_rsc_version_tracking_task_start FIDO RSC Version Tracking Task Start XEvents
XeSqlFido fido_sequence_info FIDO sequence message
XeSqlFido fido_spaceused_info FIDO spaceused message
XeSqlFido fido_t_sql_exception FIDO T-SQL execution failed.
XeSqlFido fido_transport_message_trace FIDO transport message traces
XtpEngine xtp_shutdown_close_hk_ckpt_ctrl Indicates the XTP checkpoint uninitialize progress.
XtpEngine xtp_shutdown_free_hk_internal_database Indicates the XTP shutdown progress.
XtpRuntime xtp_create_database Indicates the XTP create or open database progress.

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New Query Transformation Rules In SQL Server 2022

Brand New


Here are new lines from the query transformation stats view in SQL Server 2022:

+--------------------------------+
|              name              |
+--------------------------------+
| BuildDataExportPut             |
| BuildRemotePut                 |
| EnforceDistribution            |
| FetchXcs                       |
| GetToFetchXcs                  |
| ImplementDistribution          |
| ImplementGlobalSequenceProject |
| ImplementLocalSequenceProject  |
| LASJIsNullToDist               |
| LSJIsNullToDist                |
| MatchGbJoin                    |
| MatchGbNAryJoin                |
| PushImpliedIsNotNull           |
| RemoveSubqInCube               |
| RemoveSubqInRollup             |
| RemoveSubqInTFP                |
| SelectToFilteredExternalGet    |
| SelGetToFetchXcs               |
| SelInToJoinGb                  |
+--------------------------------+

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New System Configurations In SQL Server 2022

Brand New


Here are new sys.configuration entries in SQL Server 2022:

+------------------------------------+-------------------------------------------------------------------------------------+
|                name                |                                     description                                     |
+------------------------------------+-------------------------------------------------------------------------------------+
| Data processed daily limit in TB   | SQL On-demand data processed daily limit in TB                                      |
| Data processed weekly limit in TB  | SQL On-demand data processed weekly limit in TB                                     |
| Data processed monthly limit in TB | SQL On-demand data processed monthly limit in TB                                    |
| ADR Cleaner Thread Count           | Max number of threads ADR cleaner can assign.                                       |
| backup compression algorithm       | Configure backup compression algorithm                                              |
| hardware offload config            | Offload processing to specialized hardware                                          |
| suppress recovery model errors     | Return warning instead of error for unsupported ALTER DATABASE SET RECOVERY command |
| openrowset auto_create_statistics  | Enable or disable auto create statistics for openrowset sources.                    |
+------------------------------------+-------------------------------------------------------------------------------------+

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New Error Messages In SQL Server 2022

Brand New


Here’s a list of new error messages in SQL Server 2022:

text
The external policy action '%.*ls' was denied on the requested resource.
The user does not have the external policy action '%ls' or permission '%.*ls' to perform this action.
Purview policies to validate external policy action permissions are either expired or not found. To force a policy fetch, execute the procedure 'sys.sp_external_policy_refresh'. If the error persists, please check the errorlog for any errors related to Purview policy fetch.
Failed to startup resilient buffer pool extension because the binary version is incompatible with the persisted version.
Failed to disable buffer pool extension.
Buffer pool extension was paused due to error.
Failed to disable Resilient buffer pool extension.
Database '%.*ls' does not exist in server '%.*ls'. Please make sure that the name is entered correctly.
Cannot restore database with data file size larger than max allowed data file size of (%d) MB on Azure SQL.
Cannot restore database with log file size larger than max allowed log file size of (%d) MB on Azure SQL.
Transaction (Process ID %d) was blocked/deadlocked but failed the attempt to generate blocked process/deadlock report.
Failed to acquire lock with lock manager service, it could be due to many reasons including transient service failure.
Task has been aborted, but %S_MSG of the %S_MSG '%.*ls' may continue in the background. Please check whether the %S_MSG has finished successfullly.
Parameter %d is incorrect for this DBCC statement: %ls.
Value of '%ls' must be less than or equal to value of '%ls'. Change the values and reissue the BACKUP statement.
%.*ls '%.*ls' was previously suspended for snapshot backup.
%.*ls '%.*ls' is not suspended for snapshot backup.
Database '%.*ls' acquired suspend locks in session %d.
Database '%.*ls' released suspend locks in session %d.
Database '%.*ls' did not acquire the necessary suspend locks to freeze the database.
%.*ls '%.*ls' successfully suspended for snapshot backup in session %d.
%.*ls '%.*ls' originally suspended for snapshot backup in session %d successfully resumed in session %d.
%.*ls '%.*ls' with dbid %d failed to resume in session %d.
%.*ls '%.*ls' cancelled current resume operation as another resume operation is already in progress.
%.*ls '%.*ls' snapshot backup in progress.
Database '%.*ls' is not allowed to be suspended for snapshot backup.
Database '%.*ls' is specified multiple times in the group snapshot backup statement.
Database count changed while performing snapshot backup. (Expected: %d, Actual: %d).
Server '%.*ls' has no user databases to suspend for snapshot backup.
Invalid Identity Specified for the S3 Credential. Credential Identity should be S3 Access Key.
Write to S3 object storage device %ls failed. Device has reached its limit of %d allowed parts.
An error occurred while attempting to apply a log record. This could indicate log or database corruption. Additional messages in the SQL Server error log may provide more detail.
Task has been aborted, but %S_MSG of the %S_MSG '%.*ls' may continue in the background. Please check whether the %S_MSG has finished successfullly.
Cannot drop database '%.*ls' because of temporary unavailability. Please try again later.
Cannot %S_MSG the %S_MSG '%.*ls' because it is being used for Change Feed.
The function '%.*ls' may not have a window frame.
Window element in OVER clause can not also be specified in WINDOW clause.
The function '%.*ls' must have an OVER clause.
The log backup cannot be performed with the provided MAX_VLF_COUNT option.
The log backup cannot be performed with the provided MAX_VLF_COUNT option on Hadron secondaries.
ROWTERMINATOR and FIELDTERMINATOR can only be used with schema inference or WITH clause.
CSV format supports only TABLESAMPLE PERCENT option.
Partial file cannot be provided together with TABLESAMPLE clause.
Missing update assignment in update with action hint.
Parser version '%ls' is not supported for provided format '%ls'.
Parser version '%ls' is not supported.
Empty string value cannot be provided as '%ls' option for specified format '%ls' and PARSER_VERSION '%ls'.
Specifying database or server credential is not supported for OPENROWSET.
Option '%ls' is not supported for specified format '%ls' and PARSER_VERSION '%ls'.
An ERRORFILE_LOCATION cannot be specified without ERRORFILE_DATA_SOURCE option.
An ERRORFILE_DATA_SOURCE cannot be specified without ERRORFILE_LOCATION option.
With clause, format file and SINGLE_BLOB/SINGLE_CLOB/SINGLE_NCLOB options cannot be used with ReadMode=Metadata.
Unsupported combination of datafiletype option and format.
Window '%.*ls' is undefined.
The function '%.*ls' may not have ORDER BY in OVER or WINDOW clause.
Window frame with ROWS or RANGE must have an ORDER BY clause.
Cyclic window references are not permitted.
The function '%.*ls' must have an OVER clause or a WINDOW with ORDER BY.
Window specification defined in one window can not be redefined in another window.
Option '%ls' is not supported for specified format '%ls'.
Option '%ls' is not supported for locations with '%ls' connector when specified FORMAT is '%ls'.
Invalid column reference detected in view '%.*ls'. Please recreate the view or refresh the column definitions using sp_refreshview stored procedure.
Connector prefix '%ls' is not supported for specified FORMAT '%ls'.
The specified bulk option '%ls' is not supported for file format '%ls'. Review the documentation for supported options.
The compressed xml stream is corrupted.
The Database ID %d, Page %S_PGID, slot %d for LOB data type node does not exist. This is usually caused by transactions that can read uncommitted data on a data page. Run DBCC CHECKTABLE.
Linked server query execution failed due to an internal error related to AAD authentication.
Linked Server use self mode AAD authentication functionality is disabled on the service side and therefore cannot be used.
AAD use-self authentication to Linked Server "%ls" failed because it is not part of any Server trust group that contains current server. Use documentation to join two servers into a Server trust group: https://docs.microsoft.com/azure/azure-sql/managed-instance/server-trust-group-overview.
Linked Server access token mode AAD authentication functionality is disabled on the service side and therefore cannot be used.
AAD token for accessing linked server cannot be obtained. Error message: '%ls'.
Linked Server use MSI mode AAD authentication functionality is disabled on the service side and therefore cannot be used.
Linked Server AAD authentication using username and password is disabled on the service side and therefore cannot be used.
Linked Server login mapping with "useself" property set is not allowed when using AAD '%ls' authentication mode.
Linked Server User-assigned MSI mode AAD authentication functionality is not supported on the service side. Use system-assigned identity instead.
Querying linked server '%ls' failed. Either login for Linked Server AAD '%ls' authentication mode does not exist or login's 'useself' attribute is set to true.
The %ls option can only be specified once for the table or partition.
Invalid partition range (%d to %d). Upper bound must be greater than lower bound.
The query processor could not produce a query plan because the target DML table is not hash partitioned.
Cannot run query because internal optimization replay failed.
The UPDATE/DELETE statement attempted to modify the same row more than once. Refine the statement to ensure a target row is modified at most once.
REDISTRIBUTE_PREFIX hint expect the %ld join condition to be an equality comparison of columns with directly comparable types. Modify the query and re-run it.
Merge statements with a WHEN NOT MATCHED [BY TARGET] clause must target a hash distributed table.
Error occurred when serializing source types to move to another distribution. Please try to run the query again. If the error persists, please contact support.
The table option XML_COMPRESSION is not allowed when a table specifies a clustered columnstore index.
The enable_ordinal argument for STRING_SPLIT only supports constant values (not variables or columns).
Get node value from XML DOM failed.
Get attribute from XML DOM failed.
Get named item from XML DOM failed.
Get single node from XML DOM failed.
Get multiple nodes from XML DOM failed.
Error while creating an XML parser instance.
Variant type change failed.
Loading XML DOM from byte strean failed.
Get document element XML DOM failed.
Get next node from XML DOM node failed.
Get length of node list from XML DOM node failed.
The log for database '%.*ls' has been truncated past LSN %S_LSN and we are unable to restore page (%d:%d).
Fixed VLF transition was rejected.
The LSN %S_LSN passed to log dumper in database '%.*ls' is not valid.
CREATE/UPDATE STATISTICS failed because of an inconsistency in metadata. Please drop the statistics and execute the statement again.
Statistics histogram computation encountered an error during data collection. Please contact customer support.
CREATE STATISTICS is not supported in this version of SQL.
AUTO_CREATE_STATISTICS option also applied to AUTO_UPDATE_STATISTICS in this edition of SQL.
CREATE/UPDATE STATISTICS failed. Please execute the statement again.
Invalid bucket width value passed to date_bucket function. Only positive values are allowed.
Calculating date bucket for '%ls' column caused an overflow.
Internal APPROX_PERCENTILE_* runtime error('%ld'): '%s'
An invalid %ls value was encountered: The date value is less than the minimum date value allowed for the data type.
Failed to retrieve full-text batch size configuration. A batch size of %d will be used instead.
Failed to retrieve max full-text crawl range configuration. A crawl range of %d will be used instead.
Cannot create %S_MSG on view "%.*ls" because it uses a ANTISEMI or SEMI join, and no SEMI joins are allowed in indexed views. Consider using an INNER join instead.
The resumable index '%.*ls' on object '%.*ls' is being auto aborted because it has remained paused for more than %d minutes. Refer to the PAUSED_RESUMABLE_INDEX_ABORT_DURATION_MINUTES DATABASE SCOPED CONFIGURATION option for configuring the threshold for automatically aborting paused index operations.
The index '%.*ls' on object '%.*ls' was rebuilt with valid data rows but null stats were found.
Could not create columnstore index '%.*ls' on table '%.*ls' since column '%.*ls' is computed column which is not supported in the ORDER list.
Online columnstore index is not supported with ORDER clause.
ALTER INDEX ALL '%S_MSG' failed. There is no pending resumable index operation on '%.*ls'.
Load resource governor configuration from replicated master failed to complete.
Load resource governor configuration from replicated master failed to start. Unable to submit async task.
The ALTER TABLE SWITCH statement is not supported between a distributed table and a non-distributed table.
The ALTER TABLE SWITCH statement failed because the distribution policy of the table '%.*ls' doesn't match the distribution policy of the table '%.*ls'.
The ALTER TABLE SWITCH statement failed because the distribution key '%.*ls' of the table '%.*ls' doesn't match the distribution keys of the table '%.*ls'.
ALTER TABLE SWITCH statement failed. Source and target partitions have different values for the XML_COMPRESSION option.
The ALTER TABLE SWITCH statement failed because table '%.*ls' has %d distribution key(s) but table '%.*ls' has %d distribution keys.
Column %.*ls has been specified more than once in the partition columns list. Please try again with a valid parameter.
Column %.*ls specified in the partition columns list does not match any columns in SELECT clause. Please try again with a valid parameter.
All output columns in DATA_EXPORT query are declared as PARTITION columns. DATA_EXPORT query requires at least one column to export.
One of the parameters cannot be deduced in this context.
NEXT VALUE FOR must have ORDER BY.
NEXT VALUE FOR function cannot be used directly in a statement that contains an ORDER BY clause unless the OVER or WINDOW clause is specified.
NEXT VALUE FOR function does not support OVER and WINDOW clause in default constraints, UPDATE statements, or MERGE statements.
The ADD FILE operation failed because the requested file ID '%d' is invalid.
The ADD FILE operation failed because there is an ongoing ADD FILE operation.
Task has been aborted, but %S_MSG of the %S_MSG '%.*ls' may continue in the background. Please check whether the %S_MSG has finished successfullly.
ALTER DATABASE SCOPED CONFIGURATION SET DW_COMPATIBILITY_LEVEL statement failed.
Compatibility Level '%d' is not supported. Supported compat levels are: [%s]
Optimized Locking cannot be enabled for the database as Accelerated Database Recovery is not enabled for the database.
Optimized Locking is enabled for this database. Please disable Optimized Locking first and then disable Accelerated Database Recovery.
The Metadata needed for Optimized Locking is not populated yet. Please retry the operation.
Ledger tables are not supported with %S_MSG.
Setting query hint(s) '%.*ls' in Query Store is not supported.
Query with provided query id (%ld) cannot be removed from Query Store since it has query hint(s). Clear the query hints before removing the query.
Query with query_id %d has forced plan. No hints can be applied to it while it has forced plan.
Query with query_id %d has query store hints. Query Store can't force a plan for it while it has hints.
Cannot load Optimization Replay Script (ORS) from the Query Store
The value of (%ld) is not valid for the parameter @disable_optimized_plan_forcing. Please pass either 0 or 1.
Query with query id %d was parameterized automatically by FORCED or SIMPLE parameterization, and has a RECOMPILE hint set in Query Store. RECOMPILE is not supported on automatically parameterized statements, hence the RECOMPILE hint was ignored.
Malformed feedback data for query ID.
Replica groups id should be greater than 0
Query plan with plan_id (%ld) cannot be forced for replica group id (%ld)
'Distribution' option must be explicitly specified in a CREATE TABLE AS SELECT query.
File ID %d is already in use on database %d.
Azure File Share Dynamic Scaling failed.
S3 URL options string is not a well formed JSON document. Parsing error %d.
S3 URL options JSON should have string scalar with valid style at $.s3.url_style.
S3 URL style option '%s' is not supported. Please use Path or Virtual_Hosted.
Change Feed is not supported in contained databases. The database '%.*ls' cannot be altered to a contained database, since Change Feed has been enabled.
Column type %ls cannot be used in the OPENJSON column that returns '$.sql:identity()' value.
System error.
System error.
System error.
System error.
System error.
System error: '%ls'.
System error: '%ls'.
System error.
System error.
System error.
Consecutive wildcard characters present in path '%ls'.
File/directory path '%ls' is too long. Max length of the path is nvarchar(260).
The bulk load failed. Unexpected NULL value in data file row %ls%I64d, column %d in data file %ls. The destination column (%ls) is defined as NOT NULL.
Compression type '%1ls' is not supported.
Error occurred while reading '%1ls' for decoding with %2ls codec.
Error occurred while decoding '%1ls' using %2ls codec. Codec error code: %d. Codec error message: %3ls
File/directory path '%ls' is too long. Max length of the path is nvarchar(1024).
File '%ls' cannot be opened because it does not exist or it is used by another process.
Query failed because credential for specified path does not exist or you do not have permissions to reference the credential.
Wildcard expansion operation timed out after %lu seconds.
Provided URL format is incorrect.
Provided first row exceeds row count in first split of the data file %ls. Please retry after updating first row value or by disabling splitting.
%ls option cannot be used with %ls format.
Usage of filepath function with DATA_SOURCE '%.*ls' might result in unexpected results if number of wildcards in data source LOCATION changes.
XML type cannot be used as column type in OPENROWSET function with inline schema. This type is not supported in WITH clause.
Azure Active Directory authentication to Azure Storage is not allowed in BULK INSERT/OPENROWSET.
Cannot parse rowset options: %ls
A node or edge table cannot be created as a ledger table.
Change Feed is not supported for node or edge table '%ls'.
The pseudo column used in the index key list does not match the underlying graph object type.
Reconfigure Failed. sp_configure option 'remote data archive' cannot be updated to 1. Stretch Database functionality is currently not supported with Azure SQL Edge.
Change Feed is not supported for table '%ls' with REMOTE_DATA_ARCHIVE enabled.
%.*ls input argument should be a query text in the following form: 'SELECT col FROM OPENROWSET(BULK)'. The query binding failed, please check for syntax errors.
%.*ls input argument should be a query text in the following form: 'SELECT col FROM OPENROWSET(BULK)'. The query must project exactly one OPENROWSET column.
%.*ls input argument should be a query text in the following form: 'SELECT col FROM OPENROWSET(BULK)'. Detected unexpected operator: %hs
%.*ls input argument should be a query text in the following form: 'SELECT col FROM OPENROWSET(BULK)'. The data source must be read using OPENROWSET BULK function.
Cannot create stats for the OPENROWSET query because of the hash collision. Stats table entry with hash %s already exists. Please modify your query and try again.
External table location must be a folder. Location provided: '%ls'
External table location cannot contain wildcard characters. Location provided: '%ls'
Cannot create external table. External table location already exists. Location provided: '%ls'
An error occurred while processing file '%ls'. HRESULT = '0x%x'.
Data type '%s' is currently not supported.
Data type '%s' is not supported.
Cannot create stats on external table for more than one column.
Invalid DDL statement. Creating statistics for external tables doesn't allow INCREMENTAL, MAXDOP or SAMPLE x ROWS options, nor a filter clause.
Cannot complete the sp_set_data_processed_limit stored procedure. Invalid limit value is specified. As a valid value should be considered anything between 0 and 2147483647.
ERRORFILE path exceeds limit of %d characters.
Warning: Ignored empty matched file '%ls'.
Cannot open external file storage.
External table statistics could not be found.
Invalid or unknown format type '%.*ls'.
More than %d wildcard characters present in path '%ls'.
Data conversion error (overflow) for column '%ls' in data file/external_table_name '%ls'.
I/O operation against '%ls' failed (details: {Operation = '%ls', HRESULT = '%ls'}).
Precision loss occurred for '%ls' in column '%ls'. Set NUMERIC_ROUNDABORT to OFF to ignore the precision loss.
Cannot obtain AAD token to access storage. Error message: '%ls'.
Cannot create external table. Provided storage type is not supported for CETAS.
External table location path is not valid. Location provided: '%ls'
Cannot create statistics on lob type column.
The underlying files are updated while the query is running. Remove ALLOW_INCONSISTENT_READ option from '%ls' if you need to have consistent results.
Cannot create statistics on partition column.
Openrowset statistics for specified openrowset source do not exist. Please, correct '%.*ls' OPENROWSET query argument to make sure that you specify good OPENROWSET options.
Multiple logical file paths are not allowed.
Inferring external table schema is not supported for given format type.
Binding by name is not supported for file format '%.*ls'. Please remove any JSON path mappings from WITH schema column definitions.
%ls is not supported.
%ls is not supported for %ls.
Objects of type %ls are not supported.
%ls '%ls' is not supported.
%ls is not allowed for external table columns.
Table hint %ls is not allowed.
Query hint %ls is not allowed.
Operation %ls is not allowed for a replicated database.
Queries are not supported in the conditions of %ls statements.
%ls type of a column %ls is not allowed as a column type when executing CREATE EXTERNAL TABLE AS SELECT.
Partitioned tables are not supported.
Providing both %ls and %ls is not supported.
Cannot execute %ls over multiple databases.
GEODR options are not allowed in ALTER DATABASE statements.
%ls operation is not allowed for this type of table.
Access check for '%ls' operation against '%ls' failed with HRESULT = '0x%x'.
Distributed query timeout expired. The timeout period elapsed prior to completion of the distributed operation.
Statement ID: %s | Query hash: %s | Distributed request ID: %s. Total size of data scanned is %I64u megabytes, total size of data moved is %I64u megabytes, total size of data written is %I64u megabytes.
Non-recoverable IO failure has occurred targeting '%ls' (details: {Operation = '%ls', HRESULT = '%ls'}).
USE statement does not support switching to '%ls' database.
USE statement does not support switching to '%ls' database. Use a new connection to connect to '%ls' database.
Three-part names are not supported from '%ls' database to '%ls' database.
DATA_SOURCE option is temporary disabled.
Internal error in sp_executesql_metrics. Unable to serialize aggregated metrics to the JSON format (HRESULT = '0x%x').
Stored procedure %.*ls is not supported.
Resolving CosmosDB path has failed with error '%s'.
There was an error in CosmosDB connection string '%s'.
Stored procedure '%ls' cannot be executed on master database.
%ls is not supported in %ls database.
Column name is missing or doesn't match columns in the CosmosDB: '%s'.
Exporting LOB value failed.
Export failed. Maximum LOB value size ('%ls') has been exceeded.
Query not supported: Cannot determine result column sources.  Invalid metadata.
The query used too many masked sources.
Only 'CELL_MAPPING' can be specified as a table-level JSON hint.
Invalid PLAN PER VALUE hint definition.
The function '%.*ls' does not support %.*ls.
The PARTITION=ALL clause must be specified to enable XML compression for the table or index.
Invalid xml compression setting for columnstore index '%.*ls'.
Cannot repeat window name in the WINDOW clause.
The function '%.*ls' expects parameter %.*ls at position %d.
All parameters of '%.*ls' must be named.
'%.*ls' is not supported in this version of Azure SQL Edge.
Page id not hosted by the current page server.
%ls is not supported with this set of options.
Cannot execute stored procedure '%ls'. The security check for the current user is failing. Only members of the sysadmin role can perform this operation.
Cannot complete the sp_set_data_processed_limit stored procedure. Invalid type is specified. Valid values are: daily, weekly and monthly.
Query is rejected because SQL Serverless budget limit for a period is exceeded. (Period = %s: Limit = %lu TB, Data processed = %lu TB)
EXTERNAL FILE FORMAT '%ls' has FORMAT_TYPE = %ls which is not supported by CREATE EXTERNAL TABLE AS SELECT statement.
The column name starting with '%.*ls' is too long. The maximum length is %d characters. File: '%ls'.
String or binary data would be truncated while reading column of type '%ls'. Check ANSI_WARNINGS option. File/External table name '%ls', column '%ls'. Truncated value: '%ls'.
Error converting values NaN or Infinity to type '%ls'. NaN and Infinity are not supported. File/External table name '%ls', column '%ls', value '%ls'. Check ANSI_WARNINGS and ARITHABORT options.
Arithmetic overflow error converting '%ls' to data type '%ls'. File/External table name '%ls', column '%ls', value '%ls'. Check ANSI_WARNINGS, ARITHABORT and NUMERIC_ROUNDABORT options.
Persisting distributed query history into %ls table failed. Table does not exists or it is corrupted.
Persisting distributed query history into %ls table failed. Command '%ls' failed.
Resolving Delta logs on path '%ls' failed with error: There are null fields in file/schema resolution.
Error reading external metadata.
Resolving Delta logs on path '%ls' failed with error: Cannot parse json object from log folder.
Resolving Delta logs on path '%ls' failed with error: Cannot find value of partitioning column '%.*ls' in file '%ls'.
Resolving Delta logs on path '%ls' failed with error: Wildcard in table path is not supported.
Resolving Delta logs on path '%ls' failed with error: Could not the find expected number of log files.
Resolving Delta logs on path '%ls' failed with error: Cannot parse field field '%ls' in json object.
Resolving Delta logs on path '%ls' failed with error: Provider type '%.*ls' is not supported.
Resolving Delta logs on path '%ls' failed with error: Partitioning column '%.*ls' not found in inferred or provided schema.
Resolving Delta logs on path '%ls' failed with error: Schema inference failed to parse type '%ls'.
%.*ls input argument should be a OPENROWSET BULK query which uses external extraction.
Execution service has shut down so performing distributed computation cannot be executed unless SQL is restarted
Master Key for CosmosDb collection %ls was not specified.
Failed to enqueue system background tasks during SQL server startup.
Terminating the %ls system task because of unrecoverable exception.
Type %ls of partition column %.*ls is not supported for external tables.
Operation '%ls %ls' failed. Retry the operation later.
IO operation failed during processing '%ls' in file '%ls' with error : '%ls'.
IO operation failed during processing file '%ls' with error : '%ls'.
Budget limit cannot be changed. Condition that must be satisfied: daily limit <= weekly limit <= monthly limit.
Cannot explicitly reference delimited text file columns by name unless OPENROWSET option HEADER_ROW is set to TRUE.
Error classification failed due to internal error, please contact support.
Cannot create or alter database.
Cannot bulk load. The file "%ls" does not exist or you don't have file access rights.
Cannot bulk load because the file "%ls" could not be opened.
Openrowset statistics are not supported on %ls.
You do not have required permission to execute '%ls'.
Operation failed since the external data source '%ls' has underlying storage account that is not in the list of Outbound Firewall Rules on the server. Please add this storage account to the list of Outbound Firewall Rules on your server and retry the operation.
Session context is not supported in distributed query execution.
A %ls with the name "%ls" already exists. Use a different name for resource.
%ls option is not supported.
%ls is not supported for specified file format.
The maximum reject threshold is reached.
Warning: Rejected rows encountered during execution.
Queries referencing variables are not supported in distributed processing mode.
CosmosDb query does not support given bulk options.
Credential with name '%.*ls' has not been found or you do not have the permission to access it.
Values in column %ls are formatted as JSON objects and cannot be written using CREATE EXTERNAL TABLE AS SELECT statement. Convert %ls column to a single VARCHAR or NVARCHAR column or a set of columns with explicitly defined types.
EXECUTE %ls. Warning: Stored procedures cannot be permanently stored in master database. Script procedure and create it in other database.
Bulk load data conversion error (truncation);%I64d;%d;%ls;%ls;%d;%ls.
Data conversion error (type mismatch or invalid character for the specified codepage);%I64d;%d;%ls;%ls;%d;%ls.
Bulk load data conversion error (overflow);%I64d;%d;%ls;%ls;%d;%ls.
Operation failed due to an error in a background task. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Operation failed due to an error while processing rejected rows. Intermediate results, if any, should be discarded as such results may not be complete. Please retry the operation. If the problem persists, contact Microsoft Azure Customer Support.
Operation for removing intermediate results failed while processing rejected rows. Intermediate results, if any, should be manually deleted.
Potential conversion error while reading VARCHAR column '%.*ls' from UTF8 encoded text. Change database collation to a UTF8 collation or specify explicit column schema in WITH clause and assign UTF8 collation to VARCHAR columns.
Potential conversion error while reading VARCHAR column '%.*ls' from UTF8 encoded text. Change database collation to a UTF8 collation or specify explicit column schema in WITH clause and assign UTF8 collation to VARCHAR columns.
CODEPAGE different than 65001 is not supported when CSV 2.0 is specified.
Column '%s' of type '%s' is not compatible with external data type '%s', please try with '%s'. File/External table name: '%ls'.
External table '%ls' is not accessible because content of directory cannot be listed.
External table '%ls' is not accessible because location does not exist or it is used by another process.
Format type '%.*ls' already exists.
Parser version '%.*ls' for format type '%.*ls' already exists.
CREATE DATABASE failed. User database limit has been already reached (%d).
A path in the Openrowset function cannot be empty.
Format '%.*ls' does not support extraction of file metadata only.
Output path for rejected rows is too long. Max length of the path is nvarchar(260).
Output path for rejected rows is too long. Max length of the path is nvarchar(1024).
Use Latin1_General_100_BIN2_UTF8 collation to leverage predicate pushdown optimization.
Unable to retrieve user token details for external computation.
Parser version '%.*ls' for format type '%.*ls' does not exist.
Some info messages might been dropped.
Query execution is canceled. Operation for removing intermediate results while processing rejected rows did not perform. Intermediate results, if any, should be manually deleted.
Arithmetic overflow error converting a value to data type '%ls'. File/External table name '%ls', column '%ls'. Please try with '%ls'.
Location provided by DATA_SOURCE '%.*ls' cannot contain any wildcards.
Number of wildcards in LOCATION must match the number of columns in PARTITION clause.
The column name '%.*ls' specified in the PARTITION option does not match any column specified in the columns list.
A column has been specified more than once in the PARTITION list. Column '%.*ls' is specified more than once.
Openrowset is not supported.
Cannot parse table options: %ls
Internal error led to query cancellation: [Diagnostics: '%.*ls']
The query must contain no more than %.*ls OPENROWSET columns.
Column '%ls' contains NULL values and cannot be used as PARTITION column.
Column '%ls' contains path delimiter and cannot be used as PARTITION column. The actual value is '%ls'.
Number of partition columns exceeds the maximum number of partition columns allowed which is %d.
Number of created partitions exceeds the limit. There are more than %d files created.
Virtual or partition columns found in Delta external table.
Virtual or partition columns not supported for Delta external table.
Invalid list of columns in PARTITION option. Only columns that expose wildcards are allowed and all such columns need to be listed.
Multiple logical file paths limit has been reached. Statement contains %ld logical file paths, maximum allowed limit is %d.
Warning: Unable to resolve path %ls. Error number %ld, Level %ld, State %ld, Message "%ls".
Warning: Maximum number of warnings reached (%ld). Please try resolving warnings and resubmit the query.
Path '%ls' was referenced multiple times in result set '%ls'.
Database name '%ls' is reserved. Choose a different database name.
The specified location is invalid: '%ls'.
The specified storage account does not have hierarchical namespace enabled.
Cannot access the specified location '%ls', because it does not exist or you do not have permission.
An error occurred while attempting to delete the specified location '%ls' (HRESULT = '0x%x').
A conflict operation on this LTR backup is still in progress.
LTR backup migration %ls feature is not supported on subscription '%ls'.
Copy LTR backup from source subscription '{0}' to target subscription '{1}' is not allowed.
A required parameter was not provided for LTR backup %ls operation. Missing parameter '%ls'
LTR Copy feature is not supported to copy LTR backups within same server.
LTR backup specified for LTR backup %ls operation does not exists.
Target server '%ls' not found or is not ready for LTR backup copy operation.
Target Database '%ls' not found on server '%ls' for LTR backup copy operation.
Failed to start LTR backup copy request in target region.
Specified Backup Storage Redundancy '%ls' is not supported in target region.
Active backup redundancy '%ls' of database '%ls' does not match the requested backup redundancy of LTR backup '%ls'.
LTR Migration requests are not supported for databases of type '%ls'.
Another LTR backup with same backup time for target database.
Copy operation failed for LTR backup blobs.
Restore verification failed after max attempts were reached. Last failure reason: %ls
Restore verification failed. Failure reason: %ls
LTR backup specified for LTR backup %ls operation does not exists.
Another LTR backup exist with same backup time for target database.
Changing backup storage redundancy is not allowed for LTR Copy operations.
LTR Backup Copy/Storage Update feature is not supported for Hyperscale Database LTR Backups currently.
LTR Migration not supported between source and target database with different is_ledger_on property.
CPU vectorization level(s) detected:  %ls
SQL server is started in a safe boot mode. No new connections can be created. This is informational message.
Failed to exit safe mode either becuase we are not in safe mode or due to an error.
Failed to boot database in safe mode.
The hardware offload configuration hasn't changed. No action is required.
The hardware offload configuration has been modified. Restart SQL Server for the new configuration to take effect.
This operation requires QAT libraries to be loaded.
Could not read data from replication table '%s'. If retrying does not fix the issue, drop and reconfigure replication.
Failed to create a database backup on a secondary replica for database "%.*ls.". Required information could not be committed on the primary replica. Check the health of the database in the SQL Server error log on the current primary replica. If the database is healthy, try the operation again.
Failed to create a database backup on a secondary replica for database "%.*ls.". The differential bitmaps could not be cleared and the checkpoint could not be run on the primary replica. Check the health of the database in the SQL Server error log on the current primary replica. If the database is healthy, try the operation again.
Failed to create a full backup on the secondary replica for database "%.*ls.". The primary database lock could not be acquired on the primary replica. Check the health of the database in the SQL Server error log on the current primary replica. If the database is healthy, try the operation again.
 Failed to initialize a full backup on the secondary replica for database "%.*ls.". Verify that the database is a member of the availability group, and then try again.
Failed to create a full backup on secondary replica for database "%.*ls.". The checkpoint could not be run on the primary replica. Check the health of the database in the SQL Server error log on the current primary replica. If the database is healthy, try the operation again.
Failed to create a database backup on secondary replica for database "%ls". The checkpoint LSN from primary replica could not be redone. Check the health of the database in the SQL Server error log on both primary and secondary replica. If the database is healthy, try the operation again.
The %ls operation is not allowed by the current availability-group configuration. The required_synchronized_secondaries_to_commit needs to be 0 when changing availability mode to ASYNCHRONOUS_COMMIT. Change required_synchronized_secondaries_to_commit to 0 and retry the operation.
System error.
System error.
System error.
System error.
System error.
System error.
System error.
System error.
System error.
System error.
System error: "%ls".
System error: '%.*ls', '%.*ls'.
System error: '%.*ls'.
System error: '%.*ls'.
System error: '%s'.
System error: '%s'.
System error.
System error.
System error: %s.
System error: %ld.
System error: %s.
1 row was rejected during query execution.
%ld rows were rejected during query execution.
Table manifest generation error.
An invalid synctoken was used for a reference fetch during attribute synchronization with an external governance engine.
A database was found with the wrong state during an external governance operation.
A database was not found during an external governance operation.
A schema was not found during an external governance operation.
A table was not found during an external governance operation.
A column was not found during an external governance operation.
The database registration was not found during an external governance operation.
The database registration attributes could not be obtained during an external governance operation.
An external governance operation was attempted on a database that differs from the current one.
The sensitivity classification DDL commands are disabled when a database is under external governance.
The references to the attribute synchronization data blobs must be in JSON format.
The references to the attribute synchronization data blobs must be in a JSON array.
A reference to the attribute synchronization data blobs must be a JSON object.
A reference to the attribute synchronization data blobs does not have the proper JSON format.
Malformed resource path.
A HTTP error occurred during attribute synchronization.
An attribute synchronization URL was not found.
Access forbidden to an attribute synchronization URL.
Invalid JSON for attribute synchronization data.
Cannot create attribute because it is missing information.
Invalid JSON format for classification attribute.
Unsupported attribute synchronization event.
Unsupported kind of synchronization attribute .
Cannot update synchronization attribute because version is older.
Cannot create HTTP client for attribute synchronization.
Cannot add more %s agent in MI, number of continuous mode agents has hit limits of %d. Otherwise some agents may not running due to desktop heap used up.
Cannot allow ReplDistpatcherUsers connect to NamePipe with error msg: %s
Internal Error: A expected large object wasn't found.
Invalid IAM chain encountered while dropping allocation unit.
[DbId: %d][FileId: %d] Could not obtain file add/remove latch to purge invalid file ranges before shrinking the file.
Lock ordinal population was aborted due to database exclusive waiter.
Forwarding of row [FileId: %d][PageInFile: %d][SlotId: %d] during logical revert failed due to insufficient space.
[DbId:%d] Sum of row sizes (%d) on page (%d:%d) exceeds maximum size of a page.
Could not find row version because it has been cleaned, this is due to transaction abort for some other reason on any node in the system where version is not required to be kept for aborted transaction.
Version cleanup was aborted for database id '%d' due to logical pause of db.
Internal Error: Tried to access an expired large object.
Failure to copy remote consolidated rowgroup blob HoBt id 0x%I64X, rowgroup id %d in database %d to Azure Block Blob Storage. Error code 0x%X.
: Encountered an unexpected error while trying to access a lob row (HRESULT = 0x%x).
An error occurred while writing remote column store segment HoBt 0x%I64X, Object %d, Column %d, Type %d in database %d. The segement could not be encrypted.
: Encountered an unexpected error while trying to access/update remote object (HRESULT = 0x%x).
An error occurred while writing remote rowgroup metadata HoBt 0x%I64X, Rowgroup %d,in database %d. The metadata could not be encrypted.
Could not process request due to internal error encountered during control node communication
: Encountered an unexpected error while trying to access/update fork entries (HRESULT = 0x%x).
Failed to retrieve Blob Conatiner info.
This operation cannot be preformed in this version of Database.
Cannot obtain a LOCK resource at this time due to internal error. Rerun your statement when there are fewer active users.
The provided transaction was not found.
Invalid nesting level for lock manager table.
Invalid nested transaction value for requesting lock.
An error occurred while releasing a lock with error code: %d state: %d severity: %d
An error occurred while requesting a lock with error code: %d state: %d severity: %d
An error occurred while releasing all locks for transaction id %d with error code: %d state: %d severity: %d
Cannot release locks for transaction %d as it has active nested transactions
This DDL statement is not supported in this version of SQL Server.
This statement cannot be executed in this version of Database.
Transaction manager already exists.
Transaction manager not found.
Transaction manager lock acquisition failure
Transaction manager address not initialized
Found a fatal inconsistency in Delta files.
Encountered error %lu during parsing of RowGroup metadata. Contact Technical Support.
Encountered unexpected error during physical catalog maintenance. Contact Technical Support.
The SQL instances has not been correctly setup to allow this operation. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Lock manager initialization failed.
Lock manager does not exist. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Lock manager shutdown failed.
Point in time can only be specified for a Read transaction.
The Database Controller required for this operation was not found. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Exceeded the resource limit on the number concurrent DDLs and active transactions. Please scale up to a higher SLO or reduce the workload on the SQL instance.
Logical Database Name was not provided
The handler for the work item does not exists.
Timed out while waiting for internal task to complete.
Lock manager client does not exist.
Lock manager client initialization failed.
Client initialization failed with error %d.
Transaction context encode failed with error %d
Transaction context decode failed with error %d and size %d.
Database '%ls' configuration '%ls' not found.
Failed to start an async task to sync the physical catalog.
The satement failed due to an internal error while retrieving the query text.
Background task failed.
Lock release failed due to an internal error. Check the errorlog for more information.
DDL statements are not allowed in User transactions.
An operation that requires a feature to be enabled was started, but the feature is disabled. Aborting. Contact support for assistance.
Invalid Transaction context while requesting lock.
Transaction abort sequence number entry not found in cache
DW Temp Table Creation Fail
Failed to acquire the data update lock for DB Id '%ls'.
Updating the rowcount of a distributed table is not allowed unless trace flag 12127 is enabled. Rerun the statement by enabling the said trace flag.
Fido GLM remote execute command failed.
Transport DBM endpoint not available.
Transport not initialized.
DDL statements cannot cross DB boundaries.
The statement could not be serialized. Please try again.
Transport UCS connection string resolve failed.
Transport get response failed.
Failed to start the client sync thread during manager startup.
Transaction Action failed with error 0x%x.
Database name '%.*ls' is not allowed in this edition of SQL.
Background task queue failed.
Background task discovery failed.
Background task failed with error: %d, state: %d and message: '%ls'.
Failed to start the Server due to error %d. Check errorlog for more info.
Failed to start database '%ls' as it already exists.
Encountered exception when executing DBCC command.
Attempt to concurrently modify index [%ls].[%ls] row with Key %ls by multiple transactions '%I64d', '%I64d'.
Failed to set the drop time of object: '%I64d' as its create was not tracked. TxnId %I64d.
Failed Update TxnId of object: '%I64d' by TxnId %I64d. Old TxnId %I64d.
Failed to open internal table.
A NULL or unexpected value was retured by a remote call.
Unexpected operation performed on an internal table.
Failed to Register Database '%ls' in master.
Bulk insert bucketization failed.
Failed to Sync Database '%ls' to Server.
Failed to acquire DW transaction lock.
Severe error occured. Error:%d, State:%d.
Table '%.*ls' does not exist.
Validations failed for the internal task handler.
Transaction got aborted due to unexpect situation.
Transaction Manager fail to create schema
Resource manager lock acquisition failure
Resource manager not found.
An error occurred while releasing all locks for transaction id 0x
An error occurred while releasing all locks for transaction id 0x
An error occurred while commit transaction id 0x
An error occurred while rollback transaction id 0x
An error occurred while begin transaction, transaction options = %d, HRESULT = 0x%08X
An error occurred while get list, transaction id 0x
Changes in encryption are not allowed on this database type if tables are present. Please drop all tables and try again.
Failed to initialize a remote connection for an internal component.
%ls is not a supported statement type.
%ls is not a supported option in %ls statement.
Failed to get the client id from the Resource Manager.
Operation failed due to an error in a background task.  Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Failed to Begin a new transaction as a valid one already exists. Please Commit or Rollback the existing transaction before starting a new one.
Dropping multiple objects including Temp table is not supported in this version of SQL Server
Operation failed as the Database '%.*ls' is shutting down. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
You must have a compute pool provisioned in order to enable encryption. Create a compute pool and try again.
Failure in the compression engine. If the problem persists contact Microsoft Azure Customer Support.
An error occurred while set transaction token, HRESULT = 0x%08X
An inconsistency was detected while enumerating files for the database. If the problem persists contact Microsoft Azure Customer Support.
Catalog sync failed while updating system tables for [%I64d] database, rowset [%I64d], directory [%I64d], rowgroup [%I64d]. Used by failpoints.
This operation is not supported in this Database Version.
Failed to find a valid TxnId of object: '%ld'
Can't set retention policy on an invalid object id: '%ld'
Internal error. Unable to load database settings.
An error occured while timestamp conversion, please provide correct format in the form yyyy-mm-ddThh:mm:ss
An error occurred while begin transaction, requested point in time not found '%ls'
Point in time not supported for this statement type
ALTER TABLE RANGE statement failed. The specified table '%.*ls' is not partitioned.
ALTER TABLE RANGE statement failed. The specified range must not be 'NULL'.
This DML statement is not supported in this database version.
DeltaForce encountered an operational exception.
Internal table IQ_CATATLOG_OBJECTS_TABLE error.
An error occured while updating the data encryption key.
The reencryption task encountered a blob that was already encrypted.
An error occured with clone with message '%ls'.
An error occurred while initializing resource manager
Index quality DMV got invalid arguments.
Unable to get remote storage space usage: Error: %d, Severity: %d, State: %d, Line: %d '%s'
Internal error. Encryption scan was aborted.
A SERVICE_OBJECTIVE must be specified when creating a Synapse pool.
Pool '%.*ls' does not exist. Make sure that the name is entered correctly.
DBCC command failed with error : '%.*ls'.
Cannot specify a temporary object (i.e., View, Table or Stored Procedure) in a rename statement.
The metadata backup path was incorrectly formatted.
Index store client does not exist.
%ls is not supported for %ls.
Encountered exception during generation of script for clone.
Increase rowset blob directory generation id failed
Database collation name '%.*ls' is not valid.
Failed to clean up rows for object: '%d'. (HRESULT = 0x%x)
Connection to reserved databases are not allowed.
Failed complete data warehouse maintenance operation. See telemetry for more details.
The metadata backup failed.
Failed to update metadata of cloned table
Rowset info is not correct, please check the following info: %ls
Failed to serialize source table directory info
The supplied T-SQL statement is too long. The maximum allowed length is 4000 characters.
%ls is allowed only when connected to the logical master of a Synapse workspace.
DBCC CHECKIDENTITY with NORESEED is not supported in Azure Synapse Analytics
Failed to set the undrop time of object: '%I64d' as it was not found or drop was not tracked. TxnId %I64d.
Toad index tuning policy check failed.  See other errors and telemetry for details.
The period of %ld %S_MSG is too big for data retention.
Retention Policy is not supported on temporary table
Failed to Alter Column as a concurrent Alter Column transaction has been detected.
Creating or altering table '%.*ls' failed because its maximum row size exceeds the allowed maximum of %d bytes including %d bytes of internal overhead.
Creating a Synapse SQL pool with name '%ls' is not allowed as it is a reserved system name. Please choose another name for your Synapse SQL pool.
%ls is an invalid name for a pool. Please make sure that it begins with a lowercase letter, consists only of lowercase letters, numbers, or hyphens ('-'), and does not end with a hyphen. The length cannot exceed 60 characters.
MAX_SERVICE_OBJECTIVE '%ls' cannot be less than or equal to SERVICE_OBJECTIVE '%ls'.
MAX_SERVICE_OBJECTIVE '%ls' cannot be more than '%ld' times the value of SERVICE_OBJECTIVE '%ls'.
'%ls' is an invalid name for a pool as it contains profanity. Please choose a different name for your pool.
Get directory info failed
%ls is allowed only when connected to Synapse frontend.
A WORKLOAD_GROUP must be specified when creating a Synapse workload classifier.
START_TIME and END_TIME must be specified together when creating a Synapse workload classifier.
Invalid data requested from database completed requests table.
The DDL statement failed due to an internal error. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
Unable to perform operation as the data provided is invalid.
The database '%.*ls' failed to sync. Please retry the operation again. If the problem persists contact Microsoft Azure Customer Support.
There is already an object named '%.*ls' in the temp db.
%ls is allowed only when connected to Synapse frontend.
The client sync failed with a request to retry the operation again.
Redo of Block %I64d.%I64d on Database [%ls] failed with error '%.*ls'.
There is not enough resources to perform the operation. Please retry your operation later.
An error occured when looking for clone container: '%ls'.
Cannot run this stored procedure as Change Feed feature is not enabled.
Caller is not authorized to initiate the requested action. Only members of the db_owner fixed database roles can perform this operation.
Could not enable Change Feed for database '%s'. Change Feed is not supported on system databases, or on a distribution database.
Could not enable Change Feed for database '%s'. Change Feed can not be enabled on a DB with Change Data Capture or transactional replication publishing.
Could not enable Change Feed for database '%s' as it is already enabled.
Change Feed is not enabled on database '%s'.
The specified database scoped credential name can't be found. It must have the identity of 'SHARED ACCESS SIGNATURE'
The specified database scoped credential name does not match the landing zone URL path
Parameter '%s' cannot be null or empty. Specify a value for the named parameter and retry the operation.
Could not update the metadata. The failure occurred when executing the command '%s'. The error/state returned was %d/%d: '%s'. Use the action and error to determine the cause of the failure and resubmit the request.
The specified table group can't be found in the current database.
The application lock request '%s' needed to modify Change Feed metadata was not granted. The value returned from the request was %d: -1 = timeout; -2 = canceled; -3 = deadlock victim; -999 validation or other call error. Examine the error cause and resbmit the request.
The value for parameter @maxtrans specified must be greater than 0.
Tables contained in the changefeed schema cannot be enabled for Change Feed.
Enabling Change Feed for a temporal history table '%ls' is not allowed.
Can not enable Change Feed on table '%s' or add ColumnSet column to it because Change Feed does not support ColumnSet.
A memory-optimized table cannot be enabled for Change Feed.
Change Feed is already enabled on source table '%s.%s' with link table id '%s'. A table can only be enabled once among all table groups.
Enabling Change Feed on a table with primary key on computed column is not allowed.
Enabling Change Feed on a table without primary key is not allowed.
Can not enable Change Feed on a table with primary key whose columns' type are user-defined types, geometry, geography, hierachyid, sql_variant or timestamp
Cannot enable Change Feed on a table with encrypted columns.
Cannot find an object ID for the Change Feed system table '%s'. Verify that the system table exists and is accessible by querying it directly. If it does not exist, drop and reconfigure Change Feed.
Error occured while exporting initial snapshot to landing zone.
Enabling Change Feed for a ledger history table '%ls' is not allowed.
Could not allocate memory for Change Feed operation. Verify that SQL Server has sufficient memory for all operations. Check the memory settings on the server and examine memory usage to see if another application is excessively consuming memory.
Failed to load load landing zone library with error %d. Verify that SQL Server is installed properly.
Could not disable table because it is no longer enabled for table group.
Could not remove the metadata. The failure occurred when executing the command '%s'. The error/state returned was %d/%d: '%s'. Use the action and error to determine the cause of the failure and resubmit the request.
Could not disable Change Feed for database '%s' as it is already disabled.
Error occured while publish incremental data to landing zone.
Invalid change feed table state.
Change Feed snapshot was cancelled.
Error occured while process Change Feed on database %d.
Error occured while update Change Feed table status for table %ld.
Error occured while interacting with landing zone.
Can not enable Change Feed on a table where the columns' data type are user-defined types, geometry, geography, hierachyid, sql_variant or timestamp
Can not enable Change Feed on a table with computed columns.
Error occured while trying to retrieve storage info from Synapse Gateway Service with result code %d.
Parameter '%s' is invalid. Specify a valid value for the named parameter and retry the operation.
Landing Zone parameter is not valid on Azure Database.
Schema changes on table '%s' are not supported because it is enabled for change feed.
There is an issue with cleaning up metadata of some of the table groups of this database.  Retry by dropping the table groups first and then disable Change Feed on the database.
Cannot disable primary key index "%.*ls" on table "%.*ls" because the table has change feed enabled on it.
Cannot alter the table '%.*ls' because it has change feed enabled on it.
Change Feed
Another connection with session ID %I64d is already running 'sp_replcmds' for Change Feed in the current database.
Change Feed task is being aborted.
Cannot rename the table because it is being used for Change Feed
ALTER TABLE SWITCH statement failed because the partitioned destination table is enabled for Change Feed.
ALTER TABLE SWITCH statement failed because the partitioned source table is enabled for Change Feed.
Snapshot DATA_EXPORT query failed.
The number of tables enabled for a Change Feed table group can not exceed %d. Current number of table enabled: %d.
Aborting Synapse Link Capture task for this database timed out.  Retry this operation later.
Change Feed is not supported on Free, Basic or Standard tier Single Database (S0,S1,S2) and Database in Elastic pool with max eDTUs < 100 or max vCore < 1. Please upgrade to a higher Service Objective.
The elastic pool cannot lower its service tier with database max eDTUs < 100 or max vCore < 1 since one or more of its database(s) use Change Feed.
The database cannot lower its service tier to Standard(S0,S1,S2), Basic or Free, or move to elastic pool with database max eDTUs < 100 or max vCore < 1 since it has Change Feed enabled.
Aborting Synapse Link Commit task for table group '%s' timed out.  Retry this operation later.
Aborting Synapse Link Snapshot task for table %ld timed out.  Retry this operation later.
Aborting Synapse Link Publish task for partition %ld timed out.  Retry this operation later.
Failed to cleanup previous change feed setup. Please try the operation again. If the problem persists contact Microsoft Azure Customer Support.
Cannot enable '%S_MSG' on '%s' because it is being used for '%S_MSG'.
Replication: Distribution
Replication: transactional or snapshot publication
Replication: merge publication
Change Data Capture is not supported on Free, Basic or Standard tier Single Database (S0,S1,S2) and Database in Elastic pool with max eDTUs < 100 or max vCore < 1. Please upgrade to a higher Service Objective.
The elastic pool cannot lower its service tier with database max eDTUs < 100 or max vCore < 1 since one or more of its database(s) use Change Data Capture (CDC).
The database cannot lower its service tier to Standard(S0,S1,S2), Basic or Free, or move to elastic pool with database max eDTUs < 100 or max vCore < 1 since it has Change Data Capture (CDC) enabled.
Cannot set @enable_extended_ddl_handling parameter to 1 as this feature is not enabled.
Capture instance name '%s' exceeds the length limit of 78 characters when @enable_extended_ddl_handling is enabled. Specify a name that satisfies the length constraint.
One capture instance already exist with DDL handling enabled for source table '%s.%s'. A table can have only one capture instance with DDL handling enabled. If the current tracking options are not appropriate, disable change tracking for the obsolete instance by using sys.sp_cdc_disable_table and retry the operation.
All columns are not captured for source table '%s.%s' when using DDL handling feature. DDL handling feature is only supported when all columns are captured in CT table. If user wants to use DDL handling feature then enable CDC on a table without the parameter @captured_column_list or pass NULL for this parameter, this is will by default capture all columns.
Could not enable Change Data Capture for database '%s'. Change Data Capture cannot be enabled on a DB with Change Feed enabled.
Could not alter captured column of a CDC tracked table with character/binary/unicode as target data type with ansi warnings turned off.
Update mask evaluation will be disabled in net_changes_function because the CLR configuration option is disabled.
Internal error when retrieving lock information. Please try the operation again. If the problem persists contact Microsoft Azure Customer Support.
Failed to get db lock with error %d during redo operation.
Could not get clone tx ctx. Please try the operation again. If the problem persists contact Microsoft Azure Customer Support.
Alter of System table Columns are not allowed.
Table '%.*ls' already exists. Choose a different table name or rename the existing table.
Failed to find a TSRBRowGroupObject from the in-memory list
Index quality generation was aborted due to server shutdown.
The DB Version upgrade cannot modify user created data and metadata.
The DB Version upgrade cannot modify user created data and metadata. Index [%.*ls].[%.*ls] row with Key %ls was created by transactions '%I64d'.
Index maintenance operation complete:  %d actions completed successfully in %d iterations with %d non-retriable errors and %d retriable errors encountered.  Successful work performed by this command has been committed.  If failures have occurred, please retry the command at a later time.
Cache db version too low
The requested SLO (%ls) for this pool exceeds the maximum allowed SLO (%ls).
You have already reached the limit of %ld SQL pools in this workspace.
You have already reached the limit of %ld SQL pools in this subscription.
Sum of SLOs for all pools in this workspace (%ls) plus the requested SLO for the new pool (%ls) exceeds the limit (%ls).
Sum of SLOs for all pools in this subscription (%ls) plus the requested SLO for the new pool (%ls) exceeds the limit (%ls).
The user provided a disallowed value for %ls for Auto-Pause. The value provided is %ld. The value must be between [%ld, %ld] or 0 (zero).
Internal error when resolving the DW temp table name during statement execution. Please try the operation again. If the problem persists contact Microsoft Azure Customer Support.
The metadata log for the database '%.*ls' is corrupted at Block '%I64d' RecordId '%I64d'.
The metadata log Block '%I64d' for the database '%.*ls' is not valid.
Read of the metadata log Block '%I64d' for the database '%.*ls' failed. Check errorlog for more info.
The metadata log Block was flushed to disk but the trnasaction aborted.
Failed to read or write the Max ASN data (HRESULT = 0x%x).
Internal error. Unable to gain access to the manifest file table. Result [%x]
Internal error. Unable to insert record to the manifest file table. Result [%x]
Internal error. Encounter unexpected error while writing manifest file
Attempt to commit the block list for a manifest file blob failed. Blob Prefix is "%ls", Blob name is "%ls". Storage Errorcode %ld.
Invalid number of arguments passed to unit test '%ls'.
Target '%.*ls' is not available on SQL Database Managed Instance.
Event '%.*ls' is not available on SQL Database Managed Instance.
Action '%.*ls' is not available on SQL Database Managed Instance.
Auto start XE sessions are disabled.
XE session '%s' started.
XE session '%s' stopping.
A Attn token is received, the session id is '%d', No user action is required.
Failed to schedule asynchronous resume fulltext crawl task for database id %d with error %d.
The size of the provided %ls is %u bytes, which exceeds the maximum allowed size of %u bytes.
Received param '%.*ls' successfully.
Received param '%d' successfully.
The value '%d' is not within range for the '%.*ls' parameter.
The specified method '%.*ls' is not supported.
Serializing payload value failed
Outbound connection not allowed for the specified external endpoint.
An error occurred, failed to communicate with the external rest endpoint. HRESULT: 0x%x.
An error occurred, failed to parse url. HRESULT: 0x%x.
Accessing the external endpoint is only allowed via HTTPS.
The response's headers size is %u bytes, which exceeds the maximum allowed size of %u bytes.
Connections to the domain %ls are not allowed.
The length of the provided %ls after percent-encoding is %u, which exceeds the maximum allowed length of %u bytes.
Only alphanumeric characters, hyphens, underscores, and dots are allowed in the hostname or in the fully qualified domain name.
The %ls cannot contain nested structures. Please check the formatting of the JSON and try again with a flat structure.
Warning: header '%ls' was overwritten by a system-defined value.
The %ls contains invalid characters. Only printable US ASCII characters are allowed.
The %ls contains an empty key.
The %ls could not be parsed. jsonError = %d.
The %ls is not a json object datatype.
One of the %ls values could not be parsed.
An unexpected error occurred during validating that the connection is allowed to the hostname. See 'https://aka.ms/sqldb_httpinvoke_errordetails' for assistance.
Connection to the external endpoint IP is not allowed. URL contains a hostname that is resolved to a blocked IP. See 'https://aka.ms/sqldb_httpinvoke_errordetails' for assistance.
DNS resolution of the hostname has failed with windows sockets error %d.
An out of memory exception has occurred during external endpoint invocation.
The database scoped credential '%.*ls' has an invalid identity '%.*ls' for use with an external rest endpoint.
The external rest endpoint execution exceeded the timeout value.
There was an error configuring the log shipping backup server. The primary_server_with_port_override is set to '%s'. It is only valid on a contained availability group
Secret provided can not contain more than 120 characters. Please provide a valid credential.
Cannot update database encryption key protector while protector change is already in progress.
The connection has been flow controlled in the last %d seconds for a period of %d seconds. The connection is extensively flow controlled and is being closed.
Cannot enable Change Feed on the FileTable '%ls'. Change Feed is not supported for FileTable objects.
Cannot create server audit with GUID '%s' in this version of SQL Server: Please specify another GUID value.
Specifying a private key file or binary is not allowed when importing or exporting a certificate using the PFX format.
WITH PRIVATE KEY must be specified when importing or exporting a certificate using the PFX format.
Invalid certificate encoding FORMAT value provided. The supported values are 'DER' and 'PFX'.
The specified PFX file or the binary literal cannot be imported as it contains multiple certificates.
The specified file or the binary literal is not supported as it does not contain a private key.
Could not find Azure AD principal mapping to Windows principal '%ls'.
Found multiple Azure AD principals mapping to Windows principal '%ls'.
Windows principal '%ls' does not map to provided Azure AD principal '%ls', please use a different Azure AD principal.
Internal enclave error. Enclave was provided with an invalid expression handle. For more information, contact Customer Support Services.
Database encryption scan for database '%.*ls' was suspended. Reissue ALTER DB to resume the scan.
ALGORITHM has an invalid value. The allowed values are '%ls', '%ls'.
The underlying operating system does not support encrypting private keys using '%ls'. Consider using '%ls'.
Specifying ALGORITHM is not allowed when exporting a certificate using the DER format.
ALGORITHM must be specified when exporting a certificate using the PFX format. The supported algorithms are '%ls', '%ls'.
The session context key '%s' is too long. Maximum allowed length of session context key is %d characters.
Maximum number of session context keys used for audit specification has been exceeded. The maximum allowed number of keys is %d.
Operator Audit option is not supported for this target type, use EXTERNAL_MONITOR target.
The private key password is invalid, or the file was encrypted with an algorithm not supported by the underlying operating system.
Valid values of the database compatibility level are %d, %d, %d, %d, %d, or %d.
Cannot bulk load file split because either secret or file_properties option is missing.
Error related to '%ls' where one of participants is Azure SQL Managed Instance.
'%ls' feature where one of participants is Azure SQL Managed Instance is disabled.
Deprecated feature '%ls' with Azure SQL Managed Instance as a participant is not supported in this version of SQL Server.
Tuple mover stvf skipped rowset in DW mode
During migration to rowgroup consolidation, distribution type extended property must be set on the CCI table.
Could not create columnstore index '%.*ls' on table '%.*ls' since data type of column '%.*ls' is not supported in the ORDER list.
Columnstore tuple mover is unable to acquire lock.
TRIPLE_DES_3KEY
AES_256
STATISTICS_ONLY
striped_metadata
rbio_connection
Maximum number of concurrent DBCC commands running in the enclave has been reached. The maximum number of concurrent DBCC queries is %d. Try rerunning the query.
Configuring Always Encrypted enclave in %ls mode.
%ls enclave lost due to internal error. For more information, contact Customer Support Services.
Failed to acquire a token using a managed service identity. Make sure managed identities are enabled on the machine hosting SQL Server. Authentication method: %ls, Return code: '0x%08x'. Validate that Azure Active Directory Identity as been assigned to this server. For more information, contact Customer Support Services
DevOps login, '%s', can not be created as another non-devops server principal with name or object ID already exists.
DevOps user, '%.*ls', can not be created as another non-devops database principal with name or object ID already exists.
The server encountered an unexpected exception. API:'%ls' Return code: '0x%08x'. For more information, contact Customer Support Services.
Internal error occurred while obtaining an authentication token for an external service. Authentication method: %ls, Status: 0x%08x, CorrelationId: %ls.
Failed to acquire a token using a managed service identity. Make sure managed identities are enabled on the machine hosting SQL Server. Authentication method: %ls, Return code: '0x%08x', CorrelationId: %ls. Validate that Azure Active Directory Identity as been assigned to this server. For more information, contact Customer Support Services
Failed to flush the Ledger Transactions table to disk in database with ID %d due to error %d. Check the errorlog for more information.
Failed to retrieve the information about the latest transaction persisted in sys.db_ledger_transactions in database with ID %d due to error %d. Check the errorlog for more information.
Error occurred while generating the hash for a ledger transaction. Return code: '%d'.
Error occurred while generating a hash for the MERKLE_TREE_AGG aggregate function. Return code: '%d'.
Failed to generate the Ledger Blocks in the database with ID %d due to error %d. Check the errorlog for more information.
Azure Active Directory Administrator is not enabled for this server. Please set up the AAD Admin on this server and try again.
The logical server AAD tenant ID does not match the given devops AAD tenant ID.
Unexpected data type for encrypted column while generating ledger hash.
CREATE TABLE failed because column '%.*ls' in table '%.*ls' exceeds the maximum of %d columns allowed for ledger tables.
Table cannot have more than one 'GENERATED ALWAYS AS %ls' column.
'GENERATED ALWAYS AS %ls' column '%.*ls' has invalid data type.
'GENERATED ALWAYS AS %ls' column '%.*ls' cannot be nullable.
'GENERATED ALWAYS AS %ls' column '%.*ls' can only be nullable.
LEDGER = ON cannot be specified with SYSTEM_VERSIONING = OFF and APPEND_ONLY = OFF.
LEDGER = ON cannot be specified with SYSTEM_VERSIONING = ON and APPEND_ONLY = ON.
LEDGER = ON cannot be specified with PERIOD FOR SYSTEM_TIME and APPEND_ONLY = ON.
APPEND_ONLY = ON cannot be specified with generated always end columns.
Server identity does not have Azure Active Directory Readers permission. Please follow the steps here : https://docs.microsoft.com/en-us/azure/azure-sql/database/authentication-aad-service-principal
LEDGER = ON cannot be specified with system versioning retention period.
An existing History Table cannot be specified with LEDGER=ON.
System Versioning cannot be altered for Ledger Tables.
SQL Audit could not write to '%s'. Make sure that SAS key is valid or Managed Identity has permissions to access the storage. This is an informative message. This error doesn't affect SQL availability.
SQL Audit failed to create the audit file for the audit '%s' at '%s'. Make sure that SAS key is valid or Managed Identity has permissions to access the storage. This is an informative message. This error doesn't affect SQL availability.
Updates are not allowed for the append only Ledger table '%.*ls'.
%S_MSG is not allowed on Ledger tables.
Cannot update ledger history table '%.*ls'.
LEDGER = ON cannot be specified on a table with a column set column.
Copy operation for the database '%.*ls' on the server '%.*ls' cannot be started because both source and target SLOs need to be DC series. Source DB SLO: '%.*ls' , Partner DB SLO: '%.*ls'
A transaction cannot update more than %d ledger tables.
The '%s' parameter provided for ledger verification cannot be null.
The hash computed from sys.database_ledger_transactions for block %I64d does not match the hash persisted in sys.database_ledger_blocks.
The computed hash does not match the previous block hash persisted in sys.database_ledger_blocks for block %I64d.
The hash of block %I64d in the database ledger does not match the hash provided in the digest for this block.
Invalid input for parameter '@digests' provided for ledger verification. The value should be a valid JSON document that contains values for the 'block_id' and 'hash' of each digest.
Ledger verification successfully verified up to block %I64d.
The computed hash from '%s' and the associated history table does not match the hash persisted in sys.database_ledger_transactions for transaction %I64d.
Invalid table ID '%d' is present in databse ledger table sys.database_ledger_transactions.
Error occurred while initializing hash algorithm at startup. Return code: '%d'.
Creation of Ledger view failed due to error %d.
Cannot add PRIMARY KEY, UNIQUE KEY or CHECK constraint to the ledger history table '%.*ls'.
Foreign key '%.*ls' is not valid. A ledger history table cannot be used in a foreign key definition.
Foreign key '%.*ls' is not valid. An append only ledger table cannot be the referencing table of a foreign key constraint with cascading actions.
Ledger tables cannot be created on system databases.
Ledger tables cannot contain columns of XML, sql_variant, filestream or user-defined types. Any computed columns cannot be timestamp columns.
Cannot create UNIQUE index on ledger history table '%.*ls'.
Cannot create a trigger on a system-versioned ledger table '%.*ls'.
Switching partition failed on table '%.*ls' because it is not a supported operation on ledger tables or their corresponding history table.
Enabling Change Tracking for a ledger history table '%.*ls' is not allowed.
Table '%.*ls' is a FileTable. LEDGER = ON cannot be used on FileTables.
LEDGER = ON is not allowed for table variables.
Cannot drop object '%.*ls' because it is a ledger history table or a ledger view.
Only nullable columns without a default value WITH VALUES can be added to ledger tables.
Column '%.*ls' in table '%.*ls' cannot be dropped because it is already a dropped ledger column.
Cannot ALTER VIEW '%.*ls' because it is a ledger view.
System-time PERIOD cannot be added to table '%.*ls' because it is a ledger table.
ALTER TABLE ALTER COLUMN failed for table '%.*ls' because it is a ledger table and the operation would need to modify existing data that is immutable.
Ledger verification failed.
The default ledger view name is constructed as <table_name>_Ledger, which exceeds the maximum length of %d characters. Specify a ledger table name that is %d characters or less, or specify a user-defined ledger view name that is %d characters or less.
Cannot create index on view '%.*ls' because it is a ledger view. The indexes should be created on the ledger table or its history table.
View '%.*ls' is not updatable because it is a ledger view.
Query cannot be executed, access token is expired. Please login with a new access token and execute query again.
Error storing Babylon policy for DBID %d. Major error: %d, Minor error: %d, State: %d
Fatal error: Unable to pull policies for %d consecutive attempts. Shutting down SQL.
TYPE, SID, Default Database, Default Language, Password option not allowed for External logins
Error refreshing the external access control policy from metadata. Error code %d.
Setting LEDGER to ON failed because ledger view '%.*ls' is not specified in two-part name format.
Error in parsing Babylon json policy element/event with error message %s.
Service returned an empty response. URL: '%ls'.
Exception in fetching the policy from Purview. URL: '%ls'. Major error code: %d, Minor error code: %d, State: %d
Error occurred while obtaining an authentication token for external service %ls; no authentication method is configured.
Error in Babylon SDK with error message %s.
The ledger digest storage cannot be configured on secondary databases.
The provided Ledger storage target type '%s' is invalid.
The provided ledger storage path '%s' is invalid.
Uploading ledger digests is being enabled or disabled for database '%s'. Please wait for the previous request to complete.
%ls operation failed for %ls. Error code: %d.
Failed to generate a digest in the database with ID %d due to error %d. Check the errorlog for more information.
Failed to retrieve digest information from path '%ls' due to error %d. Verify that the provided path exists and the required permissions have been granted to the SQL service.
Invalid path specified for a ledger digest URL. Verify that the provided paths are valid.
Fulltext indexes are not allowed on ledger tables.
Uploading ledger digest failed for database with id %d due to error %d.
No digests were found based on the input locations and block IDs.
Unable to %S_MSG audit because %S_MSG contains question mark.
LEDGER = OFF cannot be specified for tables in databases that were created with LEDGER = ON.
Error occurred while reading Purview Policy Endpoint.
Error occurred while reading STS Url.
Error occurred while fetching the TenantId.
Error fetching the Purview Resource Endpoint.
Error occurred while trying to record the ledger table history operation of the ledger table '%.*ls'.
Error occurred while trying to record the ledger column history operation of the column '%.*ls' in ledger table '%.*ls'.
Cannot alter, drop, or rename object '%.*ls' because it is a ledger dropped object.
Cannot rename ledger object '%.*ls' because it is not a supported operation.
Cannot rename column '%.*ls' of ledger object '%.*ls' because it is not a supported operation.
Cannot alter schema of dropped ledger object '%.*ls' because it is not a supported operation.
Encountered failure while initializing Confidential Ledger Adapter with URL %ls and error code %ld.
Encountered failure while initializing Confidential Ledger Data Iterator with URL %ls and error code %ld.
%ls. The attestation URL specified by the client is not reachable. URL: '%ls'. Return code: '0x%08x'. Check your networking configuration.
Invalid input for parameter '@locations' provided for ledger verification. The value should be a valid JSON document that contains values for the 'path', 'last_digest_block_id' and 'is_current' of each location.
Invalid input for parameter '@table_name' provided for ledger verification. The specified value cannot contain a server or database name and must point to an existing ledger table.
Ledger verification failed due to error %d.
Uploading ledger digests is currently not supported for this resource type.
Ledger verification for table '%.*ls' failed because its clustered index is disabled.
The statement failed because a nonclustered index cannot be created on table '%.*ls' that is a ledger table and has a clustered columnstore index.
Cannot update dropped ledger table '%.*ls'.
The statement failed because a clustered columnstore index cannot be created on table '%.*ls' that is a ledger table and has a nonclustered index.
Ledger verification was aborted by the user.
The use of replication is not supported with ledger table '%s'
Enabling Change Data Capture for a ledger history table '%ls' is not allowed.
The specified digestStorageEndpoint is invalid. It must be an Azure blob storage or Azure Confidential Ledger endpoint.
Changing the ledger property is not supported for this resource type.
Error while trying to invoke Purview policy pull task.
'%ls' is not a valid option for the @type parameter. Enter 'update' or 'reload'.
Encountered Internal Error while calling %ls. Error code %ld, State %ld.
Server identity does not have permissions to access MS Graph.
DDL statement executed on the database is not allowed because Azure Active Directory only authentication is enabled on the server.
Posted digest is not globally committed in Azure Confidential Ledger. Ledger URL '%ls' and error code %ld.
Encountered Internal Error while calling Azure Confidential Ledger. Ledger URL '%ls' and error code %ld.
Failed to parse response from Identity Service. Ledger URL '%ls' and error code %ld.
Encountered error while trying to retrieve AAD Token to call Azure Confidential Ledger. Ledger URL '%ls' and error code %ld.
Encountered error while trying to retrieve Network Certificate from Identity Service. Ledger URL '%ls' and error code %ld.
Service Principal or Managed Identity is not authorized to call Azure Confidential Ledger. Ledger URL '%ls' and error code %ld.
AAD Authentication is enabled. This is an informational message only; no user action is required.
Server identity does not have the required permissions to access the MS graph. Please follow the steps here : https://aka.ms/UMI-AzureSQL-permissions
Endpoint is required.
The server encountered an unexpected exception.
The source and target table names provided as parameters to 'sp_copy_data_in_batches' must be valid table names and cannot be null or empty.
The source and target table names provided as parameters to 'sp_copy_data_in_batches' cannot contain a database or server name.
The source and target tables provided to 'sp_copy_data_in_batches' must be user tables.
The source and target tables provided to 'sp_copy_data_in_batches' cannot be memory optimized tables.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot be the source of merge or transactional replication or have change tracking or change data capture enabled.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have an XML, spatial or fulltext index.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have a disabled clustered index.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have any non-clustered indexes or statistics other than the ones for the clustered index.
The source and target tables provided to 'sp_copy_data_in_batches' cannot have a column set column.
The source and target tables provided to 'sp_copy_data_in_batches' cannot have any security policies.
The source and target tables provided to 'sp_copy_data_in_batches' cannot be graph node or edge tables.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have any indexed views referencing it.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' must be empty.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have any INSERT trigger.
The source and target tables provided to 'sp_copy_data_in_batches' must be using the same partition function and partitioning columns.
The source and target tables provided to 'sp_copy_data_in_batches' must have the same number of columns when excluding the TRANSACTION ID and SEQUENCE NUMBER generated always columns.
'sp_copy_data_in_batches' failed because column '%.*ls' at ordinal %d in table '%.*ls' has a different name than the column '%.*ls' at the same ordinal in table '%.*ls' (excluding the TRANSACTION ID and SEQUENCE NUMBER generated always columns).
'sp_copy_data_in_batches' failed because column '%.*ls' has data type %s in source table '%.*ls' which is different from its type %s in target table '%.*ls'.
'sp_copy_data_in_batches' failed because column '%.*ls' does not have the same collation, nullability, sparse, ANSI_PADDING, vardecimal, identity or generated always attribute, CLR type or schema collection in tables '%.*ls' and '%.*ls'.
'sp_copy_data_in_batches' failed because column '%.*ls' in table '%.*ls' is computed column but the same column in '%.*ls' is not computed or they do not have the same persistent attribute .
The source and target tables provided to 'sp_copy_data_in_batches' cannot contain columns of data type text, ntext, image or with the ROWGUIDCOL or FILESTREAM attributes.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have any RULE constraints.
'sp_copy_data_in_batches' failed because computed column '%.*ls' defined as '%.*ls' in table '%.*ls' is different from the same column in table '%.*ls' defined as '%.*ls'.
The target table '%.*ls' provided to 'sp_copy_data_in_batches' cannot have clustered columnstore index.
The source and target tables provided as parameters to 'sp_copy_data_in_batches' cannot be temporary tables.
Internal enclave error: Cannot initialize the %ls enclave. Load method: %ls. Last Error: 0x%08x. For more information, contact Customer Support Services.
Authentication bearer service failed to return a valid challenge. Verify URL '%ls' is correct and reachable. Return code: '0x%08x'. Please check network connectivity and firewall setup, then retry the operation
Ledger verification to detect inconsistencies for index '%.*ls' (database ID %d) failed due to exception %d, state %d.
Ledger verification detected inconsistencies for index '%.*ls' (database ID %d). There are %ld rows that are inconsistent between the table and the index.
Internal parsing error: Fail to parse the service URL '%ls'. Failure method: %ls. Return code: '0x%08x'. For more information, contact Customer Support Services.
Snapshot isolation must be enabled on the database when sp_verify_database_ledger is executed.
Ledger verification detected an inconsistency in the definition of ledger view '%.*ls' for the ledger table '%.*ls'.
A value cannot be given for the column '%.*ls' on ledger table '%.*ls' because it is a dropped ledger column.
The column '%.*ls' on ledger table '%.*ls' cannot be dropped because it is a TRANSACTION_ID or SEQUENCE_NUMBER GENERATED ALWAYS column.
The column '%.*ls' on ledger table '%.*ls' cannot be dropped because it is an identity or computed column.
Failed to convert string to guid when fetching tenantID fabric property %.*ls'
A secondary of secondary database (chaining) cannot be created because automatic upload of ledger digests has been configured for this database.
Automatic upload of ledger digests cannot be enabled because this database is configured with secondaries of secondaries (chaining).
CertPFX using AES encryption is not supported on the current operating system.
Unable to locate PFXExportCertStoreEx API in crypt32.dll, needed for CertPFX using AES encryption ErrorCode: %d.
Unable to locate PFXExportCertStoreEx API in securityapi.dll, needed for CertPFX using AES encryption ErrorCode: %d.
Unable to determine the blob length needed to export the PFX certificate. ErrorCode: %d.
Unable to export the PFX certificate. ErrorCode: %d.
The column '%.*ls' on ledger table '%.*ls' is a sequence number generated always column and cannot be referenced by computed columns, check constraints, filtered index or statistics expressions.
Cannot create %S_MSG on view '%.*ls'. It contains references to sequence number generated always columns.
Cannot bind a rule to a temporal or ledger history table.
Cannot bind a rule to a sequence number generated always column.
Server response exceeded the buffer size. Ledger URL '%ls' and error code %ld.
Internal error occurred while obtaining ARC resource information from IMDS endpoint. Substate: '%ls', status: 0x%08x.
Internal error occurred while obtaining ARC resource information from IMDS endpoint. Error code: '%ls'. Error message: '%ls'. Return code: '0x%08x'.
Internal error occurred while obtaining ARC resource information from IMDS endpoint. Return code: '0x%08x'.
Error retrieving IMDS endpoint. Ensure the IMDS_ENDPOINT environmental variable is set.
Geo-replication cannot be stopped because the database has Ledger Digest Uploads enabled. Disable Ledger Digest Uploads and retry the operation.
The Geo-primary database cannot be dropped because the database has Ledger Digest Uploads enabled. Disable Ledger Digest Uploads and retry the operation.
The Azure Confidential Ledger server identity check failed. Ledger URL '%ls' and error code %ld.
IMDS resource information. Subscription ID: %ls, Resource Group: %ls, Name: %ls.
The external language '%.*ls' returned error messages: '%.*ls'.
Variable '%.*ls' has unsupported data type for parameter exchange in EXEC EXTERNAL LANGUAGE statement.
The function PREDICT expects parameter 'RUNTIME' of type ntext/nchar/nvarchar.
The 'RUNTIME' parameter is invalid.
The procedure '%s' cannot be executed because it is not supported in Azure SQL Edge.
Service environment '%s' is not ready.
Error sending a message to the service.
Error initialization external services framework.
Request to drop streaming job '%s' failed because the job is currently running. Stop the job before dropping.
Request to stop streaming job '%s' failed because the job is not currently running.
Request to create streaming job '%s' failed. The Streaming job query cannot be null or empty.
External data source '%s' with location prefix '%s' is not supported as input for streaming.
External data source '%s' with location prefix '%s' is not supported as output for streaming.
External data source '%s' with location prefix '%s' is not supported for streaming.
External data source '%s' has an invalid location for streaming.
External stream '%s' has an invalid location.
External stream '%s' has invalid properties.
Kafka datasource '%s' should specify a value for PARTITIONS in the properties field.
External file format '%s' type is not supported for streaming.
External file format '%s' encoding is not supported for streaming.
Error while processing streaming job: '%s'.
Transient error communicating with the streaming runtime. Please retry the operation.
Transient error communicating with the streaming runtime due to unfinished stop streaming job operation. Please retry the operation.
Error while launching mssql-flight-server with HRESULT 0x%x
Error while stopping mssql-flight-server with HRESULT 0x%x
Requires AAD login for managing T-SQL streaming jobs.
Error creating the streaming job request with service auth issue.
Error creating the streaming job request.
Error sending the streaming job request.
T-SQL streaming is not supported.
The sysadmin role is required for operations on T-SQL streaming jobs.
The database scoped credential '%.*ls' has a secret with more than 200 characters. Long secret value is not supported in Synapse T-SQL Streaming.
'%.*ls' is not a supported Azure region for Synapse T-SQL streaming.
Request to update streaming job '%s' failed. The query statement cannot be updated when the job is running.
Request to update streaming job '%s' failed. Query statement update and online scaling cannot be done at the same time or both not set.
Request to scale streaming job '%s' failed. The job cannot be scaled when not running.
Request to stop streaming job '%s' failed. The job is in Created state and not running.
Specified invalid LSN: '%.*ls' for database '%.*ls' while publishing external actor LSN progress.
System databases cannot be %ls.
Hardware generation '%.*ls' is currently unavailable in Azure SQL Database. Please create a SQL Database support request to resolve.
Server DNS Alias name '%.*ls' may only contain a single '@' when used to denote a SQL Server alias.
DNS alias '%.*ls' cannot be moved between DNS zones. Target server '%.*ls' is in a DNS zone ('%.*ls') that is different from the current server's '%.*ls' DNS zone ('%.*ls').
A recovery request for a database that is currently in an elastic pool must include either a target elastic pool name or a target service objective.
Changing geo-backup policy is not supported for %s tier of SQL Data Warehouse.
Cannot perform this operation when the database is paused.
Enabling long-term retention (LTR) for a serverless database is not supported if auto-pause is enabled.
Enabling auto-pause for a serverless database is not supported if long-term retention (LTR) is enabled.
Enabling geo-replication for a serverless database is not supported if auto-pause is enabled.
Enabling auto-pause for a serverless database is not supported if geo-replication is enabled.
Elastic pool '%ls' does not exist in server '%ls'. Please make sure that the elastic pool name is entered correctly. Please contact Microsoft support if further assistance is needed.
The edition '%.*ls' does not support '%.*ls' bytes as the database data max size. For more details, see <>.
'%ls' is not a valid service level objective for elastic pool '%ls'.
It is not possible to add an additional database to an existing hybrid link as a single link can contain only one database. Please use a different distributed availability group name and try again.
Failed to transition to secondary role for physical database '%ls' (ID %d) of Windows Fabric partition '%ls' (partition ID '%ls').
Failed to obtain if the application is the VLDB reverse migration target. Application name: '%ls'. HRESULT [%d].
Failed to start up the log replica for physical database '%ls'. HRESULT [%d].
HyperScale Storage V1 to V2 migration source database '%ls' is already Storage V2.
HyperScale Storage V1 to V2 migration for source database '%ls' is already started.
Source database '%ls' is in geo relationship and is not supported for migration.
Source database '%ls' does not match the logical database id provided.
Failed to transition to PRIMARY role for physical database '%ls' (ID %d) of Windows Fabric partition '%ls' (partition ID '%ls').
Transition to PRIMARY role for physical database '%ls' (ID %d) of Windows Fabric partition '%ls' (partition ID '%ls') has been aborted.
File in memory-optimized filegroup must have MAXSIZE set to be UNLIMITED.
There are %d orphaned internal table(s) eligible for removal. Investigate the error log for the table identifiers. CHECKPOINT the database, create a full database backup, and re-run DBCC CHECKCATALOG with trace flag 9947 enabled to remove these tables.
The operation on database '%ls' cannot complete because XTP engine is running in checkpoint-only mode due to insufficient memory. Memory-optimized tables are not accessible in this mode. Consider changing database service level objective to increase available memory.
BACKUP WITH COPY_ONLY cannot be performed until after the next automatic BACKUP LOG operation
BACKUP WITH COPY_ONLY cannot be performed since database encryption key for the database '%.*ls' still exists. Retry command after you drop database encryption key.
The Persistent Version Store filegroup must be set to the PRIMARY filegroup in order to be restored on SQL Database Managed Instance.
Cross-db xact outcome cleanup failed due to unavailable/inaccessible databases.
Changing recovery model for datatabase with ID %lu is not supported and corresponding error has been suppressed as per server configuration. See https://go.microsoft.com/fwlink/?linkid=2112920 for more information.
Renaming local instance is not allowed in SQL Database Managed Instance.
SQL Database Managed Instance does not support creating route with TRANSPORT or MIRROR address.
Cannot change the recovery model in Managed Instance Azure Arc environment
Cannot rename managed database '%.*ls' to an empty name.
SQL Database Managed Instance does not support modifying default size and max size of TempDb files.
Memory-optimized filegroup must be empty on the SQL Server source database when replicated to Azure SQL Managed Instance with service tier not supporting In-memory OLTP capabilities. Consider using Managed Instance with service tier supporting In-memory OLTP capabilities.
Source database on SQL Server needs to have a single log file instead of multiple log files for data replication to Azure SQL Managed Instance. Consider using a single log file on the source database and try again.
Maximum number of %u files was reached on Azure SQL Database Managed Instance preventing data replication. Consider reducing the number of files on the source and try again.
Source database on SQL Server must not use FileStream or FileTables for data replication to Azure SQL Managed Instance. Consider removing FileStream and FileTables on the source database on SQL Server and try again.
Source database '%.*ls' on SQL Server must not contain files in DEFUNCT state for data replication to Azure SQL Managed Instance to work.
Source database '%.*ls' on SQL Server contains '%.*ls' which is not supported for data replication to Azure SQL Managed Instance.
The functionality is not available on the managed instance at this time.
An error occurred while tryig to fixup backup metadata on boot page of database: '%.*ls'.
An error occurred while tryig to retreive Hybrid Ag backup metadata pending flag for database: '%.*ls'.
An error occurred while tryig to retreive Backup Uris property for database: '%.*ls'.
Backup Uris property for database: '%.*ls' contains invalid data.
Can not open hybrid backup info metadata file for database '%.*ls' Error: %u.
An error occured while loading info from hybrid backup metadata file. Database '%.*ls' Error: %u.
An error occured while writing info to hybrid backup metadata file. Database '%.*ls' Error: %u.
An error occured while doing a fixup of boot page for hybrid during link drop.
Operation was aborted as replication to Azure SQL Managed Instance did not start within %u minutes since it was initiated. Please verify the network connectivity and firewall rules are configured according to the guidelines described at https://aka.ms/mi-link-troubleshooting, and retry the operation.
%ls operation timed out. Request was sent to the service resulting in response timeout. The operation might start anyway.
%ls operation has been cancelled.
Reason: Unable to create or update firewall rules since Deny Public Network Access is set to Yes. Please set Deny Public Network Access to No and retry the operation (https://docs.microsoft.com/azure/azure-sql/database/connectivity-settings#deny-public-network-access).
Reason: Unable to set Deny Public Network Access to Yes since there is no private endpoint enabled to access the server. Please set up private endpoints and retry the operation (https://docs.microsoft.com/azure/sql-database/sql-database-private-endpoint-overview#how-to-set-up-private-link-for-azure-sql-database).
The SQL Pool '%.*ls' already exists. Please choose a new name.
Could not create SQL Pool '%.*ls'. Please try again later.
The server role '%.*ls' already exists. Please choose a new name.
Could not create Server Role '%.*ls'. Please try again later.
Could not create SQL Pool '%.*ls', it must be less than %d characters.
Can not connect to the SQL pool since it is paused. Please resume the SQL pool and try again.
The SQL pool is warming up. Please try again.
The IPv6 firewall rule name cannot be empty.
'%.*ls' is not a valid IPv6 address.
The IPv6 address that starts with '%.*ls' is too long. Maximum length is %d.
Start IPv6 address of firewall rule cannot exceed End IPv6 address.
Windows Azure SQL Database supports a maximum of 128 IPv6 firewall rules.
IPv6 Feature Support is not Enabled
Cannot open database "%.*ls" requested by the login because this database is currently being dropped. The login failed.
The elastic pool '%.*ls' has reached its active database count limit. The active database count for the elastic pool cannot exceed (%d) for the current service tier.
The specified endpoint returned an unexpected number of rows. The number of rows in the endpoint response must match the number of rows in the request.
Output column '%.*ls' specified in the WITH clause uses the %ls data type which is not supported by the runtime.
Error converting JSON value '%.*ls' to the %ls data type.
Could not parse the JSON package since it does not conform to the defined format.
Error converting a JSON value to %ls. The result would be truncated.
Unexpected status code received from the external endpoint. HTTP Status Code: %d.
Destination instance does not have sufficient storage space to '%ls'. Please make sufficient storage space available at the destination and try again.
Choosen subnet has resource of different type.
Subscription '%.*ls' isn't enabled for a feature '%.*ls'.
Maintenance window parameters are not allowed in the instance update operation.
The specified maintenance window slot '%.*ls' isn't supported.
The server %ls no longer has access to the Azure Key Vault required for the current TDE configuration. In order to change the encryption setting for the server you must first re-establish access to the Key Vault. https://go.microsoft.com/fwlink/?linkid=2095036
The operation is not allowed because the current geo-replication configuration does not allow this combination of %ls. Change the setting on the geo-replication partner before applying the change on this instance.
Managed Instance deployment failed due to conflict with the following error related to preparation of network intent policy:  %ls. Information about the network requirements and how to set them could be found at (https://go.microsoft.com/fwlink/?linkid=871071). You can find more details about this error in the virtual network Activity log.
Long Term Retention is not supported : %ls
Long Term Retention policy is invalid : %ls
Cannot fetch SQL Managed Instance available timezones because the functionality is not supported..
The operation could not be completed because an Azure Active Directory error was encountered. The error message from Active Directory Authentication library (ADAL) is '%ls'.
Managed instance deletion failed since there are resource(s) preventing its deletion: %ls (https://go.microsoft.com/fwlink/?linkid=2109712).
The server identity is incorrectly configured on server '%ls'. Follow steps in "Assign an Azure AD identity to your server" (https://aka.ms/'%ls'byoksetup)
The server '%ls' requires the following Azure Key Vault permissions: '%ls'. Please grant the missing permissions to the service principal with ID '%ls'. (https://aka.ms/'%ls'byoksetup)
The provided Key Vault uri '%ls' is not valid. Please ensure the key vault has been configured with soft-delete and purge protection. (https://aka.ms/'%ls'byoksetup)
'%ls' server configuration does not support Data Encryption feature. For information about supported configurations please visit https://aka.ms/'%ls'byoksetup.
AAD login '%s' cannot be added because a non AAD login exists with the same name.
The operation could not be completed because managed instance %ls contains databases that are in the Inaccessible state. Please either drop inaccessible databases or fix the issues with access to the customer-managed TDE protector key for managed instance before retrying operation. https://go.microsoft.com/fwlink/?linkid=2111623
Changing the hardware generation to deprecated %ls generation is not possible.
'%ls'
Backup storage type parameter is not allowed in the instance update operation.
The Azure SQL DB Service Management API surface has been deprecated. Please update callers to the Resource Management API surface. For more information, please see https://aka.ms/sqldbsmretirement.
The login for '%ls' was not able to be provisioned on sql instance '%ls'
The login for '%ls' was not able to be dropped on sql instance '%ls', it is currently in state '%ls'
The login for '%ls' was not able to be dropped on sql instance '%ls', rollback of drop is not supported.
Configuring backup storage account type to '%s' failed during Database create or update.
Managed Instance%ls deployment failed as provided subnet '%ls' was not delegated to Microsoft.Sql/managedInstances. Information on how to set subnet delegation for Managed Instance could be found at (https://go.microsoft.com/fwlink/?linkid=2123307).
Submitted request could not be accepted as maximum number of '%ls' concurrent management operations would be exceeded. Terminate some of the ongoing operations or try again later. For more details check: (https://aka.ms/mierror-man-op-limit)
Vulnerability Assessment scan was canceled.
Vulnerability Assessment failed to read archived blob.
Vulnerability Assessment storage account is on VNET or have firewalls.
Vulnerability Assessment storage account type is unsupported.
Vulnerability Assessment Baseline file exceeds the size limit (10MB).
Vulnerability Assessment baseline file isn't in the right format.
The baseline received for Vulnerability Assessment is invalid
Unable to perform operation due to server '%.*ls' being in Inaccessible state. Please re-validate the Azure Key Vault Key (https://aka.ms/'%ls'byoksetup) before retrying
Data Encryption is not supported in the selected region.
Infrastructure Encryption is not supported in the selected region.
'%ls' server configuration does not support Infrastructure Encryption.
The differential backup interval hours of %d is not a valid configuration. Valid differential backup interval must be %ls hours.
Unable to perform operation due to server being in Stopped state. Please start the server first before retrying.
Geo-Restore is not allowed for managed instances with LRS/ZRS backup storage account type.
Unable to perform operation due to server being in Upgrading state. Please wait the server to Ready before retrying.
Upgrade elastic server version to '%ls' failed: %s.
AKV host '%ls' is not resolvable from SQL, on server '%ls'.
Property with name zoneRedundant is specified but not supported in managed instance update operation. Please remove it from operation request and submit operation again.
Property with name zoneRedundant is specified but not supported in managed instance create operation. Please remove it from operation request and submit operation again.
The server in replication is not supported for stopping operaion.
The requested storage account type of '%ls' is not supported for edition '%ls'.
Managed Instance Failover cannot be initiated. Automated backup needs to complete the first full backup for a new database. Please try again later.
A conflict request to change backup storage redundancy is still in progress.
The restored database is too large for '%s' edition. Select a target edition with sufficient storage for the allocated database size. After restore, perform a shrink database operation to reclaim unused space before scaling the DB size to '%s'.
This managed instance cannot be deployed because its DNS-zone does not match the DNS-prefix of its intended virtual cluster for subnet '%.*ls'. Although this virtual cluster is empty, its DNS-prefix cannot be changed. Empty virtual clusters will be automatically removed after several hours. Consider waiting for this virtual cluster to expire or manually deleting this virtual cluster and then creating the managed instance.
Native restore file number limit was exceeded. The limit for SQL Managed Instance GP service tier is '%d' files. The restore request was initiated with '%d' files.
Specified public maintenance configuration '%ls' for the database '%ls' conflicts with the maintenance configuration '%ls' of the elastic pool '%ls'
The requested partner managed server '%ls' could not be resolved.
The service objective assignment for the resource has failed: the requested maintenance configuration '%ls' is temporarily unavailable. Try again later or choose another maintenance configuration.
Provided subnet cannot be used for deploying managed instance as it is not on allow list. Only subnets from allow list can be used.
Property with name DatabaseSurfaceAreaVersion cannot be changed from '%ls' to '%ls' because downgrade is not supported.
Property with name DatabaseSurfaceAreaVersion is specified but not available in managed instance update operation. Please remove it from operation request and submit operation again.
Property with name DatabaseSurfaceAreaVersion is specified but not availabale in managed instance create operation. Please remove it from operation request and submit operation again.
A user assigned managed identity must be specified when identity type is set to 'UserAssigned' or 'SystemAssigned,UserAssigned'.  Please specify the user assigned managed identity to be assigned to the server '%ls' or change the identity type to a different value.
The primary user assigned managed identity '%ls' must be a part of the managed identities being assigned to the server '%ls' or already assigned to the server.
One or more identity id(s) provided are not valid ARM resource id(s). Please input valid id(s) and try again. For more details, go to https://aka.ms/sqltdebyokcreateserver
ZoneRedundant feature is not supported for the selected service tier. For more details visit aka.ms/sqlmi-service-tier-characteristics.
Enabling zoneRedundant feature is not possible once managed instance is created. For more details visit aka.ms/sqlmi-high-availability.
Disabling zoneRedundant feature is not possible once managed instance is created. For more details visit aka.ms/sqlmi-high-availability.
The operation %ls cannot be completed for the instance that has an active %ls configured.
The ImportExport operation with Request Id '%ls' failed due to '%ls'.
You have reached the maximum number of %ls active user certificates for the hybrid link. Please reduce the number of active certificates and try again.
The operation was not allowed because of the outbound firewall rule configuration for '%ls'.
The specified server name cannot be used. Name is available, but still present in the collection due to recent usage. It can take up to 7 days to remove the name from the collection. Please submit operation again using different server name or try again later.
The managed identity with ID '%ls' requires the following Azure Key Vault permissions: '%ls' to the key '%ls'. Please grant the missing permissions to the identity. (https://aka.ms/sqltdebyokcreateserver)
A primary user assigned managed identity has not been specified. Please specify the primary managed identity that you would like to use for the server '%ls'.
Changing managed instance subnet is not supported operation. Please remove this parameter from the request.
Selected subnet is in another Virtual Network. Moving managed instance to another Virtual Network is not possible. Please provide subnet from Virtual Network '%ls'.
Provided subnet is having different DNS zone from the current. Changing instance DNS zone is not supported. Please provide subnet with same DNS zone, create a new subnet or provide empty one.
It is not possible to update subnet while running on Gen4 hardware as it is being deprecated. Please upgrade your hardware from Gen4 to Gen5 as part of the changing managed instance subnet operation by specifying both parameters at the same time: destination subnet and hardware generation.
Please specify primary user-assigned managed identity having the following Azure Key Vault permissions '%ls' to access the key '%ls'. (https://aka.ms/sqltdebyokcreateserver)
Please change identity type to 'UserAssigned' or 'SystemAssigned,UserAssigned' and assign a primary user-assigned managed identity having the following Azure Key Vault permissions '%ls' to access the key '%ls'. (https://aka.ms/sqltdebyokcreateserver)
Cross '%ls' '%ls' operation is not supported.
No restore point available
User attempted to failover or force-terminate a geo-link while the secondary is in checkpoint-only mode due to insufficient memory and so cannot enter the primary role. Consider upgrading the database service level objective of the geo-secondary to increase available memory.
The source database of a named replica cannot itself be a named replica.
The operation cannot be performed since the database '%ls' is a named replica.
A named replica must be created in the same subscription and region as the source database.
Backup blob copy failed with exception '{0}'
The create operation has timed out in one of the backend workflows. Please retry the operation.
The operation could not be completed because some of the database files are exceeding General Purpose file size limit of %ls GB.
The backup storage redundancy type selected cannot be used with data in zone-redundant storage. When data is in zone-redundant storage, you can only backup the data using zone-redundant backup storage.
Database movement of database '{0}' from managed server '{1}' does not exist.
Only one user assigned managed identity is supported at the Database Level.
A user assigned managed identity must be specified when identity type is set to 'UserAssigned'.  Please specify the user assigned managed identity to be assigned to the database '%ls' or change the identity type to None.
Only one identity delegation is supported at the Database Level.
User assigned managed identities are not supported on 'master', 'model', 'tempdb', 'msdb', or 'resource' databases.
Identity delegations are not supported on 'master', 'model', 'tempdb', 'msdb', or 'resource' databases.
Updating identities is not supported on this resource type.
%ls from the %ls service tier to the %ls service tier are not supported.
Operation cannot be executed as instance is in stopping/stopped state. Please start your instance and submit the request again.
Operation cannot be executed as instance is in starting state. Please wait for start operation to complete then try again.
You cannot start instance that is already started or in starting state.
You cannot stop instance that is already stopped or in stopping state.
You cannot stop the instance that has running operation on an instance or on one or more of its databases. Please wait for ongoing operation to finish or cancel ongoing operation, then try again.
Stop operation failed because it was interrupted with instance delete operation.
It is not possible to stop the instance with zone redundancy enabled. Refer to the following article for limits of managed instance start/stop feature: https://go.microsoft.com/fwlink/?linkid=2169085
It is not possible to stop the instance that is part of the failover group. Refer to the following article for limits of managed instance start/stop feature: https://go.microsoft.com/fwlink/?linkid=2169085
One or multiple schedule items are missing start and/or stop value. Schedule items must have all values populated. Please correct your schedule and submit again.
One or multiple schedule items have a time span overlap. Please correct your schedule and submit again.
A time span between two successive actions must be at least 1 hour. Please correct your schedule and submit again.
Managed instance '%.*ls' does not have start/stop schedule configured.
No managed service identities are associated with resource %ls.
Resource identifier internal_id %ls is invalid.
The restore operation of a CRM database failed because a required TDE certificate was missing. Please retry the restore operation to an existing elastic pool.
The backup storage redundancy type selected cannot be used with data stored in zone-redundant storage. When data is in zone-redundant storage, you can only backup the data using zone-redundant backup storage.
SQL Managed Instance cannot update the instance zone redundancy because the storage redundancy type is still updating. Complete these updates first, and then try to update the instance zone redundancy again.
SQL Managed Instance cannot update the instance zone redundancy and the backup storage redundancy for the same managed instance at the same time. Verify that your backup storage redundancy type has the same or more durability than your instance zone redundancy, and then update each consecutively.
The managed instance cannot be updated to a multi-availability zone because the backup storage redundancy must be either zone or geo-zone redundant. Update the backup storage redundancy type, and then update the instance redundancy.
SQL Managed Instance cannot complete the requested operation because another operation is in progress. Wait for the operation to complete and then try again.
The backup redundancy request cannot start because the update is already in progress.
Failed to update the backup storage. Contact Microsoft Support for assistance.
The elastic pool has reached its storage limit. The storage allocated for the elastic pool cannot exceed (%d) MB. (%d) MB storage has been allocated and the operation requires (%d) MB more storage to be allocated. See 'http://aka.ms/file-space-manage' for assistance.
Native restore backup contains files in forbidden states.
Subnet currently used by managed instance and provided destination subnet are part of the virtual networks that are not connected with virtual network peering, or have peering established but don't have allowed traffic. In order to move managed instance from one subnet to another, virtual network peering needs to be established from both source and target virtual network. Please configure virtual network requirements and then try the operation again. Learn more https://docs.microsoft.com/en-us/azure/virtual-network/tutorial-connect-virtual-networks-portal#peer-virtual-networks.
Subnet provided for managed instance deployment is located on subscription different than the one submitted for managed instance. Managed instance and subnet used for deploying the instance must be on the same subscription. Please provide another subnet or switch to the subnet subscription and then try the operation again.
Parameter '%s' cannot be null or empty. Specify a value for the named parameter and retry the operation.
The parameter '%ls' is invalid. '%ls'
The restored database is too large for the requested service level objective '%s'. Submit a new restore request to a target service level objective which has sufficient storage larger than the the max size of the database, %s bytes. After restore, a shrink database operation can be performed to to reclaim unused space before scaling the DB size to the originally requested service level objective.
The attempted CRUD operation of Start/Stop schedule on the Azure SQL Managed Instance '%ls' cannot be executed. The schedule does not exist for a given managed instance.
Cannot create Managed Instance in the subnet '%ls' because subnet is too small. Minimal allowed size of a subnet is %d IP addresses. See https://aka.ms/move-managed-instance on how to move your instance to a larger subnet.
Subnet selected for managed instance migration has address range that overlaps with address range of subnet that holds geo replicated secondary instance. Please verify that your subnet is configured according to guidelines in https://aka.ms/move-managed-instance.
Subnet selected for managed instance migration is not configured to enable communication with a geo replicated secondary instance. Please check if all of the required ports are open. To properly configure your subnet read the guidelines in https://aka.ms/move-managed-instance.
The database can't be restored into the resource pool due to the remaining storage capacity in the pool. The database required {0} bytes, while the pool has only {1} bytes of storage available. Please restore as a single database outside resource pool or increase resources for the pool.
The largest database file size of database '{0}' exceeds data file size limit {1} for General Purpose SQL Managed Instance service tier. See: https://docs.microsoft.com/azure/azure-sql/managed-instance/resource-limits#service-tier-characteristics.
Storage account limit {0} for General Purpose SQL Managed Instance '{1}' exceeded. See: https://docs.microsoft.com/azure/azure-sql/managed-instance/resource-limits#service-tier-characteristics.
Unable to add keys to the Azure SQL Server due to CryptographicException. Error details: Exponent: '%ls', Modulus: %ls'. For additional support, contact your system administrator or Microsoft Customer Support Services
The key vault provided '%ls' on  server '%ls' uses unsupported RSA Key Exponent. Exponent value: '%ls'. For additional support, contact your system administrator or Microsoft Customer Support Services
Database restore is not supported when Database-level CMK is configured in preview.
Database-level CMK in preview is not supported for Hyperscale edition..
Geo Replication and Database Copy is not supported when Database-level CMK is configured in preview.
Standby replicas are not supported in DTU based purchasing models. Neither source nor target for standby replicas may be DTU based.
AKV endpoint '%ls' is not reachable from SQL, on server '%ls'.
Specified public maintenance configuration '{0}' either doesn't exist, or not applicable to the resource or not supported in this region.
Maintenance window feature is not supported for the named replica.
Maintenance window feature is not available for '%ls' hardware generation.
Ring buildout '%ls' does not support deletion of seedNodes.
Standby replicas are not supported in Elastic Pools. Neither source nor target for standby replicas may be inside an Elastic Pool.
Read scale-out cannot be enabled on a standby replica.
Temporary tables are not supported for this type of external tables.
CREATE EXTERNAL TABLE failed, because it attempted to set the %.*ls option multiple times.
'%ls' contains an unsupported prefix. Retry with supported connector prefix.
Use of external data source with '%ls' type and '%ls' connector prefix is not supported.
Connector specified in external data source location '%ls' requires FILE_FORMAT to be set.
%ls external table is either not supported or disabled on the server. See 'http://aka.ms/sqlsrvrerrmsg46551' for assistance.
PARSER_VERSION
ERRORFILE_DATA_SOURCE
TABLE_OPTIONS
An error occurred while establishing connection to remote data source: %ls
An error occurred while excecuting query on remote server: %ls
An error occurred while retrieving data from remote server: %ls
An error occurred while initializing Global Query: %ls
External table schema does not match actual schema from remote table: %ls
An error occurred while fetching table metadata in Global Query: %ls
An error occurred while fetching data in Global Query: %ls
An error occurred while cancelling Global Query operation: %ls
An error occurred during Global Query cleanup: %ls
An error occurred while executing Global Query operation: %ls
Logical server %ls defined in the elastic query configuration is not in the list of Outbound Firewall Rules on the server. Please add this logical server name to the list of Outbound Firewall Rules on your %ls server and retry the operation.
External data sources of SHARD_MAP_MANAGER type cannot be queried when outbound firewall rules are set.
The option 'hadoop connectivity' cannot be enabled in this edition of SQL Server.
 Reason: Replicated Master is not online at this point and user connections are disallowed.
 Reason: Azure Active Directory only authentication is enabled. Please contact your system administrator.
Reason: Login failed because login token present in the feature extension is invalid.
Reason: Login failed due to client TLS version being less than minimal TLS version allowed by the server.
Reason: An instance-specific error occurred while establishing a connection to SQL Server. Connection was denied since Deny Public Network Access is set to Yes (https://docs.microsoft.com/azure/azure-sql/database/connectivity-settings#deny-public-network-access). To connect to this server, use the Private Endpoint from inside your virtual network (https://docs.microsoft.com/azure/sql-database/sql-database-private-endpoint-overview#how-to-set-up-private-link-for-azure-sql-database).
The login was denied since the target is not part of the Network Seurity Perimeter.
Connections to this database are no longer allowed.
Server access failure due to RBAC Deny.
 Cannot verify connect permissions on database '%ls'.
 Cannot verify connect permissions on the default database.
 Token is expired.
 Incorrect or invalid token.
 The server is not currently configured to accept this token.
Could not verify credentials on connected endpoint.
 Reason: Azure Active Directory only authentication is enabled. Please contact your system administrator.
Reason: Login failed because of invalid feature extension offset.
Reason: Login failed because Azure Dns Caching feature extension is malformed.
Internal API Error. Result %d, File Name %s, Line Number %d
Reason: Login failed because login does not have CONNECT permission on the specified SQL Pool.
Reason: Login failed because login to Datawarehouse Reserved Databases are not allowed.
Reason: Retrieving IPv6 address failed.
Reason: Retrieving IPv6 server firewall rules failed.
Reason: Retrieving IPv6 server database firewall rules failed.
Reason: Login to public IPv6 endpoint is disabled.
Reason: Login to public IPv6 endpoint from an IPv4 source is disabled.
Reason: Retrieving IPv4 address from IPv4 mapped IPv6 address failed.
Option 'autoseeding_system_databases' is invalid for creating availability group '%.*ls'. Option 'autoseeding_system_databases' can only be used with contained availability group. Correct the option and retry the operation.
Option 'autoseeding_system_databases' and 'reuse_system_databases' cannot be set at same time for creating availability group '%.*ls'. remove one option and retry the operation.
Data Retention cleanup is disabled for this database. Data Retention cleanup must be enabled on a database to enable data cleanup.
Data Retention Cleanup cannot be applied on table '%.*ls' because it has infinite retention period.
Data retention cleanup on table(database id %lu, table id %ld) cannot be executed. Either data retention cleanup is disabled on the database, appropriate lock could not be obtained or the table does not exist anymore.
%ld is not a valid value for data retention period.
'%.*ls' is not a valid period unit for data retention.
The period of %ld %S_MSG is too big for data retention.
Filter column '%.*ls' has unsupported datatype for data retention.
Filter column '%.*ls' does not exist in the target table or view.
Drop column operation failed on table '%.*ls' because the column is being used as a filter column for data retention.
'%.*ls' is being used as the filter column for data retention. Altering the filter column while data retention is 'on' is not supported.
FILTER_COLUMN for data retention has not been defined for table '%.*ls'.
Data retention cannot be set on temporal history table.
Data retention cannot be set on ledger tables or their history tables.
Policy based data retention is not supported for system databases.
Procedure expects '%u' parameters.
Procedure sp_manage_msdtc_transaction was called with invalid operation.
MSDTC operation %s on transaction %s failed, %s
Resetting MSDTC log failed, %s.
MSDTC WMI Error, %ls.
WMI cannot connnect, it may not be installed.
Reason: Windows Authentication for Azure AD Principals is not enabled on this instance.
Reason: There was an internal error while attempting Windows Authentication for Azure AD Principals.
When auto-rotation of TDE Protector is enabled, both primary and secondary servers must be connected to the same key vault. Please add key '%ls' (from the same key vault connected to primary server) to the secondary server '%ls'. (https://aka.ms/sqltdeautorotation)
All servers linked by GeoDr should have the same key material as the encryption protector of the primary server. Please add the key '%ls' with the same key material to the secondary server '%ls'. (https://aka.ms/sqltdebyokgeodr)
Service principal is disabled.
Service principal has insufficient permissions.
Reason: There was an user error while attempting Windows Authentication for Azure AD Principals.
One or more errors occurred during a native external table operation.  The last error code was 0x%08x.  See previous error messages (if any) for further details.
One or more SQL Server host errors occurred during a native external table operation.  The last error was %d.  See previous error messages (if any) for further details.
Operation not implemented or not supported:  '%s'.  [0x%8x][%d] '%s'(), %s: %u.
File is invalid or corrupt:  '%s'.  [0x%08x][%d] '%s'(), %s: %u.
Internal failure:  '%s'.  [0x%08x][%d] '%s'(), %s: %u.
Internal SQL Server host failure:  '%s' %s. [0x%08x][%d] '%s'(), %s: %u.
External Meson client operation failure: '%s'.
The object with name '%s' is not an external table.
Cannot find external table with id %d.
Cannot find column with id %d in object %d.
Column_id %d is already marked as partition column in object_id %d.
Column_id %d is already marked to be part of index_id %d in object_id %d.
Bad directory layout encountered when inferring partition information from path '%ls', starting at root '%ls'. Make sure your directories have column_name=value form or don't use '=' in them.
The passed in location path must end with '\' or '/'. Please fix the location path '%ls' for object_id %d.
Cannot parse '%ls', directory '%ls' is not part of object_id %d.
Couldn't take snapshot due to XStore throttling for file "%ls".
Reporting transient fault for the database '%.*ls' because of an upgrade step on secondary compute.
Could not initialize %S_MSG configuration for database '%ls' (URI: '%ls'), Native error [%d].
Planned failover on database '%.*ls' would take too long due to replication lag between the geo-primary and geo-secondary. Please reduce workload and try again later, or use forced failover if data loss is acceptable.
Grow file not supported in this version of SQL Server.
Hyperscale does not support database copy with elastic pools.
Fuzzing error: %ls
Striped file max size is not consistent with its range.
Page server manager initialization failed. Native error [%d].
Failed to execute AdhocXeventSession command for error: 0x%X, please check error log for details.
Shrink timeout waiting to acquire schema modify lock in WLP mode to process IAM pageID %d:%d on database ID %d
%lu is not a valid value for MAX_DURATION; MAX_DURATION must be equal to %lu.
Database cannot be paused due to missing first full backup: Server '%.*ls', Database '%.*ls'.
(De)activation workflow for database '%.*ls' in server '%.*ls' failed because another (de)activation workflow is in progress. Please wait for the current workflow to complete before starting a new one.
Unable to install the AAD Cert. Verify that '%s' exists and is in the correct PFX format. Error state [%d].
Unable to install the AAD Cert. Cannot load cert path from registry. Error state [%d].
CREATE DATABASE statement is not supported in a Synapse workspace. To create a SQL pool, use the Azure Synapse Portal or the Synapse REST API.
Cannot process create or update request. Too many create or update operations in progress for subscription '%ls'.
The elastic pool '%ls' is busy with another operation. Please wait until the ongoing operation finishes and try again.
ALTER DATABASE NAME statement is not supported in a Synapse workspace. To update the name of a SQL pool, use the Azure Synapse Portal or the Synapse REST API.
DROP DATABASE statement is not supported in a Synapse workspace. To delete a SQL pool, use the Azure Synapse Portal or the Synapse REST API.
https://go.microsoft.com/fwlink/?linkid=2139274.
Server '%ls' requires permissions: '%ls' on Azure Key Vault for key '%ls'. Please grant the server both access and required permissions to key vault and retry.
Choose a different name for this workspace resource. A '%ls' with the name '%ls' already exists.
The '%ls' operation failed to complete. Retry the operation. Create a support request if the retry attempts do not succeed.
Select a different name for this server. A server with the name '%ls' already exists.
The data exfiltration upsert operation is already in progress.
Failed to perform data exfiltration operation.
The logical server extension '%ls' not found.
Before creating a resource. Grant the workspace Managed Identity required permissions in the Azure Key Vault of the workspace. Then activate your workspace after you have granted access.
Database is logically paused. Wait for physicalPauseDelay to expire to issue Physical pause (deactivation) of DB.
Choose a different name for this '%ls' resource. Deletion of a '%ls' with the name '%ls' is currently in progress. The selected name can be used when the operation is completed.
The requested service level objective for this pool exceeds the current limit. To increase the limit, please create support ticket.
The count of pools in this workspace exceeds the current limit. To increase the limit, please create support ticket.
The count of pools in this subscription exceeds the current limit. To increase the limit, please create support ticket.
The combined usage of pools on the workspace exceeds the current limit. To increase the limit, please create support ticket.
The combined usage of pools in this subscription exceeds the current limit. To increase the limit, please create support ticket.
The databases count on the workspace exceeds the current limit. To increase the limit, please create support ticket.
The databases count in this subscription exceeds the current limit. To increase the limit, please create support ticket.
Restore/GeoRestore very large database is blocked in this region. To enable it, please create support ticket.

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New System Object Column Names In SQL Server 2022

Brand New


What does it all mean? We’ll have to find out!

+--------------------------------------------------------+-------------------------------------+
|                      object_name                       |             column_name             |
+--------------------------------------------------------+-------------------------------------+
| backup_metadata_store                                  | backup_finish_date                  |
| backup_metadata_store                                  | backup_metadata_uuid                |
| backup_metadata_store                                  | backup_path                         |
| backup_metadata_store                                  | backup_size                         |
| backup_metadata_store                                  | backup_start_date                   |
| backup_metadata_store                                  | backup_storage_redundancy           |
| backup_metadata_store                                  | backup_type                         |
| backup_metadata_store                                  | checkpoint_lsn                      |
| backup_metadata_store                                  | compressed_backup_size              |
| backup_metadata_store                                  | compression_algorithm               |
| backup_metadata_store                                  | database_backup_lsn                 |
| backup_metadata_store                                  | database_guid                       |
| backup_metadata_store                                  | database_version                    |
| backup_metadata_store                                  | differential_base_guid              |
| backup_metadata_store                                  | differential_base_lsn               |
| backup_metadata_store                                  | first_lsn                           |
| backup_metadata_store                                  | is_damaged                          |
| backup_metadata_store                                  | last_lsn                            |
| backup_metadata_store                                  | last_recovery_fork_guid             |
| backup_metadata_store                                  | last_valid_restore_time             |
| backup_metadata_store                                  | physical_database_name              |
| backup_metadata_store                                  | server_name                         |
| backup_metadata_store                                  | time_zone                           |
| database_ledger_blocks                                 | block_id                            |
| database_ledger_blocks                                 | block_size                          |
| database_ledger_blocks                                 | previous_block_hash                 |
| database_ledger_blocks                                 | transactions_root_hash              |
| database_ledger_digest_locations                       | is_current                          |
| database_ledger_digest_locations                       | last_digest_block_id                |
| database_ledger_digest_locations                       | path                                |
| database_ledger_transactions                           | block_id                            |
| database_ledger_transactions                           | commit_time                         |
| database_ledger_transactions                           | principal_name                      |
| database_ledger_transactions                           | table_hashes                        |
| database_ledger_transactions                           | transaction_id                      |
| database_ledger_transactions                           | transaction_ordinal                 |
| database_query_store_internal_state                    | messaging_memory_used_mb            |
| database_query_store_internal_state                    | pending_message_count               |
| db_ledger_blocks                                       | block_id                            |
| db_ledger_blocks                                       | block_size                          |
| db_ledger_blocks                                       | previous_block_hash                 |
| db_ledger_blocks                                       | transactions_root_hash              |
| db_ledger_blocks                                       | version                             |
| db_ledger_digest_locations                             | is_current                          |
| db_ledger_digest_locations                             | last_digest_block_id                |
| db_ledger_digest_locations                             | path                                |
| db_ledger_digest_locations                             | storage_type                        |
| db_ledger_transactions                                 | block_id                            |
| db_ledger_transactions                                 | commit_LSN                          |
| db_ledger_transactions                                 | commit_ts                           |
| db_ledger_transactions                                 | principal_name                      |
| db_ledger_transactions                                 | table_hashes                        |
| db_ledger_transactions                                 | transaction_description             |
| db_ledger_transactions                                 | transaction_id                      |
| db_ledger_transactions                                 | transaction_ordinal                 |
| db_ledger_transactions                                 | type                                |
| db_ledger_transactions                                 | version                             |
| dm_change_feed_errors                                  | batch_end_lsn                       |
| dm_change_feed_errors                                  | batch_start_lsn                     |
| dm_change_feed_errors                                  | capture_phase_number                |
| dm_change_feed_errors                                  | command_id                          |
| dm_change_feed_errors                                  | entry_time                          |
| dm_change_feed_errors                                  | error_message                       |
| dm_change_feed_errors                                  | error_number                        |
| dm_change_feed_errors                                  | error_severity                      |
| dm_change_feed_errors                                  | error_state                         |
| dm_change_feed_errors                                  | sequence_value                      |
| dm_change_feed_errors                                  | session_id                          |
| dm_change_feed_errors                                  | source_task                         |
| dm_change_feed_errors                                  | table_group_id                      |
| dm_change_feed_errors                                  | table_id                            |
| dm_change_feed_errors                                  | tran_begin_lsn                      |
| dm_change_feed_errors                                  | tran_commit_lsn                     |
| dm_change_feed_log_scan_sessions                       | batch_end_lsn                       |
| dm_change_feed_log_scan_sessions                       | batch_processing_phase              |
| dm_change_feed_log_scan_sessions                       | batch_start_lsn                     |
| dm_change_feed_log_scan_sessions                       | command_count                       |
| dm_change_feed_log_scan_sessions                       | currently_processed_commit_lsn      |
| dm_change_feed_log_scan_sessions                       | currently_processed_commit_time     |
| dm_change_feed_log_scan_sessions                       | currently_processed_lsn             |
| dm_change_feed_log_scan_sessions                       | duration                            |
| dm_change_feed_log_scan_sessions                       | empty_scan_count                    |
| dm_change_feed_log_scan_sessions                       | end_time                            |
| dm_change_feed_log_scan_sessions                       | error_count                         |
| dm_change_feed_log_scan_sessions                       | is_session_failed                   |
| dm_change_feed_log_scan_sessions                       | latency                             |
| dm_change_feed_log_scan_sessions                       | log_record_count                    |
| dm_change_feed_log_scan_sessions                       | schema_change_count                 |
| dm_change_feed_log_scan_sessions                       | session_id                          |
| dm_change_feed_log_scan_sessions                       | start_time                          |
| dm_change_feed_log_scan_sessions                       | tran_count                          |
| dm_column_encryption_enclave_properties                | name                                |
| dm_column_encryption_enclave_properties                | value                               |
| dm_database_backups                                    | backup_file_id                      |
| dm_database_backups                                    | backup_finish_date                  |
| dm_database_backups                                    | backup_start_date                   |
| dm_database_backups                                    | backup_type                         |
| dm_database_backups                                    | database_guid                       |
| dm_database_backups                                    | in_retention                        |
| dm_database_backups                                    | physical_database_name              |
| dm_database_backups                                    | physical_server_name                |
| dm_database_external_policy_actions                    | action_namespace                    |
| dm_database_external_policy_actions                    | action_provider_string              |
| dm_database_external_policy_actions                    | action_type                         |
| dm_database_external_policy_actions                    | sql_action_id                       |
| dm_database_external_policy_principal_assigned_actions | action_namespace                    |
| dm_database_external_policy_principal_assigned_actions | action_type                         |
| dm_database_external_policy_principal_assigned_actions | principal_aad_object_id             |
| dm_database_external_policy_principal_assigned_actions | principal_sid                       |
| dm_database_external_policy_principal_assigned_actions | role_assignment_scope               |
| dm_database_external_policy_principal_assigned_actions | role_assignment_type                |
| dm_database_external_policy_principal_assigned_actions | role_assignment_type_desc           |
| dm_database_external_policy_principal_assigned_actions | role_guid                           |
| dm_database_external_policy_principal_assigned_actions | role_name                           |
| dm_database_external_policy_principals                 | aad_object_id                       |
| dm_database_external_policy_principals                 | authentication_type                 |
| dm_database_external_policy_principals                 | authentication_type_desc            |
| dm_database_external_policy_principals                 | sid                                 |
| dm_database_external_policy_principals                 | type                                |
| dm_database_external_policy_principals                 | type_desc                           |
| dm_database_external_policy_role_actions               | role_guid                           |
| dm_database_external_policy_role_actions               | sql_action_id                       |
| dm_database_external_policy_role_members               | assignment_scope                    |
| dm_database_external_policy_role_members               | assignment_type                     |
| dm_database_external_policy_role_members               | assignment_type_desc                |
| dm_database_external_policy_role_members               | principal_aad_object_id             |
| dm_database_external_policy_role_members               | role_guid                           |
| dm_database_external_policy_roles                      | modify_date                         |
| dm_database_external_policy_roles                      | role_guid                           |
| dm_database_external_policy_roles                      | role_name                           |
| dm_dist_requests                                       | dist_client_id                      |
| dm_dist_requests                                       | dist_statement_hash                 |
| dm_dist_requests                                       | dist_statement_id                   |
| dm_dist_requests                                       | session_id                          |
| dm_dw_databases                                        | database_type                       |
| dm_dw_databases                                        | logical_database_id                 |
| dm_dw_databases                                        | logical_db_name                     |
| dm_dw_databases                                        | sync_point                          |
| dm_dw_locks                                            | acquire_time                        |
| dm_dw_locks                                            | is_user_transaction                 |
| dm_dw_locks                                            | pool_id                             |
| dm_dw_locks                                            | request_id                          |
| dm_dw_locks                                            | request_mode                        |
| dm_dw_locks                                            | request_status                      |
| dm_dw_locks                                            | request_time                        |
| dm_dw_locks                                            | resource_database_id                |
| dm_dw_locks                                            | resource_entity_id                  |
| dm_dw_locks                                            | resource_type                       |
| dm_dw_locks                                            | session_id                          |
| dm_dw_locks                                            | transaction_id                      |
| dm_dw_pit_databases                                    | database_type                       |
| dm_dw_pit_databases                                    | logical_database_id                 |
| dm_dw_pit_databases                                    | pit_db_name                         |
| dm_dw_pit_databases                                    | pit_key                             |
| dm_dw_pit_databases                                    | sql_db_id                           |
| dm_dw_quality_clustering                               | index_id                            |
| dm_dw_quality_clustering                               | max_overlap                         |
| dm_dw_quality_clustering                               | object_id                           |
| dm_dw_quality_clustering                               | partition_id                        |
| dm_dw_quality_clustering                               | quality                             |
| dm_dw_quality_clustering                               | total_cell_count                    |
| dm_dw_quality_clustering                               | total_overlap                       |
| dm_dw_quality_clustering                               | total_row_groups_analyzed           |
| dm_dw_quality_clustering                               | unit_of_work                        |
| dm_dw_quality_delta                                    | index_id                            |
| dm_dw_quality_delta                                    | object_id                           |
| dm_dw_quality_delta                                    | partition_id                        |
| dm_dw_quality_delta                                    | quality                             |
| dm_dw_quality_delta                                    | total_rows_analyzed                 |
| dm_dw_quality_delta                                    | unit_of_work                        |
| dm_dw_quality_index                                    | clustering_quality                  |
| dm_dw_quality_index                                    | delta_quality                       |
| dm_dw_quality_index                                    | index_id                            |
| dm_dw_quality_index                                    | object_id                           |
| dm_dw_quality_index                                    | overall_quality                     |
| dm_dw_quality_index                                    | partition_id                        |
| dm_dw_quality_index                                    | row_group_quality                   |
| dm_dw_quality_index                                    | unit_of_work                        |
| dm_dw_quality_row_group                                | average_rows                        |
| dm_dw_quality_row_group                                | index_id                            |
| dm_dw_quality_row_group                                | object_id                           |
| dm_dw_quality_row_group                                | partition_id                        |
| dm_dw_quality_row_group                                | quality                             |
| dm_dw_quality_row_group                                | total_poor_row_groups_analyzed      |
| dm_dw_quality_row_group                                | total_row_groups_analyzed           |
| dm_dw_quality_row_group                                | unit_of_work                        |
| dm_dw_resource_manager_abort_cache                     | asn                                 |
| dm_dw_resource_manager_abort_cache                     | bsn                                 |
| dm_dw_resource_manager_abort_cache                     | nested_id                           |
| dm_dw_resource_manager_active_tran                     | current_read_version                |
| dm_dw_resource_manager_active_tran                     | ddl_step                            |
| dm_dw_resource_manager_active_tran                     | is_pit                              |
| dm_dw_resource_manager_active_tran                     | is_txn_owner                        |
| dm_dw_resource_manager_active_tran                     | nested_id                           |
| dm_dw_resource_manager_active_tran                     | read_version                        |
| dm_dw_resource_manager_active_tran                     | txn_tag                             |
| dm_dw_resource_manager_active_tran                     | txn_type                            |
| dm_dw_resource_manager_active_tran                     | write_version                       |
| dm_dw_tran_manager_abort_cache                         | asn                                 |
| dm_dw_tran_manager_abort_cache                         | bsn                                 |
| dm_dw_tran_manager_abort_cache                         | nested_id                           |
| dm_dw_tran_manager_active_cache                        | bsn                                 |
| dm_dw_tran_manager_active_cache                        | resource_manager_id                 |
| dm_dw_tran_manager_active_cache                        | tag                                 |
| dm_dw_tran_manager_commit_cache                        | bsn                                 |
| dm_dw_tran_manager_commit_cache                        | csn                                 |
| dm_dw_tran_manager_commit_cache                        | min_active_bsn                      |
| dm_dw_tran_manager_commit_cache                        | state                               |
| dm_dw_tran_manager_commit_cache                        | tag                                 |
| dm_exec_requests_history                               | command                             |
| dm_exec_requests_history                               | data_processed_mb                   |
| dm_exec_requests_history                               | distributed_statement_id            |
| dm_exec_requests_history                               | end_time                            |
| dm_exec_requests_history                               | error                               |
| dm_exec_requests_history                               | error_code                          |
| dm_exec_requests_history                               | login_name                          |
| dm_exec_requests_history                               | query_hash                          |
| dm_exec_requests_history                               | query_text                          |
| dm_exec_requests_history                               | rejected_rows_path                  |
| dm_exec_requests_history                               | start_time                          |
| dm_exec_requests_history                               | status                              |
| dm_exec_requests_history                               | total_elapsed_time_ms               |
| dm_exec_requests_history                               | transaction_id                      |
| dm_external_data_processed                             | data_processed_mb                   |
| dm_external_data_processed                             | type                                |
| dm_external_policy_cache                               | last_policy_cache_update_time       |
| dm_external_policy_cache                               | last_pull_type                      |
| dm_external_policy_cache                               | last_pull_type_desc                 |
| dm_external_policy_cache                               | number_of_cached_policies           |
| dm_external_policy_cache                               | policy_cache_state                  |
| dm_external_policy_cache                               | policy_cache_state_desc             |
| dm_os_out_of_memory_events                             | allocation_potential_memory_mb      |
| dm_os_out_of_memory_events                             | available_physical_memory_mb        |
| dm_os_out_of_memory_events                             | committed_memory_mb                 |
| dm_os_out_of_memory_events                             | committed_memory_target_mb          |
| dm_os_out_of_memory_events                             | current_job_object_memory_limit_mb  |
| dm_os_out_of_memory_events                             | event_time                          |
| dm_os_out_of_memory_events                             | initial_job_object_memory_limit_mb  |
| dm_os_out_of_memory_events                             | non_sos_memory_usage_mb             |
| dm_os_out_of_memory_events                             | oom_cause                           |
| dm_os_out_of_memory_events                             | oom_cause_desc                      |
| dm_os_out_of_memory_events                             | oom_factor                          |
| dm_os_out_of_memory_events                             | oom_factor_desc                     |
| dm_os_out_of_memory_events                             | oom_resource_pools                  |
| dm_os_out_of_memory_events                             | possible_leaked_memory_clerks       |
| dm_os_out_of_memory_events                             | possible_non_sos_leaked_memory_mb   |
| dm_os_out_of_memory_events                             | process_memory_usage_mb             |
| dm_os_out_of_memory_events                             | top_memory_clerks                   |
| dm_os_out_of_memory_events                             | top_resource_pools                  |
| dm_request_phases                                      | avg_rows                            |
| dm_request_phases                                      | avg_time_ms                         |
| dm_request_phases                                      | dist_request_id                     |
| dm_request_phases                                      | dist_statement_id                   |
| dm_request_phases                                      | end_time                            |
| dm_request_phases                                      | error_id                            |
| dm_request_phases                                      | id                                  |
| dm_request_phases                                      | input_dop                           |
| dm_request_phases                                      | max_rows                            |
| dm_request_phases                                      | max_time_ms                         |
| dm_request_phases                                      | min_rows                            |
| dm_request_phases                                      | min_time_ms                         |
| dm_request_phases                                      | operation_type                      |
| dm_request_phases                                      | output_dop                          |
| dm_request_phases                                      | parent_ids                          |
| dm_request_phases                                      | start_time                          |
| dm_request_phases                                      | state_desc                          |
| dm_request_phases                                      | stdev_rows                          |
| dm_request_phases                                      | stdev_time_ms                       |
| dm_request_phases                                      | task_retries                        |
| dm_request_phases                                      | total_bytes_processed               |
| dm_request_phases                                      | total_elapsed_time_ms               |
| dm_request_phases                                      | total_rows                          |
| dm_request_phases_exec_task_stats                      | avg_rows                            |
| dm_request_phases_exec_task_stats                      | avg_time_ms                         |
| dm_request_phases_exec_task_stats                      | dist_request_id                     |
| dm_request_phases_exec_task_stats                      | error_id                            |
| dm_request_phases_exec_task_stats                      | id                                  |
| dm_request_phases_exec_task_stats                      | max_rows                            |
| dm_request_phases_exec_task_stats                      | max_time_ms                         |
| dm_request_phases_exec_task_stats                      | min_rows                            |
| dm_request_phases_exec_task_stats                      | min_time_ms                         |
| dm_request_phases_exec_task_stats                      | stdev_rows                          |
| dm_request_phases_exec_task_stats                      | stdev_time_ms                       |
| dm_request_phases_exec_task_stats                      | total_bytes_processed               |
| dm_request_phases_exec_task_stats                      | total_rows                          |
| dm_request_phases_task_group_stats                     | dist_request_id                     |
| dm_request_phases_task_group_stats                     | dist_statement_id                   |
| dm_request_phases_task_group_stats                     | end_time                            |
| dm_request_phases_task_group_stats                     | id                                  |
| dm_request_phases_task_group_stats                     | input_dop                           |
| dm_request_phases_task_group_stats                     | operation_type                      |
| dm_request_phases_task_group_stats                     | output_dop                          |
| dm_request_phases_task_group_stats                     | parent_ids                          |
| dm_request_phases_task_group_stats                     | start_time                          |
| dm_request_phases_task_group_stats                     | state_desc                          |
| dm_request_phases_task_group_stats                     | task_retries                        |
| dm_server_external_policy_actions                      | action_namespace                    |
| dm_server_external_policy_actions                      | action_provider_string              |
| dm_server_external_policy_actions                      | action_type                         |
| dm_server_external_policy_actions                      | sql_action_id                       |
| dm_server_external_policy_principal_assigned_actions   | action_namespace                    |
| dm_server_external_policy_principal_assigned_actions   | action_type                         |
| dm_server_external_policy_principal_assigned_actions   | principal_aad_object_id             |
| dm_server_external_policy_principal_assigned_actions   | principal_sid                       |
| dm_server_external_policy_principal_assigned_actions   | role_assignment_scope               |
| dm_server_external_policy_principal_assigned_actions   | role_assignment_type                |
| dm_server_external_policy_principal_assigned_actions   | role_assignment_type_desc           |
| dm_server_external_policy_principal_assigned_actions   | role_guid                           |
| dm_server_external_policy_principal_assigned_actions   | role_name                           |
| dm_server_external_policy_principals                   | aad_object_id                       |
| dm_server_external_policy_principals                   | authentication_type                 |
| dm_server_external_policy_principals                   | authentication_type_desc            |
| dm_server_external_policy_principals                   | sid                                 |
| dm_server_external_policy_principals                   | type                                |
| dm_server_external_policy_principals                   | type_desc                           |
| dm_server_external_policy_role_actions                 | role_guid                           |
| dm_server_external_policy_role_actions                 | sql_action_id                       |
| dm_server_external_policy_role_members                 | assignment_scope                    |
| dm_server_external_policy_role_members                 | assignment_type                     |
| dm_server_external_policy_role_members                 | assignment_type_desc                |
| dm_server_external_policy_role_members                 | principal_aad_object_id             |
| dm_server_external_policy_role_members                 | role_guid                           |
| dm_server_external_policy_roles                        | modify_date                         |
| dm_server_external_policy_roles                        | role_guid                           |
| dm_server_external_policy_roles                        | role_name                           |
| dm_server_hardware_offload_config                      | config                              |
| dm_server_hardware_offload_config                      | config_in_use                       |
| dm_server_hardware_offload_config                      | hardware_offload                    |
| dm_server_hardware_offload_config                      | is_loaded                           |
| dm_server_hardware_offload_config                      | is_loaded_desc                      |
| dm_server_suspend_status                               | db_id                               |
| dm_server_suspend_status                               | db_name                             |
| dm_server_suspend_status                               | is_diffmap_cleared                  |
| dm_server_suspend_status                               | is_writeio_frozen                   |
| dm_server_suspend_status                               | suspend_session_id                  |
| dm_server_suspend_status                               | suspend_time_ms                     |
| dm_toad_tuning_zones                                   | actions_discovered                  |
| dm_toad_tuning_zones                                   | actions_scheduled                   |
| dm_toad_tuning_zones                                   | entry_data                          |
| dm_toad_tuning_zones                                   | priority_score                      |
| dm_toad_tuning_zones                                   | total_actions_scheduled             |
| dm_toad_tuning_zones                                   | zone_type                           |
| dm_toad_work_item_handlers                             | message_id                          |
| dm_toad_work_item_handlers                             | producer_id                         |
| dm_toad_work_item_handlers                             | producer_type                       |
| dm_toad_work_item_handlers                             | state                               |
| dm_toad_work_item_handlers                             | task_address                        |
| dm_toad_work_item_handlers                             | workitem_type                       |
| dm_toad_work_items                                     | body_size                           |
| dm_toad_work_items                                     | message_id                          |
| dm_toad_work_items                                     | producer_id                         |
| dm_toad_work_items                                     | producer_type                       |
| dm_toad_work_items                                     | retry_count                         |
| dm_toad_work_items                                     | workitem_type                       |
| dm_toad_work_items                                     | workitem_version                    |
| dm_xcs_enumerate_blobdirectory                         | container_path                      |
| dm_xcs_enumerate_blobdirectory                         | etag                                |
| dm_xcs_enumerate_blobdirectory                         | last_modified_date                  |
| dm_xcs_enumerate_blobdirectory                         | part_key_name                       |
| dm_xcs_enumerate_blobdirectory                         | part_key_val                        |
| dm_xcs_enumerate_blobdirectory                         | relative_path                       |
| dm_xcs_enumerate_blobdirectory                         | size_in_bytes                       |
| external_job_streams                                   | is_input                            |
| external_job_streams                                   | is_output                           |
| external_job_streams                                   | job_id                              |
| external_job_streams                                   | stream_id                           |
| external_libraries_installed_table                     | db_id                               |
| external_libraries_installed_table                     | external_library_id                 |
| external_libraries_installed_table                     | language_id                         |
| external_libraries_installed_table                     | mdversion                           |
| external_libraries_installed_table                     | name                                |
| external_libraries_installed_table                     | principal_id                        |
| external_stream_columns                                | column_id                           |
| external_stream_columns                                | object_id                           |
| external_streaming_jobs                                | create_date                         |
| external_streaming_jobs                                | is_ms_shipped                       |
| external_streaming_jobs                                | is_published                        |
| external_streaming_jobs                                | is_schema_published                 |
| external_streaming_jobs                                | modify_date                         |
| external_streaming_jobs                                | name                                |
| external_streaming_jobs                                | object_id                           |
| external_streaming_jobs                                | parent_object_id                    |
| external_streaming_jobs                                | principal_id                        |
| external_streaming_jobs                                | schema_id                           |
| external_streaming_jobs                                | statement                           |
| external_streaming_jobs                                | status                              |
| external_streaming_jobs                                | type                                |
| external_streaming_jobs                                | type_desc                           |
| external_streaming_jobs                                | uses_ansi_nulls                     |
| external_streams                                       | create_date                         |
| external_streams                                       | data_source_id                      |
| external_streams                                       | file_format_id                      |
| external_streams                                       | input_options                       |
| external_streams                                       | is_ms_shipped                       |
| external_streams                                       | is_published                        |
| external_streams                                       | is_schema_published                 |
| external_streams                                       | location                            |
| external_streams                                       | max_column_id_used                  |
| external_streams                                       | modify_date                         |
| external_streams                                       | name                                |
| external_streams                                       | object_id                           |
| external_streams                                       | output_options                      |
| external_streams                                       | parent_object_id                    |
| external_streams                                       | principal_id                        |
| external_streams                                       | schema_id                           |
| external_streams                                       | type                                |
| external_streams                                       | type_desc                           |
| external_streams                                       | uses_ansi_nulls                     |
| external_table_partitioning_columns                    | column_id                           |
| external_table_partitioning_columns                    | object_id                           |
| external_table_partitioning_columns                    | ordinal_id                          |
| extgov_attribute_sync_state                            | current_blob_references             |
| extgov_attribute_sync_state                            | current_sync_token                  |
| extgov_attribute_sync_state                            | database_id                         |
| extgov_attribute_sync_state                            | database_name                       |
| extgov_attribute_sync_state                            | last_blob_fetch_attempt             |
| extgov_attribute_sync_state                            | last_blob_fetch_error               |
| extgov_attribute_sync_state                            | last_blob_fetch_success             |
| extgov_attribute_sync_state                            | last_ref_fetch_attempt              |
| extgov_attribute_sync_state                            | last_ref_fetch_error                |
| extgov_attribute_sync_state                            | last_ref_fetch_success              |
| extgov_attribute_sync_state                            | last_sync_success                   |
| extgov_attribute_sync_state                            | last_synchronizing_attempt          |
| extgov_attribute_sync_state                            | last_synchronizing_error            |
| extgov_attribute_sync_state                            | last_synchronizing_success          |
| extgov_attribute_sync_state                            | next_sync_token                     |
| extgov_attribute_sync_state                            | state                               |
| extgov_attribute_sync_state                            | state_desc                          |
| extgov_attribute_sync_tables_synchronizing             | last_fetch                          |
| extgov_attribute_sync_tables_synchronizing             | last_synchronizing_attempt          |
| extgov_attribute_sync_tables_synchronizing             | last_synchronizing_error            |
| extgov_attribute_sync_tables_synchronizing             | schema_id                           |
| extgov_attribute_sync_tables_synchronizing             | schema_name                         |
| extgov_attribute_sync_tables_synchronizing             | table_id                            |
| extgov_attribute_sync_tables_synchronizing             | table_name                          |
| fn_filelog                                             | AllocUnitId                         |
| fn_filelog                                             | AllocUnitName                       |
| fn_filelog                                             | Article ID                          |
| fn_filelog                                             | Begin Time                          |
| fn_filelog                                             | Beginlog Status                     |
| fn_filelog                                             | Bulk allocated extent count         |
| fn_filelog                                             | Bulk allocated extent ids           |
| fn_filelog                                             | Bulk allocation first IAM Page ID   |
| fn_filelog                                             | Bulk AllocUnitId                    |
| fn_filelog                                             | Bulk RowsetId                       |
| fn_filelog                                             | Byte Offset                         |
| fn_filelog                                             | Bytes Freed                         |
| fn_filelog                                             | Checkpoint Begin                    |
| fn_filelog                                             | Checkpoint End                      |
| fn_filelog                                             | CHKPT Begin DB Version              |
| fn_filelog                                             | CHKPT End DB Version                |
| fn_filelog                                             | CI Index Id                         |
| fn_filelog                                             | CI Table Id                         |
| fn_filelog                                             | Column Offset                       |
| fn_filelog                                             | Command                             |
| fn_filelog                                             | Command Type                        |
| fn_filelog                                             | Compression Info                    |
| fn_filelog                                             | Compression Log Type                |
| fn_filelog                                             | Context                             |
| fn_filelog                                             | CopyVerionInfo Source Page Id       |
| fn_filelog                                             | CopyVerionInfo Source Page LSN      |
| fn_filelog                                             | CopyVerionInfo Source Slot Count    |
| fn_filelog                                             | CopyVerionInfo Source Slot Id       |
| fn_filelog                                             | Current LSN                         |
| fn_filelog                                             | Database Name                       |
| fn_filelog                                             | Description                         |
| fn_filelog                                             | Dirty Pages                         |
| fn_filelog                                             | End AGE                             |
| fn_filelog                                             | End Time                            |
| fn_filelog                                             | File ID                             |
| fn_filelog                                             | File Status                         |
| fn_filelog                                             | FileGroup ID                        |
| fn_filelog                                             | Flag Bits                           |
| fn_filelog                                             | Flags                               |
| fn_filelog                                             | Format LSN                          |
| fn_filelog                                             | InvalidateCache Id                  |
| fn_filelog                                             | InvalidateCache keys                |
| fn_filelog                                             | Last Distributed Backup End LSN     |
| fn_filelog                                             | Last Distributed End LSN            |
| fn_filelog                                             | Lock Information                    |
| fn_filelog                                             | Log Record                          |
| fn_filelog                                             | Log Record Fixed Length             |
| fn_filelog                                             | Log Record Length                   |
| fn_filelog                                             | Log Reserve                         |
| fn_filelog                                             | LogBlockGeneration                  |
| fn_filelog                                             | Logical Name                        |
| fn_filelog                                             | LSN before writes                   |
| fn_filelog                                             | Mark Name                           |
| fn_filelog                                             | Master DBID                         |
| fn_filelog                                             | Master XDESID                       |
| fn_filelog                                             | Max XDESID                          |
| fn_filelog                                             | Meta Status                         |
| fn_filelog                                             | Minimum LSN                         |
| fn_filelog                                             | Modify Size                         |
| fn_filelog                                             | New Size                            |
| fn_filelog                                             | New Split Page                      |
| fn_filelog                                             | New Value                           |
| fn_filelog                                             | NewAllocUnitId                      |
| fn_filelog                                             | Next Replicated End LSN             |
| fn_filelog                                             | Num Elements                        |
| fn_filelog                                             | Num Transactions                    |
| fn_filelog                                             | Number of Locks                     |
| fn_filelog                                             | Offset                              |
| fn_filelog                                             | Offset in Row                       |
| fn_filelog                                             | Old Size                            |
| fn_filelog                                             | Old Value                           |
| fn_filelog                                             | Oldest Active LSN                   |
| fn_filelog                                             | Oldest Active Transaction ID        |
| fn_filelog                                             | Oldest Replicated Begin LSN         |
| fn_filelog                                             | Operation                           |
| fn_filelog                                             | Page ID                             |
| fn_filelog                                             | PageFormat FormatOption             |
| fn_filelog                                             | PageFormat PageFlags                |
| fn_filelog                                             | PageFormat PageLevel                |
| fn_filelog                                             | PageFormat PageStat                 |
| fn_filelog                                             | PageFormat PageType                 |
| fn_filelog                                             | Pages Written                       |
| fn_filelog                                             | Parent Transaction ID               |
| fn_filelog                                             | Partial Status                      |
| fn_filelog                                             | PartitionId                         |
| fn_filelog                                             | Physical Name                       |
| fn_filelog                                             | Prepare Time                        |
| fn_filelog                                             | Preplog Begin LSN                   |
| fn_filelog                                             | Previous LSN                        |
| fn_filelog                                             | Previous Page LSN                   |
| fn_filelog                                             | Previous Savepoint                  |
| fn_filelog                                             | Publication ID                      |
| fn_filelog                                             | Repl Min Hold LSN                   |
| fn_filelog                                             | Replicated Records                  |
| fn_filelog                                             | Rowbits Bit Count                   |
| fn_filelog                                             | Rowbits Bit Value                   |
| fn_filelog                                             | Rowbits First Bit                   |
| fn_filelog                                             | RowFlags                            |
| fn_filelog                                             | RowLog Contents 0                   |
| fn_filelog                                             | RowLog Contents 1                   |
| fn_filelog                                             | RowLog Contents 2                   |
| fn_filelog                                             | RowLog Contents 3                   |
| fn_filelog                                             | RowLog Contents 4                   |
| fn_filelog                                             | RowLog Contents 5                   |
| fn_filelog                                             | Rows Deleted                        |
| fn_filelog                                             | RowsetId                            |
| fn_filelog                                             | Savepoint Name                      |
| fn_filelog                                             | Server Name                         |
| fn_filelog                                             | Server UID                          |
| fn_filelog                                             | Slot ID                             |
| fn_filelog                                             | SPID                                |
| fn_filelog                                             | Tag Bits                            |
| fn_filelog                                             | Text Size                           |
| fn_filelog                                             | TextPtr                             |
| fn_filelog                                             | Transaction Begin                   |
| fn_filelog                                             | Transaction ID                      |
| fn_filelog                                             | Transaction Name                    |
| fn_filelog                                             | Transaction SID                     |
| fn_filelog                                             | Virtual Clock                       |
| fn_filelog                                             | VLFs added                          |
| fn_filelog                                             | Xact ID                             |
| fn_filelog                                             | Xact Node ID                        |
| fn_filelog                                             | Xact Node Local ID                  |
| fn_filelog                                             | Xact Type                           |
| fn_ledger_retrieve_digests_from_url                    | digest                              |
| fn_xcs_get_file_rowcount                               | row_count                           |
| ledger_column_history                                  | column_id                           |
| ledger_column_history                                  | column_name                         |
| ledger_column_history                                  | object_id                           |
| ledger_column_history                                  | operation_type                      |
| ledger_column_history                                  | operation_type_desc                 |
| ledger_column_history                                  | sequence_number                     |
| ledger_column_history                                  | transaction_id                      |
| ledger_columns_history_internal                        | column_id                           |
| ledger_columns_history_internal                        | column_name                         |
| ledger_columns_history_internal                        | ledger_end_sequence_number          |
| ledger_columns_history_internal                        | ledger_end_transaction_id           |
| ledger_columns_history_internal                        | ledger_start_sequence_number        |
| ledger_columns_history_internal                        | ledger_start_transaction_id         |
| ledger_columns_history_internal                        | object_id                           |
| ledger_columns_history_internal                        | operation_type                      |
| ledger_columns_history_internal_history                | column_id                           |
| ledger_columns_history_internal_history                | column_name                         |
| ledger_columns_history_internal_history                | ledger_end_sequence_number          |
| ledger_columns_history_internal_history                | ledger_end_transaction_id           |
| ledger_columns_history_internal_history                | ledger_start_sequence_number        |
| ledger_columns_history_internal_history                | ledger_start_transaction_id         |
| ledger_columns_history_internal_history                | object_id                           |
| ledger_columns_history_internal_history                | operation_type                      |
| ledger_table_history                                   | ledger_view_name                    |
| ledger_table_history                                   | ledger_view_schema_name             |
| ledger_table_history                                   | object_id                           |
| ledger_table_history                                   | operation_type                      |
| ledger_table_history                                   | operation_type_desc                 |
| ledger_table_history                                   | schema_name                         |
| ledger_table_history                                   | sequence_number                     |
| ledger_table_history                                   | table_name                          |
| ledger_table_history                                   | transaction_id                      |
| ledger_tables_history_internal                         | ledger_end_sequence_number          |
| ledger_tables_history_internal                         | ledger_end_transaction_id           |
| ledger_tables_history_internal                         | ledger_start_sequence_number        |
| ledger_tables_history_internal                         | ledger_start_transaction_id         |
| ledger_tables_history_internal                         | ledger_view_name                    |
| ledger_tables_history_internal                         | ledger_view_schema_name             |
| ledger_tables_history_internal                         | object_id                           |
| ledger_tables_history_internal                         | operation_type                      |
| ledger_tables_history_internal                         | operation_type_column_name          |
| ledger_tables_history_internal                         | operation_type_desc_column_name     |
| ledger_tables_history_internal                         | schema_name                         |
| ledger_tables_history_internal                         | sequence_number_column_name         |
| ledger_tables_history_internal                         | status                              |
| ledger_tables_history_internal                         | table_name                          |
| ledger_tables_history_internal                         | transaction_id_column_name          |
| ledger_tables_history_internal_history                 | ledger_end_sequence_number          |
| ledger_tables_history_internal_history                 | ledger_end_transaction_id           |
| ledger_tables_history_internal_history                 | ledger_start_sequence_number        |
| ledger_tables_history_internal_history                 | ledger_start_transaction_id         |
| ledger_tables_history_internal_history                 | ledger_view_name                    |
| ledger_tables_history_internal_history                 | ledger_view_schema_name             |
| ledger_tables_history_internal_history                 | object_id                           |
| ledger_tables_history_internal_history                 | operation_type                      |
| ledger_tables_history_internal_history                 | operation_type_column_name          |
| ledger_tables_history_internal_history                 | operation_type_desc_column_name     |
| ledger_tables_history_internal_history                 | schema_name                         |
| ledger_tables_history_internal_history                 | sequence_number_column_name         |
| ledger_tables_history_internal_history                 | status                              |
| ledger_tables_history_internal_history                 | table_name                          |
| ledger_tables_history_internal_history                 | transaction_id_column_name          |
| plan_persist_plan_feedback                             | create_time                         |
| plan_persist_plan_feedback                             | feature_id                          |
| plan_persist_plan_feedback                             | feedback_data                       |
| plan_persist_plan_feedback                             | last_updated_time                   |
| plan_persist_plan_feedback                             | plan_feedback_id                    |
| plan_persist_plan_feedback                             | plan_id                             |
| plan_persist_plan_feedback                             | state                               |
| plan_persist_plan_forcing_locations                    | plan_forcing_location_id            |
| plan_persist_plan_forcing_locations                    | plan_id                             |
| plan_persist_plan_forcing_locations                    | query_id                            |
| plan_persist_plan_forcing_locations                    | replica_group_id                    |
| plan_persist_query_variant                             | dispatcher_plan_id                  |
| plan_persist_query_variant                             | parent_query_id                     |
| plan_persist_query_variant                             | query_variant_query_id              |
| plan_persist_replicas                                  | replica_group_id                    |
| plan_persist_replicas                                  | replica_name                        |
| plan_persist_replicas                                  | role_type                           |
| plan_persist_runtime_stats_v2                          | count_executions                    |
| plan_persist_runtime_stats_v2                          | execution_type                      |
| plan_persist_runtime_stats_v2                          | first_execution_time                |
| plan_persist_runtime_stats_v2                          | last_clr_time                       |
| plan_persist_runtime_stats_v2                          | last_cpu_time                       |
| plan_persist_runtime_stats_v2                          | last_dop                            |
| plan_persist_runtime_stats_v2                          | last_duration                       |
| plan_persist_runtime_stats_v2                          | last_execution_time                 |
| plan_persist_runtime_stats_v2                          | last_log_bytes_used                 |
| plan_persist_runtime_stats_v2                          | last_logical_io_reads               |
| plan_persist_runtime_stats_v2                          | last_logical_io_writes              |
| plan_persist_runtime_stats_v2                          | last_num_physical_io_reads          |
| plan_persist_runtime_stats_v2                          | last_page_server_io_reads           |
| plan_persist_runtime_stats_v2                          | last_physical_io_reads              |
| plan_persist_runtime_stats_v2                          | last_query_max_used_memory          |
| plan_persist_runtime_stats_v2                          | last_rowcount                       |
| plan_persist_runtime_stats_v2                          | last_tempdb_space_used              |
| plan_persist_runtime_stats_v2                          | max_clr_time                        |
| plan_persist_runtime_stats_v2                          | max_cpu_time                        |
| plan_persist_runtime_stats_v2                          | max_dop                             |
| plan_persist_runtime_stats_v2                          | max_duration                        |
| plan_persist_runtime_stats_v2                          | max_log_bytes_used                  |
| plan_persist_runtime_stats_v2                          | max_logical_io_reads                |
| plan_persist_runtime_stats_v2                          | max_logical_io_writes               |
| plan_persist_runtime_stats_v2                          | max_num_physical_io_reads           |
| plan_persist_runtime_stats_v2                          | max_page_server_io_reads            |
| plan_persist_runtime_stats_v2                          | max_physical_io_reads               |
| plan_persist_runtime_stats_v2                          | max_query_max_used_memory           |
| plan_persist_runtime_stats_v2                          | max_rowcount                        |
| plan_persist_runtime_stats_v2                          | max_tempdb_space_used               |
| plan_persist_runtime_stats_v2                          | min_clr_time                        |
| plan_persist_runtime_stats_v2                          | min_cpu_time                        |
| plan_persist_runtime_stats_v2                          | min_dop                             |
| plan_persist_runtime_stats_v2                          | min_duration                        |
| plan_persist_runtime_stats_v2                          | min_log_bytes_used                  |
| plan_persist_runtime_stats_v2                          | min_logical_io_reads                |
| plan_persist_runtime_stats_v2                          | min_logical_io_writes               |
| plan_persist_runtime_stats_v2                          | min_num_physical_io_reads           |
| plan_persist_runtime_stats_v2                          | min_page_server_io_reads            |
| plan_persist_runtime_stats_v2                          | min_physical_io_reads               |
| plan_persist_runtime_stats_v2                          | min_query_max_used_memory           |
| plan_persist_runtime_stats_v2                          | min_rowcount                        |
| plan_persist_runtime_stats_v2                          | min_tempdb_space_used               |
| plan_persist_runtime_stats_v2                          | plan_id                             |
| plan_persist_runtime_stats_v2                          | replica_group_id                    |
| plan_persist_runtime_stats_v2                          | runtime_stats_id                    |
| plan_persist_runtime_stats_v2                          | runtime_stats_interval_id           |
| plan_persist_runtime_stats_v2                          | sumsquare_clr_time                  |
| plan_persist_runtime_stats_v2                          | sumsquare_cpu_time                  |
| plan_persist_runtime_stats_v2                          | sumsquare_dop                       |
| plan_persist_runtime_stats_v2                          | sumsquare_duration                  |
| plan_persist_runtime_stats_v2                          | sumsquare_log_bytes_used            |
| plan_persist_runtime_stats_v2                          | sumsquare_logical_io_reads          |
| plan_persist_runtime_stats_v2                          | sumsquare_logical_io_writes         |
| plan_persist_runtime_stats_v2                          | sumsquare_num_physical_io_reads     |
| plan_persist_runtime_stats_v2                          | sumsquare_page_server_io_reads      |
| plan_persist_runtime_stats_v2                          | sumsquare_physical_io_reads         |
| plan_persist_runtime_stats_v2                          | sumsquare_query_max_used_memory     |
| plan_persist_runtime_stats_v2                          | sumsquare_rowcount                  |
| plan_persist_runtime_stats_v2                          | sumsquare_tempdb_space_used         |
| plan_persist_runtime_stats_v2                          | total_clr_time                      |
| plan_persist_runtime_stats_v2                          | total_cpu_time                      |
| plan_persist_runtime_stats_v2                          | total_dop                           |
| plan_persist_runtime_stats_v2                          | total_duration                      |
| plan_persist_runtime_stats_v2                          | total_log_bytes_used                |
| plan_persist_runtime_stats_v2                          | total_logical_io_reads              |
| plan_persist_runtime_stats_v2                          | total_logical_io_writes             |
| plan_persist_runtime_stats_v2                          | total_num_physical_io_reads         |
| plan_persist_runtime_stats_v2                          | total_page_server_io_reads          |
| plan_persist_runtime_stats_v2                          | total_physical_io_reads             |
| plan_persist_runtime_stats_v2                          | total_query_max_used_memory         |
| plan_persist_runtime_stats_v2                          | total_rowcount                      |
| plan_persist_runtime_stats_v2                          | total_tempdb_space_used             |
| plan_persist_wait_stats_v2                             | count_executions                    |
| plan_persist_wait_stats_v2                             | execution_type                      |
| plan_persist_wait_stats_v2                             | last_query_wait_time_ms             |
| plan_persist_wait_stats_v2                             | max_query_wait_time_ms              |
| plan_persist_wait_stats_v2                             | min_query_wait_time_ms              |
| plan_persist_wait_stats_v2                             | plan_id                             |
| plan_persist_wait_stats_v2                             | replica_group_id                    |
| plan_persist_wait_stats_v2                             | runtime_stats_interval_id           |
| plan_persist_wait_stats_v2                             | sumsquare_query_wait_time_ms        |
| plan_persist_wait_stats_v2                             | total_query_wait_time_ms            |
| plan_persist_wait_stats_v2                             | wait_category                       |
| plan_persist_wait_stats_v2                             | wait_stats_id                       |
| polaris_executed_requests_history                      | command                             |
| polaris_executed_requests_history                      | data_processed_mb                   |
| polaris_executed_requests_history                      | distributed_statement_id            |
| polaris_executed_requests_history                      | end_time                            |
| polaris_executed_requests_history                      | error                               |
| polaris_executed_requests_history                      | error_code                          |
| polaris_executed_requests_history                      | id                                  |
| polaris_executed_requests_history                      | login_name                          |
| polaris_executed_requests_history                      | query_hash                          |
| polaris_executed_requests_history                      | query_info                          |
| polaris_executed_requests_history                      | rejected_rows_path                  |
| polaris_executed_requests_history                      | sql_handle                          |
| polaris_executed_requests_history                      | start_time                          |
| polaris_executed_requests_history                      | statement_offset_end                |
| polaris_executed_requests_history                      | statement_offset_start              |
| polaris_executed_requests_history                      | status                              |
| polaris_executed_requests_history                      | total_elapsed_time_ms               |
| polaris_executed_requests_history                      | transaction_id                      |
| polaris_executed_requests_text                         | id                                  |
| polaris_executed_requests_text                         | last_access                         |
| polaris_executed_requests_text                         | sql_handle                          |
| polaris_executed_requests_text                         | sql_text                            |
| polaris_file_cache_entries                             | file_id                             |
| polaris_file_cache_entries                             | file_path                           |
| polaris_file_cache_entries                             | file_version                        |
| polaris_file_cache_streams                             | file_id                             |
| polaris_file_cache_streams                             | stream_key                          |
| polaris_file_cache_streams                             | stream_offset                       |
| polaris_file_cache_streams                             | stream_size                         |
| polaris_file_statistics                                | access_date                         |
| polaris_file_statistics                                | additional_props                    |
| polaris_file_statistics                                | hash_key                            |
| polaris_file_statistics                                | is_auto                             |
| polaris_file_statistics                                | source_props                        |
| polaris_file_statistics                                | stats_blob                          |
| query_store_plan_feedback                              | create_time                         |
| query_store_plan_feedback                              | feature_desc                        |
| query_store_plan_feedback                              | feature_id                          |
| query_store_plan_feedback                              | feedback_data                       |
| query_store_plan_feedback                              | last_updated_time                   |
| query_store_plan_feedback                              | plan_feedback_id                    |
| query_store_plan_feedback                              | plan_id                             |
| query_store_plan_feedback                              | state                               |
| query_store_plan_feedback                              | state_desc                          |
| query_store_plan_forcing_locations                     | plan_forcing_location_id            |
| query_store_plan_forcing_locations                     | plan_id                             |
| query_store_plan_forcing_locations                     | query_id                            |
| query_store_plan_forcing_locations                     | replica_group_id                    |
| query_store_query_hints                                | comment                             |
| query_store_query_hints                                | last_query_hint_failure_reason      |
| query_store_query_hints                                | last_query_hint_failure_reason_desc |
| query_store_query_hints                                | query_hint_failure_count            |
| query_store_query_hints                                | query_hint_id                       |
| query_store_query_hints                                | query_hint_text                     |
| query_store_query_hints                                | query_id                            |
| query_store_query_hints                                | source                              |
| query_store_query_hints                                | source_desc                         |
| query_store_query_variant                              | dispatcher_plan_id                  |
| query_store_query_variant                              | parent_query_id                     |
| query_store_query_variant                              | query_variant_query_id              |
| query_store_replicas                                   | replica_group_id                    |
| query_store_replicas                                   | replica_name                        |
| query_store_replicas                                   | role_type                           |
| sql_pools_table                                        | alter_role_id                       |
| sql_pools_table                                        | auto_pause_timer                    |
| sql_pools_table                                        | connect_role_id                     |
| sql_pools_table                                        | create_date                         |
| sql_pools_table                                        | guid                                |
| sql_pools_table                                        | id                                  |
| sql_pools_table                                        | is_auto_resume_on                   |
| sql_pools_table                                        | is_result_set_caching_on            |
| sql_pools_table                                        | max_service_objective               |
| sql_pools_table                                        | modify_date                         |
| sql_pools_table                                        | name                                |
| sql_pools_table                                        | owner_id                            |
| sql_pools_table                                        | service_objective                   |
| sql_pools_table                                        | service_tier                        |
| sql_pools_table                                        | state                               |
+--------------------------------------------------------+-------------------------------------+

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New System Object Columns In SQL Server 2022

Brand New


Here’s a list of new system object columns in SQL Server 2022!

+----------------------------------------+------------------------------------------------+
|              object_name               |                  column_name                   |
+----------------------------------------+------------------------------------------------+
| all_columns                            | is_data_deletion_filter_column                 |
| all_columns                            | is_dropped_ledger_column                       |
| all_columns                            | ledger_view_column_type                        |
| all_columns                            | ledger_view_column_type_desc                   |
| all_views                              | is_dropped_ledger_view                         |
| all_views                              | ledger_view_type                               |
| all_views                              | ledger_view_type_desc                          |
| assembly_files                         | sha2_256                                       |
| assembly_files                         | sha2_512                                       |
| column_store_segments                  | collation_id                                   |
| column_store_segments                  | max_deep_data                                  |
| column_store_segments                  | min_deep_data                                  |
| columns                                | is_data_deletion_filter_column                 |
| columns                                | is_dropped_ledger_column                       |
| columns                                | ledger_view_column_type                        |
| columns                                | ledger_view_column_type_desc                   |
| computed_columns                       | is_data_deletion_filter_column                 |
| computed_columns                       | is_dropped_ledger_column                       |
| computed_columns                       | ledger_view_column_type                        |
| computed_columns                       | ledger_view_column_type_desc                   |
| database_audit_specifications          | is_session_context_enabled                     |
| database_audit_specifications          | session_context_keys                           |
| database_principals                    | tenant_id                                      |
| databases                              | is_change_feed_enabled                         |
| databases                              | is_data_retention_enabled                      |
| databases                              | is_ledger_on                                   |
| dm_db_xtp_checkpoint_stats             | closed_checkpoint_epoch_value                  |
| dm_db_xtp_checkpoint_stats             | db_in_checkpoint_only_mode                     |
| dm_exec_requests                       | dist_statement_id                              |
| dm_exec_requests                       | label                                          |
| dm_hadr_cached_replica_states          | secondary_role_allow_connections               |
| dm_hadr_cached_replica_states          | secondary_role_allow_connections_desc          |
| dm_hadr_cluster_members                | number_of_current_votes                        |
| dm_io_virtual_file_stats               | num_of_pushed_bytes_returned                   |
| dm_io_virtual_file_stats               | num_of_pushed_reads                            |
| dm_os_buffer_descriptors               | buffer_address                                 |
| dm_os_buffer_descriptors               | latch_address                                  |
| dm_os_buffer_descriptors               | latch_desc                                     |
| dm_os_loaded_modules                   | target                                         |
| dm_os_nodes                            | cached_tasks                                   |
| dm_os_nodes                            | cached_tasks_removed                           |
| dm_os_nodes                            | cached_tasks_reused                            |
| dm_os_schedulers                       | queued_disk_io_count                           |
| dm_os_sublatches                       | class_desc                                     |
| dm_os_sublatches                       | latch_desc                                     |
| dm_os_tasks                            | task_local_storage                             |
| dm_os_worker_local_storage             | performance_counters_address                   |
| dm_tran_persistent_version_store_stats | pvs_off_row_page_skipped_oldest_aborted_xdesid |
| dm_xe_session_events                   | event_fire_average_time                        |
| dm_xe_session_events                   | event_fire_count                               |
| dm_xe_session_events                   | event_fire_max_time                            |
| dm_xe_session_events                   | event_fire_min_time                            |
| dm_xe_sessions                         | total_target_memory                            |
| external_file_formats                  | parser_version                                 |
| external_tables                        | partition_desc                                 |
| external_tables                        | partition_type                                 |
| external_tables                        | table_options                                  |
| fn_get_audit_file                      | client_tls_version                             |
| fn_get_audit_file                      | client_tls_version_name                        |
| fn_get_audit_file                      | database_transaction_id                        |
| fn_get_audit_file                      | external_policy_permissions_checked            |
| fn_get_audit_file                      | ledger_start_sequence_number                   |
| fn_get_audit_file                      | session_context                                |
| identity_columns                       | is_data_deletion_filter_column                 |
| identity_columns                       | is_dropped_ledger_column                       |
| identity_columns                       | ledger_view_column_type                        |
| identity_columns                       | ledger_view_column_type_desc                   |
| internal_partitions                    | xml_compression                                |
| internal_partitions                    | xml_compression_desc                           |
| masked_columns                         | is_data_deletion_filter_column                 |
| masked_columns                         | is_dropped_ledger_column                       |
| masked_columns                         | ledger_view_column_type                        |
| masked_columns                         | ledger_view_column_type_desc                   |
| partitions                             | xml_compression                                |
| partitions                             | xml_compression_desc                           |
| query_store_plan                       | has_compile_replay_script                      |
| query_store_plan                       | is_optimized_plan_forcing_disabled             |
| query_store_plan                       | plan_type                                      |
| query_store_plan                       | plan_type_desc                                 |
| query_store_runtime_stats              | avg_page_server_io_reads                       |
| query_store_runtime_stats              | last_page_server_io_reads                      |
| query_store_runtime_stats              | max_page_server_io_reads                       |
| query_store_runtime_stats              | min_page_server_io_reads                       |
| query_store_runtime_stats              | replica_group_id                               |
| query_store_runtime_stats              | stdev_page_server_io_reads                     |
| query_store_wait_stats                 | replica_group_id                               |
| server_audit_specifications            | is_session_context_enabled                     |
| server_audit_specifications            | session_context_keys                           |
| server_audits                          | is_operator_audit                              |
| server_principals                      | tenant_id                                      |
| stats                                  | auto_drop                                      |
| syscscolsegments                       | collation_id                                   |
| syscscolsegments                       | max_deep_data                                  |
| syscscolsegments                       | min_deep_data                                  |
| sysextfileformats                      | parser_version                                 |
| syslogins                              | ##MS_DatabaseConnector##                       |
| syslogins                              | ##MS_DatabaseManager##                         |
| syslogins                              | ##MS_DefinitionReader##                        |
| syslogins                              | ##MS_LoginManager##                            |
| syslogins                              | ##MS_SecurityDefinitionReader##                |
| syslogins                              | ##MS_ServerStateManager##                      |
| syslogins                              | ##MS_ServerStateReader##                       |
| sysowners                              | tenantid                                       |
| sysrscols                              | ordlock                                        |
| system_columns                         | is_data_deletion_filter_column                 |
| system_columns                         | is_dropped_ledger_column                       |
| system_columns                         | ledger_view_column_type                        |
| system_columns                         | ledger_view_column_type_desc                   |
| system_views                           | is_dropped_ledger_view                         |
| system_views                           | ledger_view_type                               |
| system_views                           | ledger_view_type_desc                          |
| sysxlgns                               | tenantid                                       |
| tables                                 | data_retention_period                          |
| tables                                 | data_retention_period_unit                     |
| tables                                 | data_retention_period_unit_desc                |
| tables                                 | is_dropped_ledger_table                        |
| tables                                 | ledger_type                                    |
| tables                                 | ledger_type_desc                               |
| tables                                 | ledger_view_id                                 |
| views                                  | is_dropped_ledger_view                         |
| views                                  | ledger_view_type                               |
| views                                  | ledger_view_type_desc                          |
+----------------------------------------+------------------------------------------------+

Thanks for readiing!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.

New System Objects In SQL Server 2022

Today!


SQL Server 2022 was released today, so I’m digging around looking for new stuff. I’ll provide what details I can as I go, but it’s brand new so 🤷‍♂️

Here’s a list of new system objects for you to speculate about!

+------------------------------------------------------------+----------------------------------+
|                            name                            |            type_desc             |
+------------------------------------------------------------+----------------------------------+
| backup_metadata_store                                      | INTERNAL_TABLE                   |
| database_ledger_blocks                                     | VIEW                             |
| database_ledger_digest_locations                           | VIEW                             |
| database_ledger_transactions                               | VIEW                             |
| database_query_store_internal_state                        | VIEW                             |
| db_ledger_blocks                                           | INTERNAL_TABLE                   |
| db_ledger_digest_locations                                 | INTERNAL_TABLE                   |
| db_ledger_transactions                                     | INTERNAL_TABLE                   |
| dm_change_feed_errors                                      | VIEW                             |
| dm_change_feed_log_scan_sessions                           | VIEW                             |
| dm_column_encryption_enclave_properties                    | VIEW                             |
| dm_database_backups                                        | VIEW                             |
| dm_database_external_policy_actions                        | VIEW                             |
| dm_database_external_policy_principal_assigned_actions     | VIEW                             |
| dm_database_external_policy_principals                     | VIEW                             |
| dm_database_external_policy_role_actions                   | VIEW                             |
| dm_database_external_policy_role_members                   | VIEW                             |
| dm_database_external_policy_roles                          | VIEW                             |
| dm_dist_requests                                           | VIEW                             |
| dm_dw_databases                                            | VIEW                             |
| dm_dw_locks                                                | VIEW                             |
| dm_dw_pit_databases                                        | VIEW                             |
| dm_dw_quality_clustering                                   | VIEW                             |
| dm_dw_quality_delta                                        | VIEW                             |
| dm_dw_quality_index                                        | VIEW                             |
| dm_dw_quality_row_group                                    | VIEW                             |
| dm_dw_resource_manager_abort_cache                         | VIEW                             |
| dm_dw_resource_manager_active_tran                         | VIEW                             |
| dm_dw_tran_manager_abort_cache                             | VIEW                             |
| dm_dw_tran_manager_active_cache                            | VIEW                             |
| dm_dw_tran_manager_commit_cache                            | VIEW                             |
| dm_exec_requests_history                                   | VIEW                             |
| dm_external_data_processed                                 | VIEW                             |
| dm_external_policy_cache                                   | VIEW                             |
| dm_os_out_of_memory_events                                 | VIEW                             |
| dm_request_phases                                          | VIEW                             |
| dm_request_phases_exec_task_stats                          | VIEW                             |
| dm_request_phases_task_group_stats                         | VIEW                             |
| dm_server_external_policy_actions                          | VIEW                             |
| dm_server_external_policy_principal_assigned_actions       | VIEW                             |
| dm_server_external_policy_principals                       | VIEW                             |
| dm_server_external_policy_role_actions                     | VIEW                             |
| dm_server_external_policy_role_members                     | VIEW                             |
| dm_server_external_policy_roles                            | VIEW                             |
| dm_server_hardware_offload_config                          | VIEW                             |
| dm_server_suspend_status                                   | VIEW                             |
| dm_toad_tuning_zones                                       | VIEW                             |
| dm_toad_work_item_handlers                                 | VIEW                             |
| dm_toad_work_items                                         | VIEW                             |
| dm_xcs_enumerate_blobdirectory                             | SQL_INLINE_TABLE_VALUED_FUNCTION |
| external_job_streams                                       | VIEW                             |
| external_libraries_installed_table                         | INTERNAL_TABLE                   |
| external_stream_columns                                    | VIEW                             |
| external_streaming_jobs                                    | VIEW                             |
| external_streams                                           | VIEW                             |
| external_table_partitioning_columns                        | VIEW                             |
| extgov_attribute_sync_state                                | VIEW                             |
| extgov_attribute_sync_tables_synchronizing                 | VIEW                             |
| fn_cdc_is_ddl_handling_enabled                             | SQL_SCALAR_FUNCTION              |
| fn_filelog                                                 | SQL_INLINE_TABLE_VALUED_FUNCTION |
| fn_ledger_retrieve_digests_from_url                        | SQL_INLINE_TABLE_VALUED_FUNCTION |
| fn_xcs_get_file_rowcount                                   | SQL_INLINE_TABLE_VALUED_FUNCTION |
| ledger_column_history                                      | VIEW                             |
| ledger_columns_history_internal                            | INTERNAL_TABLE                   |
| ledger_columns_history_internal_history                    | INTERNAL_TABLE                   |
| ledger_table_history                                       | VIEW                             |
| ledger_tables_history_internal                             | INTERNAL_TABLE                   |
| ledger_tables_history_internal_history                     | INTERNAL_TABLE                   |
| PK_Sql_Pools_Table_Id                                      | PRIMARY_KEY_CONSTRAINT           |
| plan_persist_plan_feedback                                 | INTERNAL_TABLE                   |
| plan_persist_plan_forcing_locations                        | INTERNAL_TABLE                   |
| plan_persist_query_variant                                 | INTERNAL_TABLE                   |
| plan_persist_replicas                                      | INTERNAL_TABLE                   |
| plan_persist_runtime_stats_v2                              | INTERNAL_TABLE                   |
| plan_persist_wait_stats_v2                                 | INTERNAL_TABLE                   |
| polaris_executed_requests_history                          | INTERNAL_TABLE                   |
| polaris_executed_requests_text                             | INTERNAL_TABLE                   |
| polaris_file_cache_entries                                 | INTERNAL_TABLE                   |
| polaris_file_cache_streams                                 | INTERNAL_TABLE                   |
| polaris_file_statistics                                    | INTERNAL_TABLE                   |
| query_store_plan_feedback                                  | VIEW                             |
| query_store_plan_forcing_locations                         | VIEW                             |
| query_store_query_hints                                    | VIEW                             |
| query_store_query_variant                                  | VIEW                             |
| query_store_replicas                                       | VIEW                             |
| sp_cdc_set_scheduler_job                                   | EXTENDED_STORED_PROCEDURE        |
| sp_change_feed_create_table_group                          | SQL_STORED_PROCEDURE             |
| sp_change_feed_disable_db                                  | SQL_STORED_PROCEDURE             |
| sp_change_feed_disable_table                               | SQL_STORED_PROCEDURE             |
| sp_change_feed_drop_table_group                            | SQL_STORED_PROCEDURE             |
| sp_change_feed_enable_db                                   | SQL_STORED_PROCEDURE             |
| sp_change_feed_enable_table                                | SQL_STORED_PROCEDURE             |
| sp_change_feed_vupgrade                                    | SQL_STORED_PROCEDURE             |
| sp_cleanup_all_average_column_length_statistics            | EXTENDED_STORED_PROCEDURE        |
| sp_cleanup_all_openrowset_statistics                       | EXTENDED_STORED_PROCEDURE        |
| sp_cleanup_all_user_data_in_master                         | EXTENDED_STORED_PROCEDURE        |
| sp_cleanup_data_retention                                  | SQL_STORED_PROCEDURE             |
| sp_collect_backend_plan                                    | EXTENDED_STORED_PROCEDURE        |
| sp_copy_data_in_batches                                    | EXTENDED_STORED_PROCEDURE        |
| sp_create_format_type                                      | EXTENDED_STORED_PROCEDURE        |
| sp_create_format_type_synonym                              | EXTENDED_STORED_PROCEDURE        |
| sp_create_openrowset_statistics                            | EXTENDED_STORED_PROCEDURE        |
| sp_create_parser_version                                   | EXTENDED_STORED_PROCEDURE        |
| sp_create_streaming_job                                    | SQL_STORED_PROCEDURE             |
| sp_delete_database_engine_configuration_internal           | EXTENDED_STORED_PROCEDURE        |
| sp_discover_trident_table                                  | SQL_STORED_PROCEDURE             |
| sp_drop_format_type                                        | EXTENDED_STORED_PROCEDURE        |
| sp_drop_openrowset_statistics                              | EXTENDED_STORED_PROCEDURE        |
| sp_drop_parser_version                                     | EXTENDED_STORED_PROCEDURE        |
| sp_drop_storage_location                                   | EXTENDED_STORED_PROCEDURE        |
| sp_drop_streaming_job                                      | SQL_STORED_PROCEDURE             |
| sp_drop_trident_data_location                              | SQL_STORED_PROCEDURE             |
| sp_execute_flight_query                                    | EXTENDED_STORED_PROCEDURE        |
| sp_executesql_metrics                                      | EXTENDED_STORED_PROCEDURE        |
| sp_external_policy_refresh                                 | EXTENDED_STORED_PROCEDURE        |
| sp_fido_build_basic_histogram                              | EXTENDED_STORED_PROCEDURE        |
| sp_fido_build_histogram                                    | EXTENDED_STORED_PROCEDURE        |
| sp_fido_execute_graph_request                              | EXTENDED_STORED_PROCEDURE        |
| sp_fido_get_CS_rowset_row_count                            | EXTENDED_STORED_PROCEDURE        |
| sp_fido_get_remote_storage_size                            | EXTENDED_STORED_PROCEDURE        |
| sp_fido_glm_server_execute_batch                           | EXTENDED_STORED_PROCEDURE        |
| sp_fido_glms_get_storage_containers                        | EXTENDED_STORED_PROCEDURE        |
| sp_fido_glms_set_storage_containers                        | EXTENDED_STORED_PROCEDURE        |
| sp_fido_glms_unregister_appname                            | EXTENDED_STORED_PROCEDURE        |
| sp_fido_indexstore_update_topology                         | EXTENDED_STORED_PROCEDURE        |
| sp_fido_indexstore_upgrade_node                            | EXTENDED_STORED_PROCEDURE        |
| sp_fido_remove_retention_policy                            | EXTENDED_STORED_PROCEDURE        |
| sp_fido_set_ddl_step                                       | EXTENDED_STORED_PROCEDURE        |
| sp_fido_set_retention_policy                               | EXTENDED_STORED_PROCEDURE        |
| sp_fido_setup_endpoints                                    | EXTENDED_STORED_PROCEDURE        |
| sp_fido_spaceused                                          | SQL_STORED_PROCEDURE             |
| sp_fido_tran_abort                                         | EXTENDED_STORED_PROCEDURE        |
| sp_fido_tran_begin                                         | EXTENDED_STORED_PROCEDURE        |
| sp_fido_tran_commit                                        | EXTENDED_STORED_PROCEDURE        |
| sp_fido_tran_get_state                                     | EXTENDED_STORED_PROCEDURE        |
| sp_fido_tran_set_token                                     | EXTENDED_STORED_PROCEDURE        |
| sp_generate_database_ledger_digest                         | SQL_STORED_PROCEDURE             |
| sp_generate_external_table_statistics_description_and_hash | EXTENDED_STORED_PROCEDURE        |
| sp_generate_openrowset_statistics_props                    | EXTENDED_STORED_PROCEDURE        |
| sp_generate_trident_table_manifest                         | EXTENDED_STORED_PROCEDURE        |
| sp_get_dmv_collector_views                                 | EXTENDED_STORED_PROCEDURE        |
| sp_get_external_table_cardinality                          | EXTENDED_STORED_PROCEDURE        |
| sp_get_fido_lock                                           | EXTENDED_STORED_PROCEDURE        |
| sp_get_fido_lock_batch                                     | EXTENDED_STORED_PROCEDURE        |
| sp_get_file_splits                                         | EXTENDED_STORED_PROCEDURE        |
| sp_get_migration_vlf_state                                 | EXTENDED_STORED_PROCEDURE        |
| sp_get_openrowset_statistics_additional_props              | EXTENDED_STORED_PROCEDURE        |
| sp_get_openrowset_statistics_cardinality                   | EXTENDED_STORED_PROCEDURE        |
| sp_get_streaming_job                                       | SQL_STORED_PROCEDURE             |
| sp_get_total_openrowset_statistics_count                   | EXTENDED_STORED_PROCEDURE        |
| sp_get_trident_data_location                               | SQL_STORED_PROCEDURE             |
| sp_help_change_feed                                        | SQL_STORED_PROCEDURE             |
| sp_invoke_external_rest_endpoint                           | SQL_STORED_PROCEDURE             |
| sp_ldw_apply_file_updates_for_ext_table                    | SQL_STORED_PROCEDURE             |
| sp_ldw_get_file_updates_for_ext_table                      | SQL_STORED_PROCEDURE             |
| sp_ldw_normalize_ext_tab_name                              | SQL_STORED_PROCEDURE             |
| sp_ldw_update_stats_for_ext_table                          | SQL_STORED_PROCEDURE             |
| sp_manage_msdtc_transaction                                | EXTENDED_STORED_PROCEDURE        |
| sp_memory_leak_detection                                   | SQL_STORED_PROCEDURE             |
| sp_metadata_sync_connector_add                             | SQL_STORED_PROCEDURE             |
| sp_metadata_sync_connector_drop                            | SQL_STORED_PROCEDURE             |
| sp_metadata_sync_connectors_status                         | SQL_STORED_PROCEDURE             |
| sp_MSchange_feed_ddl_event                                 | SQL_STORED_PROCEDURE             |
| sp_process_memory_leak_record                              | EXTENDED_STORED_PROCEDURE        |
| sp_publish_database_to_syms                                | EXTENDED_STORED_PROCEDURE        |
| sp_query_store_clear_hints                                 | EXTENDED_STORED_PROCEDURE        |
| sp_query_store_clear_message_queues                        | EXTENDED_STORED_PROCEDURE        |
| sp_query_store_set_hints                                   | EXTENDED_STORED_PROCEDURE        |
| sp_release_all_fido_locks                                  | EXTENDED_STORED_PROCEDURE        |
| sp_release_fido_lock                                       | EXTENDED_STORED_PROCEDURE        |
| sp_reset_inactive_duration_flag                            | EXTENDED_STORED_PROCEDURE        |
| sp_reset_msdtc_log                                         | EXTENDED_STORED_PROCEDURE        |
| sp_set_data_processed_limit                                | EXTENDED_STORED_PROCEDURE        |
| sp_set_database_engine_configuration_internal              | EXTENDED_STORED_PROCEDURE        |
| sp_set_def_format_type_default_target                      | EXTENDED_STORED_PROCEDURE        |
| sp_set_def_format_type_extractor                           | EXTENDED_STORED_PROCEDURE        |
| sp_set_def_format_type_md_preprocessor                     | EXTENDED_STORED_PROCEDURE        |
| sp_set_distributed_feedback_context                        | EXTENDED_STORED_PROCEDURE        |
| sp_set_format_type_ls_syntax                               | EXTENDED_STORED_PROCEDURE        |
| sp_set_msdtc_network                                       | EXTENDED_STORED_PROCEDURE        |
| sp_set_parser_version_default_target                       | EXTENDED_STORED_PROCEDURE        |
| sp_set_parser_version_extractor                            | EXTENDED_STORED_PROCEDURE        |
| sp_set_parser_version_md_preprocessor                      | EXTENDED_STORED_PROCEDURE        |
| sp_set_trident_data_location                               | SQL_STORED_PROCEDURE             |
| sp_show_external_table_average_column_length_statistics    | EXTENDED_STORED_PROCEDURE        |
| sp_show_openrowset_statistics                              | EXTENDED_STORED_PROCEDURE        |
| sp_shutdown_feedback_client_connection                     | EXTENDED_STORED_PROCEDURE        |
| sp_start_fixed_vlf                                         | EXTENDED_STORED_PROCEDURE        |
| sp_start_flight_server                                     | EXTENDED_STORED_PROCEDURE        |
| sp_start_glm_server                                        | EXTENDED_STORED_PROCEDURE        |
| sp_start_streaming_job                                     | SQL_STORED_PROCEDURE             |
| sp_stop_flight_server                                      | EXTENDED_STORED_PROCEDURE        |
| sp_stop_streaming_job                                      | SQL_STORED_PROCEDURE             |
| sp_update_logical_pause_deactivation_params                | EXTENDED_STORED_PROCEDURE        |
| sp_update_logical_pause_flag                               | EXTENDED_STORED_PROCEDURE        |
| sp_update_streaming_job                                    | SQL_STORED_PROCEDURE             |
| sp_upgrade_vdw_configuration_parameters                    | EXTENDED_STORED_PROCEDURE        |
| sp_verify_database_ledger                                  | EXTENDED_STORED_PROCEDURE        |
| sp_verify_database_ledger_from_digest_storage              | EXTENDED_STORED_PROCEDURE        |
| sp_xcs_mark_column_relation                                | EXTENDED_STORED_PROCEDURE        |
| sql_pools_table                                            | INTERNAL_TABLE                   |
+------------------------------------------------------------+----------------------------------+

Thanks for reading!

Going Further


If this is the kind of SQL Server stuff you love learning about, you’ll love my training. I’m offering a 75% discount to my blog readers if you click from here. I’m also available for consulting if you just don’t have time for that and need to solve performance problems quickly.