github.com/pingcap/tidb/parser@v0.0.0-20231013125129-93a834a6bf8d/mysql/errname.go (about)

     1  // Copyright 2015 PingCAP, Inc.
     2  //
     3  // Licensed under the Apache License, Version 2.0 (the "License");
     4  // you may not use this file except in compliance with the License.
     5  // You may obtain a copy of the License at
     6  //
     7  //     http://www.apache.org/licenses/LICENSE-2.0
     8  //
     9  // Unless required by applicable law or agreed to in writing, software
    10  // distributed under the License is distributed on an "AS IS" BASIS,
    11  // See the License for the specific language governing permissions and
    12  // limitations under the License.
    13  
    14  package mysql
    15  
    16  // ErrMessage is a error message with the format specifier.
    17  type ErrMessage struct {
    18  	Raw          string
    19  	RedactArgPos []int
    20  }
    21  
    22  // Message creates a error message with the format specifier.
    23  func Message(message string, redactArgs []int) *ErrMessage {
    24  	return &ErrMessage{Raw: message, RedactArgPos: redactArgs}
    25  }
    26  
    27  // MySQLErrName maps error code to MySQL error messages.
    28  var MySQLErrName = map[uint16]*ErrMessage{
    29  	ErrHashchk:                                  Message("hashchk", nil),
    30  	ErrNisamchk:                                 Message("isamchk", nil),
    31  	ErrNo:                                       Message("NO", nil),
    32  	ErrYes:                                      Message("YES", nil),
    33  	ErrCantCreateFile:                           Message("Can't create file '%-.200s' (errno: %d - %s)", nil),
    34  	ErrCantCreateTable:                          Message("Can't create table '%-.200s' (errno: %d)", nil),
    35  	ErrCantCreateDB:                             Message("Can't create database '%-.192s' (errno: %d)", nil),
    36  	ErrDBCreateExists:                           Message("Can't create database '%-.192s'; database exists", nil),
    37  	ErrDBDropExists:                             Message("Can't drop database '%-.192s'; database doesn't exist", nil),
    38  	ErrDBDropDelete:                             Message("Error dropping database (can't delete '%-.192s', errno: %d)", nil),
    39  	ErrDBDropRmdir:                              Message("Error dropping database (can't rmdir '%-.192s', errno: %d)", nil),
    40  	ErrCantDeleteFile:                           Message("Error on delete of '%-.192s' (errno: %d - %s)", nil),
    41  	ErrCantFindSystemRec:                        Message("Can't read record in system table", nil),
    42  	ErrCantGetStat:                              Message("Can't get status of '%-.200s' (errno: %d - %s)", nil),
    43  	ErrCantGetWd:                                Message("Can't get working directory (errno: %d - %s)", nil),
    44  	ErrCantLock:                                 Message("Can't lock file (errno: %d - %s)", nil),
    45  	ErrCantOpenFile:                             Message("Can't open file: '%-.200s' (errno: %d - %s)", nil),
    46  	ErrFileNotFound:                             Message("Can't find file: '%-.200s' (errno: %d - %s)", nil),
    47  	ErrCantReadDir:                              Message("Can't read dir of '%-.192s' (errno: %d - %s)", nil),
    48  	ErrCantSetWd:                                Message("Can't change dir to '%-.192s' (errno: %d - %s)", nil),
    49  	ErrCheckread:                                Message("Record has changed since last read in table '%-.192s'", nil),
    50  	ErrDiskFull:                                 Message("Disk full (%s); waiting for someone to free some space... (errno: %d - %s)", nil),
    51  	ErrDupKey:                                   Message("Can't write; duplicate key in table '%-.192s'", nil),
    52  	ErrErrorOnClose:                             Message("Error on close of '%-.192s' (errno: %d - %s)", nil),
    53  	ErrErrorOnRead:                              Message("Error reading file '%-.200s' (errno: %d - %s)", nil),
    54  	ErrErrorOnRename:                            Message("Error on rename of '%-.210s' to '%-.210s' (errno: %d - %s)", nil),
    55  	ErrErrorOnWrite:                             Message("Error writing file '%-.200s' (errno: %d - %s)", nil),
    56  	ErrFileUsed:                                 Message("'%-.192s' is locked against change", nil),
    57  	ErrFilsortAbort:                             Message("Sort aborted", nil),
    58  	ErrFormNotFound:                             Message("View '%-.192s' doesn't exist for '%-.192s'", nil),
    59  	ErrGetErrno:                                 Message("Got error %d from storage engine", nil),
    60  	ErrIllegalHa:                                Message("Table storage engine for '%-.192s' doesn't have this option", nil),
    61  	ErrKeyNotFound:                              Message("Can't find record in '%-.192s'", nil),
    62  	ErrNotFormFile:                              Message("Incorrect information in file: '%-.200s'", nil),
    63  	ErrNotKeyFile:                               Message("Incorrect key file for table '%-.200s'; try to repair it", nil),
    64  	ErrOldKeyFile:                               Message("Old key file for table '%-.192s'; repair it!", nil),
    65  	ErrOpenAsReadonly:                           Message("Table '%-.192s' is read only", nil),
    66  	ErrOutofMemory:                              Message("Out of memory; restart server and try again (needed %d bytes)", nil),
    67  	ErrOutOfSortMemory:                          Message("Out of sort memory, consider increasing server sort buffer size", nil),
    68  	ErrUnexpectedEOF:                            Message("Unexpected EOF found when reading file '%-.192s' (errno: %d - %s)", nil),
    69  	ErrConCount:                                 Message("Too many connections", nil),
    70  	ErrOutOfResources:                           Message("Out of memory; check if mysqld or some other process uses all available memory; if not, you may have to use 'ulimit' to allow mysqld to use more memory or you can add more swap space", nil),
    71  	ErrBadHost:                                  Message("Can't get hostname for your address", nil),
    72  	ErrHandshake:                                Message("Bad handshake", nil),
    73  	ErrDBaccessDenied:                           Message("Access denied for user '%-.48s'@'%-.64s' to database '%-.192s'", nil),
    74  	ErrAccessDenied:                             Message("Access denied for user '%-.48s'@'%-.64s' (using password: %s)", nil),
    75  	ErrNoDB:                                     Message("No database selected", nil),
    76  	ErrUnknownCom:                               Message("Unknown command", nil),
    77  	ErrBadNull:                                  Message("Column '%-.192s' cannot be null", nil),
    78  	ErrBadDB:                                    Message("Unknown database '%-.192s'", nil),
    79  	ErrTableExists:                              Message("Table '%-.192s' already exists", nil),
    80  	ErrBadTable:                                 Message("Unknown table '%-.100s'", nil),
    81  	ErrNonUniq:                                  Message("Column '%-.192s' in %-.192s is ambiguous", nil),
    82  	ErrServerShutdown:                           Message("Server shutdown in progress", nil),
    83  	ErrBadField:                                 Message("Unknown column '%-.192s' in '%-.192s'", nil),
    84  	ErrFieldNotInGroupBy:                        Message("Expression #%d of %s is not in GROUP BY clause and contains nonaggregated column '%s' which is not functionally dependent on columns in GROUP BY clause; this is incompatible with sql_mode=only_full_group_by", nil),
    85  	ErrWrongGroupField:                          Message("Can't group on '%-.192s'", nil),
    86  	ErrWrongSumSelect:                           Message("Statement has sum functions and columns in same statement", nil),
    87  	ErrWrongValueCount:                          Message("Column count doesn't match value count", nil),
    88  	ErrTooLongIdent:                             Message("Identifier name '%-.100s' is too long", nil),
    89  	ErrDupFieldName:                             Message("Duplicate column name '%-.192s'", nil),
    90  	ErrDupKeyName:                               Message("Duplicate key name '%-.192s'", nil),
    91  	ErrDupEntry:                                 Message("Duplicate entry '%-.64s' for key '%-.192s'", nil),
    92  	ErrWrongFieldSpec:                           Message("Incorrect column specifier for column '%-.192s'", nil),
    93  	ErrParse:                                    Message("%s %s", nil),
    94  	ErrEmptyQuery:                               Message("Query was empty", nil),
    95  	ErrNonuniqTable:                             Message("Not unique table/alias: '%-.192s'", nil),
    96  	ErrInvalidDefault:                           Message("Invalid default value for '%-.192s'", nil),
    97  	ErrMultiplePriKey:                           Message("Multiple primary key defined", nil),
    98  	ErrTooManyKeys:                              Message("Too many keys specified; max %d keys allowed", nil),
    99  	ErrTooManyKeyParts:                          Message("Too many key parts specified; max %d parts allowed", nil),
   100  	ErrTooLongKey:                               Message("Specified key was too long (%d bytes); max key length is %d bytes", nil),
   101  	ErrKeyColumnDoesNotExits:                    Message("Key column '%-.192s' doesn't exist in table", nil),
   102  	ErrBlobUsedAsKey:                            Message("BLOB column '%-.192s' can't be used in key specification with the used table type", nil),
   103  	ErrTooBigFieldlength:                        Message("Column length too big for column '%-.192s' (max = %d); use BLOB or TEXT instead", nil),
   104  	ErrWrongAutoKey:                             Message("Incorrect table definition; there can be only one auto column and it must be defined as a key", nil),
   105  	ErrReady:                                    Message("%s: ready for connections.\nVersion: '%s'  socket: '%s'  port: %d", nil),
   106  	ErrNormalShutdown:                           Message("%s: Normal shutdown\n", nil),
   107  	ErrGotSignal:                                Message("%s: Got signal %d. Aborting!\n", nil),
   108  	ErrShutdownComplete:                         Message("%s: Shutdown complete\n", nil),
   109  	ErrForcingClose:                             Message("%s: Forcing close of thread %d  user: '%-.48s'\n", nil),
   110  	ErrIpsock:                                   Message("Can't create IP socket", nil),
   111  	ErrNoSuchIndex:                              Message("Table '%-.192s' has no index like the one used in CREATE INDEX; recreate the table", nil),
   112  	ErrWrongFieldTerminators:                    Message("Field separator argument is not what is expected; check the manual", nil),
   113  	ErrBlobsAndNoTerminated:                     Message("You can't use fixed rowlength with BLOBs; please use 'fields terminated by'", nil),
   114  	ErrTextFileNotReadable:                      Message("The file '%-.128s' must be in the database directory or be readable by all", nil),
   115  	ErrFileExists:                               Message("File '%-.200s' already exists", nil),
   116  	ErrLoadInfo:                                 Message("Records: %d  Deleted: %d  Skipped: %d  Warnings: %d", nil),
   117  	ErrAlterInfo:                                Message("Records: %d  Duplicates: %d", nil),
   118  	ErrWrongSubKey:                              Message("Incorrect prefix key; the used key part isn't a string, the used length is longer than the key part, or the storage engine doesn't support unique prefix keys", nil),
   119  	ErrCantRemoveAllFields:                      Message("You can't delete all columns with ALTER TABLE; use DROP TABLE instead", nil),
   120  	ErrCantDropFieldOrKey:                       Message("Can't DROP '%-.192s'; check that column/key exists", nil),
   121  	ErrInsertInfo:                               Message("Records: %d  Duplicates: %d  Warnings: %d", nil),
   122  	ErrUpdateTableUsed:                          Message("You can't specify target table '%-.192s' for update in FROM clause", nil),
   123  	ErrNoSuchThread:                             Message("Unknown thread id: %d", nil),
   124  	ErrKillDenied:                               Message("You are not owner of thread %d", nil),
   125  	ErrNoTablesUsed:                             Message("No tables used", nil),
   126  	ErrTooBigSet:                                Message("Too many strings for column %-.192s and SET", nil),
   127  	ErrNoUniqueLogFile:                          Message("Can't generate a unique log-filename %-.200s.(1-999)\n", nil),
   128  	ErrTableNotLockedForWrite:                   Message("Table '%-.192s' was locked with a READ lock and can't be updated", nil),
   129  	ErrTableNotLocked:                           Message("Table '%-.192s' was not locked with LOCK TABLES", nil),
   130  	ErrBlobCantHaveDefault:                      Message("BLOB/TEXT/JSON column '%-.192s' can't have a default value", nil),
   131  	ErrWrongDBName:                              Message("Incorrect database name '%-.100s'", nil),
   132  	ErrWrongTableName:                           Message("Incorrect table name '%-.100s'", nil),
   133  	ErrTooBigSelect:                             Message("The SELECT would examine more than MAXJOINSIZE rows; check your WHERE and use SET SQLBIGSELECTS=1 or SET MAXJOINSIZE=# if the SELECT is okay", nil),
   134  	ErrUnknown:                                  Message("Unknown error", nil),
   135  	ErrUnknownProcedure:                         Message("Unknown procedure '%-.192s'", nil),
   136  	ErrWrongParamcountToProcedure:               Message("Incorrect parameter count to procedure '%-.192s'", nil),
   137  	ErrWrongParametersToProcedure:               Message("Incorrect parameters to procedure '%-.192s'", nil),
   138  	ErrUnknownTable:                             Message("Unknown table '%-.192s' in %-.32s", nil),
   139  	ErrFieldSpecifiedTwice:                      Message("Column '%-.192s' specified twice", nil),
   140  	ErrInvalidGroupFuncUse:                      Message("Invalid use of group function", nil),
   141  	ErrUnsupportedExtension:                     Message("Table '%-.192s' uses an extension that doesn't exist in this MySQL version", nil),
   142  	ErrTableMustHaveColumns:                     Message("A table must have at least 1 column", nil),
   143  	ErrRecordFileFull:                           Message("The table '%-.192s' is full", nil),
   144  	ErrUnknownCharacterSet:                      Message("Unknown character set: '%-.64s'", nil),
   145  	ErrTooManyTables:                            Message("Too many tables; MySQL can only use %d tables in a join", nil),
   146  	ErrTooManyFields:                            Message("Too many columns", nil),
   147  	ErrTooBigRowsize:                            Message("Row size too large. The maximum row size for the used table type, not counting BLOBs, is %d. This includes storage overhead, check the manual. You have to change some columns to TEXT or BLOBs", nil),
   148  	ErrStackOverrun:                             Message("Thread stack overrun:  Used: %d of a %d stack.  Use 'mysqld --threadStack=#' to specify a bigger stack if needed", nil),
   149  	ErrWrongOuterJoin:                           Message("Cross dependency found in OUTER JOIN; examine your ON conditions", nil),
   150  	ErrNullColumnInIndex:                        Message("Table handler doesn't support NULL in given index. Please change column '%-.192s' to be NOT NULL or use another handler", nil),
   151  	ErrCantFindUdf:                              Message("Can't load function '%-.192s'", nil),
   152  	ErrCantInitializeUdf:                        Message("Can't initialize function '%-.192s'; %-.80s", nil),
   153  	ErrUdfNoPaths:                               Message("No paths allowed for shared library", nil),
   154  	ErrUdfExists:                                Message("Function '%-.192s' already exists", nil),
   155  	ErrCantOpenLibrary:                          Message("Can't open shared library '%-.192s' (errno: %d %-.128s)", nil),
   156  	ErrCantFindDlEntry:                          Message("Can't find symbol '%-.128s' in library", nil),
   157  	ErrFunctionNotDefined:                       Message("Function '%-.192s' is not defined", nil),
   158  	ErrHostIsBlocked:                            Message("Host '%-.64s' is blocked because of many connection errors; unblock with 'mysqladmin flush-hosts'", nil),
   159  	ErrHostNotPrivileged:                        Message("Host '%-.64s' is not allowed to connect to this MySQL server", nil),
   160  	ErrPasswordAnonymousUser:                    Message("You are using MySQL as an anonymous user and anonymous users are not allowed to change passwords", nil),
   161  	ErrPasswordNotAllowed:                       Message("You must have privileges to update tables in the mysql database to be able to change passwords for others", nil),
   162  	ErrPasswordNoMatch:                          Message("Can't find any matching row in the user table", nil),
   163  	ErrUpdateInfo:                               Message("Rows matched: %d  Changed: %d  Warnings: %d", nil),
   164  	ErrCantCreateThread:                         Message("Can't create a new thread (errno %d); if you are not out of available memory, you can consult the manual for a possible OS-dependent bug", nil),
   165  	ErrWrongValueCountOnRow:                     Message("Column count doesn't match value count at row %d", nil),
   166  	ErrCantReopenTable:                          Message("Can't reopen table: '%-.192s'", nil),
   167  	ErrInvalidUseOfNull:                         Message("Invalid use of NULL value", nil),
   168  	ErrRegexp:                                   Message("Got error '%-.64s' from regexp", nil),
   169  	ErrMixOfGroupFuncAndFields:                  Message("Mixing of GROUP columns (MIN(),MAX(),COUNT(),...) with no GROUP columns is illegal if there is no GROUP BY clause", nil),
   170  	ErrNonexistingGrant:                         Message("There is no such grant defined for user '%-.48s' on host '%-.64s'", nil),
   171  	ErrTableaccessDenied:                        Message("%-.128s command denied to user '%-.48s'@'%-.64s' for table '%-.64s'", nil),
   172  	ErrColumnaccessDenied:                       Message("%-.16s command denied to user '%-.48s'@'%-.64s' for column '%-.192s' in table '%-.192s'", nil),
   173  	ErrIllegalGrantForTable:                     Message("Illegal GRANT/REVOKE command; please consult the manual to see which privileges can be used", nil),
   174  	ErrGrantWrongHostOrUser:                     Message("The host or user argument to GRANT is too long", nil),
   175  	ErrNoSuchTable:                              Message("Table '%-.192s.%-.192s' doesn't exist", nil),
   176  	ErrNonexistingTableGrant:                    Message("There is no such grant defined for user '%-.48s' on host '%-.64s' on table '%-.192s'", nil),
   177  	ErrNotAllowedCommand:                        Message("The used command is not allowed with this MySQL version", nil),
   178  	ErrSyntax:                                   Message("You have an error in your SQL syntax; check the manual that corresponds to your MySQL server version for the right syntax to use", nil),
   179  	ErrDelayedCantChangeLock:                    Message("Delayed insert thread couldn't get requested lock for table %-.192s", nil),
   180  	ErrTooManyDelayedThreads:                    Message("Too many delayed threads in use", nil),
   181  	ErrAbortingConnection:                       Message("Aborted connection %d to db: '%-.192s' user: '%-.48s' (%-.64s)", nil),
   182  	ErrNetPacketTooLarge:                        Message("Got a packet bigger than 'max_allowed_packet' bytes", nil),
   183  	ErrNetReadErrorFromPipe:                     Message("Got a read error from the connection pipe", nil),
   184  	ErrNetFcntl:                                 Message("Got an error from fcntl()", nil),
   185  	ErrNetPacketsOutOfOrder:                     Message("Got packets out of order", nil),
   186  	ErrNetUncompress:                            Message("Couldn't uncompress communication packet", nil),
   187  	ErrNetRead:                                  Message("Got an error reading communication packets", nil),
   188  	ErrNetReadInterrupted:                       Message("Got timeout reading communication packets", nil),
   189  	ErrNetErrorOnWrite:                          Message("Got an error writing communication packets", nil),
   190  	ErrNetWriteInterrupted:                      Message("Got timeout writing communication packets", nil),
   191  	ErrTooLongString:                            Message("Result string is longer than 'maxAllowedPacket' bytes", nil),
   192  	ErrTableCantHandleBlob:                      Message("The used table type doesn't support BLOB/TEXT columns", nil),
   193  	ErrTableCantHandleAutoIncrement:             Message("The used table type doesn't support AUTOINCREMENT columns", nil),
   194  	ErrDelayedInsertTableLocked:                 Message("INSERT DELAYED can't be used with table '%-.192s' because it is locked with LOCK TABLES", nil),
   195  	ErrWrongColumnName:                          Message("Incorrect column name '%-.100s'", nil),
   196  	ErrWrongKeyColumn:                           Message("The used storage engine can't index column '%-.192s'", nil),
   197  	ErrWrongMrgTable:                            Message("Unable to open underlying table which is differently defined or of non-MyISAM type or doesn't exist", nil),
   198  	ErrDupUnique:                                Message("Can't write, because of unique constraint, to table '%-.192s'", nil),
   199  	ErrBlobKeyWithoutLength:                     Message("BLOB/TEXT column '%-.192s' used in key specification without a key length", nil),
   200  	ErrPrimaryCantHaveNull:                      Message("All parts of a PRIMARY KEY must be NOT NULL; if you need NULL in a key, use UNIQUE instead", nil),
   201  	ErrTooManyRows:                              Message("Result consisted of more than one row", nil),
   202  	ErrRequiresPrimaryKey:                       Message("This table type requires a primary key", nil),
   203  	ErrNoRaidCompiled:                           Message("This version of MySQL is not compiled with RAID support", nil),
   204  	ErrUpdateWithoutKeyInSafeMode:               Message("You are using safe update mode and you tried to update a table without a WHERE that uses a KEY column", nil),
   205  	ErrKeyDoesNotExist:                          Message("Key '%-.192s' doesn't exist in table '%-.192s'", nil),
   206  	ErrCheckNoSuchTable:                         Message("Can't open table", nil),
   207  	ErrCheckNotImplemented:                      Message("The storage engine for the table doesn't support %s", nil),
   208  	ErrCantDoThisDuringAnTransaction:            Message("You are not allowed to execute this command in a transaction", nil),
   209  	ErrErrorDuringCommit:                        Message("Got error %d during COMMIT", nil),
   210  	ErrErrorDuringRollback:                      Message("Got error %d during ROLLBACK", nil),
   211  	ErrErrorDuringFlushLogs:                     Message("Got error %d during FLUSHLOGS", nil),
   212  	ErrErrorDuringCheckpoint:                    Message("Got error %d during CHECKPOINT", nil),
   213  	ErrNewAbortingConnection:                    Message("Aborted connection %d to db: '%-.192s' user: '%-.48s' host: '%-.64s' (%-.64s)", nil),
   214  	ErrDumpNotImplemented:                       Message("The storage engine for the table does not support binary table dump", nil),
   215  	ErrFlushMasterBinlogClosed:                  Message("Binlog closed, cannot RESET MASTER", nil),
   216  	ErrIndexRebuild:                             Message("Failed rebuilding the index of  dumped table '%-.192s'", nil),
   217  	ErrMaster:                                   Message("Error from master: '%-.64s'", nil),
   218  	ErrMasterNetRead:                            Message("Net error reading from master", nil),
   219  	ErrMasterNetWrite:                           Message("Net error writing to master", nil),
   220  	ErrFtMatchingKeyNotFound:                    Message("Can't find FULLTEXT index matching the column list", nil),
   221  	ErrLockOrActiveTransaction:                  Message("Can't execute the given command because you have active locked tables or an active transaction", nil),
   222  	ErrUnknownSystemVariable:                    Message("Unknown system variable '%-.64s'", nil),
   223  	ErrCrashedOnUsage:                           Message("Table '%-.192s' is marked as crashed and should be repaired", nil),
   224  	ErrCrashedOnRepair:                          Message("Table '%-.192s' is marked as crashed and last (automatic?) repair failed", nil),
   225  	ErrWarningNotCompleteRollback:               Message("Some non-transactional changed tables couldn't be rolled back", nil),
   226  	ErrTransCacheFull:                           Message("Multi-statement transaction required more than 'maxBinlogCacheSize' bytes of storage; increase this mysqld variable and try again", nil),
   227  	ErrSlaveMustStop:                            Message("This operation cannot be performed with a running slave; run STOP SLAVE first", nil),
   228  	ErrSlaveNotRunning:                          Message("This operation requires a running slave; configure slave and do START SLAVE", nil),
   229  	ErrBadSlave:                                 Message("The server is not configured as slave; fix in config file or with CHANGE MASTER TO", nil),
   230  	ErrMasterInfo:                               Message("Could not initialize master info structure; more error messages can be found in the MySQL error log", nil),
   231  	ErrSlaveThread:                              Message("Could not create slave thread; check system resources", nil),
   232  	ErrTooManyUserConnections:                   Message("User %-.64s already has more than 'maxUserConnections' active connections", nil),
   233  	ErrSetConstantsOnly:                         Message("You may only use constant expressions with SET", nil),
   234  	ErrLockWaitTimeout:                          Message("Lock wait timeout exceeded; try restarting transaction", nil),
   235  	ErrLockTableFull:                            Message("The total number of locks exceeds the lock table size", nil),
   236  	ErrReadOnlyTransaction:                      Message("Update locks cannot be acquired during a READ UNCOMMITTED transaction", nil),
   237  	ErrDropDBWithReadLock:                       Message("DROP DATABASE not allowed while thread is holding global read lock", nil),
   238  	ErrCreateDBWithReadLock:                     Message("CREATE DATABASE not allowed while thread is holding global read lock", nil),
   239  	ErrWrongArguments:                           Message("Incorrect arguments to %s", nil),
   240  	ErrNoPermissionToCreateUser:                 Message("'%-.48s'@'%-.64s' is not allowed to create new users", nil),
   241  	ErrUnionTablesInDifferentDir:                Message("Incorrect table definition; all MERGE tables must be in the same database", nil),
   242  	ErrLockDeadlock:                             Message("Deadlock found when trying to get lock; try restarting transaction", nil),
   243  	ErrTableCantHandleFt:                        Message("The used table type doesn't support FULLTEXT indexes", nil),
   244  	ErrCannotAddForeign:                         Message("Cannot add foreign key constraint", nil),
   245  	ErrNoReferencedRow:                          Message("Cannot add or update a child row: a foreign key constraint fails", nil),
   246  	ErrRowIsReferenced:                          Message("Cannot delete or update a parent row: a foreign key constraint fails", nil),
   247  	ErrConnectToMaster:                          Message("Error connecting to master: %-.128s", nil),
   248  	ErrQueryOnMaster:                            Message("Error running query on master: %-.128s", nil),
   249  	ErrErrorWhenExecutingCommand:                Message("Error when executing command %s: %-.128s", nil),
   250  	ErrWrongUsage:                               Message("Incorrect usage of %s and %s", nil),
   251  	ErrWrongNumberOfColumnsInSelect:             Message("The used SELECT statements have a different number of columns", nil),
   252  	ErrCantUpdateWithReadlock:                   Message("Can't execute the query because you have a conflicting read lock", nil),
   253  	ErrMixingNotAllowed:                         Message("Mixing of transactional and non-transactional tables is disabled", nil),
   254  	ErrDupArgument:                              Message("Option '%s' used twice in statement", nil),
   255  	ErrUserLimitReached:                         Message("User '%-.64s' has exceeded the '%s' resource (current value: %d)", nil),
   256  	ErrSpecificAccessDenied:                     Message("Access denied; you need (at least one of) the %-.128s privilege(s) for this operation", nil),
   257  	ErrLocalVariable:                            Message("Variable '%-.64s' is a SESSION variable and can't be used with SET GLOBAL", nil),
   258  	ErrGlobalVariable:                           Message("Variable '%-.64s' is a GLOBAL variable and should be set with SET GLOBAL", nil),
   259  	ErrNoDefault:                                Message("Variable '%-.64s' doesn't have a default value", nil),
   260  	ErrWrongValueForVar:                         Message("Variable '%-.64s' can't be set to the value of '%-.200s'", nil),
   261  	ErrWrongTypeForVar:                          Message("Incorrect argument type to variable '%-.64s'", nil),
   262  	ErrVarCantBeRead:                            Message("Variable '%-.64s' can only be set, not read", nil),
   263  	ErrCantUseOptionHere:                        Message("Incorrect usage/placement of '%s'", nil),
   264  	ErrNotSupportedYet:                          Message("This version of TiDB doesn't yet support '%s'", nil),
   265  	ErrMasterFatalErrorReadingBinlog:            Message("Got fatal error %d from master when reading data from binary log: '%-.320s'", nil),
   266  	ErrSlaveIgnoredTable:                        Message("Slave SQL thread ignored the query because of replicate-*-table rules", nil),
   267  	ErrIncorrectGlobalLocalVar:                  Message("Variable '%-.192s' is a %s variable", nil),
   268  	ErrWrongFkDef:                               Message("Incorrect foreign key definition for '%-.192s': %s", nil),
   269  	ErrKeyRefDoNotMatchTableRef:                 Message("Key reference and table reference don't match", nil),
   270  	ErrOperandColumns:                           Message("Operand should contain %d column(s)", nil),
   271  	ErrSubqueryNo1Row:                           Message("Subquery returns more than 1 row", nil),
   272  	ErrUnknownStmtHandler:                       Message("Unknown prepared statement handler %s given to %s", nil),
   273  	ErrCorruptHelpDB:                            Message("Help database is corrupt or does not exist", nil),
   274  	ErrCyclicReference:                          Message("Cyclic reference on subqueries", nil),
   275  	ErrAutoConvert:                              Message("Converting column '%s' from %s to %s", nil),
   276  	ErrIllegalReference:                         Message("Reference '%-.64s' not supported (%s)", nil),
   277  	ErrDerivedMustHaveAlias:                     Message("Every derived table must have its own alias", nil),
   278  	ErrSelectReduced:                            Message("Select %d was reduced during optimization", nil),
   279  	ErrTablenameNotAllowedHere:                  Message("Table '%s' from one of the %ss cannot be used in %s", nil),
   280  	ErrNotSupportedAuthMode:                     Message("Client does not support authentication protocol requested by server; consider upgrading MySQL client", nil),
   281  	ErrSpatialCantHaveNull:                      Message("All parts of a SPATIAL index must be NOT NULL", nil),
   282  	ErrCollationCharsetMismatch:                 Message("COLLATION '%s' is not valid for CHARACTER SET '%s'", nil),
   283  	ErrSlaveWasRunning:                          Message("Slave is already running", nil),
   284  	ErrSlaveWasNotRunning:                       Message("Slave already has been stopped", nil),
   285  	ErrTooBigForUncompress:                      Message("Uncompressed data size too large; the maximum size is %d (probably, length of uncompressed data was corrupted)", nil),
   286  	ErrZlibZMem:                                 Message("ZLIB: Not enough memory", nil),
   287  	ErrZlibZBuf:                                 Message("ZLIB: Not enough room in the output buffer (probably, length of uncompressed data was corrupted)", nil),
   288  	ErrZlibZData:                                Message("ZLIB: Input data corrupted", nil),
   289  	ErrCutValueGroupConcat:                      Message("Some rows were cut by GROUPCONCAT(%s)", nil),
   290  	ErrWarnTooFewRecords:                        Message("Row %d doesn't contain data for all columns", nil),
   291  	ErrWarnTooManyRecords:                       Message("Row %d was truncated; it contained more data than there were input columns", nil),
   292  	ErrWarnNullToNotnull:                        Message("Column set to default value; NULL supplied to NOT NULL column '%s' at row %d", nil),
   293  	ErrWarnDataOutOfRange:                       Message("Out of range value for column '%s' at row %d", nil),
   294  	WarnDataTruncated:                           Message("Data truncated for column '%s' at row %d", nil),
   295  	ErrWarnUsingOtherHandler:                    Message("Using storage engine %s for table '%s'", nil),
   296  	ErrCantAggregate2collations:                 Message("Illegal mix of collations (%s,%s) and (%s,%s) for operation '%s'", nil),
   297  	ErrDropUser:                                 Message("Cannot drop one or more of the requested users", nil),
   298  	ErrRevokeGrants:                             Message("Can't revoke all privileges for one or more of the requested users", nil),
   299  	ErrCantAggregate3collations:                 Message("Illegal mix of collations (%s,%s), (%s,%s), (%s,%s) for operation '%s'", nil),
   300  	ErrCantAggregateNcollations:                 Message("Illegal mix of collations for operation '%s'", nil),
   301  	ErrVariableIsNotStruct:                      Message("Variable '%-.64s' is not a variable component (can't be used as XXXX.variableName)", nil),
   302  	ErrUnknownCollation:                         Message("Unknown collation: '%-.64s'", nil),
   303  	ErrSlaveIgnoredSslParams:                    Message("SSL parameters in CHANGE MASTER are ignored because this MySQL slave was compiled without SSL support; they can be used later if MySQL slave with SSL is started", nil),
   304  	ErrServerIsInSecureAuthMode:                 Message("Server is running in --secure-auth mode, but '%s'@'%s' has a password in the old format; please change the password to the new format", nil),
   305  	ErrWarnFieldResolved:                        Message("Field or reference '%-.192s%s%-.192s%s%-.192s' of SELECT #%d was resolved in SELECT #%d", nil),
   306  	ErrBadSlaveUntilCond:                        Message("Incorrect parameter or combination of parameters for START SLAVE UNTIL", nil),
   307  	ErrMissingSkipSlave:                         Message("It is recommended to use --skip-slave-start when doing step-by-step replication with START SLAVE UNTIL; otherwise, you will get problems if you get an unexpected slave's mysqld restart", nil),
   308  	ErrUntilCondIgnored:                         Message("SQL thread is not to be started so UNTIL options are ignored", nil),
   309  	ErrWrongNameForIndex:                        Message("Incorrect index name '%-.100s'", nil),
   310  	ErrWrongNameForCatalog:                      Message("Incorrect catalog name '%-.100s'", nil),
   311  	ErrWarnQcResize:                             Message("Query cache failed to set size %d; new query cache size is %d", nil),
   312  	ErrBadFtColumn:                              Message("Column '%-.192s' cannot be part of FULLTEXT index", nil),
   313  	ErrUnknownKeyCache:                          Message("Unknown key cache '%-.100s'", nil),
   314  	ErrWarnHostnameWontWork:                     Message("MySQL is started in --skip-name-resolve mode; you must restart it without this switch for this grant to work", nil),
   315  	ErrUnknownStorageEngine:                     Message("Unknown storage engine '%s'", nil),
   316  	ErrWarnDeprecatedSyntax:                     Message("'%s' is deprecated and will be removed in a future release. Please use %s instead", nil),
   317  	ErrNonUpdatableTable:                        Message("The target table %-.100s of the %s is not updatable", nil),
   318  	ErrFeatureDisabled:                          Message("The '%s' feature is disabled; you need MySQL built with '%s' to have it working", nil),
   319  	ErrOptionPreventsStatement:                  Message("The MySQL server is running with the %s option so it cannot execute this statement", nil),
   320  	ErrDuplicatedValueInType:                    Message("Column '%-.100s' has duplicated value '%-.64s' in %s", nil),
   321  	ErrTruncatedWrongValue:                      Message("Truncated incorrect %-.64s value: '%-.128s'", nil),
   322  	ErrTooMuchAutoTimestampCols:                 Message("Incorrect table definition; there can be only one TIMESTAMP column with CURRENTTIMESTAMP in DEFAULT or ON UPDATE clause", nil),
   323  	ErrInvalidOnUpdate:                          Message("Invalid ON UPDATE clause for '%-.192s' column", nil),
   324  	ErrUnsupportedPs:                            Message("This command is not supported in the prepared statement protocol yet", nil),
   325  	ErrGetErrmsg:                                Message("Got error %d '%-.100s' from %s", nil),
   326  	ErrGetTemporaryErrmsg:                       Message("Got temporary error %d '%-.100s' from %s", nil),
   327  	ErrUnknownTimeZone:                          Message("Unknown or incorrect time zone: '%-.64s'", nil),
   328  	ErrWarnInvalidTimestamp:                     Message("Invalid TIMESTAMP value in column '%s' at row %d", nil),
   329  	ErrInvalidCharacterString:                   Message("Invalid %s character string: '%.64s'", nil),
   330  	ErrWarnAllowedPacketOverflowed:              Message("Result of %s() was larger than max_allowed_packet (%d) - truncated", nil),
   331  	ErrConflictingDeclarations:                  Message("Conflicting declarations: '%s%s' and '%s%s'", nil),
   332  	ErrSpNoRecursiveCreate:                      Message("Can't create a %s from within another stored routine", nil),
   333  	ErrSpAlreadyExists:                          Message("%s %s already exists", nil),
   334  	ErrSpDoesNotExist:                           Message("%s %s does not exist", nil),
   335  	ErrSpDropFailed:                             Message("Failed to DROP %s %s", nil),
   336  	ErrSpStoreFailed:                            Message("Failed to CREATE %s %s", nil),
   337  	ErrSpLilabelMismatch:                        Message("%s with no matching label: %s", nil),
   338  	ErrSpLabelRedefine:                          Message("Redefining label %s", nil),
   339  	ErrSpLabelMismatch:                          Message("End-label %s without match", nil),
   340  	ErrSpUninitVar:                              Message("Referring to uninitialized variable %s", nil),
   341  	ErrSpBadselect:                              Message("PROCEDURE %s can't return a result set in the given context", nil),
   342  	ErrSpBadreturn:                              Message("RETURN is only allowed in a FUNCTION", nil),
   343  	ErrSpBadstatement:                           Message("%s is not allowed in stored procedures", nil),
   344  	ErrUpdateLogDeprecatedIgnored:               Message("The update log is deprecated and replaced by the binary log; SET SQLLOGUPDATE has been ignored.", nil),
   345  	ErrUpdateLogDeprecatedTranslated:            Message("The update log is deprecated and replaced by the binary log; SET SQLLOGUPDATE has been translated to SET SQLLOGBIN.", nil),
   346  	ErrQueryInterrupted:                         Message("Query execution was interrupted", nil),
   347  	ErrSpWrongNoOfArgs:                          Message("Incorrect number of arguments for %s %s; expected %d, got %d", nil),
   348  	ErrSpCondMismatch:                           Message("Undefined CONDITION: %s", nil),
   349  	ErrSpNoreturn:                               Message("No RETURN found in FUNCTION %s", nil),
   350  	ErrSpNoreturnend:                            Message("FUNCTION %s ended without RETURN", nil),
   351  	ErrSpBadCursorQuery:                         Message("Cursor statement must be a SELECT", nil),
   352  	ErrSpBadCursorSelect:                        Message("Cursor SELECT must not have INTO", nil),
   353  	ErrSpCursorMismatch:                         Message("Undefined CURSOR: %s", nil),
   354  	ErrSpCursorAlreadyOpen:                      Message("Cursor is already open", nil),
   355  	ErrSpCursorNotOpen:                          Message("Cursor is not open", nil),
   356  	ErrSpUndeclaredVar:                          Message("Undeclared variable: %s", nil),
   357  	ErrSpWrongNoOfFetchArgs:                     Message("Incorrect number of FETCH variables", nil),
   358  	ErrSpFetchNoData:                            Message("No data - zero rows fetched, selected, or processed", nil),
   359  	ErrSpDupParam:                               Message("Duplicate parameter: %s", nil),
   360  	ErrSpDupVar:                                 Message("Duplicate variable: %s", nil),
   361  	ErrSpDupCond:                                Message("Duplicate condition: %s", nil),
   362  	ErrSpDupCurs:                                Message("Duplicate cursor: %s", nil),
   363  	ErrSpCantAlter:                              Message("Failed to ALTER %s %s", nil),
   364  	ErrSpSubselectNyi:                           Message("Subquery value not supported", nil),
   365  	ErrStmtNotAllowedInSfOrTrg:                  Message("%s is not allowed in stored function or trigger", nil),
   366  	ErrSpVarcondAfterCurshndlr:                  Message("Variable or condition declaration after cursor or handler declaration", nil),
   367  	ErrSpCursorAfterHandler:                     Message("Cursor declaration after handler declaration", nil),
   368  	ErrSpCaseNotFound:                           Message("Case not found for CASE statement", nil),
   369  	ErrFparserTooBigFile:                        Message("Configuration file '%-.192s' is too big", nil),
   370  	ErrFparserBadHeader:                         Message("Malformed file type header in file '%-.192s'", nil),
   371  	ErrFparserEOFInComment:                      Message("Unexpected end of file while parsing comment '%-.200s'", nil),
   372  	ErrFparserErrorInParameter:                  Message("Error while parsing parameter '%-.192s' (line: '%-.192s')", nil),
   373  	ErrFparserEOFInUnknownParameter:             Message("Unexpected end of file while skipping unknown parameter '%-.192s'", nil),
   374  	ErrViewNoExplain:                            Message("EXPLAIN/SHOW can not be issued; lacking privileges for underlying table", nil),
   375  	ErrFrmUnknownType:                           Message("File '%-.192s' has unknown type '%-.64s' in its header", nil),
   376  	ErrWrongObject:                              Message("'%-.192s.%-.192s' is not %s", nil),
   377  	ErrNonupdateableColumn:                      Message("Column '%-.192s' is not updatable", nil),
   378  	ErrViewSelectDerived:                        Message("View's SELECT contains a subquery in the FROM clause", nil),
   379  	ErrViewSelectClause:                         Message("View's SELECT contains a '%s' clause", nil),
   380  	ErrViewSelectVariable:                       Message("View's SELECT contains a variable or parameter", nil),
   381  	ErrViewSelectTmptable:                       Message("View's SELECT refers to a temporary table '%-.192s'", nil),
   382  	ErrViewWrongList:                            Message("View's SELECT and view's field list have different column counts", nil),
   383  	ErrWarnViewMerge:                            Message("View merge algorithm can't be used here for now (assumed undefined algorithm)", nil),
   384  	ErrWarnViewWithoutKey:                       Message("View being updated does not have complete key of underlying table in it", nil),
   385  	ErrViewInvalid:                              Message("View '%-.192s.%-.192s' references invalid table(s) or column(s) or function(s) or definer/invoker of view lack rights to use them", nil),
   386  	ErrSpNoDropSp:                               Message("Can't drop or alter a %s from within another stored routine", nil),
   387  	ErrSpGotoInHndlr:                            Message("GOTO is not allowed in a stored procedure handler", nil),
   388  	ErrTrgAlreadyExists:                         Message("Trigger already exists", nil),
   389  	ErrTrgDoesNotExist:                          Message("Trigger does not exist", nil),
   390  	ErrTrgOnViewOrTempTable:                     Message("Trigger's '%-.192s' is view or temporary table", nil),
   391  	ErrTrgCantChangeRow:                         Message("Updating of %s row is not allowed in %strigger", nil),
   392  	ErrTrgNoSuchRowInTrg:                        Message("There is no %s row in %s trigger", nil),
   393  	ErrNoDefaultForField:                        Message("Field '%-.192s' doesn't have a default value", nil),
   394  	ErrDivisionByZero:                           Message("Division by 0", nil),
   395  	ErrTruncatedWrongValueForField:              Message("Incorrect %-.32s value: '%-.128s' for column '%.192s' at row %d", nil),
   396  	ErrIllegalValueForType:                      Message("Illegal %s '%-.192s' value found during parsing", nil),
   397  	ErrViewNonupdCheck:                          Message("CHECK OPTION on non-updatable view '%-.192s.%-.192s'", nil),
   398  	ErrViewCheckFailed:                          Message("CHECK OPTION failed '%-.192s.%-.192s'", nil),
   399  	ErrProcaccessDenied:                         Message("%-.16s command denied to user '%-.48s'@'%-.64s' for routine '%-.192s'", nil),
   400  	ErrRelayLogFail:                             Message("Failed purging old relay logs: %s", nil),
   401  	ErrPasswdLength:                             Message("Password hash should be a %d-digit hexadecimal number", nil),
   402  	ErrUnknownTargetBinlog:                      Message("Target log not found in binlog index", nil),
   403  	ErrIoErrLogIndexRead:                        Message("I/O error reading log index file", nil),
   404  	ErrBinlogPurgeProhibited:                    Message("Server configuration does not permit binlog purge", nil),
   405  	ErrFseekFail:                                Message("Failed on fseek()", nil),
   406  	ErrBinlogPurgeFatalErr:                      Message("Fatal error during log purge", nil),
   407  	ErrLogInUse:                                 Message("A purgeable log is in use, will not purge", nil),
   408  	ErrLogPurgeUnknownErr:                       Message("Unknown error during log purge", nil),
   409  	ErrRelayLogInit:                             Message("Failed initializing relay log position: %s", nil),
   410  	ErrNoBinaryLogging:                          Message("You are not using binary logging", nil),
   411  	ErrReservedSyntax:                           Message("The '%-.64s' syntax is reserved for purposes internal to the MySQL server", nil),
   412  	ErrWsasFailed:                               Message("WSAStartup Failed", nil),
   413  	ErrDiffGroupsProc:                           Message("Can't handle procedures with different groups yet", nil),
   414  	ErrNoGroupForProc:                           Message("Select must have a group with this procedure", nil),
   415  	ErrOrderWithProc:                            Message("Can't use ORDER clause with this procedure", nil),
   416  	ErrLoggingProhibitChangingOf:                Message("Binary logging and replication forbid changing the global server %s", nil),
   417  	ErrNoFileMapping:                            Message("Can't map file: %-.200s, errno: %d", nil),
   418  	ErrWrongMagic:                               Message("Wrong magic in %-.64s", nil),
   419  	ErrPsManyParam:                              Message("Prepared statement contains too many placeholders", nil),
   420  	ErrKeyPart0:                                 Message("Key part '%-.192s' length cannot be 0", nil),
   421  	ErrViewChecksum:                             Message("View text checksum failed", nil),
   422  	ErrViewMultiupdate:                          Message("Can not modify more than one base table through a join view '%-.192s.%-.192s'", nil),
   423  	ErrViewNoInsertFieldList:                    Message("Can not insert into join view '%-.192s.%-.192s' without fields list", nil),
   424  	ErrViewDeleteMergeView:                      Message("Can not delete from join view '%-.192s.%-.192s'", nil),
   425  	ErrCannotUser:                               Message("Operation %s failed for %.256s", nil),
   426  	ErrXaerNota:                                 Message("XAERNOTA: Unknown XID", nil),
   427  	ErrXaerInval:                                Message("XAERINVAL: Invalid arguments (or unsupported command)", nil),
   428  	ErrXaerRmfail:                               Message("XAERRMFAIL: The command cannot be executed when global transaction is in the  %.64s state", nil),
   429  	ErrXaerOutside:                              Message("XAEROUTSIDE: Some work is done outside global transaction", nil),
   430  	ErrXaerRmerr:                                Message("XAERRMERR: Fatal error occurred in the transaction branch - check your data for consistency", nil),
   431  	ErrXaRbrollback:                             Message("XARBROLLBACK: Transaction branch was rolled back", nil),
   432  	ErrNonexistingProcGrant:                     Message("There is no such grant defined for user '%-.48s' on host '%-.64s' on routine '%-.192s'", nil),
   433  	ErrProcAutoGrantFail:                        Message("Failed to grant EXECUTE and ALTER ROUTINE privileges", nil),
   434  	ErrProcAutoRevokeFail:                       Message("Failed to revoke all privileges to dropped routine", nil),
   435  	ErrDataTooLong:                              Message("Data too long for column '%s' at row %d", nil),
   436  	ErrSpBadSQLstate:                            Message("Bad SQLSTATE: '%s'", nil),
   437  	ErrStartup:                                  Message("%s: ready for connections.\nVersion: '%s'  socket: '%s'  port: %d  %s", nil),
   438  	ErrLoadFromFixedSizeRowsToVar:               Message("Can't load value from file with fixed size rows to variable", nil),
   439  	ErrCantCreateUserWithGrant:                  Message("You are not allowed to create a user with GRANT", nil),
   440  	ErrWrongValueForType:                        Message("Incorrect %-.32s value: '%-.128s' for function %-.32s", nil),
   441  	ErrTableDefChanged:                          Message("Table definition has changed, please retry transaction", nil),
   442  	ErrSpDupHandler:                             Message("Duplicate handler declared in the same block", nil),
   443  	ErrSpNotVarArg:                              Message("OUT or INOUT argument %d for routine %s is not a variable or NEW pseudo-variable in BEFORE trigger", nil),
   444  	ErrSpNoRetset:                               Message("Not allowed to return a result set from a %s", nil),
   445  	ErrCantCreateGeometryObject:                 Message("Cannot get geometry object from data you send to the GEOMETRY field", nil),
   446  	ErrFailedRoutineBreakBinlog:                 Message("A routine failed and has neither NO SQL nor READS SQL DATA in its declaration and binary logging is enabled; if non-transactional tables were updated, the binary log will miss their changes", nil),
   447  	ErrBinlogUnsafeRoutine:                      Message("This function has none of DETERMINISTIC, NO SQL, or READS SQL DATA in its declaration and binary logging is enabled (you *might* want to use the less safe logBinTrustFunctionCreators variable)", nil),
   448  	ErrBinlogCreateRoutineNeedSuper:             Message("You do not have the SUPER privilege and binary logging is enabled (you *might* want to use the less safe logBinTrustFunctionCreators variable)", nil),
   449  	ErrExecStmtWithOpenCursor:                   Message("You can't execute a prepared statement which has an open cursor associated with it. Reset the statement to re-execute it.", nil),
   450  	ErrStmtHasNoOpenCursor:                      Message("The statement (%d) has no open cursor.", nil),
   451  	ErrCommitNotAllowedInSfOrTrg:                Message("Explicit or implicit commit is not allowed in stored function or trigger.", nil),
   452  	ErrNoDefaultForViewField:                    Message("Field of view '%-.192s.%-.192s' underlying table doesn't have a default value", nil),
   453  	ErrSpNoRecursion:                            Message("Recursive stored functions and triggers are not allowed.", nil),
   454  	ErrTooBigScale:                              Message("Too big scale %d specified for column '%-.192s'. Maximum is %d.", nil),
   455  	ErrTooBigPrecision:                          Message("Too big precision %d specified for column '%-.192s'. Maximum is %d.", nil),
   456  	ErrMBiggerThanD:                             Message("For float(M,D), double(M,D) or decimal(M,D), M must be >= D (column '%-.192s').", nil),
   457  	ErrWrongLockOfSystemTable:                   Message("You can't combine write-locking of system tables with other tables or lock types", nil),
   458  	ErrConnectToForeignDataSource:               Message("Unable to connect to foreign data source: %.64s", nil),
   459  	ErrQueryOnForeignDataSource:                 Message("There was a problem processing the query on the foreign data source. Data source : %-.64s", nil),
   460  	ErrForeignDataSourceDoesntExist:             Message("The foreign data source you are trying to reference does not exist. Data source :  %-.64s", nil),
   461  	ErrForeignDataStringInvalidCantCreate:       Message("Can't create federated table. The data source connection string '%-.64s' is not in the correct format", nil),
   462  	ErrForeignDataStringInvalid:                 Message("The data source connection string '%-.64s' is not in the correct format", nil),
   463  	ErrCantCreateFederatedTable:                 Message("Can't create federated table. Foreign data src :  %-.64s", nil),
   464  	ErrTrgInWrongSchema:                         Message("Trigger in wrong schema", nil),
   465  	ErrStackOverrunNeedMore:                     Message("Thread stack overrun:  %d bytes used of a %d byte stack, and %d bytes needed.  Use 'mysqld --threadStack=#' to specify a bigger stack.", nil),
   466  	ErrTooLongBody:                              Message("Routine body for '%-.100s' is too long", nil),
   467  	ErrWarnCantDropDefaultKeycache:              Message("Cannot drop default keycache", nil),
   468  	ErrTooBigDisplaywidth:                       Message("Display width out of range for column '%-.192s' (max = %d)", nil),
   469  	ErrXaerDupid:                                Message("XAERDUPID: The XID already exists", nil),
   470  	ErrDatetimeFunctionOverflow:                 Message("Datetime function: %-.32s field overflow", nil),
   471  	ErrCantUpdateUsedTableInSfOrTrg:             Message("Can't update table '%-.192s' in stored function/trigger because it is already used by statement which invoked this stored function/trigger.", nil),
   472  	ErrViewPreventUpdate:                        Message("The definition of table '%-.192s' prevents operation %.192s on table '%-.192s'.", nil),
   473  	ErrPsNoRecursion:                            Message("The prepared statement contains a stored routine call that refers to that same statement. It's not allowed to execute a prepared statement in such a recursive manner", nil),
   474  	ErrSpCantSetAutocommit:                      Message("Not allowed to set autocommit from a stored function or trigger", nil),
   475  	ErrMalformedDefiner:                         Message("Definer is not fully qualified", nil),
   476  	ErrViewFrmNoUser:                            Message("View '%-.192s'.'%-.192s' has no definer information (old table format). Current user is used as definer. Please recreate the view!", nil),
   477  	ErrViewOtherUser:                            Message("You need the SUPER privilege for creation view with '%-.192s'@'%-.192s' definer", nil),
   478  	ErrNoSuchUser:                               Message("The user specified as a definer ('%-.64s'@'%-.64s') does not exist", nil),
   479  	ErrForbidSchemaChange:                       Message("Changing schema from '%-.192s' to '%-.192s' is not allowed.", nil),
   480  	ErrRowIsReferenced2:                         Message("Cannot delete or update a parent row: a foreign key constraint fails (%.192s)", nil),
   481  	ErrNoReferencedRow2:                         Message("Cannot add or update a child row: a foreign key constraint fails (%.192s)", nil),
   482  	ErrSpBadVarShadow:                           Message("Variable '%-.64s' must be quoted with `...`, or renamed", nil),
   483  	ErrTrgNoDefiner:                             Message("No definer attribute for trigger '%-.192s'.'%-.192s'. The trigger will be activated under the authorization of the invoker, which may have insufficient privileges. Please recreate the trigger.", nil),
   484  	ErrOldFileFormat:                            Message("'%-.192s' has an old format, you should re-create the '%s' object(s)", nil),
   485  	ErrSpRecursionLimit:                         Message("Recursive limit %d (as set by the maxSpRecursionDepth variable) was exceeded for routine %.192s", nil),
   486  	ErrSpProcTableCorrupt:                       Message("Failed to load routine %-.192s. The table mysql.proc is missing, corrupt, or contains bad data (internal code %d)", nil),
   487  	ErrSpWrongName:                              Message("Incorrect routine name '%-.192s'", nil),
   488  	ErrTableNeedsUpgrade:                        Message("Table upgrade required. Please do \"REPAIR TABLE `%-.32s`\"", nil),
   489  	ErrSpNoAggregate:                            Message("AGGREGATE is not supported for stored functions", nil),
   490  	ErrMaxPreparedStmtCountReached:              Message("Can't create more than maxPreparedStmtCount statements (current value: %d)", nil),
   491  	ErrViewRecursive:                            Message("`%-.192s`.`%-.192s` contains view recursion", nil),
   492  	ErrNonGroupingFieldUsed:                     Message("Non-grouping field '%-.192s' is used in %-.64s clause", nil),
   493  	ErrTableCantHandleSpkeys:                    Message("The used table type doesn't support SPATIAL indexes", nil),
   494  	ErrNoTriggersOnSystemSchema:                 Message("Triggers can not be created on system tables", nil),
   495  	ErrRemovedSpaces:                            Message("Leading spaces are removed from name '%s'", nil),
   496  	ErrAutoincReadFailed:                        Message("Failed to read auto-increment value from storage engine", nil),
   497  	ErrUsername:                                 Message("user name", nil),
   498  	ErrHostname:                                 Message("host name", nil),
   499  	ErrWrongStringLength:                        Message("String '%-.70s' is too long for %s (should be no longer than %d)", nil),
   500  	ErrNonInsertableTable:                       Message("The target table %-.100s of the %s is not insertable-into", nil),
   501  	ErrAdminWrongMrgTable:                       Message("Table '%-.64s' is differently defined or of non-MyISAM type or doesn't exist", nil),
   502  	ErrTooHighLevelOfNestingForSelect:           Message("Too high level of nesting for select", nil),
   503  	ErrNameBecomesEmpty:                         Message("Name '%-.64s' has become ''", nil),
   504  	ErrAmbiguousFieldTerm:                       Message("First character of the FIELDS TERMINATED string is ambiguous; please use non-optional and non-empty FIELDS ENCLOSED BY", nil),
   505  	ErrForeignServerExists:                      Message("The foreign server, %s, you are trying to create already exists.", nil),
   506  	ErrForeignServerDoesntExist:                 Message("The foreign server name you are trying to reference does not exist. Data source :  %-.64s", nil),
   507  	ErrIllegalHaCreateOption:                    Message("Table storage engine '%-.64s' does not support the create option '%.64s'", nil),
   508  	ErrPartitionRequiresValues:                  Message("Syntax : %-.64s PARTITIONING requires definition of VALUES %-.64s for each partition", nil),
   509  	ErrPartitionWrongValues:                     Message("Only %-.64s PARTITIONING can use VALUES %-.64s in partition definition", nil),
   510  	ErrPartitionMaxvalue:                        Message("MAXVALUE can only be used in last partition definition", nil),
   511  	ErrPartitionSubpartition:                    Message("Subpartitions can only be hash partitions and by key", nil),
   512  	ErrPartitionSubpartMix:                      Message("Must define subpartitions on all partitions if on one partition", nil),
   513  	ErrPartitionWrongNoPart:                     Message("Wrong number of partitions defined, mismatch with previous setting", nil),
   514  	ErrPartitionWrongNoSubpart:                  Message("Wrong number of subpartitions defined, mismatch with previous setting", nil),
   515  	ErrWrongExprInPartitionFunc:                 Message("Constant, random or timezone-dependent expressions in (sub)partitioning function are not allowed", nil),
   516  	ErrNoConstExprInRangeOrList:                 Message("Expression in RANGE/LIST VALUES must be constant", nil),
   517  	ErrFieldNotFoundPart:                        Message("Field in list of fields for partition function not found in table", nil),
   518  	ErrListOfFieldsOnlyInHash:                   Message("List of fields is only allowed in KEY partitions", nil),
   519  	ErrInconsistentPartitionInfo:                Message("The partition info in the frm file is not consistent with what can be written into the frm file", nil),
   520  	ErrPartitionFuncNotAllowed:                  Message("The %-.192s function returns the wrong type", nil),
   521  	ErrPartitionsMustBeDefined:                  Message("For %-.64s partitions each partition must be defined", nil),
   522  	ErrRangeNotIncreasing:                       Message("VALUES LESS THAN value must be strictly increasing for each partition", nil),
   523  	ErrInconsistentTypeOfFunctions:              Message("VALUES value must be of same type as partition function", nil),
   524  	ErrMultipleDefConstInListPart:               Message("Multiple definition of same constant in list partitioning", nil),
   525  	ErrPartitionEntry:                           Message("Partitioning can not be used stand-alone in query", nil),
   526  	ErrMixHandler:                               Message("The mix of handlers in the partitions is not allowed in this version of MySQL", nil),
   527  	ErrPartitionNotDefined:                      Message("For the partitioned engine it is necessary to define all %-.64s", nil),
   528  	ErrTooManyPartitions:                        Message("Too many partitions (including subpartitions) were defined", nil),
   529  	ErrSubpartition:                             Message("It is only possible to mix RANGE/LIST partitioning with HASH/KEY partitioning for subpartitioning", nil),
   530  	ErrCantCreateHandlerFile:                    Message("Failed to create specific handler file", nil),
   531  	ErrBlobFieldInPartFunc:                      Message("A BLOB field is not allowed in partition function", nil),
   532  	ErrUniqueKeyNeedAllFieldsInPf:               Message("A %-.192s must include all columns in the table's partitioning function", nil),
   533  	ErrNoParts:                                  Message("Number of %-.64s = 0 is not an allowed value", nil),
   534  	ErrPartitionMgmtOnNonpartitioned:            Message("Partition management on a not partitioned table is not possible", nil),
   535  	ErrForeignKeyOnPartitioned:                  Message("Foreign key clause is not yet supported in conjunction with partitioning", nil),
   536  	ErrDropPartitionNonExistent:                 Message("Error in list of partitions to %-.64s", nil),
   537  	ErrDropLastPartition:                        Message("Cannot remove all partitions, use DROP TABLE instead", nil),
   538  	ErrCoalesceOnlyOnHashPartition:              Message("COALESCE PARTITION can only be used on HASH/KEY partitions", nil),
   539  	ErrReorgHashOnlyOnSameNo:                    Message("REORGANIZE PARTITION can only be used to reorganize partitions not to change their numbers", nil),
   540  	ErrReorgNoParam:                             Message("REORGANIZE PARTITION without parameters can only be used on auto-partitioned tables using HASH PARTITIONs", nil),
   541  	ErrOnlyOnRangeListPartition:                 Message("%-.64s PARTITION can only be used on RANGE/LIST partitions", nil),
   542  	ErrAddPartitionSubpart:                      Message("Trying to Add partition(s) with wrong number of subpartitions", nil),
   543  	ErrAddPartitionNoNewPartition:               Message("At least one partition must be added", nil),
   544  	ErrCoalescePartitionNoPartition:             Message("At least one partition must be coalesced", nil),
   545  	ErrReorgPartitionNotExist:                   Message("More partitions to reorganize than there are partitions", nil),
   546  	ErrSameNamePartition:                        Message("Duplicate partition name %-.192s", nil),
   547  	ErrNoBinlog:                                 Message("It is not allowed to shut off binlog on this command", nil),
   548  	ErrConsecutiveReorgPartitions:               Message("When reorganizing a set of partitions they must be in consecutive order", nil),
   549  	ErrReorgOutsideRange:                        Message("Reorganize of range partitions cannot change total ranges except for last partition where it can extend the range", nil),
   550  	ErrPartitionFunctionFailure:                 Message("Partition function not supported in this version for this handler", nil),
   551  	ErrPartState:                                Message("Partition state cannot be defined from CREATE/ALTER TABLE", nil),
   552  	ErrLimitedPartRange:                         Message("The %-.64s handler only supports 32 bit integers in VALUES", nil),
   553  	ErrPluginIsNotLoaded:                        Message("Plugin '%-.192s' is not loaded", nil),
   554  	ErrWrongValue:                               Message("Incorrect %-.32s value: '%-.128s'", nil),
   555  	ErrNoPartitionForGivenValue:                 Message("Table has no partition for value %-.64s", nil),
   556  	ErrFilegroupOptionOnlyOnce:                  Message("It is not allowed to specify %s more than once", nil),
   557  	ErrCreateFilegroupFailed:                    Message("Failed to create %s", nil),
   558  	ErrDropFilegroupFailed:                      Message("Failed to drop %s", nil),
   559  	ErrTablespaceAutoExtend:                     Message("The handler doesn't support autoextend of tablespaces", nil),
   560  	ErrWrongSizeNumber:                          Message("A size parameter was incorrectly specified, either number or on the form 10M", nil),
   561  	ErrSizeOverflow:                             Message("The size number was correct but we don't allow the digit part to be more than 2 billion", nil),
   562  	ErrAlterFilegroupFailed:                     Message("Failed to alter: %s", nil),
   563  	ErrBinlogRowLoggingFailed:                   Message("Writing one row to the row-based binary log failed", nil),
   564  	ErrBinlogRowWrongTableDef:                   Message("Table definition on master and slave does not match: %s", nil),
   565  	ErrBinlogRowRbrToSbr:                        Message("Slave running with --log-slave-updates must use row-based binary logging to be able to replicate row-based binary log events", nil),
   566  	ErrEventAlreadyExists:                       Message("Event '%-.192s' already exists", nil),
   567  	ErrEventStoreFailed:                         Message("Failed to store event %s. Error code %d from storage engine.", nil),
   568  	ErrEventDoesNotExist:                        Message("Unknown event '%-.192s'", nil),
   569  	ErrEventCantAlter:                           Message("Failed to alter event '%-.192s'", nil),
   570  	ErrEventDropFailed:                          Message("Failed to drop %s", nil),
   571  	ErrEventIntervalNotPositiveOrTooBig:         Message("INTERVAL is either not positive or too big", nil),
   572  	ErrEventEndsBeforeStarts:                    Message("ENDS is either invalid or before STARTS", nil),
   573  	ErrEventExecTimeInThePast:                   Message("Event execution time is in the past. Event has been disabled", nil),
   574  	ErrEventOpenTableFailed:                     Message("Failed to open mysql.event", nil),
   575  	ErrEventNeitherMExprNorMAt:                  Message("No datetime expression provided", nil),
   576  	ErrObsoleteColCountDoesntMatchCorrupted:     Message("Column count of mysql.%s is wrong. Expected %d, found %d. The table is probably corrupted", nil),
   577  	ErrObsoleteCannotLoadFromTable:              Message("Cannot load from mysql.%s. The table is probably corrupted", nil),
   578  	ErrEventCannotDelete:                        Message("Failed to delete the event from mysql.event", nil),
   579  	ErrEventCompile:                             Message("Error during compilation of event's body", nil),
   580  	ErrEventSameName:                            Message("Same old and new event name", nil),
   581  	ErrEventDataTooLong:                         Message("Data for column '%s' too long", nil),
   582  	ErrDropIndexNeededInForeignKey:              Message("Cannot drop index '%-.192s': needed in a foreign key constraint", nil),
   583  	ErrWarnDeprecatedSyntaxWithVer:              Message("The syntax '%s' is deprecated and will be removed in MySQL %s. Please use %s instead", nil),
   584  	ErrCantWriteLockLogTable:                    Message("You can't write-lock a log table. Only read access is possible", nil),
   585  	ErrCantLockLogTable:                         Message("You can't use locks with log tables.", nil),
   586  	ErrForeignDuplicateKeyOldUnused:             Message("Upholding foreign key constraints for table '%.192s', entry '%-.192s', key %d would lead to a duplicate entry", nil),
   587  	ErrColCountDoesntMatchPleaseUpdate:          Message("Column count of mysql.%s is wrong. Expected %d, found %d. Created with MySQL %d, now running %d. Please use mysqlUpgrade to fix this error.", nil),
   588  	ErrTempTablePreventsSwitchOutOfRbr:          Message("Cannot switch out of the row-based binary log format when the session has open temporary tables", nil),
   589  	ErrStoredFunctionPreventsSwitchBinlogFormat: Message("Cannot change the binary logging format inside a stored function or trigger", nil),
   590  	ErrNdbCantSwitchBinlogFormat:                Message("The NDB cluster engine does not support changing the binlog format on the fly yet", nil),
   591  	ErrPartitionNoTemporary:                     Message("Cannot create temporary table with partitions", nil),
   592  	ErrPartitionConstDomain:                     Message("Partition constant is out of partition function domain", nil),
   593  	ErrPartitionFunctionIsNotAllowed:            Message("This partition function is not allowed", nil),
   594  	ErrDdlLog:                                   Message("Error in DDL log", nil),
   595  	ErrNullInValuesLessThan:                     Message("Not allowed to use NULL value in VALUES LESS THAN", nil),
   596  	ErrWrongPartitionName:                       Message("Incorrect partition name", nil),
   597  	ErrCantChangeTxCharacteristics:              Message("Transaction characteristics can't be changed while a transaction is in progress", nil),
   598  	ErrDupEntryAutoincrementCase:                Message("ALTER TABLE causes autoIncrement resequencing, resulting in duplicate entry '%-.192s' for key '%-.192s'", nil),
   599  	ErrEventModifyQueue:                         Message("Internal scheduler error %d", nil),
   600  	ErrEventSetVar:                              Message("Error during starting/stopping of the scheduler. Error code %d", nil),
   601  	ErrPartitionMerge:                           Message("Engine cannot be used in partitioned tables", nil),
   602  	ErrCantActivateLog:                          Message("Cannot activate '%-.64s' log", nil),
   603  	ErrRbrNotAvailable:                          Message("The server was not built with row-based replication", nil),
   604  	ErrBase64Decode:                             Message("Decoding of base64 string failed", nil),
   605  	ErrEventRecursionForbidden:                  Message("Recursion of EVENT DDL statements is forbidden when body is present", nil),
   606  	ErrEventsDB:                                 Message("Cannot proceed because system tables used by Event Scheduler were found damaged at server start", nil),
   607  	ErrOnlyIntegersAllowed:                      Message("Only integers allowed as number here", nil),
   608  	ErrUnsuportedLogEngine:                      Message("This storage engine cannot be used for log tables\"", nil),
   609  	ErrBadLogStatement:                          Message("You cannot '%s' a log table if logging is enabled", nil),
   610  	ErrCantRenameLogTable:                       Message("Cannot rename '%s'. When logging enabled, rename to/from log table must rename two tables: the log table to an archive table and another table back to '%s'", nil),
   611  	ErrWrongParamcountToNativeFct:               Message("Incorrect parameter count in the call to native function '%-.192s'", nil),
   612  	ErrWrongParametersToNativeFct:               Message("Incorrect parameters in the call to native function '%-.192s'", nil),
   613  	ErrWrongParametersToStoredFct:               Message("Incorrect parameters in the call to stored function '%-.192s'", nil),
   614  	ErrNativeFctNameCollision:                   Message("This function '%-.192s' has the same name as a native function", nil),
   615  	ErrDupEntryWithKeyName:                      Message("Duplicate entry '%-.64s' for key '%-.192s'", nil),
   616  	ErrBinlogPurgeEmFile:                        Message("Too many files opened, please execute the command again", nil),
   617  	ErrEventCannotCreateInThePast:               Message("Event execution time is in the past and ON COMPLETION NOT PRESERVE is set. The event was dropped immediately after creation.", nil),
   618  	ErrEventCannotAlterInThePast:                Message("Event execution time is in the past and ON COMPLETION NOT PRESERVE is set. The event was not changed. Specify a time in the future.", nil),
   619  	ErrSlaveIncident:                            Message("The incident %s occurred on the master. Message: %-.64s", nil),
   620  	ErrNoPartitionForGivenValueSilent:           Message("Table has no partition for some existing values", nil),
   621  	ErrBinlogUnsafeStatement:                    Message("Unsafe statement written to the binary log using statement format since BINLOGFORMAT = STATEMENT. %s", nil),
   622  	ErrSlaveFatal:                               Message("Fatal : %s", nil),
   623  	ErrSlaveRelayLogReadFailure:                 Message("Relay log read failure: %s", nil),
   624  	ErrSlaveRelayLogWriteFailure:                Message("Relay log write failure: %s", nil),
   625  	ErrSlaveCreateEventFailure:                  Message("Failed to create %s", nil),
   626  	ErrSlaveMasterComFailure:                    Message("Master command %s failed: %s", nil),
   627  	ErrBinlogLoggingImpossible:                  Message("Binary logging not possible. Message: %s", nil),
   628  	ErrViewNoCreationCtx:                        Message("View `%-.64s`.`%-.64s` has no creation context", nil),
   629  	ErrViewInvalidCreationCtx:                   Message("Creation context of view `%-.64s`.`%-.64s' is invalid", nil),
   630  	ErrSrInvalidCreationCtx:                     Message("Creation context of stored routine `%-.64s`.`%-.64s` is invalid", nil),
   631  	ErrTrgCorruptedFile:                         Message("Corrupted TRG file for table `%-.64s`.`%-.64s`", nil),
   632  	ErrTrgNoCreationCtx:                         Message("Triggers for table `%-.64s`.`%-.64s` have no creation context", nil),
   633  	ErrTrgInvalidCreationCtx:                    Message("Trigger creation context of table `%-.64s`.`%-.64s` is invalid", nil),
   634  	ErrEventInvalidCreationCtx:                  Message("Creation context of event `%-.64s`.`%-.64s` is invalid", nil),
   635  	ErrTrgCantOpenTable:                         Message("Cannot open table for trigger `%-.64s`.`%-.64s`", nil),
   636  	ErrCantCreateSroutine:                       Message("Cannot create stored routine `%-.64s`. Check warnings", nil),
   637  	ErrNeverUsed:                                Message("Ambiguous slave modes combination. %s", nil),
   638  	ErrNoFormatDescriptionEventBeforeBinlogStatement:         Message("The BINLOG statement of type `%s` was not preceded by a format description BINLOG statement.", nil),
   639  	ErrSlaveCorruptEvent:                                     Message("Corrupted replication event was detected", nil),
   640  	ErrLoadDataInvalidColumn:                                 Message("Invalid column reference (%-.64s) in LOAD DATA", nil),
   641  	ErrLogPurgeNoFile:                                        Message("Being purged log %s was not found", nil),
   642  	ErrXaRbtimeout:                                           Message("XARBTIMEOUT: Transaction branch was rolled back: took too long", nil),
   643  	ErrXaRbdeadlock:                                          Message("XARBDEADLOCK: Transaction branch was rolled back: deadlock was detected", nil),
   644  	ErrNeedReprepare:                                         Message("Prepared statement needs to be re-prepared", nil),
   645  	ErrDelayedNotSupported:                                   Message("DELAYED option not supported for table '%-.192s'", nil),
   646  	WarnNoMasterInfo:                                         Message("The master info structure does not exist", nil),
   647  	WarnOptionIgnored:                                        Message("<%-.64s> option ignored", nil),
   648  	WarnPluginDeleteBuiltin:                                  Message("Built-in plugins cannot be deleted", nil),
   649  	WarnPluginBusy:                                           Message("Plugin is busy and will be uninstalled on shutdown", nil),
   650  	ErrVariableIsReadonly:                                    Message("%s variable '%s' is read-only. Use SET %s to assign the value", nil),
   651  	ErrWarnEngineTransactionRollback:                         Message("Storage engine %s does not support rollback for this statement. Transaction rolled back and must be restarted", nil),
   652  	ErrSlaveHeartbeatFailure:                                 Message("Unexpected master's heartbeat data: %s", nil),
   653  	ErrSlaveHeartbeatValueOutOfRange:                         Message("The requested value for the heartbeat period is either negative or exceeds the maximum allowed (%s seconds).", nil),
   654  	ErrNdbReplicationSchema:                                  Message("Bad schema for mysql.ndbReplication table. Message: %-.64s", nil),
   655  	ErrConflictFnParse:                                       Message("Error in parsing conflict function. Message: %-.64s", nil),
   656  	ErrExceptionsWrite:                                       Message("Write to exceptions table failed. Message: %-.128s\"", nil),
   657  	ErrTooLongTableComment:                                   Message("Comment for table '%-.64s' is too long (max = %d)", nil),
   658  	ErrTooLongFieldComment:                                   Message("Comment for field '%-.64s' is too long (max = %d)", nil),
   659  	ErrFuncInexistentNameCollision:                           Message("FUNCTION %s does not exist. Check the 'Function Name Parsing and Resolution' section in the Reference Manual", nil),
   660  	ErrDatabaseName:                                          Message("Database", nil),
   661  	ErrTableName:                                             Message("Table", nil),
   662  	ErrPartitionName:                                         Message("Partition", nil),
   663  	ErrSubpartitionName:                                      Message("Subpartition", nil),
   664  	ErrTemporaryName:                                         Message("Temporary", nil),
   665  	ErrRenamedName:                                           Message("Renamed", nil),
   666  	ErrTooManyConcurrentTrxs:                                 Message("Too many active concurrent transactions", nil),
   667  	WarnNonASCIISeparatorNotImplemented:                      Message("Non-ASCII separator arguments are not fully supported", nil),
   668  	ErrDebugSyncTimeout:                                      Message("debug sync point wait timed out", nil),
   669  	ErrDebugSyncHitLimit:                                     Message("debug sync point hit limit reached", nil),
   670  	ErrDupSignalSet:                                          Message("Duplicate condition information item '%s'", nil),
   671  	ErrSignalWarn:                                            Message("Unhandled user-defined warning condition", nil),
   672  	ErrSignalNotFound:                                        Message("Unhandled user-defined not found condition", nil),
   673  	ErrSignalException:                                       Message("Unhandled user-defined exception condition", nil),
   674  	ErrResignalWithoutActiveHandler:                          Message("RESIGNAL when handler not active", nil),
   675  	ErrSignalBadConditionType:                                Message("SIGNAL/RESIGNAL can only use a CONDITION defined with SQLSTATE", nil),
   676  	WarnCondItemTruncated:                                    Message("Data truncated for condition item '%s'", nil),
   677  	ErrCondItemTooLong:                                       Message("Data too long for condition item '%s'", nil),
   678  	ErrUnknownLocale:                                         Message("Unknown locale: '%-.64s'", nil),
   679  	ErrSlaveIgnoreServerIds:                                  Message("The requested server id %d clashes with the slave startup option --replicate-same-server-id", nil),
   680  	ErrQueryCacheDisabled:                                    Message("Query cache is disabled; restart the server with queryCacheType=1 to enable it", nil),
   681  	ErrSameNamePartitionField:                                Message("Duplicate partition field name '%-.192s'", nil),
   682  	ErrPartitionColumnList:                                   Message("Inconsistency in usage of column lists for partitioning", nil),
   683  	ErrWrongTypeColumnValue:                                  Message("Partition column values of incorrect type", nil),
   684  	ErrTooManyPartitionFuncFields:                            Message("Too many fields in '%-.192s'", nil),
   685  	ErrMaxvalueInValuesIn:                                    Message("Cannot use MAXVALUE as value in VALUES IN", nil),
   686  	ErrTooManyValues:                                         Message("Cannot have more than one value for this type of %-.64s partitioning", nil),
   687  	ErrRowSinglePartitionField:                               Message("Row expressions in VALUES IN only allowed for multi-field column partitioning", nil),
   688  	ErrFieldTypeNotAllowedAsPartitionField:                   Message("Field '%-.192s' is of a not allowed type for this type of partitioning", nil),
   689  	ErrPartitionFieldsTooLong:                                Message("The total length of the partitioning fields is too large", nil),
   690  	ErrBinlogRowEngineAndStmtEngine:                          Message("Cannot execute statement: impossible to write to binary log since both row-incapable engines and statement-incapable engines are involved.", nil),
   691  	ErrBinlogRowModeAndStmtEngine:                            Message("Cannot execute statement: impossible to write to binary log since BINLOGFORMAT = ROW and at least one table uses a storage engine limited to statement-based logging.", nil),
   692  	ErrBinlogUnsafeAndStmtEngine:                             Message("Cannot execute statement: impossible to write to binary log since statement is unsafe, storage engine is limited to statement-based logging, and BINLOGFORMAT = MIXED. %s", nil),
   693  	ErrBinlogRowInjectionAndStmtEngine:                       Message("Cannot execute statement: impossible to write to binary log since statement is in row format and at least one table uses a storage engine limited to statement-based logging.", nil),
   694  	ErrBinlogStmtModeAndRowEngine:                            Message("Cannot execute statement: impossible to write to binary log since BINLOGFORMAT = STATEMENT and at least one table uses a storage engine limited to row-based logging.%s", nil),
   695  	ErrBinlogRowInjectionAndStmtMode:                         Message("Cannot execute statement: impossible to write to binary log since statement is in row format and BINLOGFORMAT = STATEMENT.", nil),
   696  	ErrBinlogMultipleEnginesAndSelfLoggingEngine:             Message("Cannot execute statement: impossible to write to binary log since more than one engine is involved and at least one engine is self-logging.", nil),
   697  	ErrBinlogUnsafeLimit:                                     Message("The statement is unsafe because it uses a LIMIT clause. This is unsafe because the set of rows included cannot be predicted.", nil),
   698  	ErrBinlogUnsafeInsertDelayed:                             Message("The statement is unsafe because it uses INSERT DELAYED. This is unsafe because the times when rows are inserted cannot be predicted.", nil),
   699  	ErrBinlogUnsafeSystemTable:                               Message("The statement is unsafe because it uses the general log, slow query log, or performanceSchema table(s). This is unsafe because system tables may differ on slaves.", nil),
   700  	ErrBinlogUnsafeAutoincColumns:                            Message("Statement is unsafe because it invokes a trigger or a stored function that inserts into an AUTOINCREMENT column. Inserted values cannot be logged correctly.", nil),
   701  	ErrBinlogUnsafeUdf:                                       Message("Statement is unsafe because it uses a UDF which may not return the same value on the slave.", nil),
   702  	ErrBinlogUnsafeSystemVariable:                            Message("Statement is unsafe because it uses a system variable that may have a different value on the slave.", nil),
   703  	ErrBinlogUnsafeSystemFunction:                            Message("Statement is unsafe because it uses a system function that may return a different value on the slave.", nil),
   704  	ErrBinlogUnsafeNontransAfterTrans:                        Message("Statement is unsafe because it accesses a non-transactional table after accessing a transactional table within the same transaction.", nil),
   705  	ErrMessageAndStatement:                                   Message("%s Statement: %s", nil),
   706  	ErrSlaveConversionFailed:                                 Message("Column %d of table '%-.192s.%-.192s' cannot be converted from type '%-.32s' to type '%-.32s'", nil),
   707  	ErrSlaveCantCreateConversion:                             Message("Can't create conversion table for table '%-.192s.%-.192s'", nil),
   708  	ErrInsideTransactionPreventsSwitchBinlogFormat:           Message("Cannot modify @@session.binlogFormat inside a transaction", nil),
   709  	ErrPathLength:                                            Message("The path specified for %.64s is too long.", nil),
   710  	ErrWarnDeprecatedSyntaxNoReplacement:                     Message("%s is deprecated and will be removed in a future release.%s", nil),
   711  	ErrWrongNativeTableStructure:                             Message("Native table '%-.64s'.'%-.64s' has the wrong structure", nil),
   712  	ErrWrongPerfSchemaUsage:                                  Message("Invalid performanceSchema usage.", nil),
   713  	ErrWarnISSkippedTable:                                    Message("Table '%s'.'%s' was skipped since its definition is being modified by concurrent DDL statement", nil),
   714  	ErrInsideTransactionPreventsSwitchBinlogDirect:           Message("Cannot modify @@session.binlogDirectNonTransactionalUpdates inside a transaction", nil),
   715  	ErrStoredFunctionPreventsSwitchBinlogDirect:              Message("Cannot change the binlog direct flag inside a stored function or trigger", nil),
   716  	ErrSpatialMustHaveGeomCol:                                Message("A SPATIAL index may only contain a geometrical type column", nil),
   717  	ErrTooLongIndexComment:                                   Message("Comment for index '%-.64s' is too long (max = %d)", nil),
   718  	ErrLockAborted:                                           Message("Wait on a lock was aborted due to a pending exclusive lock", nil),
   719  	ErrDataOutOfRange:                                        Message("%s value is out of range in '%s'", nil),
   720  	ErrWrongSpvarTypeInLimit:                                 Message("A variable of a non-integer based type in LIMIT clause", nil),
   721  	ErrBinlogUnsafeMultipleEnginesAndSelfLoggingEngine:       Message("Mixing self-logging and non-self-logging engines in a statement is unsafe.", nil),
   722  	ErrBinlogUnsafeMixedStatement:                            Message("Statement accesses nontransactional table as well as transactional or temporary table, and writes to any of them.", nil),
   723  	ErrInsideTransactionPreventsSwitchSQLLogBin:              Message("Cannot modify @@session.sqlLogBin inside a transaction", nil),
   724  	ErrStoredFunctionPreventsSwitchSQLLogBin:                 Message("Cannot change the sqlLogBin inside a stored function or trigger", nil),
   725  	ErrFailedReadFromParFile:                                 Message("Failed to read from the .par file", nil),
   726  	ErrValuesIsNotIntType:                                    Message("VALUES value for partition '%-.64s' must have type INT", nil),
   727  	ErrAccessDeniedNoPassword:                                Message("Access denied for user '%-.48s'@'%-.64s'", nil),
   728  	ErrSetPasswordAuthPlugin:                                 Message("SET PASSWORD has no significance for user '%-.48s'@'%-.255s' as authentication plugin does not support it.", nil),
   729  	ErrGrantPluginUserExists:                                 Message("GRANT with IDENTIFIED WITH is illegal because the user %-.*s already exists", nil),
   730  	ErrTruncateIllegalForeignKey:                             Message("Cannot truncate a table referenced in a foreign key constraint (%.192s)", nil),
   731  	ErrPluginIsPermanent:                                     Message("Plugin '%s' is forcePlusPermanent and can not be unloaded", nil),
   732  	ErrSlaveHeartbeatValueOutOfRangeMin:                      Message("The requested value for the heartbeat period is less than 1 millisecond. The value is reset to 0, meaning that heartbeating will effectively be disabled.", nil),
   733  	ErrSlaveHeartbeatValueOutOfRangeMax:                      Message("The requested value for the heartbeat period exceeds the value of `slaveNetTimeout' seconds. A sensible value for the period should be less than the timeout.", nil),
   734  	ErrStmtCacheFull:                                         Message("Multi-row statements required more than 'maxBinlogStmtCacheSize' bytes of storage; increase this mysqld variable and try again", nil),
   735  	ErrMultiUpdateKeyConflict:                                Message("Primary key/partition key update is not allowed since the table is updated both as '%-.192s' and '%-.192s'.", nil),
   736  	ErrTableNeedsRebuild:                                     Message("Table rebuild required. Please do \"ALTER TABLE `%-.32s` FORCE\" or dump/reload to fix it!", nil),
   737  	WarnOptionBelowLimit:                                     Message("The value of '%s' should be no less than the value of '%s'", nil),
   738  	ErrIndexColumnTooLong:                                    Message("Index column size too large. The maximum column size is %d bytes.", nil),
   739  	ErrErrorInTriggerBody:                                    Message("Trigger '%-.64s' has an error in its body: '%-.256s'", nil),
   740  	ErrErrorInUnknownTriggerBody:                             Message("Unknown trigger has an error in its body: '%-.256s'", nil),
   741  	ErrIndexCorrupt:                                          Message("Index %s is corrupted", nil),
   742  	ErrUndoRecordTooBig:                                      Message("Undo log record is too big.", nil),
   743  	ErrBinlogUnsafeInsertIgnoreSelect:                        Message("INSERT IGNORE... SELECT is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are ignored. This order cannot be predicted and may differ on master and the slave.", nil),
   744  	ErrBinlogUnsafeInsertSelectUpdate:                        Message("INSERT... SELECT... ON DUPLICATE KEY UPDATE is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are updated. This order cannot be predicted and may differ on master and the slave.", nil),
   745  	ErrBinlogUnsafeReplaceSelect:                             Message("REPLACE... SELECT is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are replaced. This order cannot be predicted and may differ on master and the slave.", nil),
   746  	ErrBinlogUnsafeCreateIgnoreSelect:                        Message("CREATE... IGNORE SELECT is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are ignored. This order cannot be predicted and may differ on master and the slave.", nil),
   747  	ErrBinlogUnsafeCreateReplaceSelect:                       Message("CREATE... REPLACE SELECT is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are replaced. This order cannot be predicted and may differ on master and the slave.", nil),
   748  	ErrBinlogUnsafeUpdateIgnore:                              Message("UPDATE IGNORE is unsafe because the order in which rows are updated determines which (if any) rows are ignored. This order cannot be predicted and may differ on master and the slave.", nil),
   749  	ErrPluginNoUninstall:                                     Message("Plugin '%s' is marked as not dynamically uninstallable. You have to stop the server to uninstall it.", nil),
   750  	ErrPluginNoInstall:                                       Message("Plugin '%s' is marked as not dynamically installable. You have to stop the server to install it.", nil),
   751  	ErrBinlogUnsafeWriteAutoincSelect:                        Message("Statements writing to a table with an auto-increment column after selecting from another table are unsafe because the order in which rows are retrieved determines what (if any) rows will be written. This order cannot be predicted and may differ on master and the slave.", nil),
   752  	ErrBinlogUnsafeCreateSelectAutoinc:                       Message("CREATE TABLE... SELECT...  on a table with an auto-increment column is unsafe because the order in which rows are retrieved by the SELECT determines which (if any) rows are inserted. This order cannot be predicted and may differ on master and the slave.", nil),
   753  	ErrBinlogUnsafeInsertTwoKeys:                             Message("INSERT... ON DUPLICATE KEY UPDATE  on a table with more than one UNIQUE KEY is unsafe", nil),
   754  	ErrTableInFkCheck:                                        Message("Table is being used in foreign key check.", nil),
   755  	ErrUnsupportedEngine:                                     Message("Storage engine '%s' does not support system tables. [%s.%s]", nil),
   756  	ErrBinlogUnsafeAutoincNotFirst:                           Message("INSERT into autoincrement field which is not the first part in the composed primary key is unsafe.", nil),
   757  	ErrCannotLoadFromTableV2:                                 Message("Cannot load from %s.%s. The table is probably corrupted", nil),
   758  	ErrMasterDelayValueOutOfRange:                            Message("The requested value %d for the master delay exceeds the maximum %d", nil),
   759  	ErrOnlyFdAndRbrEventsAllowedInBinlogStatement:            Message("Only FormatDescriptionLogEvent and row events are allowed in BINLOG statements (but %s was provided)", nil),
   760  	ErrPartitionExchangeDifferentOption:                      Message("Non matching attribute '%-.64s' between partition and table", nil),
   761  	ErrPartitionExchangePartTable:                            Message("Table to exchange with partition is partitioned: '%-.64s'", nil),
   762  	ErrPartitionExchangeTempTable:                            Message("Table to exchange with partition is temporary: '%-.64s'", nil),
   763  	ErrPartitionInsteadOfSubpartition:                        Message("Subpartitioned table, use subpartition instead of partition", nil),
   764  	ErrUnknownPartition:                                      Message("Unknown partition '%-.64s' in table '%-.64s'", nil),
   765  	ErrTablesDifferentMetadata:                               Message("Tables have different definitions", nil),
   766  	ErrRowDoesNotMatchPartition:                              Message("Found a row that does not match the partition", nil),
   767  	ErrBinlogCacheSizeGreaterThanMax:                         Message("Option binlogCacheSize (%d) is greater than maxBinlogCacheSize (%d); setting binlogCacheSize equal to maxBinlogCacheSize.", nil),
   768  	ErrWarnIndexNotApplicable:                                Message("Cannot use %-.64s access on index '%-.64s' due to type or collation conversion on field '%-.64s'", nil),
   769  	ErrPartitionExchangeForeignKey:                           Message("Table to exchange with partition has foreign key references: '%-.64s'", nil),
   770  	ErrNoSuchKeyValue:                                        Message("Key value '%-.192s' was not found in table '%-.192s.%-.192s'", nil),
   771  	ErrRplInfoDataTooLong:                                    Message("Data for column '%s' too long", nil),
   772  	ErrNetworkReadEventChecksumFailure:                       Message("Replication event checksum verification failed while reading from network.", nil),
   773  	ErrBinlogReadEventChecksumFailure:                        Message("Replication event checksum verification failed while reading from a log file.", nil),
   774  	ErrBinlogStmtCacheSizeGreaterThanMax:                     Message("Option binlogStmtCacheSize (%d) is greater than maxBinlogStmtCacheSize (%d); setting binlogStmtCacheSize equal to maxBinlogStmtCacheSize.", nil),
   775  	ErrCantUpdateTableInCreateTableSelect:                    Message("Can't update table '%-.192s' while '%-.192s' is being created.", nil),
   776  	ErrPartitionClauseOnNonpartitioned:                       Message("PARTITION () clause on non partitioned table", nil),
   777  	ErrRowDoesNotMatchGivenPartitionSet:                      Message("Found a row not matching the given partition set", nil),
   778  	ErrNoSuchPartitionunused:                                 Message("partition '%-.64s' doesn't exist", nil),
   779  	ErrChangeRplInfoRepositoryFailure:                        Message("Failure while changing the type of replication repository: %s.", nil),
   780  	ErrWarningNotCompleteRollbackWithCreatedTempTable:        Message("The creation of some temporary tables could not be rolled back.", nil),
   781  	ErrWarningNotCompleteRollbackWithDroppedTempTable:        Message("Some temporary tables were dropped, but these operations could not be rolled back.", nil),
   782  	ErrMtsFeatureIsNotSupported:                              Message("%s is not supported in multi-threaded slave mode. %s", nil),
   783  	ErrMtsUpdatedDBsGreaterMax:                               Message("The number of modified databases exceeds the maximum %d; the database names will not be included in the replication event metadata.", nil),
   784  	ErrMtsCantParallel:                                       Message("Cannot execute the current event group in the parallel mode. Encountered event %s, relay-log name %s, position %s which prevents execution of this event group in parallel mode. Reason: %s.", nil),
   785  	ErrMtsInconsistentData:                                   Message("%s", nil),
   786  	ErrFulltextNotSupportedWithPartitioning:                  Message("FULLTEXT index is not supported for partitioned tables.", nil),
   787  	ErrDaInvalidConditionNumber:                              Message("Invalid condition number", nil),
   788  	ErrInsecurePlainText:                                     Message("Sending passwords in plain text without SSL/TLS is extremely insecure.", nil),
   789  	ErrInsecureChangeMaster:                                  Message("Storing MySQL user name or password information in the master.info repository is not secure and is therefore not recommended. Please see the MySQL Manual for more about this issue and possible alternatives.", nil),
   790  	ErrForeignDuplicateKeyWithChildInfo:                      Message("Foreign key constraint for table '%.192s', record '%-.192s' would lead to a duplicate entry in table '%.192s', key '%.192s'", nil),
   791  	ErrForeignDuplicateKeyWithoutChildInfo:                   Message("Foreign key constraint for table '%.192s', record '%-.192s' would lead to a duplicate entry in a child table", nil),
   792  	ErrSQLthreadWithSecureSlave:                              Message("Setting authentication options is not possible when only the Slave SQL Thread is being started.", nil),
   793  	ErrTableHasNoFt:                                          Message("The table does not have FULLTEXT index to support this query", nil),
   794  	ErrVariableNotSettableInSfOrTrigger:                      Message("The system variable %.200s cannot be set in stored functions or triggers.", nil),
   795  	ErrVariableNotSettableInTransaction:                      Message("The system variable %.200s cannot be set when there is an ongoing transaction.", nil),
   796  	ErrGtidNextIsNotInGtidNextList:                           Message("The system variable @@SESSION.GTIDNEXT has the value %.200s, which is not listed in @@SESSION.GTIDNEXTLIST.", nil),
   797  	ErrCantChangeGtidNextInTransactionWhenGtidNextListIsNull: Message("When @@SESSION.GTIDNEXTLIST == NULL, the system variable @@SESSION.GTIDNEXT cannot change inside a transaction.", nil),
   798  	ErrSetStatementCannotInvokeFunction:                      Message("The statement 'SET %.200s' cannot invoke a stored function.", nil),
   799  	ErrGtidNextCantBeAutomaticIfGtidNextListIsNonNull:        Message("The system variable @@SESSION.GTIDNEXT cannot be 'AUTOMATIC' when @@SESSION.GTIDNEXTLIST is non-NULL.", nil),
   800  	ErrSkippingLoggedTransaction:                             Message("Skipping transaction %.200s because it has already been executed and logged.", nil),
   801  	ErrMalformedGtidSetSpecification:                         Message("Malformed GTID set specification '%.200s'.", nil),
   802  	ErrMalformedGtidSetEncoding:                              Message("Malformed GTID set encoding.", nil),
   803  	ErrMalformedGtidSpecification:                            Message("Malformed GTID specification '%.200s'.", nil),
   804  	ErrGnoExhausted:                                          Message("Impossible to generate Global Transaction Identifier: the integer component reached the maximal value. Restart the server with a new serverUuid.", nil),
   805  	ErrBadSlaveAutoPosition:                                  Message("Parameters MASTERLOGFILE, MASTERLOGPOS, RELAYLOGFILE and RELAYLOGPOS cannot be set when MASTERAUTOPOSITION is active.", nil),
   806  	ErrAutoPositionRequiresGtidModeOn:                        Message("CHANGE MASTER TO MASTERAUTOPOSITION = 1 can only be executed when @@GLOBAL.GTIDMODE = ON.", nil),
   807  	ErrCantDoImplicitCommitInTrxWhenGtidNextIsSet:            Message("Cannot execute statements with implicit commit inside a transaction when @@SESSION.GTIDNEXT != AUTOMATIC or @@SESSION.GTIDNEXTLIST != NULL.", nil),
   808  	ErrGtidMode2Or3RequiresEnforceGtidConsistencyOn:          Message("@@GLOBAL.GTIDMODE = ON or UPGRADESTEP2 requires @@GLOBAL.ENFORCEGTIDCONSISTENCY = 1.", nil),
   809  	ErrGtidModeRequiresBinlog:                                Message("@@GLOBAL.GTIDMODE = ON or UPGRADESTEP1 or UPGRADESTEP2 requires --log-bin and --log-slave-updates.", nil),
   810  	ErrCantSetGtidNextToGtidWhenGtidModeIsOff:                Message("@@SESSION.GTIDNEXT cannot be set to UUID:NUMBER when @@GLOBAL.GTIDMODE = OFF.", nil),
   811  	ErrCantSetGtidNextToAnonymousWhenGtidModeIsOn:            Message("@@SESSION.GTIDNEXT cannot be set to ANONYMOUS when @@GLOBAL.GTIDMODE = ON.", nil),
   812  	ErrCantSetGtidNextListToNonNullWhenGtidModeIsOff:         Message("@@SESSION.GTIDNEXTLIST cannot be set to a non-NULL value when @@GLOBAL.GTIDMODE = OFF.", nil),
   813  	ErrFoundGtidEventWhenGtidModeIsOff:                       Message("Found a GtidLogEvent or PreviousGtidsLogEvent when @@GLOBAL.GTIDMODE = OFF.", nil),
   814  	ErrGtidUnsafeNonTransactionalTable:                       Message("When @@GLOBAL.ENFORCEGTIDCONSISTENCY = 1, updates to non-transactional tables can only be done in either autocommitted statements or single-statement transactions, and never in the same statement as updates to transactional tables.", nil),
   815  	ErrGtidUnsafeCreateSelect:                                Message("CREATE TABLE ... SELECT is forbidden when @@GLOBAL.ENFORCEGTIDCONSISTENCY = 1.", nil),
   816  	ErrGtidUnsafeCreateDropTemporaryTableInTransaction:       Message("When @@GLOBAL.ENFORCEGTIDCONSISTENCY = 1, the statements CREATE TEMPORARY TABLE and DROP TEMPORARY TABLE can be executed in a non-transactional context only, and require that AUTOCOMMIT = 1.", nil),
   817  	ErrGtidModeCanOnlyChangeOneStepAtATime:                   Message("The value of @@GLOBAL.GTIDMODE can only change one step at a time: OFF <-> UPGRADESTEP1 <-> UPGRADESTEP2 <-> ON. Also note that this value must be stepped up or down simultaneously on all servers; see the Manual for instructions.", nil),
   818  	ErrMasterHasPurgedRequiredGtids:                          Message("The slave is connecting using CHANGE MASTER TO MASTERAUTOPOSITION = 1, but the master has purged binary logs containing GTIDs that the slave requires.", nil),
   819  	ErrCantSetGtidNextWhenOwningGtid:                         Message("@@SESSION.GTIDNEXT cannot be changed by a client that owns a GTID. The client owns %s. Ownership is released on COMMIT or ROLLBACK.", nil),
   820  	ErrUnknownExplainFormat:                                  Message("Unknown EXPLAIN format name: '%s'", nil),
   821  	ErrCantExecuteInReadOnlyTransaction:                      Message("Cannot execute statement in a READ ONLY transaction.", nil),
   822  	ErrTooLongTablePartitionComment:                          Message("Comment for table partition '%-.64s' is too long (max = %d)", nil),
   823  	ErrSlaveConfiguration:                                    Message("Slave is not configured or failed to initialize properly. You must at least set --server-id to enable either a master or a slave. Additional error messages can be found in the MySQL error log.", nil),
   824  	ErrInnodbFtLimit:                                         Message("InnoDB presently supports one FULLTEXT index creation at a time", nil),
   825  	ErrInnodbNoFtTempTable:                                   Message("Cannot create FULLTEXT index on temporary InnoDB table", nil),
   826  	ErrInnodbFtWrongDocidColumn:                              Message("Column '%-.192s' is of wrong type for an InnoDB FULLTEXT index", nil),
   827  	ErrInnodbFtWrongDocidIndex:                               Message("Index '%-.192s' is of wrong type for an InnoDB FULLTEXT index", nil),
   828  	ErrInnodbOnlineLogTooBig:                                 Message("Creating index '%-.192s' required more than 'innodbOnlineAlterLogMaxSize' bytes of modification log. Please try again.", nil),
   829  	ErrUnknownAlterAlgorithm:                                 Message("Unknown ALGORITHM '%s'", nil),
   830  	ErrUnknownAlterLock:                                      Message("Unknown LOCK type '%s'", nil),
   831  	ErrMtsChangeMasterCantRunWithGaps:                        Message("CHANGE MASTER cannot be executed when the slave was stopped with an error or killed in MTS mode. Consider using RESET SLAVE or START SLAVE UNTIL.", nil),
   832  	ErrMtsRecoveryFailure:                                    Message("Cannot recover after SLAVE errored out in parallel execution mode. Additional error messages can be found in the MySQL error log.", nil),
   833  	ErrMtsResetWorkers:                                       Message("Cannot clean up worker info tables. Additional error messages can be found in the MySQL error log.", nil),
   834  	ErrColCountDoesntMatchCorruptedV2:                        Message("Column count of %s.%s is wrong. Expected %d, found %d. The table is probably corrupted", nil),
   835  	ErrSlaveSilentRetryTransaction:                           Message("Slave must silently retry current transaction", nil),
   836  	ErrDiscardFkChecksRunning:                                Message("There is a foreign key check running on table '%-.192s'. Cannot discard the table.", nil),
   837  	ErrTableSchemaMismatch:                                   Message("Schema mismatch (%s)", nil),
   838  	ErrTableInSystemTablespace:                               Message("Table '%-.192s' in system tablespace", nil),
   839  	ErrIoRead:                                                Message("IO Read : (%d, %s) %s", nil),
   840  	ErrIoWrite:                                               Message("IO Write : (%d, %s) %s", nil),
   841  	ErrTablespaceMissing:                                     Message("Tablespace is missing for table '%-.192s'", nil),
   842  	ErrTablespaceExists:                                      Message("Tablespace for table '%-.192s' exists. Please DISCARD the tablespace before IMPORT.", nil),
   843  	ErrTablespaceDiscarded:                                   Message("Tablespace has been discarded for table '%-.192s'", nil),
   844  	ErrInternal:                                              Message("Internal : %s", nil),
   845  	ErrInnodbImport:                                          Message("ALTER TABLE '%-.192s' IMPORT TABLESPACE failed with error %d : '%s'", nil),
   846  	ErrInnodbIndexCorrupt:                                    Message("Index corrupt: %s", nil),
   847  	ErrInvalidYearColumnLength:                               Message("Supports only YEAR or YEAR(4) column", nil),
   848  	ErrNotValidPassword:                                      Message("Your password does not satisfy the current policy requirements (%s)", nil),
   849  	ErrMustChangePassword:                                    Message("You must SET PASSWORD before executing this statement", nil),
   850  	ErrFkNoIndexChild:                                        Message("Failed to add the foreign key constraint. Missing index for constraint '%s' in the foreign table '%s'", nil),
   851  	ErrForeignKeyNoIndexInParent:                             Message("Failed to add the foreign key constraint. Missing index for constraint '%s' in the referenced table '%s'", nil),
   852  	ErrFkFailAddSystem:                                       Message("Failed to add the foreign key constraint '%s' to system tables", nil),
   853  	ErrForeignKeyCannotOpenParent:                            Message("Failed to open the referenced table '%s'", nil),
   854  	ErrFkIncorrectOption:                                     Message("Failed to add the foreign key constraint on table '%s'. Incorrect options in FOREIGN KEY constraint '%s'", nil),
   855  	ErrFkDupName:                                             Message("Duplicate foreign key constraint name '%s'", nil),
   856  	ErrPasswordFormat:                                        Message("The password hash doesn't have the expected format. Check if the correct password algorithm is being used with the PASSWORD() function.", nil),
   857  	ErrFkColumnCannotDrop:                                    Message("Cannot drop column '%-.192s': needed in a foreign key constraint '%-.192s'", nil),
   858  	ErrFkColumnCannotDropChild:                               Message("Cannot drop column '%-.192s': needed in a foreign key constraint '%-.192s' of table '%-.192s'", nil),
   859  	ErrForeignKeyColumnNotNull:                               Message("Column '%-.192s' cannot be NOT NULL: needed in a foreign key constraint '%-.192s' SET NULL", nil),
   860  	ErrDupIndex:                                              Message("Duplicate index '%-.64s' defined on the table '%-.64s.%-.64s'. This is deprecated and will be disallowed in a future release.", nil),
   861  	ErrForeignKeyColumnCannotChange:                          Message("Cannot change column '%-.192s': used in a foreign key constraint '%-.192s'", nil),
   862  	ErrForeignKeyColumnCannotChangeChild:                     Message("Cannot change column '%-.192s': used in a foreign key constraint '%-.192s' of table '%-.192s'", nil),
   863  	ErrFkCannotDeleteParent:                                  Message("Cannot delete rows from table which is parent in a foreign key constraint '%-.192s' of table '%-.192s'", nil),
   864  	ErrMalformedPacket:                                       Message("Malformed communication packet.", nil),
   865  	ErrReadOnlyMode:                                          Message("Running in read-only mode", nil),
   866  	ErrGtidNextTypeUndefinedGroup:                            Message("When @@SESSION.GTIDNEXT is set to a GTID, you must explicitly set it again after a COMMIT or ROLLBACK. If you see this error message in the slave SQL thread, it means that a table in the current transaction is transactional on the master and non-transactional on the slave. In a client connection, it means that you executed SET @@SESSION.GTIDNEXT before a transaction and forgot to set @@SESSION.GTIDNEXT to a different identifier or to 'AUTOMATIC' after COMMIT or ROLLBACK. Current @@SESSION.GTIDNEXT is '%s'.", nil),
   867  	ErrVariableNotSettableInSp:                               Message("The system variable %.200s cannot be set in stored procedures.", nil),
   868  	ErrCantSetGtidPurgedWhenGtidModeIsOff:                    Message("@@GLOBAL.GTIDPURGED can only be set when @@GLOBAL.GTIDMODE = ON.", nil),
   869  	ErrCantSetGtidPurgedWhenGtidExecutedIsNotEmpty:           Message("@@GLOBAL.GTIDPURGED can only be set when @@GLOBAL.GTIDEXECUTED is empty.", nil),
   870  	ErrCantSetGtidPurgedWhenOwnedGtidsIsNotEmpty:             Message("@@GLOBAL.GTIDPURGED can only be set when there are no ongoing transactions (not even in other clients).", nil),
   871  	ErrGtidPurgedWasChanged:                                  Message("@@GLOBAL.GTIDPURGED was changed from '%s' to '%s'.", nil),
   872  	ErrGtidExecutedWasChanged:                                Message("@@GLOBAL.GTIDEXECUTED was changed from '%s' to '%s'.", nil),
   873  	ErrBinlogStmtModeAndNoReplTables:                         Message("Cannot execute statement: impossible to write to binary log since BINLOGFORMAT = STATEMENT, and both replicated and non replicated tables are written to.", nil),
   874  	ErrAlterOperationNotSupported:                            Message("%s is not supported for this operation. Try %s.", nil),
   875  	ErrAlterOperationNotSupportedReason:                      Message("%s is not supported. Reason: %s. Try %s.", nil),
   876  	ErrAlterOperationNotSupportedReasonCopy:                  Message("COPY algorithm requires a lock", nil),
   877  	ErrAlterOperationNotSupportedReasonPartition:             Message("Partition specific operations do not yet support LOCK/ALGORITHM", nil),
   878  	ErrAlterOperationNotSupportedReasonFkRename:              Message("Columns participating in a foreign key are renamed", nil),
   879  	ErrAlterOperationNotSupportedReasonColumnType:            Message("Cannot change column type INPLACE", nil),
   880  	ErrAlterOperationNotSupportedReasonFkCheck:               Message("Adding foreign keys needs foreignKeyChecks=OFF", nil),
   881  	ErrAlterOperationNotSupportedReasonIgnore:                Message("Creating unique indexes with IGNORE requires COPY algorithm to remove duplicate rows", nil),
   882  	ErrAlterOperationNotSupportedReasonNopk:                  Message("Dropping a primary key is not allowed without also adding a new primary key", nil),
   883  	ErrAlterOperationNotSupportedReasonAutoinc:               Message("Adding an auto-increment column requires a lock", nil),
   884  	ErrAlterOperationNotSupportedReasonHiddenFts:             Message("Cannot replace hidden FTSDOCID with a user-visible one", nil),
   885  	ErrAlterOperationNotSupportedReasonChangeFts:             Message("Cannot drop or rename FTSDOCID", nil),
   886  	ErrAlterOperationNotSupportedReasonFts:                   Message("Fulltext index creation requires a lock", nil),
   887  	ErrSQLSlaveSkipCounterNotSettableInGtidMode:              Message("sqlSlaveSkipCounter can not be set when the server is running with @@GLOBAL.GTIDMODE = ON. Instead, for each transaction that you want to skip, generate an empty transaction with the same GTID as the transaction", nil),
   888  	ErrDupUnknownInIndex:                                     Message("Duplicate entry for key '%-.192s'", nil),
   889  	ErrIdentCausesTooLongPath:                                Message("Long database name and identifier for object resulted in path length exceeding %d characters. Path: '%s'.", nil),
   890  	ErrAlterOperationNotSupportedReasonNotNull:               Message("cannot silently convert NULL values, as required in this SQLMODE", nil),
   891  	ErrMustChangePasswordLogin:                               Message("Your password has expired. To log in you must change it using a client that supports expired passwords.", nil),
   892  	ErrRowInWrongPartition:                                   Message("Found a row in wrong partition %s", nil),
   893  	ErrGeneratedColumnFunctionIsNotAllowed:                   Message("Expression of generated column '%s' contains a disallowed function.", nil),
   894  	ErrUnsupportedAlterInplaceOnVirtualColumn:                Message("INPLACE ADD or DROP of virtual columns cannot be combined with other ALTER TABLE actions.", nil),
   895  	ErrWrongFKOptionForGeneratedColumn:                       Message("Cannot define foreign key with %s clause on a generated column.", nil),
   896  	ErrBadGeneratedColumn:                                    Message("The value specified for generated column '%s' in table '%s' is not allowed.", nil),
   897  	ErrUnsupportedOnGeneratedColumn:                          Message("'%s' is not supported for generated columns.", nil),
   898  	ErrGeneratedColumnNonPrior:                               Message("Generated column can refer only to generated columns defined prior to it.", nil),
   899  	ErrDependentByGeneratedColumn:                            Message("Column '%s' has a generated column dependency.", nil),
   900  	ErrGeneratedColumnRefAutoInc:                             Message("Generated column '%s' cannot refer to auto-increment column.", nil),
   901  	ErrInvalidFieldSize:                                      Message("Invalid size for column '%s'.", nil),
   902  	ErrPasswordExpireAnonymousUser:                           Message("The password for anonymous user cannot be expired.", nil),
   903  	ErrIncorrectType:                                         Message("Incorrect type for argument %s in function %s.", nil),
   904  	ErrInvalidJSONData:                                       Message("Invalid JSON data provided to function %s: %s", nil),
   905  	ErrInvalidJSONText:                                       Message("Invalid JSON text: %-.192s", nil),
   906  	ErrInvalidJSONPath:                                       Message("Invalid JSON path expression %s.", nil),
   907  	ErrInvalidTypeForJSON:                                    Message("Invalid data type for JSON data in argument %d to function %s; a JSON string or JSON type is required.", nil),
   908  	ErrInvalidJSONPathWildcard:                               Message("In this situation, path expressions may not contain the * and ** tokens.", nil),
   909  	ErrInvalidJSONContainsPathType:                           Message("The second argument can only be either 'one' or 'all'.", nil),
   910  	ErrJSONUsedAsKey:                                         Message("JSON column '%-.192s' cannot be used in key specification.", nil),
   911  	ErrJSONDocumentNULLKey:                                   Message("JSON documents may not contain NULL member names.", nil),
   912  	ErrBadUser:                                               Message("User %s does not exist.", nil),
   913  	ErrUserAlreadyExists:                                     Message("User %s already exists.", nil),
   914  	ErrInvalidJSONPathArrayCell:                              Message("A path expression is not a path to a cell in an array.", nil),
   915  	ErrInvalidEncryptionOption:                               Message("Invalid encryption option.", nil),
   916  	ErrWindowNoSuchWindow:                                    Message("Window name '%s' is not defined.", nil),
   917  	ErrWindowCircularityInWindowGraph:                        Message("There is a circularity in the window dependency graph.", nil),
   918  	ErrWindowNoChildPartitioning:                             Message("A window which depends on another cannot define partitioning.", nil),
   919  	ErrWindowNoInherentFrame:                                 Message("Window '%s' has a frame definition, so cannot be referenced by another window.", nil),
   920  	ErrWindowNoRedefineOrderBy:                               Message("Window '%s' cannot inherit '%s' since both contain an ORDER BY clause.", nil),
   921  	ErrWindowFrameStartIllegal:                               Message("Window '%s': frame start cannot be UNBOUNDED FOLLOWING.", nil),
   922  	ErrWindowFrameEndIllegal:                                 Message("Window '%s': frame end cannot be UNBOUNDED PRECEDING.", nil),
   923  	ErrWindowFrameIllegal:                                    Message("Window '%s': frame start or end is negative, NULL or of non-integral type", nil),
   924  	ErrWindowRangeFrameOrderType:                             Message("Window '%s' with RANGE N PRECEDING/FOLLOWING frame requires exactly one ORDER BY expression, of numeric or temporal type", nil),
   925  	ErrWindowRangeFrameTemporalType:                          Message("Window '%s' with RANGE frame has ORDER BY expression of datetime type. Only INTERVAL bound value allowed.", nil),
   926  	ErrWindowRangeFrameNumericType:                           Message("Window '%s' with RANGE frame has ORDER BY expression of numeric type, INTERVAL bound value not allowed.", nil),
   927  	ErrWindowRangeBoundNotConstant:                           Message("Window '%s' has a non-constant frame bound.", nil),
   928  	ErrWindowDuplicateName:                                   Message("Window '%s' is defined twice.", nil),
   929  	ErrWindowIllegalOrderBy:                                  Message("Window '%s': ORDER BY or PARTITION BY uses legacy position indication which is not supported, use expression.", nil),
   930  	ErrWindowInvalidWindowFuncUse:                            Message("You cannot use the window function '%s' in this context.'", nil),
   931  	ErrWindowInvalidWindowFuncAliasUse:                       Message("You cannot use the alias '%s' of an expression containing a window function in this context.'", nil),
   932  	ErrWindowNestedWindowFuncUseInWindowSpec:                 Message("You cannot nest a window function in the specification of window '%s'.", nil),
   933  	ErrWindowRowsIntervalUse:                                 Message("Window '%s': INTERVAL can only be used with RANGE frames.", nil),
   934  	ErrWindowNoGroupOrderUnused:                              Message("ASC or DESC with GROUP BY isn't allowed with window functions; put ASC or DESC in ORDER BY", nil),
   935  	ErrWindowExplainJson:                                     Message("To get information about window functions use EXPLAIN FORMAT=JSON", nil),
   936  	ErrWindowFunctionIgnoresFrame:                            Message("Window function '%s' ignores the frame clause of window '%s' and aggregates over the whole partition", nil),
   937  	ErrRoleNotGranted:                                        Message("%s is not granted to %s", nil),
   938  	ErrMaxExecTimeExceeded:                                   Message("Query execution was interrupted, maximum statement execution time exceeded", nil),
   939  	ErrLockAcquireFailAndNoWaitSet:                           Message("Statement aborted because lock(s) could not be acquired immediately and NOWAIT is set.", nil),
   940  	ErrDataTruncatedFunctionalIndex:                          Message("Data truncated for functional index '%s' at row %d", nil),
   941  	ErrDataOutOfRangeFunctionalIndex:                         Message("Value is out of range for functional index '%s' at row %d", nil),
   942  	ErrFunctionalIndexOnJsonOrGeometryFunction:               Message("Cannot create a functional index on a function that returns a JSON or GEOMETRY value", nil),
   943  	ErrFunctionalIndexRefAutoIncrement:                       Message("Functional index '%s' cannot refer to an auto-increment column", nil),
   944  	ErrCannotDropColumnFunctionalIndex:                       Message("Cannot drop column '%s' because it is used by a functional index. In order to drop the column, you must remove the functional index", nil),
   945  	ErrFunctionalIndexPrimaryKey:                             Message("The primary key cannot be a functional index", nil),
   946  	ErrFunctionalIndexOnLob:                                  Message("Cannot create a functional index on an expression that returns a BLOB or TEXT. Please consider using CAST", nil),
   947  	ErrFunctionalIndexFunctionIsNotAllowed:                   Message("Expression of functional index '%s' contains a disallowed function", nil),
   948  	ErrFulltextFunctionalIndex:                               Message("Fulltext functional index is not supported", nil),
   949  	ErrSpatialFunctionalIndex:                                Message("Spatial functional index is not supported", nil),
   950  	ErrWrongKeyColumnFunctionalIndex:                         Message("The used storage engine cannot index the expression '%s'", nil),
   951  	ErrFunctionalIndexOnField:                                Message("Functional index on a column is not supported. Consider using a regular index instead", nil),
   952  	ErrFKIncompatibleColumns:                                 Message("Referencing column '%s' and referenced column '%s' in foreign key constraint '%s' are incompatible.", nil),
   953  	ErrFunctionalIndexRowValueIsNotAllowed:                   Message("Expression of functional index '%s' cannot refer to a row value", nil),
   954  	ErrDependentByFunctionalIndex:                            Message("Column '%s' has a functional index dependency and cannot be dropped or renamed", nil),
   955  	ErrInvalidJsonValueForFuncIndex:                          Message("Invalid JSON value for CAST for functional index '%s'", nil),
   956  	ErrJsonValueOutOfRangeForFuncIndex:                       Message("Out of range JSON value for CAST for functional index '%s'", nil),
   957  	ErrFunctionalIndexDataIsTooLong:                          Message("Data too long for functional index '%s'", nil),
   958  	ErrFunctionalIndexNotApplicable:                          Message("Cannot use functional index '%s' due to type or collation conversion", nil),
   959  
   960  	// MariaDB errors.
   961  	ErrOnlyOneDefaultPartionAllowed:         Message("Only one DEFAULT partition allowed", nil),
   962  	ErrWrongPartitionTypeExpectedSystemTime: Message("Wrong partitioning type, expected type: `SYSTEM_TIME`", nil),
   963  	ErrSystemVersioningWrongPartitions:      Message("Wrong Partitions: must have at least one HISTORY and exactly one last CURRENT", nil),
   964  	ErrSequenceRunOut:                       Message("Sequence '%-.64s.%-.64s' has run out", nil),
   965  	ErrSequenceInvalidData:                  Message("Sequence '%-.64s.%-.64s' values are conflicting", nil),
   966  	ErrSequenceAccessFail:                   Message("Sequence '%-.64s.%-.64s' access error", nil),
   967  	ErrNotSequence:                          Message("'%-.64s.%-.64s' is not a SEQUENCE", nil),
   968  	ErrUnknownSequence:                      Message("Unknown SEQUENCE: '%-.300s'", nil),
   969  	ErrWrongInsertIntoSequence:              Message("Wrong INSERT into a SEQUENCE. One can only do single table INSERT into a sequence object (like with mysqldump).  If you want to change the SEQUENCE, use ALTER SEQUENCE instead.", nil),
   970  	ErrSequenceInvalidTableStructure:        Message("Sequence '%-.64s.%-.64s' table structure is invalid (%s)", nil),
   971  
   972  	// TiDB errors.
   973  	ErrWarnOptimizerHintInvalidInteger:  Message("integer value is out of range in '%s'", nil),
   974  	ErrWarnOptimizerHintUnsupportedHint: Message("Optimizer hint %s is not supported by TiDB and is ignored", nil),
   975  	ErrWarnOptimizerHintInvalidToken:    Message("Cannot use %s '%s' (tok = %d) in an optimizer hint", nil),
   976  	ErrWarnMemoryQuotaOverflow:          Message("Max value of MEMORY_QUOTA is %d bytes, ignore this invalid limit", nil),
   977  	ErrWarnOptimizerHintParseError:      Message("Optimizer hint syntax error at %v", nil),
   978  	ErrWarnOptimizerHintWrongPos:        Message("Optimizer hint can only be followed by certain keywords like SELECT, INSERT, etc.", nil),
   979  }