Class HSQLDialect
- java.lang.Object
-
- org.hibernate.dialect.Dialect
-
- org.hibernate.dialect.HSQLDialect
-
- All Implemented Interfaces:
FunctionContributor,TypeContributor,ConversionContext
public class HSQLDialect extends Dialect
A SQL dialect for HSQLDB (HyperSQL) 2.6.1 and above.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.hibernate.dialect.Dialect
Dialect.SizeStrategy, Dialect.SizeStrategyImpl
-
-
Field Summary
-
Fields inherited from class org.hibernate.dialect.Dialect
CLOSED_QUOTE, LEGACY_LOB_MERGE_STRATEGY, LOG_BASE2OF10, NEW_LOCATOR_LOB_MERGE_STRATEGY, QUOTE, STANDARD_MULTI_KEY_LOAD_SIZING_STRATEGY, STREAM_XFER_LOB_MERGE_STRATEGY
-
-
Constructor Summary
Constructors Constructor Description HSQLDialect()HSQLDialect(DatabaseVersion version)HSQLDialect(DialectResolutionInfo info)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidappendBooleanValueString(SqlAppender appender, boolean bool)Append the SQL literal expression representing the given boolean value to the givenSqlAppender.voidappendDatetimeFormat(SqlAppender appender, String format)Translate the given datetime format string from the pattern language defined by Java'sDateTimeFormatterto whatever pattern language is understood by the native datetime formatting function for this database (often theto_char()function).IdentifierHelperbuildIdentifierHelper(IdentifierHelperBuilder builder, DatabaseMetaData dbMetaData)TheIdentifierHelperindicated by this dialect for handling identifier conversions.StringcastPattern(CastType from, CastType to)Obtain a pattern for the SQL equivalent to acast()function call.protected StringcolumnType(int sqlTypeCode)StringcurrentTime()Translation of the HQL/JPQLcurrent_timefunction, which maps to the Java typeTimewhich is a time with no time zone.StringcurrentTimestamp()Translation of the HQL/JPQLcurrent_timestampfunction, which maps to the Java typeTimestampwhich is a datetime with no time zone.StringcurrentTimestampWithTimeZone()Translation of the HQLoffset_datetimefunction, which maps to the Java typeOffsetDateTimewhich is a datetime with a time zone.booleandoesReadCommittedCauseWritersToBlockReaders()For the underlying database, isREAD_COMMITTEDisolation implemented by forcing readers to wait for write locks to be released?booleandoesRepeatableReadCauseReadersToBlockWriters()For the underlying database, isREPEATABLE_READisolation implemented by forcing writers to wait for read locks to be released?booleandropConstraints()Do we need to drop constraints before dropping tables in this dialect?StringextractPattern(TemporalUnit unit)Obtain a pattern for the SQL equivalent to anextract()function call.StringgetCascadeConstraintsString()The keyword that specifies that adrop tableoperation should be cascaded to its constraints, typically" cascade"where the leading space is required, or the empty string if there is no such keyword in this dialect.StringgetCurrentTimestampSelectString()The command used to retrieve the current timestamp from the database.intgetDefaultStatementBatchSize()The default value to use for the configuration property "hibernate.jdbc.batch_size".SqmMultiTableInsertStrategygetFallbackSqmInsertStrategy(EntityMappingType rootEntityDescriptor, RuntimeModelCreationContext runtimeModelCreationContext)TheSqmMultiTableInsertStrategyto use when not specified byQueryEngineOptions.getCustomSqmMultiTableInsertStrategy().SqmMultiTableMutationStrategygetFallbackSqmMutationStrategy(EntityMappingType rootEntityDescriptor, RuntimeModelCreationContext runtimeModelCreationContext)TheSqmMultiTableMutationStrategyto use when not specified byQueryEngineOptions.getCustomSqmMultiTableMutationStrategy().StringgetForUpdateString()Get the string to append toSELECTstatements to acquire pessimistic UPGRADE locks for this dialect.IdentityColumnSupportgetIdentityColumnSupport()Get the appropriateIdentityColumnSupportfor this dialect.LimitHandlergetLimitHandler()Obtain aLimitHandlerthat implements pagination support forQuery.setMaxResults(int)andQuery.setFirstResult(int).protected DatabaseVersiongetMinimumSupportedVersion()Get the version of the SQL dialect that is the minimum supported by this implementation.NameQualifierSupportgetNameQualifierSupport()NullOrderinggetNullOrdering()Returns the default ordering of null.StringgetQuerySequencesString()Get theselectcommand used retrieve the names of all sequences.StringgetSelectClauseNullString(int sqlType, TypeConfiguration typeConfiguration)Given a JDBC type code, return the expression for a literal null value of that type, to use in aselectclause.SequenceInformationExtractorgetSequenceInformationExtractor()ASequenceInformationExtractorwhich is able to extractSequenceInformationfrom the JDBC result set returned whenDialect.getQuerySequencesString()is executed.SequenceSupportgetSequenceSupport()Get the appropriateSequenceSupportfor this dialect.SqlAstTranslatorFactorygetSqlAstTranslatorFactory()TemporaryTableKindgetSupportedTemporaryTableKind()The kind of temporary tables that are supported on this database.org.hibernate.query.sqm.mutation.internal.temptable.AfterUseActiongetTemporaryTableAfterUseAction()The action to take after finishing use of a temporary table.org.hibernate.query.sqm.mutation.internal.temptable.BeforeUseActiongetTemporaryTableBeforeUseAction()The action to take before beginning use of a temporary table.StringgetTemporaryTableCreateCommand()The command to create a temporary table.UniqueDelegategetUniqueDelegate()Get theUniqueDelegatesupported by this dialectViolatedConstraintNameExtractorgetViolatedConstraintNameExtractor()AViolatedConstraintNameExtractorfor extracting the name of a violated constraint from aSQLException.voidinitializeFunctionRegistry(FunctionContributions functionContributions)Initialize the given registry with any dialect-specific functions.booleanisCurrentTimestampSelectStringCallable()Is the command returned byDialect.getCurrentTimestampSelectString()treated as callable?protected voidregisterDefaultKeywords()Register the reserved words of ANSI-standard SQL as keywords.booleanrequiresFloatCastingOfIntegerDivision()Does this dialect require that integer divisions be wrapped incast()calls to tell the db parser the expected type.protected IntegerresolveSqlTypeCode(String typeName, String baseTypeName, TypeConfiguration typeConfiguration)Resolves theSqlTypestype code for the given column type name as reported by the database and the base type name (i.e.booleansupportsCommentOn()Does this dialect support commenting on tables and columns?booleansupportsCurrentTimestampSelection()Does this dialect support some way to retrieve the current timestamp value from the database?booleansupportsDistinctFromPredicate()Does this dialect support some kind ofdistinct frompredicate?booleansupportsIfExistsAfterTableName()For dropping a table, can the phraseif existsbe applied after the table name?booleansupportsIfExistsBeforeTableName()For dropping a table, can the phraseif existsbe applied before the table name?booleansupportsLateral()Does this dialect support the SQLlateralkeyword or a proprietary alternative?booleansupportsLobValueChangePropagation()Does the dialect support propagating changes to LOB values back to the database? Talking about mutating the internal value of the locator, as opposed to supplying a new locator instance.booleansupportsLockTimeouts()Does this dialect support specifying timeouts when requesting locks.booleansupportsNamedParameters(DatabaseMetaData databaseMetaData)booleansupportsOffsetInSubquery()Does this dialect supportoffsetin subqueries?booleansupportsRecursiveCTE()Does this dialect/database support recursive CTEs?booleansupportsStandardArrays()Does this database have native support for ANSI SQL standard arrays which are expressed in terms of the element type name:integer array.booleansupportsTupleCounts()Does this dialect supportcount(a,b)?booleansupportsTupleDistinctCounts()Does this dialect supportcount(distinct a,b)?StringtimestampaddPattern(TemporalUnit unit, TemporalType temporalType, IntervalType intervalType)Obtain a pattern for the SQL equivalent to atimestampadd()function call.StringtimestampdiffPattern(TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType)Obtain a pattern for the SQL equivalent to atimestampdiff()function call.StringtranslateExtractField(TemporalUnit unit)Return the name used to identify the given field as an argument to theextract()function, or of this dialect's equivalent function.-
Methods inherited from class org.hibernate.dialect.Dialect
addSqlHintOrComment, appendArrayLiteral, appendBinaryLiteral, appendDateTimeLiteral, appendDateTimeLiteral, appendDateTimeLiteral, appendIntervalLiteral, appendLiteral, appendLockHint, appendUUIDLiteral, applyLocksToSql, augmentPhysicalTableTypes, augmentRecognizedTableTypes, buildSQLExceptionConversionDelegate, canBatchTruncate, canCreateCatalog, canCreateSchema, canDisableConstraints, castType, checkVersion, closeQuote, contribute, contributeFunctions, contributeTypes, createOptionalTableUpdateOperation, currentDate, currentLocalTime, currentLocalTimestamp, defaultScrollMode, equivalentTypes, escapeComment, forceLobAsLastValue, generatedAs, getAddColumnString, getAddColumnSuffixString, getAddForeignKeyConstraintString, getAddForeignKeyConstraintString, getAddPrimaryKeyConstraintString, getAggregateSupport, getAlterColumnTypeString, getAlterTableString, getArrayTypeName, getAuxiliaryDatabaseObjectExporter, getBatchLoadSizingStrategy, getCallableStatementSupport, getCaseInsensitiveLike, getCheckCondition, getCheckCondition, getColumnAliasExtractor, getColumnComment, getCreateCatalogCommand, getCreateIndexString, getCreateIndexTail, getCreateMultisetTableString, getCreateSchemaCommand, getCreateTableString, getCreateTemporaryTableColumnAnnotation, getCreateUserDefinedTypeExtensionsString, getCreateUserDefinedTypeKindString, getCurrentSchemaCommand, getDefaultDecimalPrecision, getDefaultLobLength, getDefaultNonContextualLobCreation, getDefaultProperties, getDefaultTimestampPrecision, getDefaultUseGetGeneratedKeys, getDisableConstraintsStatement, getDisableConstraintStatement, getDmlTargetColumnQualifierSupport, getDoublePrecision, getDropCatalogCommand, getDropForeignKeyString, getDropSchemaCommand, getDropTableString, getDropUniqueKeyString, getEnableConstraintsStatement, getEnableConstraintStatement, getEnumTypeDeclaration, getFallbackSchemaManagementTool, getFloatPrecision, getForeignKeyExporter, getForUpdateNowaitString, getForUpdateNowaitString, getForUpdateSkipLockedString, getForUpdateSkipLockedString, getForUpdateString, getForUpdateString, getForUpdateString, getForUpdateString, getFractionalSecondPrecisionInNanos, getGroupBySelectItemReferenceStrategy, getHqlTranslator, getIndexExporter, getInExpressionCountLimit, getKeywords, getLobMergeStrategy, getLockingStrategy, getLockRowIdentifier, getLowercaseFunction, getMaxAliasLength, getMaxIdentifierLength, getMaxNVarcharCapacity, getMaxNVarcharLength, getMaxVarbinaryCapacity, getMaxVarbinaryLength, getMaxVarcharCapacity, getMaxVarcharLength, getMultiKeyLoadSizingStrategy, getNationalizationSupport, getNativeIdentifierGenerationType, getNativeIdentifierGeneratorStrategy, getNativeParameterMarkerStrategy, getNoColumnsInsertString, getNullColumnString, getNullColumnString, getParameterCountLimit, getPreferredSqlTypeCodeForArray, getPreferredSqlTypeCodeForBoolean, getQueryHintString, getQueryHintString, getReadLockString, getReadLockString, getReadRowLockStrategy, getResultSet, getResultSet, getResultSet, getRowIdColumnString, getSchemaNameResolver, getSelectGUIDString, getSequenceExporter, getSizeStrategy, getSqmTranslatorFactory, getTableCleaner, getTableComment, getTableExporter, getTableMigrator, getTableTypeString, getTemporaryTableCreateOptions, getTemporaryTableDdlTransactionHandling, getTemporaryTableDropCommand, getTemporaryTableExporter, getTemporaryTableTruncateCommand, getTimeZoneSupport, getTruncateTableStatement, getTruncateTableStatements, getUniqueKeyExporter, getUserDefinedTypeComment, getUserDefinedTypeExporter, getVersion, getWriteLockString, getWriteLockString, getWriteRowLockStrategy, hasAlterTable, hasDataTypeBeforeGeneratedAs, hasSelfReferentialForeignKeyBug, initDefaultProperties, inlineLiteral, isAnsiNullOn, isEmptyStringTreatedAsNull, isJdbcLogWarningsEnabledByDefault, isLockTimeoutParameterized, openQuote, ordinal, prependComment, qualifyIndexName, quote, registerColumnTypes, registerKeyword, registerKeywords, registerResultSetOutParameter, registerResultSetOutParameter, requiresCastForConcatenatingNonStrings, requiresParensForTupleCounts, requiresParensForTupleDistinctCounts, resolveSqlTypeCode, resolveSqlTypeDescriptor, resolveSqlTypeLength, rowId, rowIdSqlType, supportsAlterColumnType, supportsBindAsCallableArgument, supportsBitType, supportsCascadeDelete, supportsCaseInsensitiveLike, supportsCircularCascadeDeleteConstraints, supportsColumnCheck, supportsExistsInSelect, supportsExpectedLobUsagePattern, supportsFetchClause, supportsFractionalTimestampArithmetic, supportsIfExistsAfterAlterTable, supportsIfExistsAfterConstraintName, supportsIfExistsAfterTypeName, supportsIfExistsBeforeConstraintName, supportsIfExistsBeforeTypeName, supportsInsertReturning, supportsInsertReturningGeneratedKeys, supportsJdbcConnectionLobCreation, supportsMaterializedLobAccess, supportsNoColumnsInsert, supportsNonQueryWithCTE, supportsNoWait, supportsNullPrecedence, supportsOrderByInSubquery, supportsOrdinalSelectItemReference, supportsOuterJoinForUpdate, supportsParametersInInsertSelect, supportsPartitionBy, supportsPredicateAsExpression, supportsResultSetPositionQueryMethodsOnForwardOnlyCursor, supportsSkipLocked, supportsStandardCurrentTimestampFunction, supportsSubqueryInSelect, supportsSubqueryOnMutatingTable, supportsSubselectAsInPredicateLHS, supportsTableCheck, supportsTemporalLiteralOffset, supportsTemporaryTablePrimaryKey, supportsTemporaryTables, supportsTruncateWithCast, supportsUnboundedLobLocatorMaterialization, supportsUnionAll, supportsUnionInSubquery, supportsValuesList, supportsValuesListForInsert, supportsWait, supportsWindowFunctions, toBooleanValueString, toQuotedIdentifier, toString, transformSelectString, translateDurationField, trimPattern, useFollowOnLocking, useInputStreamToInsertBlob, useMaterializedLobWhenCapacityExceeded
-
-
-
-
Constructor Detail
-
HSQLDialect
public HSQLDialect(DialectResolutionInfo info)
-
HSQLDialect
public HSQLDialect()
-
HSQLDialect
public HSQLDialect(DatabaseVersion version)
-
-
Method Detail
-
getMinimumSupportedVersion
protected DatabaseVersion getMinimumSupportedVersion()
Description copied from class:DialectGet the version of the SQL dialect that is the minimum supported by this implementation.- Overrides:
getMinimumSupportedVersionin classDialect
-
registerDefaultKeywords
protected void registerDefaultKeywords()
Description copied from class:DialectRegister the reserved words of ANSI-standard SQL as keywords.- Overrides:
registerDefaultKeywordsin classDialect- See Also:
AnsiSqlKeywords
-
columnType
protected String columnType(int sqlTypeCode)
Description copied from class:DialectThe database column type name for a given JDBC type code defined inTypesorSqlTypes. This default implementation returns the ANSI-standard type name.This method may be overridden by concrete
Dialects as an alternative toDialect.registerColumnTypes(TypeContributions, ServiceRegistry)for simple registrations.Note that:
- Implementations of this method are expected to define a
sensible mapping for
Types.NCLOBTypes.NCHAR, andTypes.NVARCHAR. On some database, these types are simply remapped toCLOB,CHAR, andVARCHAR. - Mappings for
Types.TIMESTAMPandTypes.TIMESTAMP_WITH_TIMEZONEshould support explicit specification of precision if possible. - As specified by
DdlTypeRegistry.getDescriptor(int), this method never receivesTypes.LONGVARCHAR,Types.LONGNVARCHAR, norTypes.LONGVARBINARY, which are considered synonyms for their non-LONGcounterparts. - On the other hand, the types
SqlTypes.LONG32VARCHAR,SqlTypes.LONG32NVARCHAR, andSqlTypes.LONG32VARBINARYare not synonyms, and implementations of this method must define sensible mappings, for example to database-nativeTEXTorCLOBtypes.
- Overrides:
columnTypein classDialect- Parameters:
sqlTypeCode- a SQLtype code- Returns:
- a column type name, with
$l,$p,$splaceholders for length, precision, scale - See Also:
SqlTypes
- Implementations of this method are expected to define a
sensible mapping for
-
resolveSqlTypeCode
protected Integer resolveSqlTypeCode(String typeName, String baseTypeName, TypeConfiguration typeConfiguration)
Description copied from class:DialectResolves theSqlTypestype code for the given column type name as reported by the database and the base type name (i.e. without precision, length and scale), ornullif it can't be resolved.- Overrides:
resolveSqlTypeCodein classDialect
-
getDefaultStatementBatchSize
public int getDefaultStatementBatchSize()
Description copied from class:DialectThe default value to use for the configuration property "hibernate.jdbc.batch_size".- Overrides:
getDefaultStatementBatchSizein classDialect
-
initializeFunctionRegistry
public void initializeFunctionRegistry(FunctionContributions functionContributions)
Description copied from class:DialectInitialize the given registry with any dialect-specific functions.Support for certain SQL functions is required, and if the database does not support a required function, then the dialect must define a way to emulate it.
These required functions include the functions defined by the JPA query language specification:
-
avg(arg)- aggregate function -
count([distinct ]arg)- aggregate function -
max(arg)- aggregate function -
min(arg)- aggregate function -
sum(arg)- aggregate function
-
coalesce(arg0, arg1, ...) -
nullif(arg0, arg1)
-
lower(arg) -
upper(arg) -
length(arg) -
concat(arg0, arg1, ...) -
locate(pattern, string[, start]) -
substring(string, start[, length]) -
trim([[spec ][character ]from] string)
-
abs(arg) -
mod(arg0, arg1) -
sqrt(arg)
-
current date -
current time -
current timestamp
-
any(arg)- aggregate function -
every(arg)- aggregate function
-
var_samp(arg)- aggregate function -
var_pop(arg)- aggregate function -
stddev_samp(arg)- aggregate function -
stddev_pop(arg)- aggregate function
-
cast(arg as Type) -
extract(field from arg)
-
ln(arg) -
exp(arg) -
power(arg0, arg1) -
floor(arg) -
ceiling(arg)
-
position(pattern in string) -
substring(string from start[ for length]) -
overlay(string placing replacement from start[ for length])
java.timetypes:-
local date -
local time -
local datetime -
offset datetime -
instant
-
left(string, length) -
right(string, length) -
replace(string, pattern, replacement) -
pad(string with length spec[ character])
-
pi -
log10(arg) -
log(base, arg) -
sign(arg) -
sin(arg) -
cos(arg) -
tan(arg) -
asin(arg) -
acos(arg) -
atan(arg) -
atan2(arg0, arg1) -
round(arg0[, arg1]) -
truncate(arg0[, arg1]) -
sinh(arg) -
tanh(arg) -
cosh(arg) -
least(arg0, arg1, ...) -
greatest(arg0, arg1, ...) -
degrees(arg) -
radians(arg)
-
format(datetime as pattern) -
collate(string as collation) -
str(arg)- synonym ofcast(a as String) -
ifnull(arg0, arg1)- synonym ofcoalesce(a, b)
extract(), and desugared by the parser:-
second(arg)- synonym ofextract(second from a) -
minute(arg)- synonym ofextract(minute from a) -
hour(arg)- synonym ofextract(hour from a) -
day(arg)- synonym ofextract(day from a) -
month(arg)- synonym ofextract(month from a) -
year(arg)- synonym ofextract(year from a)
second()function returns a floating point value, contrary to the integer type returned by the native function with this name on many databases. Thus, we don't just naively map these HQL functions to the native SQL functions with the same names.- Overrides:
initializeFunctionRegistryin classDialect
-
-
currentTime
public String currentTime()
Description copied from class:DialectTranslation of the HQL/JPQLcurrent_timefunction, which maps to the Java typeTimewhich is a time with no time zone. This contradicts ANSI SQL wherecurrent_timehas the typeTIME WITH TIME ZONE.It is recommended to override this in dialects for databases which support
localtimeortime at local.- Overrides:
currentTimein classDialect
-
currentTimestamp
public String currentTimestamp()
Description copied from class:DialectTranslation of the HQL/JPQLcurrent_timestampfunction, which maps to the Java typeTimestampwhich is a datetime with no time zone. This contradicts ANSI SQL wherecurrent_timestamphas the typeTIMESTAMP WITH TIME ZONE.It is recommended to override this in dialects for databases which support
localtimestamportimestamp at local.- Overrides:
currentTimestampin classDialect
-
currentTimestampWithTimeZone
public String currentTimestampWithTimeZone()
Description copied from class:DialectTranslation of the HQLoffset_datetimefunction, which maps to the Java typeOffsetDateTimewhich is a datetime with a time zone. This in principle correctly maps to the ANSI SQLcurrent_timestampwhich has the typeTIMESTAMP WITH TIME ZONE.- Overrides:
currentTimestampWithTimeZonein classDialect
-
getSqlAstTranslatorFactory
public SqlAstTranslatorFactory getSqlAstTranslatorFactory()
Description copied from class:Dialect- Overrides:
getSqlAstTranslatorFactoryin classDialect- See Also:
StandardSqlAstTranslatorFactory,JdbcEnvironment.getSqlAstTranslatorFactory()
-
castPattern
public String castPattern(CastType from, CastType to)
Description copied from class:DialectObtain a pattern for the SQL equivalent to acast()function call. The resulting pattern must contain ?1 and ?2 placeholders for the arguments.- Overrides:
castPatternin classDialect- Parameters:
from- aCastTypeindicating the type of the value argumentto- aCastTypeindicating the type the value argument is cast to
-
timestampaddPattern
public String timestampaddPattern(TemporalUnit unit, TemporalType temporalType, IntervalType intervalType)
Description copied from class:DialectObtain a pattern for the SQL equivalent to atimestampadd()function call. The resulting pattern must contain ?1, ?2, and ?3 placeholders for the arguments.- Overrides:
timestampaddPatternin classDialect- Parameters:
unit- The unit to add to the temporaltemporalType- The type of the temporalintervalType- The type of interval to add or null if it's not a native interval
-
timestampdiffPattern
public String timestampdiffPattern(TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType)
Description copied from class:DialectObtain a pattern for the SQL equivalent to atimestampdiff()function call. The resulting pattern must contain ?1, ?2, and ?3 placeholders for the arguments.- Overrides:
timestampdiffPatternin classDialect- Parameters:
unit- the first argumentfromTemporalType- true if the first argument is a timestamp, false if a datetoTemporalType- true if the second argument is
-
extractPattern
public String extractPattern(TemporalUnit unit)
Description copied from class:DialectObtain a pattern for the SQL equivalent to anextract()function call. The resulting pattern must contain ?1 and ?2 placeholders for the arguments.This method does not need to handle
TemporalUnit.NANOSECOND,TemporalUnit.NATIVE,TemporalUnit.OFFSET,TemporalUnit.DATE,TemporalUnit.TIME,TemporalUnit.WEEK_OF_YEAR, orTemporalUnit.WEEK_OF_MONTH, which are already desugared byExtractFunction.- Overrides:
extractPatternin classDialect- Parameters:
unit- the first argument
-
supportsDistinctFromPredicate
public boolean supportsDistinctFromPredicate()
Description copied from class:DialectDoes this dialect support some kind ofdistinct frompredicate?That is, does it support syntax like:
... where FIRST_NAME IS DISTINCT FROM LAST_NAME
- Overrides:
supportsDistinctFromPredicatein classDialect- Returns:
- True if this SQL dialect is known to support some kind of
distinct frompredicate; false otherwise
-
supportsLockTimeouts
public boolean supportsLockTimeouts()
Description copied from class:DialectDoes this dialect support specifying timeouts when requesting locks.- Overrides:
supportsLockTimeoutsin classDialect- Returns:
- True is this dialect supports specifying lock timeouts.
-
getForUpdateString
public String getForUpdateString()
Description copied from class:DialectGet the string to append toSELECTstatements to acquire pessimistic UPGRADE locks for this dialect.- Overrides:
getForUpdateStringin classDialect- Returns:
- The appropriate
FOR UPDATEclause string.
-
getLimitHandler
public LimitHandler getLimitHandler()
Description copied from class:DialectObtain aLimitHandlerthat implements pagination support forQuery.setMaxResults(int)andQuery.setFirstResult(int).- Overrides:
getLimitHandlerin classDialect
-
supportsIfExistsAfterTableName
public boolean supportsIfExistsAfterTableName()
Description copied from class:DialectFor dropping a table, can the phraseif existsbe applied after the table name?- Overrides:
supportsIfExistsAfterTableNamein classDialect- Returns:
trueifif existscan be applied after the table name
-
supportsIfExistsBeforeTableName
public boolean supportsIfExistsBeforeTableName()
Description copied from class:DialectFor dropping a table, can the phraseif existsbe applied before the table name?- Overrides:
supportsIfExistsBeforeTableNamein classDialect- Returns:
trueifif existscan be applied before the table name
-
getSequenceSupport
public SequenceSupport getSequenceSupport()
Description copied from class:DialectGet the appropriateSequenceSupportfor this dialect.- Overrides:
getSequenceSupportin classDialect
-
getQuerySequencesString
public String getQuerySequencesString()
Description copied from class:DialectGet theselectcommand used retrieve the names of all sequences.- Overrides:
getQuerySequencesStringin classDialect- Returns:
- The select command; or null if sequences are not supported.
-
getSequenceInformationExtractor
public SequenceInformationExtractor getSequenceInformationExtractor()
Description copied from class:DialectASequenceInformationExtractorwhich is able to extractSequenceInformationfrom the JDBC result set returned whenDialect.getQuerySequencesString()is executed.- Overrides:
getSequenceInformationExtractorin classDialect
-
supportsStandardArrays
public boolean supportsStandardArrays()
Description copied from class:DialectDoes this database have native support for ANSI SQL standard arrays which are expressed in terms of the element type name:integer array.- Overrides:
supportsStandardArraysin classDialect- Returns:
- boolean
-
getViolatedConstraintNameExtractor
public ViolatedConstraintNameExtractor getViolatedConstraintNameExtractor()
Description copied from class:DialectAViolatedConstraintNameExtractorfor extracting the name of a violated constraint from aSQLException.- Specified by:
getViolatedConstraintNameExtractorin interfaceConversionContext- Overrides:
getViolatedConstraintNameExtractorin classDialect
-
getSelectClauseNullString
public String getSelectClauseNullString(int sqlType, TypeConfiguration typeConfiguration)
Description copied from class:DialectGiven a JDBC type code, return the expression for a literal null value of that type, to use in aselectclause.The
selectquery will be an element of aUNIONorUNION ALL.- Overrides:
getSelectClauseNullStringin classDialect- Parameters:
sqlType- TheTypestype code.typeConfiguration- The type configuration- Returns:
- The appropriate select clause value fragment.
-
getNullOrdering
public NullOrdering getNullOrdering()
Description copied from class:DialectReturns the default ordering of null.- Overrides:
getNullOrderingin classDialect
-
getFallbackSqmMutationStrategy
public SqmMultiTableMutationStrategy getFallbackSqmMutationStrategy(EntityMappingType rootEntityDescriptor, RuntimeModelCreationContext runtimeModelCreationContext)
Description copied from class:DialectTheSqmMultiTableMutationStrategyto use when not specified byQueryEngineOptions.getCustomSqmMultiTableMutationStrategy().
-
getFallbackSqmInsertStrategy
public SqmMultiTableInsertStrategy getFallbackSqmInsertStrategy(EntityMappingType rootEntityDescriptor, RuntimeModelCreationContext runtimeModelCreationContext)
Description copied from class:DialectTheSqmMultiTableInsertStrategyto use when not specified byQueryEngineOptions.getCustomSqmMultiTableInsertStrategy().
-
getSupportedTemporaryTableKind
public TemporaryTableKind getSupportedTemporaryTableKind()
Description copied from class:DialectThe kind of temporary tables that are supported on this database.- Overrides:
getSupportedTemporaryTableKindin classDialect
-
getTemporaryTableCreateCommand
public String getTemporaryTableCreateCommand()
Description copied from class:DialectThe command to create a temporary table.- Overrides:
getTemporaryTableCreateCommandin classDialect
-
getTemporaryTableAfterUseAction
public org.hibernate.query.sqm.mutation.internal.temptable.AfterUseAction getTemporaryTableAfterUseAction()
Description copied from class:DialectThe action to take after finishing use of a temporary table.- Overrides:
getTemporaryTableAfterUseActionin classDialect
-
getTemporaryTableBeforeUseAction
public org.hibernate.query.sqm.mutation.internal.temptable.BeforeUseAction getTemporaryTableBeforeUseAction()
Description copied from class:DialectThe action to take before beginning use of a temporary table.- Overrides:
getTemporaryTableBeforeUseActionin classDialect
-
supportsCurrentTimestampSelection
public boolean supportsCurrentTimestampSelection()
Description copied from class:DialectDoes this dialect support some way to retrieve the current timestamp value from the database?- Overrides:
supportsCurrentTimestampSelectionin classDialect- Returns:
- True if the current timestamp can be retrieved; false otherwise.
-
isCurrentTimestampSelectStringCallable
public boolean isCurrentTimestampSelectStringCallable()
Description copied from class:DialectIs the command returned byDialect.getCurrentTimestampSelectString()treated as callable?Typically, this indicates the use of the JDBC escape syntax.
- Overrides:
isCurrentTimestampSelectStringCallablein classDialect- Returns:
- if the
Dialect.getCurrentTimestampSelectString()is treated as callable; false otherwise.
-
getCurrentTimestampSelectString
public String getCurrentTimestampSelectString()
Description copied from class:DialectThe command used to retrieve the current timestamp from the database.- Overrides:
getCurrentTimestampSelectStringin classDialect
-
supportsCommentOn
public boolean supportsCommentOn()
Description copied from class:DialectDoes this dialect support commenting on tables and columns?- Overrides:
supportsCommentOnin classDialect- Returns:
trueif commenting is supported
-
doesReadCommittedCauseWritersToBlockReaders
public boolean doesReadCommittedCauseWritersToBlockReaders()
Description copied from class:DialectFor the underlying database, isREAD_COMMITTEDisolation implemented by forcing readers to wait for write locks to be released?- Overrides:
doesReadCommittedCauseWritersToBlockReadersin classDialect- Returns:
- True if writers block readers to achieve
READ_COMMITTED; false otherwise.
-
doesRepeatableReadCauseReadersToBlockWriters
public boolean doesRepeatableReadCauseReadersToBlockWriters()
Description copied from class:DialectFor the underlying database, isREPEATABLE_READisolation implemented by forcing writers to wait for read locks to be released?- Overrides:
doesRepeatableReadCauseReadersToBlockWritersin classDialect- Returns:
- True if readers block writers to achieve
REPEATABLE_READ; false otherwise.
-
supportsLobValueChangePropagation
public boolean supportsLobValueChangePropagation()
Description copied from class:DialectDoes the dialect support propagating changes to LOB values back to the database? Talking about mutating the internal value of the locator, as opposed to supplying a new locator instance.- For BLOBs, the internal value might be changed by:
Blob.setBinaryStream(long),Blob.setBytes(long, byte[]),Blob.setBytes(long, byte[], int, int), orBlob.truncate(long). - For CLOBs, the internal value might be changed by:
Clob.setAsciiStream(long),Clob.setCharacterStream(long),Clob.setString(long, String),Clob.setString(long, String, int, int), orClob.truncate(long).
- Overrides:
supportsLobValueChangePropagationin classDialect- Returns:
- True if the changes are propagated back to the database; false otherwise.
- For BLOBs, the internal value might be changed by:
-
appendBooleanValueString
public void appendBooleanValueString(SqlAppender appender, boolean bool)
Description copied from class:DialectAppend the SQL literal expression representing the given boolean value to the givenSqlAppender.- Overrides:
appendBooleanValueStringin classDialect- Parameters:
appender- TheSqlAppenderto append the literal expression tobool- The boolean value
-
supportsTupleCounts
public boolean supportsTupleCounts()
Description copied from class:DialectDoes this dialect supportcount(a,b)?- Overrides:
supportsTupleCountsin classDialect- Returns:
- True if the database supports counting tuples; false otherwise.
-
supportsTupleDistinctCounts
public boolean supportsTupleDistinctCounts()
Description copied from class:DialectDoes this dialect supportcount(distinct a,b)?- Overrides:
supportsTupleDistinctCountsin classDialect- Returns:
- True if the database supports counting distinct tuples; false otherwise.
-
supportsOffsetInSubquery
public boolean supportsOffsetInSubquery()
Description copied from class:DialectDoes this dialect supportoffsetin subqueries?For example:
select * from Table1 where col1 in (select col1 from Table2 order by col2 limit 1 offset 1)
- Overrides:
supportsOffsetInSubqueryin classDialect- Returns:
trueif it does
-
supportsLateral
public boolean supportsLateral()
Description copied from class:DialectDoes this dialect support the SQLlateralkeyword or a proprietary alternative?- Overrides:
supportsLateralin classDialect- Returns:
trueif the underlying database supports lateral,falseotherwise. The default isfalse.
-
supportsRecursiveCTE
public boolean supportsRecursiveCTE()
Description copied from class:DialectDoes this dialect/database support recursive CTEs?- Overrides:
supportsRecursiveCTEin classDialect- Returns:
trueif recursive CTEs are supported
-
requiresFloatCastingOfIntegerDivision
public boolean requiresFloatCastingOfIntegerDivision()
Description copied from class:DialectDoes this dialect require that integer divisions be wrapped incast()calls to tell the db parser the expected type.- Overrides:
requiresFloatCastingOfIntegerDivisionin classDialect- Returns:
- True if integer divisions must be
cast()ed to float
-
getIdentityColumnSupport
public IdentityColumnSupport getIdentityColumnSupport()
Description copied from class:DialectGet the appropriateIdentityColumnSupportfor this dialect.- Overrides:
getIdentityColumnSupportin classDialect- Returns:
- the IdentityColumnSupport
-
getNameQualifierSupport
public NameQualifierSupport getNameQualifierSupport()
Description copied from class:DialectThe support for qualified identifiers.By default, decide based on
DatabaseMetaData.- Overrides:
getNameQualifierSupportin classDialect- Returns:
- The
NameQualifierSupport, or null to useDatabaseMetaData.
-
supportsNamedParameters
public boolean supportsNamedParameters(DatabaseMetaData databaseMetaData)
Description copied from class:Dialect- Overrides:
supportsNamedParametersin classDialect
-
dropConstraints
public boolean dropConstraints()
Description copied from class:DialectDo we need to drop constraints before dropping tables in this dialect?- Overrides:
dropConstraintsin classDialect- Returns:
- True if constraints must be dropped prior to dropping the table; false otherwise.
-
getCascadeConstraintsString
public String getCascadeConstraintsString()
Description copied from class:DialectThe keyword that specifies that adrop tableoperation should be cascaded to its constraints, typically" cascade"where the leading space is required, or the empty string if there is no such keyword in this dialect.- Overrides:
getCascadeConstraintsStringin classDialect- Returns:
- The cascade drop keyword, if any, with a leading space
-
appendDatetimeFormat
public void appendDatetimeFormat(SqlAppender appender, String format)
Description copied from class:DialectTranslate the given datetime format string from the pattern language defined by Java'sDateTimeFormatterto whatever pattern language is understood by the native datetime formatting function for this database (often theto_char()function).Since it's never possible to translate every pattern letter sequences understood by
DateTimeFormatter, only the following subset of pattern letters is accepted by Hibernate:- G: era
- y: year of era
- Y: year of week-based year
- M: month of year
- w: week of week-based year (ISO week number)
- W: week of month
- E: day of week (name)
- e: day of week (number)
- d: day of month
- D: day of year
- a: AM/PM
- H: hour of day (24 hour time)
- h: hour of AM/PM (12 hour time)
- m: minutes
- s: seconds
- z,Z,x: timezone offset
In addition, punctuation characters and single-quoted literal strings are accepted.
Appends a pattern accepted by the function that formats dates and times in this dialect to a SQL fragment that is being constructed.
- Overrides:
appendDatetimeFormatin classDialect
-
translateExtractField
public String translateExtractField(TemporalUnit unit)
Description copied from class:DialectReturn the name used to identify the given field as an argument to theextract()function, or of this dialect's equivalent function.This method does not need to handle
TemporalUnit.NANOSECOND,TemporalUnit.NATIVE,TemporalUnit.OFFSET,TemporalUnit.DATE,TemporalUnit.TIME,TemporalUnit.WEEK_OF_YEAR, norTemporalUnit.WEEK_OF_MONTH, which are already desugared byExtractFunction.- Overrides:
translateExtractFieldin classDialect
-
buildIdentifierHelper
public IdentifierHelper buildIdentifierHelper(IdentifierHelperBuilder builder, DatabaseMetaData dbMetaData) throws SQLException
Description copied from class:DialectTheIdentifierHelperindicated by this dialect for handling identifier conversions. Returningnullis allowed and indicates that Hibernate should fall back to building a "standard" helper. In the fallback path, any changes made to the IdentifierHelperBuilder during this call will still be incorporated into the built IdentifierHelper.The incoming builder will have the following set:
IdentifierHelperBuilder.isGloballyQuoteIdentifiers()IdentifierHelperBuilder.getUnquotedCaseStrategy()- initialized to UPPERIdentifierHelperBuilder.getQuotedCaseStrategy()- initialized to MIXED
By default, Hibernate will do the following:
- Call
IdentifierHelperBuilder.applyIdentifierCasing(DatabaseMetaData) - Call
IdentifierHelperBuilder.applyReservedWords(DatabaseMetaData) - Applies
AnsiSqlKeywords.sql2003()as reserved words - Applies the {#link #sqlKeywords} collected here as reserved words
- Applies the Dialect's
NameQualifierSupport, if it defines one
- Overrides:
buildIdentifierHelperin classDialect- Parameters:
builder- A partially-configuredIdentifierHelperBuilder.dbMetaData- Access to the metadata returned from the driver if needed and if available. WARNING: it may benull.- Returns:
- The
IdentifierHelperinstance to use, ornullto indicate Hibernate should use its fallback path - Throws:
SQLException- Accessing theDatabaseMetaDatacan throw it. Just rethrow and Hibernate will handle it.- See Also:
Dialect.getNameQualifierSupport()
-
getUniqueDelegate
public UniqueDelegate getUniqueDelegate()
Description copied from class:DialectGet theUniqueDelegatesupported by this dialect- Overrides:
getUniqueDelegatein classDialect- Returns:
- The UniqueDelegate
-
-