This is work in progress.

Windows / Headers / esent.h

esent.h

This module defines the types and constants that are exposed through the ESE API.

Associated Error Codes

Below is a list of error codes found for this header.

SymbolicValueDescription
JET_errSuccess0x0Successful Operation
JET_errRfsFailure0xffffff9cResource Failure Simulator failure
JET_errRfsNotArmed0xffffff9bResource Failure Simulator not initialized
JET_errFileClose0xffffff9aCould not close file
JET_errOutOfThreads0xffffff99Could not start thread
JET_errTooManyIO0xffffff97System busy due to too many IOs
JET_errTaskDropped0xffffff96A requested async task could not be executed
JET_errInternalError0xffffff95Fatal internal error
JET_errDisabledFunctionality0xffffff90You are running MinESE, that does not have all features compiled in. This functionality is only supported in a full version of ESE.
JET_errUnloadableOSFunctionality0xffffff8fThe desired OS functionality could not be located and loaded / linked.
JET_errDatabaseBufferDependenciesCorrupted0xffffff01Buffer dependencies improperly set. Recovery failure
JET_errPreviousVersion0xfffffebeVersion already existed. Recovery failure
JET_errPageBoundary0xfffffebdReached Page Boundary
JET_errKeyBoundary0xfffffebcReached Key Boundary
JET_errBadPageLink0xfffffeb9Database corrupted
JET_errBadBookmark0xfffffeb8Bookmark has no corresponding address in database
JET_errNTSystemCallFailed0xfffffeb2A call to the operating system failed
JET_errBadParentPageLink0xfffffeaeDatabase corrupted
JET_errSPAvailExtCacheOutOfSync0xfffffeacAvailExt cache doesn't match btree
JET_errSPAvailExtCorrupted0xfffffeabAvailExt space tree is corrupt
JET_errSPAvailExtCacheOutOfMemory0xfffffeaaOut of memory allocating an AvailExt cache node
JET_errSPOwnExtCorrupted0xfffffea9OwnExt space tree is corrupt
JET_errDbTimeCorrupted0xfffffea8Dbtime on current page is greater than global database dbtime
JET_errKeyTruncated0xfffffea6key truncated on index that disallows key truncation
JET_errDatabaseLeakInSpace0xfffffea4Some database pages have become unreachable even from the avail tree, only an offline defragmentation can return the lost space.
JET_errBadEmptyPage0xfffffea1Database corrupted. Searching an unexpectedly empty page.
JET_errBadLineCount0xfffffe9eNumber of lines on the page is too few compared to the line being operated on
JET_errColumnIllegalNull0xfffffa20
JET_errKeyTooBig0xfffffe68Key is too large
JET_errCannotSeparateIntrinsicLV0xfffffe60illegal attempt to separate an LV which must be intrinsic
JET_errSeparatedLongValue0xfffffe5bOperation not supported on separated long-value
JET_errMustBeSeparateLongValue0xfffffe59Can only preread long value columns that can be separate, e.g. not size constrained so that they are fixed or variable columns
JET_errInvalidPreread0xfffffe58Cannot preread long values when current index secondary
JET_errInvalidLoggedOperation0xfffffe0cLogged operation cannot be redone
JET_errLogFileCorrupt0xfffffe0bLog file is corrupt
JET_errNoBackupDirectory0xfffffe09No backup directory given
JET_errBackupDirectoryNotEmpty0xfffffe08The backup directory is not emtpy
JET_errBackupInProgress0xfffffe07Backup is active already
JET_errRestoreInProgress0xfffffe06Restore in progress
JET_errMissingPreviousLogFile0xfffffe03Missing the log file for check point
JET_errLogWriteFail0xfffffe02Failure writing to log file
JET_errLogDisabledDueToRecoveryFailure0xfffffe01Try to log something after recovery faild
JET_errCannotLogDuringRecoveryRedo0xfffffe00Try to log something during recovery redo
JET_errLogGenerationMismatch0xfffffdffName of logfile does not match internal generation number
JET_errBadLogVersion0xfffffdfeVersion of log file is not compatible with Jet version
JET_errInvalidLogSequence0xfffffdfdTimestamp in next log does not match expected
JET_errLoggingDisabled0xfffffdfcLog is not active
JET_errLogBufferTooSmall0xfffffdfbLog buffer is too small for recovery
JET_errLogSequenceEnd0xfffffdf9Maximum log file number exceeded
JET_errNoBackup0xfffffdf8No backup in progress
JET_errInvalidBackupSequence0xfffffdf7Backup call out of sequence
JET_errBackupNotAllowedYet0xfffffdf5Cannot do backup now
JET_errDeleteBackupFileFail0xfffffdf4Could not delete backup file
JET_errMakeBackupDirectoryFail0xfffffdf3Could not make backup temp directory
JET_errInvalidBackup0xfffffdf2Cannot perform incremental backup when circular logging enabled
JET_errRecoveredWithErrors0xfffffdf1Restored with errors
JET_errMissingLogFile0xfffffdf0Current log file missing
JET_errLogDiskFull0xfffffdefLog disk full
JET_errBadLogSignature0xfffffdeeBad signature for a log file
JET_errBadDbSignature0xfffffdedBad signature for a db file
JET_errBadCheckpointSignature0xfffffdecBad signature for a checkpoint file
JET_errCheckpointCorrupt0xfffffdebCheckpoint file not found or corrupt
JET_errMissingPatchPage0xfffffdeaPatch file page not found during recovery
JET_errBadPatchPage0xfffffde9Patch file page is not valid
JET_errRedoAbruptEnded0xfffffde8Redo abruptly ended due to sudden failure in reading logs from log file
JET_errPatchFileMissing0xfffffde6Hard restore detected that patch file is missing from backup set
JET_errDatabaseLogSetMismatch0xfffffde5Database does not belong with the current set of log files
JET_errDatabaseStreamingFileMismatch0xfffffde4Database and streaming file do not match each other
JET_errLogFileSizeMismatch0xfffffde3actual log file size does not match JET_paramLogFileSize
JET_errCheckpointFileNotFound0xfffffde2Could not locate checkpoint file
JET_errRequiredLogFilesMissing0xfffffde1The required log files for recovery is missing.
JET_errSoftRecoveryOnBackupDatabase0xfffffde0Soft recovery is intended on a backup database. Restore should be used instead
JET_errLogFileSizeMismatchDatabasesConsistent0xfffffddfdatabases have been recovered, but the log file size used during recovery does not match JET_paramLogFileSize
JET_errLogSectorSizeMismatch0xfffffddethe log file sector size does not match the current volume's sector size
JET_errLogSectorSizeMismatchDatabasesConsistent0xfffffddddatabases have been recovered, but the log file sector size (used during recovery) does not match the current volume's sector size
JET_errLogSequenceEndDatabasesConsistent0xfffffddcdatabases have been recovered, but all possible log generations in the current sequence are used; delete all log files and the checkpoint file and backup the databases before continuing
JET_errStreamingDataNotLogged0xfffffddbIllegal attempt to replay a streaming file operation where the data wasn't logged. Probably caused by an attempt to roll-forward with circular logging enabled
JET_errDatabaseDirtyShutdown0xfffffddaDatabase was not shutdown cleanly. Recovery must first be run to properly complete database operations for the previous shutdown.
JET_errDatabaseInconsistent0xfffffddaOBSOLETE
JET_errConsistentTimeMismatch0xfffffdd9Database last consistent time unmatched
JET_errDatabasePatchFileMismatch0xfffffdd8Patch file is not generated from this backup
JET_errEndingRestoreLogTooLow0xfffffdd7The starting log number too low for the restore
JET_errStartingRestoreLogTooHigh0xfffffdd6The starting log number too high for the restore
JET_errGivenLogFileHasBadSignature0xfffffdd5Restore log file has bad signature
JET_errGivenLogFileIsNotContiguous0xfffffdd4Restore log file is not contiguous
JET_errMissingRestoreLogFiles0xfffffdd3Some restore log files are missing
JET_errMissingFullBackup0xfffffdd0The database missed a previous full backup before incremental backup
JET_errBadBackupDatabaseSize0xfffffdcfThe backup database size is not in 4k
JET_errDatabaseAlreadyUpgraded0xfffffdceAttempted to upgrade a database that is already current
JET_errDatabaseIncompleteUpgrade0xfffffdcdAttempted to use a database which was only partially converted to the current format -- must restore from backup
JET_errMissingCurrentLogFiles0xfffffdcbSome current log files are missing for continuous restore
JET_errDbTimeTooOld0xfffffdcadbtime on page smaller than dbtimeBefore in record
JET_errDbTimeTooNew0xfffffdc9dbtime on page in advance of the dbtimeBefore in record
JET_errMissingFileToBackup0xfffffdc7Some log or patch files are missing during backup
JET_errLogTornWriteDuringHardRestore0xfffffdc6torn-write was detected in a backup set during hard restore
JET_errLogTornWriteDuringHardRecovery0xfffffdc5torn-write was detected during hard recovery (log was not part of a backup set)
JET_errLogCorruptDuringHardRestore0xfffffdc3corruption was detected in a backup set during hard restore
JET_errLogCorruptDuringHardRecovery0xfffffdc2corruption was detected during hard recovery (log was not part of a backup set)
JET_errMustDisableLoggingForDbUpgrade0xfffffdc1Cannot have logging enabled while attempting to upgrade db
JET_errBadRestoreTargetInstance0xfffffdbfTargetInstance specified for restore is not found or log files don't match
JET_errRecoveredWithoutUndo0xfffffdbdSoft recovery successfully replayed all operations, but the Undo phase of recovery was skipped
JET_errDatabasesNotFromSameSnapshot0xfffffdbcDatabases to be restored are not from the same shadow copy backup
JET_errSoftRecoveryOnSnapshot0xfffffdbbSoft recovery on a database from a shadow copy backup set
JET_errCommittedLogFilesMissing0xfffffdbaOne or more logs that were committed to this database, are missing. These log files are required to maintain durable ACID semantics, but not required to maintain consistency if the JET_bitReplayIgnoreLostLogs bit is specified during recovery.
JET_errSectorSizeNotSupported0xfffffdb9The physical sector size reported by the disk subsystem, is unsupported by ESE for a specific file type.
JET_errRecoveredWithoutUndoDatabasesConsistent0xfffffdb8Soft recovery successfully replayed all operations and intended to skip the Undo phase of recovery, but the Undo phase was not required
JET_errCommittedLogFileCorrupt0xfffffdb6One or more logs were found to be corrupt during recovery. These log files are required to maintain durable ACID semantics, but not required to maintain consistency if the JET_bitIgnoreLostLogs bit and JET_paramDeleteOutOfRangeLogs is specified during recovery.
JET_errLogSequenceChecksumMismatch0xfffffdb2The previous log's accumulated segment checksum doesn't match the next log
JET_errPageInitializedMismatch0xfffffdacDatabase divergence mismatch. Page was uninitialized on remote node, but initialized on local node.
JET_errUnicodeTranslationBufferTooSmall0xfffffda7Unicode translation buffer too small
JET_errUnicodeTranslationFail0xfffffda6Unicode normalization failed
JET_errUnicodeNormalizationNotSupported0xfffffda5OS does not provide support for Unicode normalisation (and no normalisation callback was specified)
JET_errUnicodeLanguageValidationFailure0xfffffda4Can not validate the language
JET_errExistingLogFileHasBadSignature0xfffffd9eExisting log file has bad signature
JET_errExistingLogFileIsNotContiguous0xfffffd9dExisting log file is not contiguous
JET_errLogReadVerifyFailure0xfffffd9cChecksum error in log file during backup
JET_errCheckpointDepthTooDeep0xfffffd9atoo many outstanding generations between checkpoint and current generation
JET_errRestoreOfNonBackupDatabase0xfffffd99hard recovery attempted on a database that wasn't a backup database
JET_errLogFileNotCopied0xfffffd98log truncation attempted but not all required logs were copied
JET_errTransactionTooLong0xfffffd96Too many outstanding generations between JetBeginTransaction and current generation.
JET_errEngineFormatVersionNoLongerSupportedTooLow0xfffffd95The specified JET_ENGINEFORMATVERSION value is too low to be supported by this version of ESE.
JET_errEngineFormatVersionNotYetImplementedTooHigh0xfffffd94The specified JET_ENGINEFORMATVERSION value is too high, higher than this version of ESE knows about.
JET_errEngineFormatVersionParamTooLowForRequestedFeature0xfffffd93Thrown by a format feature (not at JetSetSystemParameter) if the client requests a feature that requires a version higher than that set for the JET_paramEngineFormatVersion.
JET_errEngineFormatVersionSpecifiedTooLowForLogVersion0xfffffd92The specified JET_ENGINEFORMATVERSION is set too low for this log stream, the log files have already been upgraded to a higher version. A higher JET_ENGINEFORMATVERSION value must be set in the param.
JET_errEngineFormatVersionSpecifiedTooLowForDatabaseVersion0xfffffd91The specified JET_ENGINEFORMATVERSION is set too low for this database file, the database file has already been upgraded to a higher version. A higher JET_ENGINEFORMATVERSION value must be set in the param.
JET_errBackupAbortByServer0xfffffcdfBackup was aborted by server by calling JetTerm with JET_bitTermStopBackup or by calling JetStopBackup
JET_errInvalidGrbit0xfffffc7cInvalid flags parameter
JET_errTermInProgress0xfffffc18Termination in progress
JET_errFeatureNotAvailable0xfffffc17API not supported
JET_errInvalidName0xfffffc16Invalid name
JET_errInvalidParameter0xfffffc15Invalid API parameter
JET_errDatabaseFileReadOnly0xfffffc10Tried to attach a read-only database file for read/write operations
JET_errInvalidDatabaseId0xfffffc0eInvalid database id
JET_errOutOfMemory0xfffffc0dOut of Memory
JET_errOutOfDatabaseSpace0xfffffc0cMaximum database size reached
JET_errOutOfCursors0xfffffc0bOut of table cursors
JET_errOutOfBuffers0xfffffc0aOut of database page buffers
JET_errTooManyIndexes0xfffffc09Too many indexes
JET_errTooManyKeys0xfffffc08Too many columns in an index
JET_errRecordDeleted0xfffffc07Record has been deleted
JET_errReadVerifyFailure0xfffffc06Checksum error on a database page
JET_errPageNotInitialized0xfffffc05Blank database page
JET_errOutOfFileHandles0xfffffc04Out of file handles
JET_errDiskReadVerificationFailure0xfffffc03The OS returned ERROR_CRC from file IO
JET_errDiskIO0xfffffc02Disk IO error
JET_errInvalidPath0xfffffc01Invalid file path
JET_errInvalidSystemPath0xfffffc00Invalid system path
JET_errInvalidLogDirectory0xfffffbffInvalid log directory
JET_errRecordTooBig0xfffffbfeRecord larger than maximum size
JET_errTooManyOpenDatabases0xfffffbfdToo many open databases
JET_errInvalidDatabase0xfffffbfcNot a database file
JET_errNotInitialized0xfffffbfbDatabase engine not initialized
JET_errAlreadyInitialized0xfffffbfaDatabase engine already initialized
JET_errInitInProgress0xfffffbf9Database engine is being initialized
JET_errFileAccessDenied0xfffffbf8Cannot access file, the file is locked or in use
JET_errBufferTooSmall0xfffffbf2Buffer is too small
JET_errTooManyColumns0xfffffbf0Too many columns defined
JET_errContainerNotEmpty0xfffffbedContainer is not empty
JET_errInvalidFilename0xfffffbecFilename is invalid
JET_errInvalidBookmark0xfffffbebInvalid bookmark
JET_errColumnInUse0xfffffbeaColumn used in an index
JET_errInvalidBufferSize0xfffffbe9Data buffer doesn't match column size
JET_errColumnNotUpdatable0xfffffbe8Cannot set column value
JET_errIndexInUse0xfffffbe5Index is in use
JET_errLinkNotSupported0xfffffbe4Link support unavailable
JET_errNullKeyDisallowed0xfffffbe3Null keys are disallowed on index
JET_errNotInTransaction0xfffffbe2Operation must be within a transaction
JET_errMustRollback0xfffffbdfTransaction must rollback because failure of unversioned update
JET_errTooManyActiveUsers0xfffffbddToo many active database users
JET_errInvalidCountry0xfffffbdbInvalid or unknown country/region code
JET_errInvalidLanguageId0xfffffbdaInvalid or unknown language id
JET_errInvalidCodePage0xfffffbd9Invalid or unknown code page
JET_errInvalidLCMapStringFlags0xfffffbd8Invalid flags for LCMapString()
JET_errVersionStoreEntryTooBig0xfffffbd7Attempted to create a version store entry (RCE) larger than a version bucket
JET_errVersionStoreOutOfMemoryAndCleanupTimedOut0xfffffbd6Version store out of memory (and cleanup attempt failed to complete)
JET_errVersionStoreOutOfMemory0xfffffbd3Version store out of memory (cleanup already attempted)
JET_errCannotIndex0xfffffbd1Cannot index escrow column
JET_errRecordNotDeleted0xfffffbd0Record has not been deleted
JET_errTooManyMempoolEntries0xfffffbcfToo many mempool entries requested
JET_errOutOfObjectIDs0xfffffbceOut of btree ObjectIDs (perform offline defrag to reclaim freed/unused ObjectIds)
JET_errOutOfLongValueIDs0xfffffbcdLong-value ID counter has reached maximum value. (perform offline defrag to reclaim free/unused LongValueIDs)
JET_errOutOfAutoincrementValues0xfffffbccAuto-increment counter has reached maximum value (offline defrag WILL NOT be able to reclaim free/unused Auto-increment values).
JET_errOutOfDbtimeValues0xfffffbcbDbtime counter has reached maximum value (perform offline defrag to reclaim free/unused Dbtime values)
JET_errOutOfSequentialIndexValues0xfffffbcaSequential index counter has reached maximum value (perform offline defrag to reclaim free/unused SequentialIndex values)
JET_errRunningInOneInstanceMode0xfffffbc8Multi-instance call with single-instance mode enabled
JET_errRunningInMultiInstanceMode0xfffffbc7Single-instance call with multi-instance mode enabled
JET_errSystemParamsAlreadySet0xfffffbc6Global system parameters have already been set
JET_errSystemPathInUse0xfffffbc5System path already used by another database instance
JET_errLogFilePathInUse0xfffffbc4Logfile path already used by another database instance
JET_errTempPathInUse0xfffffbc3Temp path already used by another database instance
JET_errInstanceNameInUse0xfffffbc2Instance Name already in use
JET_errSystemParameterConflict0xfffffbc1Global system parameters have already been set, but to a conflicting or disagreeable state to the specified values.
JET_errInstanceUnavailable0xfffffbbeThis instance cannot be used because it encountered a fatal error
JET_errDatabaseUnavailable0xfffffbbdThis database cannot be used because it encountered a fatal error
JET_errInstanceUnavailableDueToFatalLogDiskFull0xfffffbbcThis instance cannot be used because it encountered a log-disk-full error performing an operation (likely transaction rollback) that could not tolerate failure
JET_errInvalidSesparamId0xfffffbbbThis JET_sesparam* identifier is not known to the ESE engine.
JET_errTooManyRecords0xfffffbbaThere are too many records to enumerate, switch to an API that handles 64-bit numbers
JET_errInvalidDbparamId0xfffffbb9This JET_dbparam* identifier is not known to the ESE engine.
JET_errOutOfSessions0xfffffbb3Out of sessions
JET_errWriteConflict0xfffffbb2Write lock failed due to outstanding write lock
JET_errTransTooDeep0xfffffbb1Transactions nested too deeply
JET_errInvalidSesid0xfffffbb0Invalid session handle
JET_errWriteConflictPrimaryIndex0xfffffbafUpdate attempted on uncommitted primary index
JET_errInTransaction0xfffffbacOperation not allowed within a transaction
JET_errRollbackRequired0xfffffbabMust rollback current transaction -- cannot commit or begin a new one
JET_errTransReadOnly0xfffffbaaRead-only transaction tried to modify the database
JET_errSessionWriteConflict0xfffffba9Attempt to replace the same record by two diffrerent cursors in the same session
JET_errRecordTooBigForBackwardCompatibility0xfffffba8record would be too big if represented in a database format from a previous version of Jet
JET_errCannotMaterializeForwardOnlySort0xfffffba7The temp table could not be created due to parameters that conflict with JET_bitTTForwardOnly
JET_errSesidTableIdMismatch0xfffffba6This session handle can't be used with this table id
JET_errInvalidInstance0xfffffba5Invalid instance handle
JET_errDirtyShutdown0xfffffba4The instance was shutdown successfully but all the attached databases were left in a dirty state by request via JET_bitTermDirty
JET_errReadPgnoVerifyFailure0xfffffba2The database page read from disk had the wrong page number.
JET_errReadLostFlushVerifyFailure0xfffffba1The database page read from disk had a previous write not represented on the page.
JET_errFileSystemCorruption0xfffffb9fFile system operation failed with an error indicating the file system is corrupt.
JET_errRecoveryVerifyFailure0xfffffb9dOne or more database pages read from disk during recovery do not match the expected state.
JET_errFilteredMoveNotSupported0xfffffb9cAttempted to provide a filter to JetSetCursorFilter() in an unsupported scenario.
JET_errDatabaseDuplicate0xfffffb4fDatabase already exists
JET_errDatabaseInUse0xfffffb4eDatabase in use
JET_errDatabaseNotFound0xfffffb4dNo such database
JET_errDatabaseInvalidName0xfffffb4cInvalid database name
JET_errDatabaseInvalidPages0xfffffb4bInvalid number of pages
JET_errDatabaseCorrupted0xfffffb4aNon database file or corrupted db
JET_errDatabaseLocked0xfffffb49Database exclusively locked
JET_errCannotDisableVersioning0xfffffb48Cannot disable versioning for this database
JET_errInvalidDatabaseVersion0xfffffb47Database engine is incompatible with database
JET_errDatabase200Format0xfffffb46The database is in an older (200) format
JET_errDatabase400Format0xfffffb45The database is in an older (400) format
JET_errDatabase500Format0xfffffb44The database is in an older (500) format
JET_errPageSizeMismatch0xfffffb43The database page size does not match the engine
JET_errTooManyInstances0xfffffb42Cannot start any more database instances
JET_errDatabaseSharingViolation0xfffffb41A different database instance is using this database
JET_errAttachedDatabaseMismatch0xfffffb40An outstanding database attachment has been detected at the start or end of recovery, but database is missing or does not match attachment info
JET_errDatabaseInvalidPath0xfffffb3fSpecified path to database file is illegal
JET_errDatabaseIdInUse0xfffffb3eA database is being assigned an id already in use
JET_errForceDetachNotAllowed0xfffffb3dForce Detach allowed only after normal detach errored out
JET_errCatalogCorrupted0xfffffb3cCorruption detected in catalog
JET_errPartiallyAttachedDB0xfffffb3bDatabase is partially attached. Cannot complete attach operation
JET_errDatabaseSignInUse0xfffffb3aDatabase with same signature in use
JET_errDatabaseCorruptedNoRepair0xfffffb38Corrupted db but repair not allowed
JET_errInvalidCreateDbVersion0xfffffb37recovery tried to replay a database creation, but the database was originally created with an incompatible (likely older) version of the database engine
JET_errDatabaseNotReady0xfffffb32Recovery on this database has not yet completed enough to permit access.
JET_errDatabaseAttachedForRecovery0xfffffb31Database is attached but only for recovery. It must be explicitly attached before it can be opened.
JET_errTransactionsNotReadyDuringRecovery0xfffffb30Recovery has not seen any Begin0/Commit0 records and so does not know what trxBegin0 to assign to this transaction
JET_errTableLocked0xfffffaeaTable is exclusively locked
JET_errTableDuplicate0xfffffae9Table already exists
JET_errTableInUse0xfffffae8Table is in use, cannot lock
JET_errObjectNotFound0xfffffae7No such table or object
JET_errDensityInvalid0xfffffae5Bad file/index density
JET_errTableNotEmpty0xfffffae4Table is not empty
JET_errInvalidTableId0xfffffae2Invalid table id
JET_errTooManyOpenTables0xfffffae1Cannot open any more tables (cleanup already attempted)
JET_errIllegalOperation0xfffffae0Oper. not supported on table
JET_errTooManyOpenTablesAndCleanupTimedOut0xfffffadfCannot open any more tables (cleanup attempt failed to complete)
JET_errObjectDuplicate0xfffffadeTable or object name in use
JET_errInvalidObject0xfffffadcObject is invalid for operation
JET_errCannotDeleteTempTable0xfffffadbUse CloseTable instead of DeleteTable to delete temp table
JET_errCannotDeleteSystemTable0xfffffadaIllegal attempt to delete a system table
JET_errCannotDeleteTemplateTable0xfffffad9Illegal attempt to delete a template table
JET_errExclusiveTableLockRequired0xfffffad6Must have exclusive lock on table.
JET_errFixedDDL0xfffffad5DDL operations prohibited on this table
JET_errFixedInheritedDDL0xfffffad4On a derived table, DDL operations are prohibited on inherited portion of DDL
JET_errCannotNestDDL0xfffffad3Nesting of hierarchical DDL is not currently supported.
JET_errDDLNotInheritable0xfffffad2Tried to inherit DDL from a table not marked as a template table.
JET_errInvalidSettings0xfffffad0System parameters were set improperly
JET_errClientRequestToStopJetService0xfffffacfClient has requested stop service
JET_errCannotAddFixedVarColumnToDerivedTable0xfffffaceTemplate table was created with NoFixedVarColumnsInDerivedTables
JET_errIndexCantBuild0xfffffa87Index build failed
JET_errIndexHasPrimary0xfffffa86Primary index already defined
JET_errIndexDuplicate0xfffffa85Index is already defined
JET_errIndexNotFound0xfffffa84No such index
JET_errIndexMustStay0xfffffa83Cannot delete clustered index
JET_errIndexInvalidDef0xfffffa82Illegal index definition
JET_errInvalidCreateIndex0xfffffa7fInvalid create index description
JET_errTooManyOpenIndexes0xfffffa7eOut of index description blocks
JET_errMultiValuedIndexViolation0xfffffa7dNon-unique inter-record index keys generated for a multivalued index
JET_errIndexBuildCorrupted0xfffffa7cFailed to build a secondary index that properly reflects primary index
JET_errPrimaryIndexCorrupted0xfffffa7bPrimary index is corrupt. The database must be defragmented or the table deleted.
JET_errSecondaryIndexCorrupted0xfffffa7aSecondary index is corrupt. The database must be defragmented or the affected index must be deleted. If the corrupt index is over Unicode text, a likely cause is a sort-order change.
JET_errInvalidIndexId0xfffffa78Illegal index id
JET_errIndexTuplesSecondaryIndexOnly0xfffffa6atuple index can only be on a secondary index
JET_errIndexTuplesTooManyColumns0xfffffa69tuple index may only have eleven columns in the index
JET_errIndexTuplesOneColumnOnly0xfffffa69OBSOLETE
JET_errIndexTuplesNonUniqueOnly0xfffffa68tuple index must be a non-unique index
JET_errIndexTuplesTextBinaryColumnsOnly0xfffffa67tuple index must be on a text/binary column
JET_errIndexTuplesTextColumnsOnly0xfffffa67OBSOLETE
JET_errIndexTuplesVarSegMacNotAllowed0xfffffa66tuple index does not allow setting cbVarSegMac
JET_errIndexTuplesInvalidLimits0xfffffa65invalid min/max tuple length or max characters to index specified
JET_errIndexTuplesCannotRetrieveFromIndex0xfffffa64cannot call RetrieveColumn() with RetrieveFromIndex on a tuple index
JET_errIndexTuplesKeyTooSmall0xfffffa63specified key does not meet minimum tuple length
JET_errInvalidLVChunkSize0xfffffa62Specified LV chunk size is not supported
JET_errColumnCannotBeEncrypted0xfffffa61Only JET_coltypLongText and JET_coltypLongBinary columns without default values can be encrypted
JET_errCannotIndexOnEncryptedColumn0xfffffa60Cannot index encrypted column
JET_errColumnLong0xfffffa23Column value is long
JET_errColumnNoChunk0xfffffa22No such chunk in long value
JET_errColumnDoesNotFit0xfffffa21Field will not fit in record
JET_errNullInvalid0xfffffa20Null not valid
JET_errColumnIndexed0xfffffa1fColumn indexed, cannot delete
JET_errColumnTooBig0xfffffa1eField length is greater than maximum
JET_errColumnNotFound0xfffffa1dNo such column
JET_errColumnDuplicate0xfffffa1cField is already defined
JET_errMultiValuedColumnMustBeTagged0xfffffa1bAttempted to create a multi-valued column, but column was not Tagged
JET_errColumnRedundant0xfffffa1aSecond autoincrement or version column
JET_errInvalidColumnType0xfffffa19Invalid column data type
JET_errTaggedNotNULL0xfffffa16No non-NULL tagged columns
JET_errNoCurrentIndex0xfffffa15Invalid w/o a current index
JET_errKeyIsMade0xfffffa14The key is completely made
JET_errBadColumnId0xfffffa13Column Id Incorrect
JET_errBadItagSequence0xfffffa12Bad itagSequence for tagged column
JET_errColumnInRelationship0xfffffa11Cannot delete, column participates in relationship
JET_errCannotBeTagged0xfffffa0fAutoIncrement and Version cannot be tagged
JET_errDefaultValueTooBig0xfffffa0cDefault value exceeds maximum size
JET_errMultiValuedDuplicate0xfffffa0bDuplicate detected on a unique multi-valued column
JET_errLVCorrupted0xfffffa0aCorruption encountered in long-value tree
JET_errMultiValuedDuplicateAfterTruncation0xfffffa08Duplicate detected on a unique multi-valued column after data was normalized, and normalizing truncated the data before comparison
JET_errDerivedColumnCorruption0xfffffa07Invalid column in derived table
JET_errInvalidPlaceholderColumn0xfffffa06Tried to convert column to a primary index placeholder, but column doesn't meet necessary criteria
JET_errColumnCannotBeCompressed0xfffff9feOnly JET_coltypLongText and JET_coltypLongBinary columns can be compressed
JET_errColumnNoEncryptionKey0xfffff9fcCannot retrieve/set encrypted column without an encryption key
JET_errRecordNotFound0xfffff9bfThe key was not found
JET_errRecordNoCopy0xfffff9beNo working buffer
JET_errNoCurrentRecord0xfffff9bdCurrency not on a record
JET_errRecordPrimaryChanged0xfffff9bcPrimary key may not change
JET_errKeyDuplicate0xfffff9bbIllegal duplicate key
JET_errAlreadyPrepared0xfffff9b9Attempted to update record when record update was already in progress
JET_errKeyNotMade0xfffff9b8No call to JetMakeKey
JET_errUpdateNotPrepared0xfffff9b7No call to JetPrepareUpdate
JET_errDataHasChanged0xfffff9b5Data has changed, operation aborted
JET_errLanguageNotSupported0xfffff9adWindows installation does not support language
JET_errDecompressionFailed0xfffff9acInternal error: data could not be decompressed
JET_errUpdateMustVersion0xfffff9abNo version updates only for uncommitted tables
JET_errDecryptionFailed0xfffff9aaData could not be decrypted
JET_errEncryptionBadItag0xfffff9a9Cannot encrypt tagged columns with itag>1
JET_errTooManySorts0xfffff95bToo many sort processes
JET_errInvalidOnSort0xfffff95aInvalid operation on Sort
JET_errTempFileOpenError0xfffff8f5Temp file could not be opened
JET_errTooManyAttachedDatabases0xfffff8f3Too many open databases
JET_errDiskFull0xfffff8f0No space left on disk
JET_errPermissionDenied0xfffff8efPermission denied
JET_errFileNotFound0xfffff8edFile not found
JET_errFileInvalidType0xfffff8ecInvalid file type
JET_errFileAlreadyExists0xfffff8eaFile already exists
JET_errAfterInitialization0xfffff8c6Cannot Restore after init.
JET_errLogCorrupted0xfffff8c4Logs could not be interpreted
JET_errInvalidOperation0xfffff88eInvalid operation
JET_errAccessDenied0xfffff88dAccess denied
JET_errTooManySplits0xfffff88bInfinite split
JET_errSessionSharingViolation0xfffff88aMultiple threads are using the same session
JET_errEntryPointNotFound0xfffff889An entry point in a DLL we require could not be found
JET_errSessionContextAlreadySet0xfffff888Specified session already has a session context set
JET_errSessionContextNotSetByThisThread0xfffff887Tried to reset session context, but current thread did not orignally set the session context
JET_errSessionInUse0xfffff886Tried to terminate session in use
JET_errRecordFormatConversionFailed0xfffff885Internal error during dynamic record format conversion
JET_errOneDatabasePerSession0xfffff884Just one open user database per session is allowed (JET_paramOneDatabasePerSession)
JET_errRollbackError0xfffff883error during rollback
JET_errFlushMapVersionUnsupported0xfffff882The version of the persisted flush map is not supported by this version of the engine.
JET_errFlushMapDatabaseMismatch0xfffff881The persisted flush map and the database do not match.
JET_errFlushMapUnrecoverable0xfffff880The persisted flush map cannot be reconstructed.
JET_errDatabaseAlreadyRunningMaintenance0xfffff82cThe operation did not complete successfully because the database is already running maintenance on specified database
JET_errCallbackFailed0xfffff7cbA callback failed
JET_errCallbackNotResolved0xfffff7caA callback function could not be found
JET_errSpaceHintsInvalid0xfffff7c9An element of the JET space hints structure was not correct or actionable.
JET_errOSSnapshotInvalidSequence0xfffff69fOS Shadow copy API used in an invalid sequence
JET_errOSSnapshotTimeOut0xfffff69eOS Shadow copy ended with time-out
JET_errOSSnapshotNotAllowed0xfffff69dOS Shadow copy not allowed (backup or recovery in progress)
JET_errOSSnapshotInvalidSnapId0xfffff69cinvalid JET_OSSNAPID
JET_errLSCallbackNotSpecified0xfffff448Attempted to use Local Storage without a callback function being specified
JET_errLSAlreadySet0xfffff447Attempted to set Local Storage for an object which already had it set
JET_errLSNotSet0xfffff446Attempted to retrieve Local Storage from an object which didn't have it set
JET_errFileIOSparse0xfffff060an I/O was issued to a location that was sparse
JET_errFileIOBeyondEOF0xfffff05fa read was issued to a location beyond EOF (writes will expand the file)
JET_errFileIOAbort0xfffff05einstructs the JET_ABORTRETRYFAILCALLBACK caller to abort the specified I/O
JET_errFileIORetry0xfffff05dinstructs the JET_ABORTRETRYFAILCALLBACK caller to retry the specified I/O
JET_errFileIOFail0xfffff05cinstructs the JET_ABORTRETRYFAILCALLBACK caller to fail the specified I/O
JET_errFileCompressed0xfffff05bread/write access is not supported on compressed files
JET_errSuccess0x8e5e0000Successful Operation
JET_errRfsFailure0x8e5e0064Resource Failure Simulator failure
JET_errRfsNotArmed0x8e5e0065Resource Failure Simulator not initialized
JET_errFileClose0x8e5e0066Could not close file
JET_errOutOfThreads0x8e5e0067Could not start thread
JET_errTooManyIO0x8e5e0069System busy due to too many IOs
JET_errTaskDropped0x8e5e006aA requested async task could not be executed
JET_errInternalError0x8e5e006bFatal internal error
JET_errDisabledFunctionality0x8e5e0070You are running MinESE, that does not have all features compiled in. This functionality is only supported in a full version of ESE.
JET_errUnloadableOSFunctionality0x8e5e0071The desired OS functionality could not be located and loaded / linked.
JET_errDatabaseBufferDependenciesCorrupted0x8e5e00ffBuffer dependencies improperly set. Recovery failure
JET_errPreviousVersion0x8e5e0142Version already existed. Recovery failure
JET_errPageBoundary0x8e5e0143Reached Page Boundary
JET_errKeyBoundary0x8e5e0144Reached Key Boundary
JET_errBadPageLink0x8e5e0147Database corrupted
JET_errBadBookmark0x8e5e0148Bookmark has no corresponding address in database
JET_errNTSystemCallFailed0x8e5e014eA call to the operating system failed
JET_errBadParentPageLink0x8e5e0152Database corrupted
JET_errSPAvailExtCacheOutOfSync0x8e5e0154AvailExt cache doesn't match btree
JET_errSPAvailExtCorrupted0x8e5e0155AvailExt space tree is corrupt
JET_errSPAvailExtCacheOutOfMemory0x8e5e0156Out of memory allocating an AvailExt cache node
JET_errSPOwnExtCorrupted0x8e5e0157OwnExt space tree is corrupt
JET_errDbTimeCorrupted0x8e5e0158Dbtime on current page is greater than global database dbtime
JET_errKeyTruncated0x8e5e015akey truncated on index that disallows key truncation
JET_errDatabaseLeakInSpace0x8e5e015cSome database pages have become unreachable even from the avail tree, only an offline defragmentation can return the lost space.
JET_errBadEmptyPage0x8e5e015fDatabase corrupted. Searching an unexpectedly empty page.
JET_errBadLineCount0x8e5e0162Number of lines on the page is too few compared to the line being operated on
JET_errColumnIllegalNull0x8e5e05e0
JET_errKeyTooBig0x8e5e0198Key is too large
JET_errCannotSeparateIntrinsicLV0x8e5e01a0illegal attempt to separate an LV which must be intrinsic
JET_errSeparatedLongValue0x8e5e01a5Operation not supported on separated long-value
JET_errMustBeSeparateLongValue0x8e5e01a7Can only preread long value columns that can be separate, e.g. not size constrained so that they are fixed or variable columns
JET_errInvalidPreread0x8e5e01a8Cannot preread long values when current index secondary
JET_errInvalidLoggedOperation0x8e5e01f4Logged operation cannot be redone
JET_errLogFileCorrupt0x8e5e01f5Log file is corrupt
JET_errNoBackupDirectory0x8e5e01f7No backup directory given
JET_errBackupDirectoryNotEmpty0x8e5e01f8The backup directory is not emtpy
JET_errBackupInProgress0x8e5e01f9Backup is active already
JET_errRestoreInProgress0x8e5e01faRestore in progress
JET_errMissingPreviousLogFile0x8e5e01fdMissing the log file for check point
JET_errLogWriteFail0x8e5e01feFailure writing to log file
JET_errLogDisabledDueToRecoveryFailure0x8e5e01ffTry to log something after recovery faild
JET_errCannotLogDuringRecoveryRedo0x8e5e0200Try to log something during recovery redo
JET_errLogGenerationMismatch0x8e5e0201Name of logfile does not match internal generation number
JET_errBadLogVersion0x8e5e0202Version of log file is not compatible with Jet version
JET_errInvalidLogSequence0x8e5e0203Timestamp in next log does not match expected
JET_errLoggingDisabled0x8e5e0204Log is not active
JET_errLogBufferTooSmall0x8e5e0205Log buffer is too small for recovery
JET_errLogSequenceEnd0x8e5e0207Maximum log file number exceeded
JET_errNoBackup0x8e5e0208No backup in progress
JET_errInvalidBackupSequence0x8e5e0209Backup call out of sequence
JET_errBackupNotAllowedYet0x8e5e020bCannot do backup now
JET_errDeleteBackupFileFail0x8e5e020cCould not delete backup file
JET_errMakeBackupDirectoryFail0x8e5e020dCould not make backup temp directory
JET_errInvalidBackup0x8e5e020eCannot perform incremental backup when circular logging enabled
JET_errRecoveredWithErrors0x8e5e020fRestored with errors
JET_errMissingLogFile0x8e5e0210Current log file missing
JET_errLogDiskFull0x8e5e0211Log disk full
JET_errBadLogSignature0x8e5e0212Bad signature for a log file
JET_errBadDbSignature0x8e5e0213Bad signature for a db file
JET_errBadCheckpointSignature0x8e5e0214Bad signature for a checkpoint file
JET_errCheckpointCorrupt0x8e5e0215Checkpoint file not found or corrupt
JET_errMissingPatchPage0x8e5e0216Patch file page not found during recovery
JET_errBadPatchPage0x8e5e0217Patch file page is not valid
JET_errRedoAbruptEnded0x8e5e0218Redo abruptly ended due to sudden failure in reading logs from log file
JET_errPatchFileMissing0x8e5e021aHard restore detected that patch file is missing from backup set
JET_errDatabaseLogSetMismatch0x8e5e021bDatabase does not belong with the current set of log files
JET_errDatabaseStreamingFileMismatch0x8e5e021cDatabase and streaming file do not match each other
JET_errLogFileSizeMismatch0x8e5e021dactual log file size does not match JET_paramLogFileSize
JET_errCheckpointFileNotFound0x8e5e021eCould not locate checkpoint file
JET_errRequiredLogFilesMissing0x8e5e021fThe required log files for recovery is missing.
JET_errSoftRecoveryOnBackupDatabase0x8e5e0220Soft recovery is intended on a backup database. Restore should be used instead
JET_errLogFileSizeMismatchDatabasesConsistent0x8e5e0221databases have been recovered, but the log file size used during recovery does not match JET_paramLogFileSize
JET_errLogSectorSizeMismatch0x8e5e0222the log file sector size does not match the current volume's sector size
JET_errLogSectorSizeMismatchDatabasesConsistent0x8e5e0223databases have been recovered, but the log file sector size (used during recovery) does not match the current volume's sector size
JET_errLogSequenceEndDatabasesConsistent0x8e5e0224databases have been recovered, but all possible log generations in the current sequence are used; delete all log files and the checkpoint file and backup the databases before continuing
JET_errStreamingDataNotLogged0x8e5e0225Illegal attempt to replay a streaming file operation where the data wasn't logged. Probably caused by an attempt to roll-forward with circular logging enabled
JET_errDatabaseDirtyShutdown0x8e5e0226Database was not shutdown cleanly. Recovery must first be run to properly complete database operations for the previous shutdown.
JET_errDatabaseInconsistent0x8e5e0226OBSOLETE
JET_errConsistentTimeMismatch0x8e5e0227Database last consistent time unmatched
JET_errDatabasePatchFileMismatch0x8e5e0228Patch file is not generated from this backup
JET_errEndingRestoreLogTooLow0x8e5e0229The starting log number too low for the restore
JET_errStartingRestoreLogTooHigh0x8e5e022aThe starting log number too high for the restore
JET_errGivenLogFileHasBadSignature0x8e5e022bRestore log file has bad signature
JET_errGivenLogFileIsNotContiguous0x8e5e022cRestore log file is not contiguous
JET_errMissingRestoreLogFiles0x8e5e022dSome restore log files are missing
JET_errMissingFullBackup0x8e5e0230The database missed a previous full backup before incremental backup
JET_errBadBackupDatabaseSize0x8e5e0231The backup database size is not in 4k
JET_errDatabaseAlreadyUpgraded0x8e5e0232Attempted to upgrade a database that is already current
JET_errDatabaseIncompleteUpgrade0x8e5e0233Attempted to use a database which was only partially converted to the current format -- must restore from backup
JET_errMissingCurrentLogFiles0x8e5e0235Some current log files are missing for continuous restore
JET_errDbTimeTooOld0x8e5e0236dbtime on page smaller than dbtimeBefore in record
JET_errDbTimeTooNew0x8e5e0237dbtime on page in advance of the dbtimeBefore in record
JET_errMissingFileToBackup0x8e5e0239Some log or patch files are missing during backup
JET_errLogTornWriteDuringHardRestore0x8e5e023atorn-write was detected in a backup set during hard restore
JET_errLogTornWriteDuringHardRecovery0x8e5e023btorn-write was detected during hard recovery (log was not part of a backup set)
JET_errLogCorruptDuringHardRestore0x8e5e023dcorruption was detected in a backup set during hard restore
JET_errLogCorruptDuringHardRecovery0x8e5e023ecorruption was detected during hard recovery (log was not part of a backup set)
JET_errMustDisableLoggingForDbUpgrade0x8e5e023fCannot have logging enabled while attempting to upgrade db
JET_errBadRestoreTargetInstance0x8e5e0241TargetInstance specified for restore is not found or log files don't match
JET_errRecoveredWithoutUndo0x8e5e0243Soft recovery successfully replayed all operations, but the Undo phase of recovery was skipped
JET_errDatabasesNotFromSameSnapshot0x8e5e0244Databases to be restored are not from the same shadow copy backup
JET_errSoftRecoveryOnSnapshot0x8e5e0245Soft recovery on a database from a shadow copy backup set
JET_errCommittedLogFilesMissing0x8e5e0246One or more logs that were committed to this database, are missing. These log files are required to maintain durable ACID semantics, but not required to maintain consistency if the JET_bitReplayIgnoreLostLogs bit is specified during recovery.
JET_errSectorSizeNotSupported0x8e5e0247The physical sector size reported by the disk subsystem, is unsupported by ESE for a specific file type.
JET_errRecoveredWithoutUndoDatabasesConsistent0x8e5e0248Soft recovery successfully replayed all operations and intended to skip the Undo phase of recovery, but the Undo phase was not required
JET_errCommittedLogFileCorrupt0x8e5e024aOne or more logs were found to be corrupt during recovery. These log files are required to maintain durable ACID semantics, but not required to maintain consistency if the JET_bitIgnoreLostLogs bit and JET_paramDeleteOutOfRangeLogs is specified during recovery.
JET_errLogSequenceChecksumMismatch0x8e5e024eThe previous log's accumulated segment checksum doesn't match the next log
JET_errPageInitializedMismatch0x8e5e0254Database divergence mismatch. Page was uninitialized on remote node, but initialized on local node.
JET_errUnicodeTranslationBufferTooSmall0x8e5e0259Unicode translation buffer too small
JET_errUnicodeTranslationFail0x8e5e025aUnicode normalization failed
JET_errUnicodeNormalizationNotSupported0x8e5e025bOS does not provide support for Unicode normalisation (and no normalisation callback was specified)
JET_errUnicodeLanguageValidationFailure0x8e5e025cCan not validate the language
JET_errExistingLogFileHasBadSignature0x8e5e0262Existing log file has bad signature
JET_errExistingLogFileIsNotContiguous0x8e5e0263Existing log file is not contiguous
JET_errLogReadVerifyFailure0x8e5e0264Checksum error in log file during backup
JET_errCheckpointDepthTooDeep0x8e5e0266too many outstanding generations between checkpoint and current generation
JET_errRestoreOfNonBackupDatabase0x8e5e0267hard recovery attempted on a database that wasn't a backup database
JET_errLogFileNotCopied0x8e5e0268log truncation attempted but not all required logs were copied
JET_errTransactionTooLong0x8e5e026aToo many outstanding generations between JetBeginTransaction and current generation.
JET_errEngineFormatVersionNoLongerSupportedTooLow0x8e5e026bThe specified JET_ENGINEFORMATVERSION value is too low to be supported by this version of ESE.
JET_errEngineFormatVersionNotYetImplementedTooHigh0x8e5e026cThe specified JET_ENGINEFORMATVERSION value is too high, higher than this version of ESE knows about.
JET_errEngineFormatVersionParamTooLowForRequestedFeature0x8e5e026dThrown by a format feature (not at JetSetSystemParameter) if the client requests a feature that requires a version higher than that set for the JET_paramEngineFormatVersion.
JET_errEngineFormatVersionSpecifiedTooLowForLogVersion0x8e5e026eThe specified JET_ENGINEFORMATVERSION is set too low for this log stream, the log files have already been upgraded to a higher version. A higher JET_ENGINEFORMATVERSION value must be set in the param.
JET_errEngineFormatVersionSpecifiedTooLowForDatabaseVersion0x8e5e026fThe specified JET_ENGINEFORMATVERSION is set too low for this database file, the database file has already been upgraded to a higher version. A higher JET_ENGINEFORMATVERSION value must be set in the param.
JET_errBackupAbortByServer0x8e5e0321Backup was aborted by server by calling JetTerm with JET_bitTermStopBackup or by calling JetStopBackup
JET_errInvalidGrbit0x8e5e0384Invalid flags parameter
JET_errTermInProgress0x8e5e03e8Termination in progress
JET_errFeatureNotAvailable0x8e5e03e9API not supported
JET_errInvalidName0x8e5e03eaInvalid name
JET_errInvalidParameter0x8e5e03ebInvalid API parameter
JET_errDatabaseFileReadOnly0x8e5e03f0Tried to attach a read-only database file for read/write operations
JET_errInvalidDatabaseId0x8e5e03f2Invalid database id
JET_errOutOfMemory0x8e5e03f3Out of Memory
JET_errOutOfDatabaseSpace0x8e5e03f4Maximum database size reached
JET_errOutOfCursors0x8e5e03f5Out of table cursors
JET_errOutOfBuffers0x8e5e03f6Out of database page buffers
JET_errTooManyIndexes0x8e5e03f7Too many indexes
JET_errTooManyKeys0x8e5e03f8Too many columns in an index
JET_errRecordDeleted0x8e5e03f9Record has been deleted
JET_errReadVerifyFailure0x8e5e03faChecksum error on a database page
JET_errPageNotInitialized0x8e5e03fbBlank database page
JET_errOutOfFileHandles0x8e5e03fcOut of file handles
JET_errDiskReadVerificationFailure0x8e5e03fdThe OS returned ERROR_CRC from file IO
JET_errDiskIO0x8e5e03feDisk IO error
JET_errInvalidPath0x8e5e03ffInvalid file path
JET_errInvalidSystemPath0x8e5e0400Invalid system path
JET_errInvalidLogDirectory0x8e5e0401Invalid log directory
JET_errRecordTooBig0x8e5e0402Record larger than maximum size
JET_errTooManyOpenDatabases0x8e5e0403Too many open databases
JET_errInvalidDatabase0x8e5e0404Not a database file
JET_errNotInitialized0x8e5e0405Database engine not initialized
JET_errAlreadyInitialized0x8e5e0406Database engine already initialized
JET_errInitInProgress0x8e5e0407Database engine is being initialized
JET_errFileAccessDenied0x8e5e0408Cannot access file, the file is locked or in use
JET_errBufferTooSmall0x8e5e040eBuffer is too small
JET_errTooManyColumns0x8e5e0410Too many columns defined
JET_errContainerNotEmpty0x8e5e0413Container is not empty
JET_errInvalidFilename0x8e5e0414Filename is invalid
JET_errInvalidBookmark0x8e5e0415Invalid bookmark
JET_errColumnInUse0x8e5e0416Column used in an index
JET_errInvalidBufferSize0x8e5e0417Data buffer doesn't match column size
JET_errColumnNotUpdatable0x8e5e0418Cannot set column value
JET_errIndexInUse0x8e5e041bIndex is in use
JET_errLinkNotSupported0x8e5e041cLink support unavailable
JET_errNullKeyDisallowed0x8e5e041dNull keys are disallowed on index
JET_errNotInTransaction0x8e5e041eOperation must be within a transaction
JET_errMustRollback0x8e5e0421Transaction must rollback because failure of unversioned update
JET_errTooManyActiveUsers0x8e5e0423Too many active database users
JET_errInvalidCountry0x8e5e0425Invalid or unknown country/region code
JET_errInvalidLanguageId0x8e5e0426Invalid or unknown language id
JET_errInvalidCodePage0x8e5e0427Invalid or unknown code page
JET_errInvalidLCMapStringFlags0x8e5e0428Invalid flags for LCMapString()
JET_errVersionStoreEntryTooBig0x8e5e0429Attempted to create a version store entry (RCE) larger than a version bucket
JET_errVersionStoreOutOfMemoryAndCleanupTimedOut0x8e5e042aVersion store out of memory (and cleanup attempt failed to complete)
JET_errVersionStoreOutOfMemory0x8e5e042dVersion store out of memory (cleanup already attempted)
JET_errCannotIndex0x8e5e042fCannot index escrow column
JET_errRecordNotDeleted0x8e5e0430Record has not been deleted
JET_errTooManyMempoolEntries0x8e5e0431Too many mempool entries requested
JET_errOutOfObjectIDs0x8e5e0432Out of btree ObjectIDs (perform offline defrag to reclaim freed/unused ObjectIds)
JET_errOutOfLongValueIDs0x8e5e0433Long-value ID counter has reached maximum value. (perform offline defrag to reclaim free/unused LongValueIDs)
JET_errOutOfAutoincrementValues0x8e5e0434Auto-increment counter has reached maximum value (offline defrag WILL NOT be able to reclaim free/unused Auto-increment values).
JET_errOutOfDbtimeValues0x8e5e0435Dbtime counter has reached maximum value (perform offline defrag to reclaim free/unused Dbtime values)
JET_errOutOfSequentialIndexValues0x8e5e0436Sequential index counter has reached maximum value (perform offline defrag to reclaim free/unused SequentialIndex values)
JET_errRunningInOneInstanceMode0x8e5e0438Multi-instance call with single-instance mode enabled
JET_errRunningInMultiInstanceMode0x8e5e0439Single-instance call with multi-instance mode enabled
JET_errSystemParamsAlreadySet0x8e5e043aGlobal system parameters have already been set
JET_errSystemPathInUse0x8e5e043bSystem path already used by another database instance
JET_errLogFilePathInUse0x8e5e043cLogfile path already used by another database instance
JET_errTempPathInUse0x8e5e043dTemp path already used by another database instance
JET_errInstanceNameInUse0x8e5e043eInstance Name already in use
JET_errSystemParameterConflict0x8e5e043fGlobal system parameters have already been set, but to a conflicting or disagreeable state to the specified values.
JET_errInstanceUnavailable0x8e5e0442This instance cannot be used because it encountered a fatal error
JET_errDatabaseUnavailable0x8e5e0443This database cannot be used because it encountered a fatal error
JET_errInstanceUnavailableDueToFatalLogDiskFull0x8e5e0444This instance cannot be used because it encountered a log-disk-full error performing an operation (likely transaction rollback) that could not tolerate failure
JET_errInvalidSesparamId0x8e5e0445This JET_sesparam* identifier is not known to the ESE engine.
JET_errTooManyRecords0x8e5e0446There are too many records to enumerate, switch to an API that handles 64-bit numbers
JET_errInvalidDbparamId0x8e5e0447This JET_dbparam* identifier is not known to the ESE engine.
JET_errOutOfSessions0x8e5e044dOut of sessions
JET_errWriteConflict0x8e5e044eWrite lock failed due to outstanding write lock
JET_errTransTooDeep0x8e5e044fTransactions nested too deeply
JET_errInvalidSesid0x8e5e0450Invalid session handle
JET_errWriteConflictPrimaryIndex0x8e5e0451Update attempted on uncommitted primary index
JET_errInTransaction0x8e5e0454Operation not allowed within a transaction
JET_errRollbackRequired0x8e5e0455Must rollback current transaction -- cannot commit or begin a new one
JET_errTransReadOnly0x8e5e0456Read-only transaction tried to modify the database
JET_errSessionWriteConflict0x8e5e0457Attempt to replace the same record by two diffrerent cursors in the same session
JET_errRecordTooBigForBackwardCompatibility0x8e5e0458record would be too big if represented in a database format from a previous version of Jet
JET_errCannotMaterializeForwardOnlySort0x8e5e0459The temp table could not be created due to parameters that conflict with JET_bitTTForwardOnly
JET_errSesidTableIdMismatch0x8e5e045aThis session handle can't be used with this table id
JET_errInvalidInstance0x8e5e045bInvalid instance handle
JET_errDirtyShutdown0x8e5e045cThe instance was shutdown successfully but all the attached databases were left in a dirty state by request via JET_bitTermDirty
JET_errReadPgnoVerifyFailure0x8e5e045eThe database page read from disk had the wrong page number.
JET_errReadLostFlushVerifyFailure0x8e5e045fThe database page read from disk had a previous write not represented on the page.
JET_errFileSystemCorruption0x8e5e0461File system operation failed with an error indicating the file system is corrupt.
JET_errRecoveryVerifyFailure0x8e5e0463One or more database pages read from disk during recovery do not match the expected state.
JET_errFilteredMoveNotSupported0x8e5e0464Attempted to provide a filter to JetSetCursorFilter() in an unsupported scenario.
JET_errDatabaseDuplicate0x8e5e04b1Database already exists
JET_errDatabaseInUse0x8e5e04b2Database in use
JET_errDatabaseNotFound0x8e5e04b3No such database
JET_errDatabaseInvalidName0x8e5e04b4Invalid database name
JET_errDatabaseInvalidPages0x8e5e04b5Invalid number of pages
JET_errDatabaseCorrupted0x8e5e04b6Non database file or corrupted db
JET_errDatabaseLocked0x8e5e04b7Database exclusively locked
JET_errCannotDisableVersioning0x8e5e04b8Cannot disable versioning for this database
JET_errInvalidDatabaseVersion0x8e5e04b9Database engine is incompatible with database
JET_errDatabase200Format0x8e5e04baThe database is in an older (200) format
JET_errDatabase400Format0x8e5e04bbThe database is in an older (400) format
JET_errDatabase500Format0x8e5e04bcThe database is in an older (500) format
JET_errPageSizeMismatch0x8e5e04bdThe database page size does not match the engine
JET_errTooManyInstances0x8e5e04beCannot start any more database instances
JET_errDatabaseSharingViolation0x8e5e04bfA different database instance is using this database
JET_errAttachedDatabaseMismatch0x8e5e04c0An outstanding database attachment has been detected at the start or end of recovery, but database is missing or does not match attachment info
JET_errDatabaseInvalidPath0x8e5e04c1Specified path to database file is illegal
JET_errDatabaseIdInUse0x8e5e04c2A database is being assigned an id already in use
JET_errForceDetachNotAllowed0x8e5e04c3Force Detach allowed only after normal detach errored out
JET_errCatalogCorrupted0x8e5e04c4Corruption detected in catalog
JET_errPartiallyAttachedDB0x8e5e04c5Database is partially attached. Cannot complete attach operation
JET_errDatabaseSignInUse0x8e5e04c6Database with same signature in use
JET_errDatabaseCorruptedNoRepair0x8e5e04c8Corrupted db but repair not allowed
JET_errInvalidCreateDbVersion0x8e5e04c9recovery tried to replay a database creation, but the database was originally created with an incompatible (likely older) version of the database engine
JET_errDatabaseNotReady0x8e5e04ceRecovery on this database has not yet completed enough to permit access.
JET_errDatabaseAttachedForRecovery0x8e5e04cfDatabase is attached but only for recovery. It must be explicitly attached before it can be opened.
JET_errTransactionsNotReadyDuringRecovery0x8e5e04d0Recovery has not seen any Begin0/Commit0 records and so does not know what trxBegin0 to assign to this transaction
JET_errTableLocked0x8e5e0516Table is exclusively locked
JET_errTableDuplicate0x8e5e0517Table already exists
JET_errTableInUse0x8e5e0518Table is in use, cannot lock
JET_errObjectNotFound0x8e5e0519No such table or object
JET_errDensityInvalid0x8e5e051bBad file/index density
JET_errTableNotEmpty0x8e5e051cTable is not empty
JET_errInvalidTableId0x8e5e051eInvalid table id
JET_errTooManyOpenTables0x8e5e051fCannot open any more tables (cleanup already attempted)
JET_errIllegalOperation0x8e5e0520Oper. not supported on table
JET_errTooManyOpenTablesAndCleanupTimedOut0x8e5e0521Cannot open any more tables (cleanup attempt failed to complete)
JET_errObjectDuplicate0x8e5e0522Table or object name in use
JET_errInvalidObject0x8e5e0524Object is invalid for operation
JET_errCannotDeleteTempTable0x8e5e0525Use CloseTable instead of DeleteTable to delete temp table
JET_errCannotDeleteSystemTable0x8e5e0526Illegal attempt to delete a system table
JET_errCannotDeleteTemplateTable0x8e5e0527Illegal attempt to delete a template table
JET_errExclusiveTableLockRequired0x8e5e052aMust have exclusive lock on table.
JET_errFixedDDL0x8e5e052bDDL operations prohibited on this table
JET_errFixedInheritedDDL0x8e5e052cOn a derived table, DDL operations are prohibited on inherited portion of DDL
JET_errCannotNestDDL0x8e5e052dNesting of hierarchical DDL is not currently supported.
JET_errDDLNotInheritable0x8e5e052eTried to inherit DDL from a table not marked as a template table.
JET_errInvalidSettings0x8e5e0530System parameters were set improperly
JET_errClientRequestToStopJetService0x8e5e0531Client has requested stop service
JET_errCannotAddFixedVarColumnToDerivedTable0x8e5e0532Template table was created with NoFixedVarColumnsInDerivedTables
JET_errIndexCantBuild0x8e5e0579Index build failed
JET_errIndexHasPrimary0x8e5e057aPrimary index already defined
JET_errIndexDuplicate0x8e5e057bIndex is already defined
JET_errIndexNotFound0x8e5e057cNo such index
JET_errIndexMustStay0x8e5e057dCannot delete clustered index
JET_errIndexInvalidDef0x8e5e057eIllegal index definition
JET_errInvalidCreateIndex0x8e5e0581Invalid create index description
JET_errTooManyOpenIndexes0x8e5e0582Out of index description blocks
JET_errMultiValuedIndexViolation0x8e5e0583Non-unique inter-record index keys generated for a multivalued index
JET_errIndexBuildCorrupted0x8e5e0584Failed to build a secondary index that properly reflects primary index
JET_errPrimaryIndexCorrupted0x8e5e0585Primary index is corrupt. The database must be defragmented or the table deleted.
JET_errSecondaryIndexCorrupted0x8e5e0586Secondary index is corrupt. The database must be defragmented or the affected index must be deleted. If the corrupt index is over Unicode text, a likely cause is a sort-order change.
JET_errInvalidIndexId0x8e5e0588Illegal index id
JET_errIndexTuplesSecondaryIndexOnly0x8e5e0596tuple index can only be on a secondary index
JET_errIndexTuplesTooManyColumns0x8e5e0597tuple index may only have eleven columns in the index
JET_errIndexTuplesOneColumnOnly0x8e5e0597OBSOLETE
JET_errIndexTuplesNonUniqueOnly0x8e5e0598tuple index must be a non-unique index
JET_errIndexTuplesTextBinaryColumnsOnly0x8e5e0599tuple index must be on a text/binary column
JET_errIndexTuplesTextColumnsOnly0x8e5e0599OBSOLETE
JET_errIndexTuplesVarSegMacNotAllowed0x8e5e059atuple index does not allow setting cbVarSegMac
JET_errIndexTuplesInvalidLimits0x8e5e059binvalid min/max tuple length or max characters to index specified
JET_errIndexTuplesCannotRetrieveFromIndex0x8e5e059ccannot call RetrieveColumn() with RetrieveFromIndex on a tuple index
JET_errIndexTuplesKeyTooSmall0x8e5e059dspecified key does not meet minimum tuple length
JET_errInvalidLVChunkSize0x8e5e059eSpecified LV chunk size is not supported
JET_errColumnCannotBeEncrypted0x8e5e059fOnly JET_coltypLongText and JET_coltypLongBinary columns without default values can be encrypted
JET_errCannotIndexOnEncryptedColumn0x8e5e05a0Cannot index encrypted column
JET_errColumnLong0x8e5e05ddColumn value is long
JET_errColumnNoChunk0x8e5e05deNo such chunk in long value
JET_errColumnDoesNotFit0x8e5e05dfField will not fit in record
JET_errNullInvalid0x8e5e05e0Null not valid
JET_errColumnIndexed0x8e5e05e1Column indexed, cannot delete
JET_errColumnTooBig0x8e5e05e2Field length is greater than maximum
JET_errColumnNotFound0x8e5e05e3No such column
JET_errColumnDuplicate0x8e5e05e4Field is already defined
JET_errMultiValuedColumnMustBeTagged0x8e5e05e5Attempted to create a multi-valued column, but column was not Tagged
JET_errColumnRedundant0x8e5e05e6Second autoincrement or version column
JET_errInvalidColumnType0x8e5e05e7Invalid column data type
JET_errTaggedNotNULL0x8e5e05eaNo non-NULL tagged columns
JET_errNoCurrentIndex0x8e5e05ebInvalid w/o a current index
JET_errKeyIsMade0x8e5e05ecThe key is completely made
JET_errBadColumnId0x8e5e05edColumn Id Incorrect
JET_errBadItagSequence0x8e5e05eeBad itagSequence for tagged column
JET_errColumnInRelationship0x8e5e05efCannot delete, column participates in relationship
JET_errCannotBeTagged0x8e5e05f1AutoIncrement and Version cannot be tagged
JET_errDefaultValueTooBig0x8e5e05f4Default value exceeds maximum size
JET_errMultiValuedDuplicate0x8e5e05f5Duplicate detected on a unique multi-valued column
JET_errLVCorrupted0x8e5e05f6Corruption encountered in long-value tree
JET_errMultiValuedDuplicateAfterTruncation0x8e5e05f8Duplicate detected on a unique multi-valued column after data was normalized, and normalizing truncated the data before comparison
JET_errDerivedColumnCorruption0x8e5e05f9Invalid column in derived table
JET_errInvalidPlaceholderColumn0x8e5e05faTried to convert column to a primary index placeholder, but column doesn't meet necessary criteria
JET_errColumnCannotBeCompressed0x8e5e0602Only JET_coltypLongText and JET_coltypLongBinary columns can be compressed
JET_errColumnNoEncryptionKey0x8e5e0604Cannot retrieve/set encrypted column without an encryption key
JET_errRecordNotFound0x8e5e0641The key was not found
JET_errRecordNoCopy0x8e5e0642No working buffer
JET_errNoCurrentRecord0x8e5e0643Currency not on a record
JET_errRecordPrimaryChanged0x8e5e0644Primary key may not change
JET_errKeyDuplicate0x8e5e0645Illegal duplicate key
JET_errAlreadyPrepared0x8e5e0647Attempted to update record when record update was already in progress
JET_errKeyNotMade0x8e5e0648No call to JetMakeKey
JET_errUpdateNotPrepared0x8e5e0649No call to JetPrepareUpdate
JET_errDataHasChanged0x8e5e064bData has changed, operation aborted
JET_errLanguageNotSupported0x8e5e0653Windows installation does not support language
JET_errDecompressionFailed0x8e5e0654Internal error: data could not be decompressed
JET_errUpdateMustVersion0x8e5e0655No version updates only for uncommitted tables
JET_errDecryptionFailed0x8e5e0656Data could not be decrypted
JET_errEncryptionBadItag0x8e5e0657Cannot encrypt tagged columns with itag>1
JET_errTooManySorts0x8e5e06a5Too many sort processes
JET_errInvalidOnSort0x8e5e06a6Invalid operation on Sort
JET_errTempFileOpenError0x8e5e070bTemp file could not be opened
JET_errTooManyAttachedDatabases0x8e5e070dToo many open databases
JET_errDiskFull0x8e5e0710No space left on disk
JET_errPermissionDenied0x8e5e0711Permission denied
JET_errFileNotFound0x8e5e0713File not found
JET_errFileInvalidType0x8e5e0714Invalid file type
JET_errFileAlreadyExists0x8e5e0716File already exists
JET_errAfterInitialization0x8e5e073aCannot Restore after init.
JET_errLogCorrupted0x8e5e073cLogs could not be interpreted
JET_errInvalidOperation0x8e5e0772Invalid operation
JET_errAccessDenied0x8e5e0773Access denied
JET_errTooManySplits0x8e5e0775Infinite split
JET_errSessionSharingViolation0x8e5e0776Multiple threads are using the same session
JET_errEntryPointNotFound0x8e5e0777An entry point in a DLL we require could not be found
JET_errSessionContextAlreadySet0x8e5e0778Specified session already has a session context set
JET_errSessionContextNotSetByThisThread0x8e5e0779Tried to reset session context, but current thread did not orignally set the session context
JET_errSessionInUse0x8e5e077aTried to terminate session in use
JET_errRecordFormatConversionFailed0x8e5e077bInternal error during dynamic record format conversion
JET_errOneDatabasePerSession0x8e5e077cJust one open user database per session is allowed (JET_paramOneDatabasePerSession)
JET_errRollbackError0x8e5e077derror during rollback
JET_errFlushMapVersionUnsupported0x8e5e077eThe version of the persisted flush map is not supported by this version of the engine.
JET_errFlushMapDatabaseMismatch0x8e5e077fThe persisted flush map and the database do not match.
JET_errFlushMapUnrecoverable0x8e5e0780The persisted flush map cannot be reconstructed.
JET_errDatabaseAlreadyRunningMaintenance0x8e5e07d4The operation did not complete successfully because the database is already running maintenance on specified database
JET_errCallbackFailed0x8e5e0835A callback failed
JET_errCallbackNotResolved0x8e5e0836A callback function could not be found
JET_errSpaceHintsInvalid0x8e5e0837An element of the JET space hints structure was not correct or actionable.
JET_errOSSnapshotInvalidSequence0x8e5e0961OS Shadow copy API used in an invalid sequence
JET_errOSSnapshotTimeOut0x8e5e0962OS Shadow copy ended with time-out
JET_errOSSnapshotNotAllowed0x8e5e0963OS Shadow copy not allowed (backup or recovery in progress)
JET_errOSSnapshotInvalidSnapId0x8e5e0964invalid JET_OSSNAPID
JET_errLSCallbackNotSpecified0x8e5e0bb8Attempted to use Local Storage without a callback function being specified
JET_errLSAlreadySet0x8e5e0bb9Attempted to set Local Storage for an object which already had it set
JET_errLSNotSet0x8e5e0bbaAttempted to retrieve Local Storage from an object which didn't have it set
JET_errFileIOSparse0x8e5e0fa0an I/O was issued to a location that was sparse
JET_errFileIOBeyondEOF0x8e5e0fa1a read was issued to a location beyond EOF (writes will expand the file)
JET_errFileIOAbort0x8e5e0fa2instructs the JET_ABORTRETRYFAILCALLBACK caller to abort the specified I/O
JET_errFileIORetry0x8e5e0fa3instructs the JET_ABORTRETRYFAILCALLBACK caller to retry the specified I/O
JET_errFileIOFail0x8e5e0fa4instructs the JET_ABORTRETRYFAILCALLBACK caller to fail the specified I/O
JET_errFileCompressed0x8e5e0fa5read/write access is not supported on compressed files
JET_wrnNyi0xffffffffFunction Not Yet Implemented
JET_wrnRemainingVersions0x141The version store is still active
JET_wrnUniqueKey0x159seek on non-unique index yielded a unique key
JET_wrnSeparateLongValue0x196Column is a separated long-value
JET_wrnRecordFoundGreater0x40f
JET_wrnRecordFoundLess0x40f
JET_wrnExistingLogFileHasBadSignature0x22eExisting log file has bad signature
JET_wrnExistingLogFileIsNotContiguous0x22fExisting log file is not contiguous
JET_wrnSkipThisRecord0x234INTERNAL ERROR
JET_wrnTargetInstanceRunning0x242TargetInstance specified for restore is running
JET_wrnCommittedLogFilesLost0x249One or more logs that were committed to this database, were not recovered. The database is still clean/consistent, as though the lost log's transactions were committed lazily (and lost).
JET_wrnCommittedLogFilesRemoved0x24bOne or more logs that were committed to this database, were no recovered. The database is still clean/consistent, as though the corrupted log's transactions were committed lazily (and lost).
JET_wrnFinishWithUndo0x24cSignal used by clients to indicate JetInit() finished with undo
JET_wrnDatabaseRepaired0x253Database corruption has been repaired
JET_wrnColumnNull0x3ecColumn is NULL-valued
JET_wrnBufferTruncated0x3eeBuffer too small for data
JET_wrnDatabaseAttached0x3efDatabase is already attached
JET_wrnSortOverflow0x3f1Sort does not fit in memory
JET_wrnSeekNotEqual0x40fExact match not found during seek
JET_wrnNoErrorInfo0x41fNo extended error information
JET_wrnNoIdleActivity0x422No idle activity occured
JET_wrnNoWriteLock0x42bNo write lock at transaction level 0
JET_wrnColumnSetNull0x42cColumn set to NULL-value
JET_wrnShrinkNotPossible0x462Database file could not be shrunk because there is not enough internal free space available or there is unmovable data present.
JET_wrnTableEmpty0x515Opened an empty table
JET_wrnTableInUseBySystem0x52fSystem cleanup has a cursor open on the table
JET_wrnCorruptIndexDeleted0x587Out of date index removed
JET_wrnPrimaryIndexOutOfDate0x589The Primary index is created with an incompatible OS sort version. The table can not be safely modified.
JET_wrnSecondaryIndexOutOfDate0x58aOne or more Secondary index is created with an incompatible OS sort version. Any index over Unicode text should be deleted.
JET_wrnColumnMaxTruncated0x5e8Max length too big, truncated
JET_wrnCopyLongValue0x5f0Single instance column bursted
JET_wrnColumnSkipped0x5fbColumn value(s) not returned because the corresponding column id or itagSequence requested for enumeration was null
JET_wrnColumnNotLocal0x5fcColumn value(s) not returned because they could not be reconstructed from the data at hand
JET_wrnColumnMoreTags0x5fdColumn values exist that were not requested for enumeration
JET_wrnColumnTruncated0x5feColumn value truncated at the requested size limit during enumeration
JET_wrnColumnPresent0x5ffColumn values exist but were not returned by request
JET_wrnColumnSingleValue0x600Column value returned in JET_COLUMNENUM as a result of JET_bitEnumerateCompressOutput
JET_wrnColumnDefault0x601Column value(s) not returned because they were set to their default value(s) and JET_bitEnumerateIgnoreDefault was specified
JET_wrnColumnNotInRecord0x603Column value(s) not returned because they could not be reconstructed from the data in the record
JET_wrnColumnReference0x605Column value returned as a reference because it could not be reconstructed from the data in the record
JET_wrnDataHasChanged0x64aData has changed
JET_wrnKeyChanged0x652Moved to new key
JET_wrnFileOpenReadOnly0x715Database file is read only
JET_wrnIdleFull0x774Idle registry full
JET_wrnDefragAlreadyRunning0x7d0Online defrag already running on specified database
JET_wrnDefragNotRunning0x7d1Online defrag not running on specified database
JET_wrnCallbackNotRegistered0x834Unregistered a non-existant callback function
797 entries