SQL Server System Errors: 40000 - 40999

List of error messages between 40000 and 40999 in SQL Server 2017.

These error messages are all available by querying the sys.messages catalog view on the master database.

message_id severity is_event_logged text
40000160Replicated tables support only local (non-DTC) two-phase commit involving the master database.
40001160Secondary kill was initiated during commit.
40002160Replicated row is not found.
40003160Unexpected operation in replicated message.
40004160Column count does not match.
40005160Duplicated transaction id.
40006160Unknown transaction id.
40007160Invalid nesting level.
40008160Replication target database is not found.
40009160Transaction state locally does not match the expected state.
40010160Replicated transactions across databases are not allowed.
40011160Replicated target table %ld is not found.
40012160Replicated target index %ld on table %ld is not found.
40013160Replicated target schema %.*ls is not found.
40014160Multiple databases can not be used in the same transaction.
40015160This functionality is not supported on replicated tables.
40016160The partitioning key column '%.*ls' must be one of the keys of '%.*ls.%.*ls.%.*ls' index.
40017160Partition key can not be changed.
40018160Partition key value is outside of the valid partition key range.
40019160The partition key column '%.*ls' of table '%.*ls.%.*ls' is nullable or does not match the partition key type defined in the table group.
40020160The database is in transition and transactions are being terminated.
40021160The low and high keys specified for the partition are invalid. Low must be less than high.
40022160A partition with overlapping key ranges already exists.
40023160The name %s is too long.
40024160The last committed CSN (%d, %I64d) was not found in the log. The last seen CSN was (%d, %I64d).
40025160The transaction was aborted during commit due to a database state transition.
40028160The tablegroup name '%.*ls.%.*ls' is not valid.
40029160Replicated tables can have at most %d columns.
40030160Can not perform replica operation because the replica does not exist in local partition map.
40031160The partition key column for table '%.*ls.%.*ls' is undefined.
40032160Unsupported use of LOB in online index build.
40033160Attempted CSN epoch switch is not allowed. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40034160CSN being added must be equal last CSN+1. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40035160CSN being added must be equal or greater than the last CSN. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40036160Can not perform replica operation because this node is not the secondary for this partition.
40037160The epoch being started must not have been used. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40038160Can not get ack to rollback replication message.
40039160Can not get ack to commit replication message.
40040160Failed to initiate VDI Client for physical seeding.
40041160Corrupted column status.
40042160Corrupted column length.
40043160Corrupted variable data. Actual remaining bytes is %d, expected %d bytes.
40044160Corrupted fixed size data. Actual remaining bytes %d, expected %d bytes.
40045160Message version mismatch. Actual version is %d and the expected is %d.
40046160The minimum required message version %d for message type %d is unsupported.
40047160Invalid use of parent transaction.
40048160Corrupted fragmented row flow sequence.
40049160Corrupted fragmented row.
40050160Corrupted LOB row.
40051160Use of UPDATETEXT on replicated tables is not supported.
40052160Parallel queries are not supported on replicated tables.
40053160Attempt to replicate a non-replicated system table %ld.
40054160Tables without a clustered index are not supported in this version of SQL Server. Please create a clustered index and try again.
40056160Master, tempdb, model and mssqlsystemresource databases can not be replicated.
40057160Table is not enabled for replication.
40058160Unsupported replicated table usage option. Refer to the state to identify the cause.
40060160Attempt to replicate out of partition already locked for internal use.
40061160Unknown rowset id.
40062160Incorrect replica role transition.
40063160Replica is not found.
40064160Attempt to add a CSN to an invalid CSN vector. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40065160CSN vector can be reinitialized only with initial or invalid CSN. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40066160Transport destination is not found.
40067160Corrupted row sequence.
40068160Idempotent mode has been used on an unknown transaction.
40069160Could not obtain rowset interface.
40070160CSN mismatch detected. The local CSN is (%d,%I64d), the remote CSN is (%d,%I64d).
40071160This partition does not have enough valid secondaries to start a DML transaction. The needed count is %ld, the current counts are %ld (main quorum) and %ld (transient quorum).
40072160Corrupted rowset metadata sequence.
40073160Partitioned tables are not supported.
40074160Partition key is not found is the target rowset or is nullable or not part of index keys.
40075160Column schema mismatch for rowset %ls.%ls.%ls column %ld.
40076160Too few columns from remote rowset %ls.%ls.%ls.
40077160Remote rowset %ls.%ls.%ls column %ld is not found locally.
40078160The persisted queue logging has failed.
40079160A non-null variable length value is received for a column that is shorter locally.
40080160Corrupted (too long) packed row.
40081160Cardinality of index should not be less then zero.
40082160Induced exception for testing purposes.
40083160Corrupted CSN vector.
40084160Multiple modifications to CSN vector in the same transaction are not supported.
40085160The primary partition has lost the quorum. New transactions can not start.
40086160Primary hit an error with this secondary.
40087160Replica with the specified version is not found.
40088160CSN being set is outside the CSN epoch range. The new CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40089160The index configuration for table %ld index %ld does not match the source.
40090160The primary partition is in transition and the transaction can not commit.
40091160Truncation CSN is mismatched. The truncation CSN is (%d,%I64d), the current CSN is (%d,%I64d).
40092160This index %ld state for table %ld does not match the source.
40093160Replication background task hit a lock timeout. User transactions will be killed and the operation will be retried.
40094160Incompatible key metadata change. The scan can not be resumed.
40095130Replication transaction (Process ID %d) was deadlocked on %.*ls resources with another process and has been chosen as the deadlock victim. The operation will be retried.
40096160Critical replication task could not start. State is %d.
40097160The begin transaction message was not found when scanning persisted replication queue.
40098160Mismatched partition id found in the transaction log.
40099160Invalid nested transaction count found in the transaction log.
40101160The partition does not have persisted queues enabled.
40102160The partition can not have persisted queues modified in this state.
40103160The partition can not be changed inside a persisted object.
40104160Only sysadmin can execute this stored procedure '%.*ls'.
40105160The local partition map for database %.*ls is starting up in reduced functionality mode because of log full. Pending partition deletes will not be processed until the log is truncated.
40106160The schema scope set in the session is not the current schema scope for the current partition. Please rerun your query.
40108160The filtered replica is not a subset of the primary replica. This is only possible for table groups without a partition key.
40109160Number of parameters specified for procedure or function %.*ls is incorrect.
40110161Cannot scope database %s for sp_cloud_scope_database spec proc because it is already set up as a partition database.
40111161Unable to delete partition DB id %d.
40126161The partition database was not found during pending schema scope cleanup, deleting partition metadata only (%d, %s).
40127161%S_MSG database '%.*ls' link up with the %S_MSG database %d encountered the error: %S_MSG.
40128161Cannot pair database '%.*ls' with fabric because it is not a partition host.
40129161%S_MSG database link up with the %S_MSG database '%.*ls' encountered the error: %ls.
40130160Replication quorum parameter is %d. It should be >= 1 and <= 32.
40131160Partition key type '%.*ls' is not supported. Only BIGINT, UNIQUEIDENTIFIER, and VARBINARY(n) (0<n<=512) datatypes are supported currently.
40132160Before dropping a table group, you have to delete all the partitions.
40133150This operation is not supported in this version of SQL Server.
40134160get_new_rowversion() can only be used in an active transaction.
40135150This system metadata view is not supported.
40136150Could not disable versioning because the database is not in single user mode.
40137150Could not refresh options for all scoped databases.
40138160Query references entities from multiple partitions.
40139160The data node does not host a replica of the requested partition.
40140160Set partition failed since a different partition already was set in the current transaction. Cross partition operations within a node are not reliable or supported.
40141160Partition has to be set using sp_set_partition before executing this query.
40142160Accessing a different partition in the same transaction is not allowed.
40143160The replica that the data node hosts for the requested partition is not primary.
40144160Cannot find the object "%.*ls" because it does not exist or you do not have permissions.
40145160Database is not found.
40146160Table group object is not found.
40147160Stored procedure '%.*ls' is only for CloudDB.
40148160The existing persisted queue snapshot CSN (%d, %I64d) at %S_LSN is greater than the requested snapshot CSN (%d, %I64d) at %S_LSN.
40149160The database does not host any partitions.
40150160Downgrading the severity of error %d, severity %d, state %d because it would cause the server to be shutdown on a non-critical error.
40151160Partition is in transactionally inconsistent state.
40152160Partition delete expects no context transaction.
40153160The current database has been shutdown. The current database has been switched to master.
40154160Cannot use sp_cloud_add_partition or sp_cloud_delete_partition within a transaction when Partition DB are enabled.
40155161Invalid arguments provided to sp_cloud_add_partition spec proc (%s).
40156161Drop is not allowed on the %S_MSG database '%.*ls' as it contains partitions. Drop the partition before the operation.
40157160Too many secondaries. At most 32 are currently supported.
40158160Could not change database collation for database id %d.
40159160Database scoping cannot be run inside a transaction.
40160160Heartbeat message version mismatch. Actual version is %d and the expected is %d.
40161160Invalid partition type. Only 1 or 2 is supported.
40162160The replica that the data node hosts for the requested partition is not transactionally consistent.
40163160Become nothing expects no context transaction.
40164160Idempotent flush expects no context transaction.
40165160Prepare for full commit expects no context transaction.
40166160A CloudDB reconfiguration is going on and all new user transactions are aborted.
40167211A paired CloudDB fabric node failed and database %d must be shutdown.
40168160SILO_TO_PDB: Partition copy is disabled in M1.
40169160Waiting for database copy sync with %s.%s has failed. Please make sure the database is in the CATCH_UP state and try again later.
40170160Catchup of secondary at %s:%s:%s:%d has failed.
40171160Table group name (single part name) should not be longer than nvarchar(64).
40172160The partition is not in a state that allows deletion.
40173160This requested operation can not performed as this partition is in delete process.
40174160The partition is in transition and transactions are being terminated.
40175160Add a secondary with wait can not be used in a transaction.
40176160Rename a partition can not be used in a transaction.
40177160The new table group does not match the existing table group for the renaming partition.
40178160A partition with same name already exists.
40179161Fabric-database ('%.*ls') cannot be paired, the server is not ready to pair.
40180161Fabric-database ('%.*ls') cannot be paired, the database is already paired.
40181161Fabric-database ('%.*ls') cannot be paired, the supplied mutex ('%.*ls') could not be opened. Error code: %d
40182161The schema scope %ld being created is not empty.
40183161Could not create database side pairing mutex for database ('%.*ls'). Error code: %d
40184160Login failed. A system operation is in progress, and the database is not accepting user connections.
40185160Secondary failure report expects no context transaction.
40186160The data node does not host a replica of the requested partition with the requested version.
40187160The metadata record for the partition does not exist.
40188160Failed to update database "%.*ls" because it is switched to read-only to enforce disaster recovery RPO.
40189160The resource quota for the current database has been exceeded and this request has been aborted. Please rerun your request in the next quota window. %s
40190160A context transaction is required.
40191161Cannot create partition DB (%s).
40192160Catchup of secondary at %s:%s:%s:%d has been cancelled.
40193160The maximum allowed number of database is already paired.
40194160Table %s has a partition key already. Explicitly specifying a new partition key is not allowed. Please use "Alter table".
40195160%ls FOR SID command is not supported in this version of SQL Server.
40196160A varbinary can not be longer than max length specified.
40197160The service has encountered an error processing your request. Please try again. Error code %d.
40198160Only a primary replica can be configured as a forwarder.
40199160There should be no context transaction when entering the forwarder pending state.
40201160Destination server name is too long.
40202160Corrupted composite message.
40203160Could not register AsyncTransport endpoint.
40204160Dispatch sequence number maintenance failure
40205160Maximum transport queue size reached.
40206160Heartbeat lease time is less than the heartbeat worker interval.
40207160Async transport test failed.
40208160Corrupted received message format.
40209170Duplicate destination id.
40210160Cluster name has not been set.
40301160Invalid lock mode or resource received in lock request.
40302160Invalid identity value.
40303160Enter idempotent sequence.
40304160Target object %ld is not found.
40305160The current object is not a relation.
40306160Cannot create an index %ld on object %ld.
40307160Cannot find index %ld on object %ld.
40308160Metadata replication protocol error.
40309160Partition %ld is not found
40310160Converting a clustered index into a heap is not supported.
40311160Switching out partitions not supported.
40312160Inconsistent index build state.
40313160Not all rowsets could be deleted.
40314160Identity column not found on object %ld.
40501200The service is currently busy. Retry the request after 10 seconds. Incident ID: %ls. Code: %d
40502160Duplicate group id settings specified.
40503160Database field %ls contains invalid value '%.*ls'. Expected data type %ls.
40504160Switching Databases is not supported. Use a new connection to connect to a different Database.
40505160Incorrect user credentials.
40506160Specified SID is invalid for this version of SQL Server.
40507160'%.*ls' cannot be invoked with parameters in this version of SQL Server.
40508160USE statement is not supported to switch between databases. Use a new connection to connect to a different database.
40509160Upgrade of SAWA v1 database fails. Check the metadata of the database before re-running the upgrade.
40510160Statement '%.*ls' is not supported in this version of SQL Server.
40511160Built-in function '%.*ls' is not supported in this version of SQL Server.
40512160Deprecated feature '%ls' is not supported in this version of SQL Server.
40513160Server variable '%.*ls' is not supported in this version of SQL Server.
40514160'%ls' is not supported in this version of SQL Server.
40515160Reference to database and/or server name in '%.*ls' is not supported in this version of SQL Server.
40516160Global temp objects are not supported in this version of SQL Server.
40517160Keyword or statement option '%.*ls' is not supported in this version of SQL Server.
40518160DBCC command '%.*ls' is not supported in this version of SQL Server.
40519160Invalid value '%.*ls' of login field in gateway magic syntax.
40520160Securable class '%S_MSG' not supported in this version of SQL Server.
40521160Securable class '%S_MSG' not supported in the server scope in this version of SQL Server.
40522160Database principal '%.*ls' type is not supported in this version of SQL Server.
40523160Implicit user '%.*ls' creation is not supported in this version of SQL Server. Explicitly create the user before using it.
40524160Data type '%.*ls' is not supported in this version of SQL Server.
40525160'WITH %ls' is not supported in this version of SQL Server.
40526160'%.*ls' rowset provider not supported in this version of SQL Server.
40527160Linked servers are not supported in this version of SQL Server.
40528160Users cannot be mapped to Windows logins in this version of SQL Server.
40529160Built-in function '%.*ls' in impersonation context is not supported in this version of SQL Server.
40530160The %.*ls statement must be the only statement in the batch.
40531110Server name cannot be determined. It must appear as the first segment of the server's dns name (servername.%.*ls). Some libraries do not send the server name, in which case the server name must be included as part of the user name (username@servername). In addition, if both formats are used, the server names must match.
40532110Cannot open server "%.*ls" requested by the login. The login failed.
40533160Server '%.*ls' already exists.
40534160A valid SID is already associated with the database owner.
40535160Properties for schema scope '%.*ls' already exist.
40536160'%ls' is not supported in this service tier of the database. See Books Online for more details on feature support in different service tiers of Windows Azure SQL Database.
40537160User '%.*ls' not found in the database.
40538160A valid URL beginning with 'https://' is required as value for any filepath specified.
40539160Windows Azure Storage credential '%.*ls' was not found.
40540160Transaction was aborted as database is moved to read-only mode. This is a temporary situation and please retry the operation.
40541160Procedure cannot be called from inside a partition.
40542160Incorrect number of parameters specified for procedure.
40543160Invalid %S_MSG name specified. Length should be between 1 and %d.
40544200The database '%.*ls' has reached its size quota. Partition or delete data, drop indexes, or consult the documentation for possible resolutions.
40545200The service is experiencing a problem that is currently under investigation. Incident ID: %ls. Code: %d
40546160Cannot create UCS task pool
40548160Granting CONNECT permission to the guest user in database '%.*ls' is not permitted.
40549160Session is terminated because you have a long running transaction. Try shortening your transaction.
40550160The session has been terminated because it has acquired too many locks. Try reading or modifying fewer rows in a single transaction.
40551160The session has been terminated because of excessive TEMPDB usage. Try modifying your query to reduce temporary table space usage.
40552160The session has been terminated because of excessive transaction log space usage. Try modifying fewer rows in a single transaction.
40553160The session has been terminated because of excessive memory usage. Try modifying your query to process fewer rows.
40554100Exiting because of XEvent %ls.
40555160'%ls' is not supported for this database. See Books Online for more details on feature support in different service tiers of Windows Azure SQL Database.
40558160Error - cannot perform checkpoint on a partition database before loading partition information.
40559160File based statement options are not supported in this version of SQL Server.
40561160Database copy failed. Either the source or target database does not exist.
40562160Database copy failed. The source database has been dropped.
40563160Database copy failed. The target database has been dropped.
40564160Database copy failed. Database copy failed due to an internal error. Please drop target database and try again.</value>
40565160Database copy failed. No more than 1 concurrent database copy from the same source is allowed. Please drop target database and try again later.
40566160Database copy failed due to an internal error. Please drop target database and try again.
40567160Database copy failed due to an internal error. Please drop target database and try again.
40568160Database copy failed. Either the source or the target database has become unavailable. Please drop target database and try again.
40569160Database copy failed. Target database has become unavailable. Please drop target database and try again.
40570160Database copy failed due to an internal error. Please drop target database and try again later.
40571160Database copy failed due to an internal error. Please drop target database and try again later.
40572160Cannot obtain primary partition lock for CloudDB auto partition upgrade.
40573160Cannot upgrade CloudDB auto partitions in database '%.*ls' because the physical database is read only.
40574160Permissions for system stored procedures, server scoped catalog views, and extended stored procedures cannot be changed in this version of SQL Server.
40575160Data type '%.*ls' is not supported in a federated database.
40576160Table DDL on non-temporary tables is not supported in a filtered connection.
40577160The constraint '%ls' is not supported in a federated database.
40578160Statement '%.*ls' is not supported in a filtered connection.
40579160DML statements are not supported on non-federated tables in a filtered connection.
40580160Statement '%.*ls' is not supported in a federated database.
40581160Logically filtered secondaries are only supported if the secondary is a forwarder.
40582160Federation member metadata for a database cannot be changed when there are logically filtered secondaries attached (split is running).
40583160Federation member does not exist for the given member id and federation root
40584160Value '%.*ls' for option '%.*ls' is not supported in this version of SQL Server.
40585160Can not perform replica operation because this node is not the forwarder for this partition.
40586160Replicas with deferred commit enabled cannot be a member of a quorum.
40587160Deferred commit is only supported with forwarder replicas.
40588160Cannot create partition worker pool
40589160Replicas that are not enabled for deferred commit cannot specify RPO.
40590160The Gpm is in rebuild and cannot be accessed as it is not yet consistent.
40591160Extended event configuration could not be initialized. The error is %ls.
40592160Extended event session '%ls' could not be created or altered. XE Error %d.%d state:%d.
40593160Extended event session '%ls' returned error '%ls'.
40594160Extended event session '%ls' has been started.
40595160Extended event session '%ls' has been altered.
40596160Extended event session '%ls' has been stopped.
40597160A federation root database cannot be read only.
40598160A federation member cannot be read only.
40599160This type of KILL is not supported in Windows Azure SQL Database; Only 'KILL session ID [WITH STATUSONLY]' and 'KILL UOW' are supported.
40601160Server Admin user already exists.
40602160Could not create login. Please try again later.
40603160Cannot execute procedure because current user is not Gateway.
40604160Could not %.*ls because it would exceed the quota of the server.
40605160There is no route from the source cluster '%ls' to the target cluster '%ls'.
40606160Databases cannot be attached in this version of SQL Server.
40607160Windows logins are not supported in this version of SQL Server.
40608100This session has been assigned a tracing ID of '%.*ls'. Provide this tracing ID to customer support when you need assistance.
40609160'%.*ls' is not a valid IPv4 address.
40610160The IP address that starts with '%.*ls' is too long. Maximum length is %d.
40611160Windows Azure SQL Database supports a maximum of 128 firewall rules.
40612160Spec proc was executed against a silo that cannot be upgraded to include firewall objects.
40613170Database '%.*ls' on server '%.*ls' is not currently available. Please retry the connection later. If the problem persists, contact customer support, and provide them the session tracing ID of '%.*ls'.
40614160Start IP address of firewall rule cannot exceed End IP address.
40615160Cannot open server '%.*ls' requested by the login. Client with IP address '%.*ls' is not allowed to access the server. To enable access, use the Windows Azure Management Portal or run sp_set_firewall_rule on the master database to create a firewall rule for this IP address or address range. It may take up to five minutes for this change to take effect.
40616160'%.*ls' is not a valid login name in this version of SQL Server.
40617160The firewall rule name that starts with '%.*ls' is too long. Maximum length is %d.
40618160The firewall rule name cannot be empty.
40619160The edition '%.*ls' does not support the database data max size '%.*ls'.
40620160The login failed for user "%.*ls". The password change failed. Password change during login is not supported in this version of SQL Server.
40621160metric type
40622160metric data
40623200Reauthentication failed for login "%.*ls". Within the past reauthentification interval, the login has become invalid due to a password change, a dropped login, or other cause. Please retry login.
40624160Operation is not allowed because server '%.*ls' is disabled.
40625170Provisioning (creating, altering, or dropping) Windows Azure SQL Database servers and databases is currently disabled. This most frequently occurs for brief periods during system maintenance.
40626200The ALTER DATABASE command is in process. Please wait at least five minutes before logging into database '%.*ls', in order for the command to complete. Some system catalogs may be out of date until the command completes. If you have altered the database name, use the NEW database name for future activity.
40627200Operation on server '%.*ls' and database '%.*ls' is in progress. Please wait a few minutes before trying again.
40628160Failed to update database '%.*ls' because the database is read-only. Please contact your Windows Azure service owner. There may be billing related issues with your Windows Azure account.
40629160An edition could not be determined from maxsize '%.*ls'. Specify a valid maxsize value.
40630160Password validation failed. The password does not meet policy requirements because it is too short.
40631160The password that you specified is too long. The password should have no more than %d characters.
40632160Password validation failed. The password does not meet policy requirements because it is not complex enough.
40633160'%.*ls' is not a valid database edition in this version of SQL Server.
40634160This stored procedure can only be executed in the master database.
40635160Client with IP address "%.*ls" is temporarily blocked.
40636160Cannot use reserved database name '%.*ls' in this operation.
40637170Database copy is currently disabled.
40638160Invalid subscription id '%.*ls'. Subscription does not exist.
40639160Request does not conform to schema: %.*ls.
40640200The server encountered an unexpected exception.
40641160Location '%.*ls' cannot be found.
40642170The server is currently too busy. Please try again later.
40643160The specified x-ms-version header value is invalid.
40644140Failed to authorize access to the specified subscription.
40645160Servername "%.*ls" cannot be empty or null. It can only be made up of lowercase letters 'a'-'z', the numbers 0-9 and the hyphen. The hyphen may not lead or trail in the name.
40646160Subscription ID cannot be empty.
40647160Subscription '%.*ls' does not have the server '%.*ls'.
40648170Too many requests have been performed. Please retry later.
40649160Invalid content-type is specified. Only application/xml is supported.
40650160Subscription '%.*ls' is not ready for the operation because another operation is currently in progress. Please wait a few minutes and then try the operation again.
40651160Failed to create server because the subscription '%.*ls' is disabled.
40652160Cannot move or create server. Subscription '%.*ls' will exceed server quota.
40653160Could not find database '%.*ls' at time '%.*ls' that can be restored.
40654160Specified subregion '%.*ls' is invalid.
40655160Database 'master' cannot be restored.
40656160Quota for maximum number of concurrent restores has been exceeded.
40657160Restore is not enabled on the server.
40658160Quota for number of restores has been exceeded.
40659160Could not successfully restore database because the maximum duration for processing a restore has elapsed.
40660160Could not successfully restore database. This request has been assigned a tracing ID of '%.*ls'. Provide this tracing ID to customer support when you need assistance.
40661160Restore has been cancelled by a system administrator.
40662160An internal error was encountered when processing the restore request. This request has been assigned a tracing ID of '%.*ls'. Provide this tracing ID to customer support when you need assistance.
40663160Database '%.*ls' is currently being restored and cannot be dropped. Please wait for restore to complete.
40664160Database 'master' cannot be copied.
40665160'%.*ls' is not a supported collation.
40666160'%.*ls' is a unicode-only collation and cannot be a default collation for a database.
40667150Specifying a LOGIN is not allowed in a federation member.
40668160'%.*ls' is not a valid user name or you do not have permission.
40669170Location '%.*ls' is not accepting creation of new Windows Azure SQL Database servers at this time.
40670160The http header 'ocp-resourceprovider-registered-uri' is missing from the request or is invalid. To continue, provide a valid value for the header.
40671170Unable to '%.*ls' '%.*ls' on server '%.*ls'. Please retry the connection later.
40672160The service objective assignment for a database cannot be changed more than once per %d hour(s). Please retry the operation %d hour(s) after the last service objective assignment completed for this database.
40673160The service objective assignment for the database has failed. Please contact Microsoft customer support and provide the server name, database name and activity ID.
40674160Service objective creation or assignment is not permitted for this subscription.
40675160The service is currently too busy. Please try again later.
40677160The operation for the request uri '%.*ls' was not found. To continue, please provide a valid request uri.
40678160Invalid value for header '%.*ls'. The header must contain a single valid GUID.
40679160The operation cannot be performed since the database '%ls' is not in a replication relationship.
40680160The operation cannot be performed since the database '%ls' is in a replication relationship.
40681160The operation cannot be performed since the database '%ls' is a replication target.
40682160Failed to update database '%.*ls' because the database is a replication target.
40683160The operation cannot be performed since the database '%ls' is not a replication target.
40684160A seeding operation is already in progress for database '%ls'.
40685160A terminate operation is already in progress for database '%ls'.
40686160The operation is currently not supported.
40687160The operation cannot be performed on the database '%ls' in its current state.
40688160The databases '%ls' in server '%ls' and '%ls' in server '%ls' are already in a replication relation.
40689160Replication limit reached. The database '%ls' cannot have more than %d replication relationships.
40690160The operation cannot be performed since the replication source and target databases have different names. The source and target databases must have the same name.
40691160Replication target cannot be created in the same server as source.
40692160The alter database '%ls' failed to initiate because there are operations pending on the database. After the pending operations are complete, try again.
40693160The current operation cannot be initiated while a replication operation is in progress. You can rename the database only after the replication operation has stopped.
40694160The seeding operation cannot be initiated on a replication target database.
40695160The operation cannot be performed since the database is currently a Federation root or member database.
40696160sp_wait_for_database_copy_sync failed because the current database is not the primary database involved in a replication relationship with the specified target server '%s' and database '%s'.
40697160Login failed for user '%.*ls'.
40698160'%.*ls' cannot be performed on a free database.
40699160You cannot create a user with password in this version of SQL Server
40701160XML format used for specifying rules is invalid. %.*ls.
40702160Failed to parse XML rules.
40703160Invalid attribute name '%.*ls' in %.*ls.
40704160Invalid element name '%.*ls' in %.*ls.
40705160Invalid Feature type '%.*ls' in %.*ls.
40706160Feature name '%.*ls' does not exist.
40707160Invalid index value '%.*ls' in %.*ls.
40708160Invalid param count '%.*ls' in %.*ls.
40709160operator attribute is missing in %.*ls.
40711160Rule name '%.*ls' does not exist.
40712160Invalid usage of %.*ls.
40713160Invalid values supplied for <parameter> element in %.*ls.
40714160Out of memory.
40715160Invalid operator type %.*ls in %.*ls.
40716160Invalid input type %.*ls in %.*ls.
40717160index attribute is missing in %.*ls.
40718160one of inputtype, isnull and format attributes is required in %.*ls.
40719160Failed to get %s lock on %s rules.
40720160Rule name '%.*ls' already exists.
40721160Only one of inputtype, isnull and format attributes is required in %.*ls.
40722160Failed to clear proc cache.
40723160Rule name cannot exceed more than %d characters.
40724160Unexpected Operator attribute in %.*ls.
40801160Operation ALTER USER WITH LOGIN failed. User provided login does not match the login in the federation root database for the user provided username.
40802160A service objective assignment on server '%.*ls' and database '%.*ls' is already in progress. Please wait until the service objective assignment state for the database is marked as 'Completed'.
40803160The server '%.*ls' has reached its quota of (%d) premium databases.
40804160The specified service objective '%.*ls' is invalid.
40805160The service objective assignment for the database has failed. Please contact Microsoft customer support and provide the activity ID.
40806160The request to retrieve subscription information has timed out. Please try again later.
40807160Could not retrieve subscription information for subscription id: %.*ls, after %d attempts. Please try again later.t
40808160The edition '%.*ls' does not support the service objective '%.*ls'.
40809160No rows found in sys.dm_operation_status table for database '%.*ls' and operation '%.*ls'.
40810160More than one row found in sys.dm_operation_status table for database '%.*ls' and operation '%.*ls'.
40811160Operation '%.*ls' for database '%.*ls' cannot be cancelled as it has already completed.
40812160Database '%.*ls' cannot be dropped as create operation is in progress. The create operation will be cancelled.
40813160Could not set database as writable because the database is Premium (suspended).
40814160Could not change database edition to or from Premium for a Federation root.
40815160Could not change database edition to or from Premium for a Federation member.
40816160Could not change database edition to Premium for a database in a replication relationship.
40817160Could not change database edition from Premium for a database in a replication relationship.
40818160The replication operation on database '%ls' failed because there are alter operations pending on the database. Try again after the pending operations have completed.
40820160The server has reached its quota of (%d) premium databases.
40821160Federations are not supported on a Premium database.
40822160This feature is not available for the selected database's edition (%ls).
40823160Invalid proxy override option supplied.
40824160ProxyOverrideSupport feature switch is not turned ON.
40825160Unable to complete request now. Please try again later.
40827160The operation is not supported for your subscription offer type.
40838160Replication relationship limit reached. The database '%ls' cannot have more than one non-readable secondary.
40839160Connection to a non-readable secondary database is not allowed. See 'http://go.microsoft.com/fwlink/?LinkID=402429&clcid=0x409' for more information.
40840160Target region '%ls' is not a DR paired Azure region. See 'http://go.microsoft.com/fwlink/?LinkID=402430&clcid=0x409' for more information.
40841160Friendly termination of a non-readable replication relationship is not supported.
40842160Termination of the non-readable replication relationship for database '%ls' is currently not allowed. See 'http://go.microsoft.com/fwlink/?LinkID=402431&clcid=0x409' for more information
40843160Non-readable secondary is not supported for database copy.
40844160Database '%ls' on Server '%ls' is a '%ls' edition database in an elastic pool and cannot have a replication relationship.
40847160Could not perform the operation because server would exceed the allowed Database Throughput Unit quota of %d.
40848160The source database '%ls'.'%ls' cannot have higher performance level than the target database '%ls'.'%ls'. Upgrade the performance level on the target before upgrading source.
40849160The target database '%ls'.'%ls' cannot have lower performance level than the source database '%ls'.'%ls'. Downgrade the performance level on the source before downgrading target.
40850160Could not change database edition from '%ls' to Standard for database '%ls' in a replication relationship.
40851160Could not change database edition from '%ls' to Basic for database '%ls' in a replication relationship.
40852160Cannot open database '%.*ls' on server '%.*ls' requested by the login. Access to the database is only allowed using a security-enabled connection string.
40854160Partner server '%ls' is not compatible with server '%ls.'
40855160The operation cannot be performed since the database '%ls' is not in '%ls' state on the replication relationship.
40856160Could not change database edition for database '%ls' in a replication relationship.
40857160Elastic pool not found for server: '%ls', elastic pool name: '%ls'.
40858160Elastic pool '%ls' already exists in server: '%ls'
40859160Elastic pool does not support database edition '%ls'.
40860160Elastic pool '%ls' and service level objective '%ls' combination is invalid.
40861160The database edition '%ls' cannot be different than the elastic pool service tier which is '%ls'.
40862160Elastic pool name must be specified if the elastic pool service objective is specified.
40863160Connections to this database are no longer allowed.
40864160The DTUs for the elastic pool must be at least (%d) DTUs for service tier '%.*ls'.
40865160The DTUs for the elastic pool cannot exceed (%d) DTUs for service tier '%.*ls'.
40866160Max size (%d) is not valid. Please specify a valid max size.
40867160The DTU max per database must be at least (%d) for service tier '%.*ls'.
40868160The DTU max per database cannot exceed (%d) for service tier '%.*ls'.
40869160The DTU max per database (%d) for the elastic pool does not belong to the specified values for service tier '%.*ls'.
40870160The DTU min per database cannot exceed (%d) for service tier '%.*ls'.
40871160The DTU min per database (%d) for the elastic pool does not belong to the allowed values for service tier '%.*ls'.
40872160DTU value (%d) is not valid. Please specify a valid dtu value.
40873160The number of databases (%d) and DTU min per database (%d) cannot exceed the DTUs of the elastic pool (%d).
40874160The DTUs (%d) for the elastic pool does not belong to the specified values for service tier '%.*ls'.
40875160The elastic pool storage limit in gigabytes cannot exceed (%d) in service tier '%.*ls'.
40876160Elastic pools are not available in this region.
40877160The elastic pool is not empty.
40878160The elastic pool storage limit in gigabytes must be at least (%d) for service tier '%.*ls'.
40879160The elastic pool storage limit in gigabytes (%d) does not belong to the allowed values for service tier '%.*ls'.
40880160The DTUs (%d) for the elastic pool and the storage limit in gigabytes (%d) are inconsistent for service tier '%.*ls'.
40881160The elastic pool '%.*ls' has reached its database count limit. The database count for the elastic pool cannot exceed (%d) for service tier '%.*ls'.
40882160Can not change SLO from DataWarehouse edition to other SQL DB editions and vice versa.
40883160The service level objective '%.*ls' specified is invalid. It must be a slo supported by DataWarehouse edition.
40884160New service level objective '%.*ls' has (%d) physical databases and it is not compatible with current service level objective which has (%d) physical databases.
40885160Failed to deactivate database.
40886160Failed to change service level objective for database.
40887160Failed to activate database.
40888160Update service level objective for database feature is disabled.
40889160The DTUs or storage limit for the elastic pool '%.*ls' cannot be decreased since that would not provide sufficient storage space for its databases.
40890160The elastic pool is busy with another operation.
40891160The DTU min per database (%d) cannot exceed the DTU max per database (%d).
40892160Cannot connect to database when it is paused.
40893160The database copy link from '%s.%s' to '%s.%s' was not successfully created or was deleted before the data copy link operation completed.
40894160The database copy link from '%s.%s' to '%s.%s' is not in the catchup state after the data copy link operation completed.
40895160The database copy link from '%s.%s' to '%s.%s' was not successfully deleted before completion of copy.
40896160The database copy link from '%s.%s' to ID %s was not successfully dropped.
40897160The elastic pool storage limit in megabytes must be at least (%d) for service tier '%.*ls'.
40898160The elastic pool storage limit in megabytes (%d) does not belong to the allowed values for service tier '%.*ls'.
40899160The DTUs (%d) for the elastic pool and the storage limit in megabytes (%d) are inconsistent for service tier '%.*ls'.
40900160The service tier for an elastic pool cannot be changed.
40901160The elastic pool storage limit in megabytes cannot exceed (%d) in service tier '%.*ls'.
40902160Amount of pool storage cannot be specified when creating a Premium elastic pool.
40903200The server '%.*ls' is currently busy. Please wait a few minutes before trying again.
40904160Could not perform the operation because server would exceed the allowed Database Edition %s quota of %d.
40905160Location '%.*ls' is not accepting creation of new Azure SQL Database Servers of version '%.*ls' at this time. This location only supports the following server versions: '%.*ls'. Please retry using a supported server version.
40906160A service objective change cannot start for database %s on server %s while it is also running for database %s on server %s.
40907160Servers involved in a Disaster Recovery Configuration cannot reside in the same location
40908160A Disaster Recovery Configuration already exists for '%.*ls' and '%.*ls'
40909160A Disaster Recovery Configuration does not exist for '%.*ls' and '%.*ls'
40910160A Disaster Recovery Configuration does not exist for server '%.*ls' and virtual endpoint '%.*ls'
40911160Server '%.*ls' is not the secondary in the Disaster Recovery Configuration and cannot initiate a failover
40912160The value for custom backup retention in days must be between %d and %d
40913160Windows Azure SQL Database supports a maximum of %d Virtual Network firewall rules.
40914160Cannot open server '%.*ls' requested by the login. Client from a Virtual Network with Service Tunneling is not allowed to access the server.
40915160Secondary server specified in a Failover Group cannot reside in the same region
40916160The Failover Group '%.*ls' already exists on server '%.*ls'
40917160The Failover Group '%.*ls' does not exist on server '%.*ls'
40918160The Failover Group '%.*ls' is busy with another operation and cannot perform '%.*ls' operation. Please try again later
40919160The server '%.*ls' is currently the primary server in the Failover Group and cannot initate failover
40920160The database '%.*ls' is already included in another Failover Group
40921160The operation to add database '%.*ls' to Failover Group is in progress, please wait for this operation to finish
40922160The operation to remove database '%.*ls' from Failover Group is in progress, please wait for this operation to finish
40923160The database '%.*ls' is a secondary in an existing geo-replication relationship and cannot be added to the Failover Group
40924160The operation cannot be performed due to multiple errors: '%.*ls'
40925160Can not connect to the database in its current state.
40926160The operation cannot be performed because the geo-replication link is part of a Failover Group. You must remove the database from the group in order to individually terminate or failover.
40927160The endpoint '%.*ls' is already in use. Use a different Failover Group name.
40928160Create or update Failover Group operation successfully completed; however, some of the databases could not be added to or removed from Failover Group: '%.*ls'
40929160The source database '%ls.%ls' cannot have higher edition than the target database '%ls.%ls'. Upgrade the edition on the target before upgrading source.
40930160The target database '%ls.%ls' cannot have lower edition than the source database '%ls.%ls'. Downgrade the edition on the source before downgrading target.
40931160Failover Group name '%.*ls' cannot be empty or null. It can only be made up of lowercase letters 'a'-'z', the numbers 0-9 and the hyphen. The hyphen may not lead or trail in the name.
40932160The elastic pool cannot change its service tier since one or more of its databases use memory-optimized objects.
40933160The edition '%.*ls' does not support the database tempdb max size '%.*ls'.