Class DB2LegacyDialect
java.lang.Object
org.hibernate.dialect.Dialect
org.hibernate.community.dialect.DB2LegacyDialect
- All Implemented Interfaces:
org.hibernate.boot.model.FunctionContributor, org.hibernate.boot.model.TypeContributor, org.hibernate.exception.spi.ConversionContext
- Direct Known Subclasses:
DB2iLegacyDialect, DB2zLegacyDialect
public class DB2LegacyDialect
extends org.hibernate.dialect.Dialect
A SQL dialect for DB2.
-
Nested Class Summary
Nested classes/interfaces inherited from class org.hibernate.dialect.Dialect
org.hibernate.dialect.Dialect.SizeStrategy, org.hibernate.dialect.Dialect.SizeStrategyImpl -
Field Summary
Fields inherited from class org.hibernate.dialect.Dialect
CLOSED_QUOTE, FALSE_STRING_VALUES, LEGACY_LOB_MERGE_STRATEGY, LOG_BASE2OF10, NEW_LOCATOR_LOB_MERGE_STRATEGY, QUOTE, STANDARD_MULTI_KEY_LOAD_SIZING_STRATEGY, STREAM_XFER_LOB_MERGE_STRATEGY, TRUE_STRING_VALUES -
Constructor Summary
ConstructorsConstructorDescriptionDB2LegacyDialect(org.hibernate.dialect.DatabaseVersion version) DB2LegacyDialect(org.hibernate.engine.jdbc.dialect.spi.DialectResolutionInfo info) -
Method Summary
Modifier and TypeMethodDescriptionvoidappendBinaryLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, byte[] bytes) voidappendBooleanValueString(org.hibernate.sql.ast.spi.SqlAppender appender, boolean bool) voidappendDatetimeFormat(org.hibernate.sql.ast.spi.SqlAppender appender, String format) voidappendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, TemporalAccessor temporalAccessor, TemporalType precision, TimeZone jdbcTimeZone) voidappendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, Calendar calendar, TemporalType precision, TimeZone jdbcTimeZone) voidappendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, Date date, TemporalType precision, TimeZone jdbcTimeZone) org.hibernate.engine.jdbc.env.spi.IdentifierHelperbuildIdentifierHelper(org.hibernate.engine.jdbc.env.spi.IdentifierHelperBuilder builder, DatabaseMetaData metadata) protected org.hibernate.dialect.lock.spi.LockingSupportorg.hibernate.exception.spi.SQLExceptionConversionDelegatebooleancastPattern(org.hibernate.query.sqm.CastType from, org.hibernate.query.sqm.CastType to) protected StringcolumnType(int sqlTypeCode) voidcontributeTypes(org.hibernate.boot.model.TypeContributions typeContributions, org.hibernate.service.ServiceRegistry serviceRegistry) protected org.hibernate.dialect.unique.UniqueDelegateorg.hibernate.dialect.DatabaseVersiondetermineDatabaseVersion(org.hibernate.engine.jdbc.dialect.spi.DialectResolutionInfo info) booleanbooleanbooleanextractPattern(org.hibernate.query.common.TemporalUnit unit) generatedAs(String generatedAs) org.hibernate.dialect.aggregate.AggregateSupportgetAlterColumnTypeString(String columnName, String columnType, String columnDefinition) org.hibernate.procedure.spi.CallableStatementSupportgetCreateIndexTail(boolean unique, List<org.hibernate.mapping.Column> columns) org.hibernate.dialect.DatabaseVersionDB2 LUW VersionintintgetDisableConstraintStatement(String tableName, String name) org.hibernate.dialect.DmlTargetColumnQualifierSupportString[]getDropSchemaCommand(String schemaName) getDual()getEnableConstraintStatement(String tableName, String name) org.hibernate.query.sqm.mutation.spi.SqmMultiTableInsertStrategygetFallbackSqmInsertStrategy(org.hibernate.metamodel.mapping.EntityMappingType rootEntityDescriptor, org.hibernate.metamodel.spi.RuntimeModelCreationContext runtimeModelCreationContext) org.hibernate.query.sqm.mutation.spi.SqmMultiTableMutationStrategygetFallbackSqmMutationStrategy(org.hibernate.metamodel.mapping.EntityMappingType rootEntityDescriptor, org.hibernate.metamodel.spi.RuntimeModelCreationContext runtimeModelCreationContext) getForUpdateSkipLockedString(String aliases) longSince we're usingseconds_between()andadd_seconds(), it makes sense to use seconds as the "native" precision.@Nullable org.hibernate.dialect.temptable.TemporaryTableStrategyorg.hibernate.dialect.identity.IdentityColumnSupportintorg.hibernate.dialect.pagination.LimitHandler@Nullable org.hibernate.dialect.temptable.TemporaryTableStrategyorg.hibernate.dialect.lock.spi.LockingSupportintprotected intDB2 doesn't support thegenerate_seriesfunction orlateralrecursive CTEs, so it has to be emulated with a top level recursive CTE which requires an upper bound on the amount of elements that the series can return.intintintgetReadLockString(int timeout) getReadLockString(Timeout timeout) getResultSet(CallableStatement statement, int position) getResultSet(CallableStatement statement, String name) getSelectClauseNullString(int sqlType, org.hibernate.type.spi.TypeConfiguration typeConfiguration) org.hibernate.tool.schema.extract.spi.SequenceInformationExtractororg.hibernate.dialect.sequence.SequenceSupportorg.hibernate.sql.ast.SqlAstTranslatorFactoryorg.hibernate.tool.schema.spi.Exporter<org.hibernate.mapping.Table> getTruncateTableStatement(String tableName) org.hibernate.dialect.unique.UniqueDelegateorg.hibernate.exception.spi.ViolatedConstraintNameExtractorgetWriteLockString(int timeout) getWriteLockString(Timeout timeout) voidinitializeFunctionRegistry(org.hibernate.boot.model.FunctionContributions functionContributions) booleanprotected voidregisterColumnTypes(org.hibernate.boot.model.TypeContributions typeContributions, org.hibernate.service.ServiceRegistry serviceRegistry) protected voidintregisterResultSetOutParameter(CallableStatement statement, int col) intregisterResultSetOutParameter(CallableStatement statement, String name) booleanThe more "standard" syntax isrid_bit(alias)but here we usealias.rowid.intbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanprotected booleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleantimestampaddPattern(org.hibernate.query.common.TemporalUnit unit, TemporalType temporalType, org.hibernate.query.sqm.IntervalType intervalType) timestampdiffPattern(org.hibernate.query.common.TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType) static StringtimestampdiffPatternV10(org.hibernate.query.common.TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType) translateExtractField(org.hibernate.query.common.TemporalUnit unit) booleanMethods inherited from class org.hibernate.dialect.Dialect
addPartitionKeyToPrimaryKey, addSqlHintOrComment, addUseIndexQueryHint, appendArrayLiteral, appendCheckConstraintOptions, appendIntervalLiteral, appendIntervalLiteral, appendLiteral, appendLockHint, appendUUIDLiteral, applyLocksToSql, augmentPhysicalTableTypes, augmentRecognizedTableTypes, buildLockingClauseStrategy, buildOptimisticForceIncrementStrategy, buildOptimisticStrategy, buildPessimisticForceIncrementStrategy, buildPessimisticReadStrategy, buildPessimisticWriteStrategy, buildReadStrategy, buildStringToBooleanCast, buildStringToBooleanCastDecode, buildStringToBooleanDecode, canBatchTruncate, canCreateCatalog, canCreateSchema, castType, checkVersion, closeQuote, contribute, contributeFunctions, createOptionalTableUpdateOperation, currentDate, currentLocalTime, currentLocalTimestamp, currentTime, currentTimestamp, currentTimestampWithTimeZone, defaultScrollMode, doesRepeatableReadCauseReadersToBlockWriters, equivalentTypes, escapeComment, forceLobAsLastValue, getAddColumnString, getAddColumnSuffixString, getAddForeignKeyConstraintString, getAddForeignKeyConstraintString, getAddPrimaryKeyConstraintString, getAlterTableString, getArrayTypeName, getAuxiliaryDatabaseObjectExporter, getBatchLoadSizingStrategy, getBeforeDropStatement, getCascadeConstraintsString, getCaseInsensitiveLike, getCatalogSeparator, getCheckCondition, getCheckCondition, getCheckCondition, getCheckCondition, getCheckCondition, getCheckCondition, getCheckConstraintString, getColumnAliasExtractor, getColumnComment, getCreateCatalogCommand, getCreateEnumTypeCommand, getCreateEnumTypeCommand, getCreateIndexString, getCreateMultisetTableString, getCreateSchemaCommand, getCreateTableString, getCreateTemporaryTableColumnAnnotation, getCreateUserDefinedTypeKindString, getCrossReferenceParentTableFilter, getCurrentSchemaCommand, getDefaultIntervalSecondScale, getDefaultLobLength, getDefaultNonContextualLobCreation, getDefaultOrdinalityColumnName, getDefaultProperties, getDefaultTimestampPrecision, getDefaultUseGetGeneratedKeys, getDisableConstraintsStatement, getDoublePrecision, getDropCatalogCommand, getDropEnumTypeCommand, getDropEnumTypeCommand, getDropForeignKeyString, getDropTableString, getDropUniqueKeyString, getEnableConstraintsStatement, getEnumTypeDeclaration, getEnumTypeDeclaration, getFallbackSchemaManagementTool, getFloatPrecision, getForeignKeyExporter, getForUpdateNowaitString, getForUpdateNowaitString, getForUpdateString, getForUpdateString, getForUpdateString, getForUpdateString, getForUpdateString, getForUpdateString, getForUpdateString, getFunctionalDependencyAnalysisSupport, getGroupBySelectItemReferenceStrategy, getHqlTranslator, getIndexExporter, getInformationExtractor, getKeywords, getLobMergeStrategy, getLockingClauseStrategy, getLockingStrategy, getLockingStrategy, getLockRowIdentifier, getMaxAliasLength, getMaxNVarcharCapacity, getMaxNVarcharLength, getMaxVarbinaryCapacity, getMaxVarbinaryLength, getMaxVarcharCapacity, getMinimumSupportedVersion, getMultiKeyLoadSizingStrategy, getNameQualifierSupport, getNationalizationSupport, getNativeIdentifierGeneratorStrategy, getNativeParameterMarkerStrategy, getNativeValueGenerationStrategy, getNoColumnsInsertString, getNullColumnString, getNullColumnString, getNullOrdering, getParameterCountLimit, getPersistentTemporaryTableStrategy, getPessimisticLockStyle, getQueryHintString, getQueryHintString, getReadLockString, getReadLockString, getReadRowLockStrategy, getRowIdColumnString, getSchemaNameResolver, getSelectClauseNullString, getSelectGUIDString, getSequenceExporter, getSizeStrategy, getSqmTranslatorFactory, getSupportedTemporaryTableKind, getTableCleaner, getTableComment, getTableMigrator, getTableTypeString, getTemporaryTableAfterUseAction, getTemporaryTableBeforeUseAction, getTemporaryTableCreateCommand, getTemporaryTableCreateOptions, getTemporaryTableDdlTransactionHandling, getTemporaryTableDropCommand, getTemporaryTableExporter, getTemporaryTableTruncateCommand, getTimeoutInSeconds, getTimeZoneSupport, getTruncateTableStatements, getUniqueKeyExporter, getUserDefinedTypeComment, getUserDefinedTypeExporter, getVersion, getWriteLockString, getWriteLockString, getWriteRowLockStrategy, hasAlterTable, hasDataTypeBeforeGeneratedAs, hasSelfReferentialForeignKeyBug, initDefaultProperties, isEmptyStringTreatedAsNull, isJdbcLogWarningsEnabledByDefault, isLob, openQuote, ordinal, prependComment, qualifyIndexName, quote, quoteCollation, registerKeyword, registerKeywords, requiresColumnListInCreateView, requiresFloatCastingOfIntegerDivision, requiresParensForTupleCounts, requiresParensForTupleDistinctCounts, resolveSqlTypeCode, resolveSqlTypeCode, resolveSqlTypeDescriptor, resolveSqlTypeLength, stripsTrailingSpacesFromChar, supportsArrayConstructor, supportsBatchUpdates, supportsBindAsCallableArgument, supportsBindingNullForSetObject, supportsBindingNullSqlTypeForSetNull, supportsBitType, supportsCascadeDelete, supportsCaseInsensitiveLike, supportsCircularCascadeDeleteConstraints, supportsColumnCheck, supportsConflictClauseForInsertCTE, supportsCrossJoin, supportsDuplicateSelectItemsInQueryGroup, supportsExpectedLobUsagePattern, supportsFetchClause, supportsFilterClause, supportsForUpdate, supportsFractionalTimestampArithmetic, supportsIfExistsAfterAlterTable, supportsIfExistsAfterConstraintName, supportsIfExistsAfterTableName, supportsIfExistsAfterTypeName, supportsIfExistsBeforeConstraintName, supportsIfExistsBeforeTypeName, supportsInsertReturningGeneratedKeys, supportsIntersect, supportsJdbcConnectionLobCreation, supportsJoinInMutationStatementSubquery, supportsJoinsInDelete, supportsLockTimeouts, supportsMaterializedLobAccess, supportsNamedColumnCheck, supportsNamedParameters, supportsNestedSubqueryCorrelation, supportsNestedWithClause, supportsNoColumnsInsert, supportsNoWait, supportsOrderByInSubquery, supportsOrdinalSelectItemReference, supportsOuterJoinForUpdate, supportsRecursiveCycleClause, supportsRecursiveCycleUsingClause, supportsRecursiveSearchClause, supportsRowConstructor, supportsRowValueConstructorDistinctFromSyntax, supportsRowValueConstructorGtLtSyntax, supportsSimpleQueryGrouping, supportsSkipLocked, supportsStandardArrays, supportsStandardCurrentTimestampFunction, supportsSubqueryInSelect, supportsSubqueryOnMutatingTable, supportsSubselectAsInPredicateLHS, supportsTableCheck, supportsTableOptions, supportsTemporalLiteralOffset, supportsTemporaryTablePrimaryKey, supportsTemporaryTables, supportsTruncateWithCast, supportsTupleCounts, supportsUnboundedLobLocatorMaterialization, supportsUnionAll, supportsUnionInSubquery, supportsUpdateReturning, supportsUserDefinedTypes, supportsValuesListForInsert, supportsWait, supportsWithClause, toBooleanValueString, toQuotedIdentifier, toString, transformSelectString, translateDurationField, trimPattern, unquoteGetGeneratedKeys, useArrayForMultiValuedParameters, useCrossReferenceForeignKeys, useFollowOnLocking, useInputStreamToInsertBlob, useMaterializedLobWhenCapacityExceeded
-
Constructor Details
-
DB2LegacyDialect
public DB2LegacyDialect() -
DB2LegacyDialect
public DB2LegacyDialect(org.hibernate.engine.jdbc.dialect.spi.DialectResolutionInfo info) -
DB2LegacyDialect
public DB2LegacyDialect(org.hibernate.dialect.DatabaseVersion version)
-
-
Method Details
-
determineDatabaseVersion
public org.hibernate.dialect.DatabaseVersion determineDatabaseVersion(org.hibernate.engine.jdbc.dialect.spi.DialectResolutionInfo info) - Overrides:
determineDatabaseVersionin classorg.hibernate.dialect.Dialect
-
buildLockingSupport
protected org.hibernate.dialect.lock.spi.LockingSupport buildLockingSupport() -
registerDefaultKeywords
protected void registerDefaultKeywords()- Overrides:
registerDefaultKeywordsin classorg.hibernate.dialect.Dialect
-
getDB2Version
public org.hibernate.dialect.DatabaseVersion getDB2Version()DB2 LUW Version -
getTableExporter
public org.hibernate.tool.schema.spi.Exporter<org.hibernate.mapping.Table> getTableExporter()- Overrides:
getTableExporterin classorg.hibernate.dialect.Dialect
-
getDefaultStatementBatchSize
public int getDefaultStatementBatchSize()- Overrides:
getDefaultStatementBatchSizein classorg.hibernate.dialect.Dialect
-
getPreferredSqlTypeCodeForBoolean
public int getPreferredSqlTypeCodeForBoolean()- Overrides:
getPreferredSqlTypeCodeForBooleanin classorg.hibernate.dialect.Dialect
-
columnType
- Overrides:
columnTypein classorg.hibernate.dialect.Dialect
-
registerColumnTypes
protected void registerColumnTypes(org.hibernate.boot.model.TypeContributions typeContributions, org.hibernate.service.ServiceRegistry serviceRegistry) - Overrides:
registerColumnTypesin classorg.hibernate.dialect.Dialect
-
createUniqueDelegate
protected org.hibernate.dialect.unique.UniqueDelegate createUniqueDelegate() -
getMaxVarcharLength
public int getMaxVarcharLength()- Overrides:
getMaxVarcharLengthin classorg.hibernate.dialect.Dialect
-
getDefaultDecimalPrecision
public int getDefaultDecimalPrecision()- Overrides:
getDefaultDecimalPrecisionin classorg.hibernate.dialect.Dialect
-
supportsPredicateAsExpression
protected boolean supportsPredicateAsExpression()- Overrides:
supportsPredicateAsExpressionin classorg.hibernate.dialect.Dialect
-
supportsDistinctFromPredicate
public boolean supportsDistinctFromPredicate()- Overrides:
supportsDistinctFromPredicatein classorg.hibernate.dialect.Dialect
-
initializeFunctionRegistry
public void initializeFunctionRegistry(org.hibernate.boot.model.FunctionContributions functionContributions) - Overrides:
initializeFunctionRegistryin classorg.hibernate.dialect.Dialect
-
getMaximumSeriesSize
protected int getMaximumSeriesSize()DB2 doesn't support thegenerate_seriesfunction orlateralrecursive CTEs, so it has to be emulated with a top level recursive CTE which requires an upper bound on the amount of elements that the series can return. -
getPreferredSqlTypeCodeForArray
public int getPreferredSqlTypeCodeForArray()- Overrides:
getPreferredSqlTypeCodeForArrayin classorg.hibernate.dialect.Dialect
-
getDropSchemaCommand
-
getFractionalSecondPrecisionInNanos
public long getFractionalSecondPrecisionInNanos()Since we're usingseconds_between()andadd_seconds(), it makes sense to use seconds as the "native" precision.- Overrides:
getFractionalSecondPrecisionInNanosin classorg.hibernate.dialect.Dialect
-
timestampdiffPattern
public String timestampdiffPattern(org.hibernate.query.common.TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType) - Overrides:
timestampdiffPatternin classorg.hibernate.dialect.Dialect
-
timestampdiffPatternV10
public static String timestampdiffPatternV10(org.hibernate.query.common.TemporalUnit unit, TemporalType fromTemporalType, TemporalType toTemporalType) -
timestampaddPattern
public String timestampaddPattern(org.hibernate.query.common.TemporalUnit unit, TemporalType temporalType, org.hibernate.query.sqm.IntervalType intervalType) - Overrides:
timestampaddPatternin classorg.hibernate.dialect.Dialect
-
appendDateTimeLiteral
public void appendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, TemporalAccessor temporalAccessor, TemporalType precision, TimeZone jdbcTimeZone) - Overrides:
appendDateTimeLiteralin classorg.hibernate.dialect.Dialect
-
appendDateTimeLiteral
public void appendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, Date date, TemporalType precision, TimeZone jdbcTimeZone) - Overrides:
appendDateTimeLiteralin classorg.hibernate.dialect.Dialect
-
appendDateTimeLiteral
public void appendDateTimeLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, Calendar calendar, TemporalType precision, TimeZone jdbcTimeZone) - Overrides:
appendDateTimeLiteralin classorg.hibernate.dialect.Dialect
-
getLowercaseFunction
- Overrides:
getLowercaseFunctionin classorg.hibernate.dialect.Dialect
-
dropConstraints
public boolean dropConstraints()- Overrides:
dropConstraintsin classorg.hibernate.dialect.Dialect
-
getCreateIndexTail
-
getSequenceSupport
public org.hibernate.dialect.sequence.SequenceSupport getSequenceSupport()- Overrides:
getSequenceSupportin classorg.hibernate.dialect.Dialect
-
getQuerySequencesString
- Overrides:
getQuerySequencesStringin classorg.hibernate.dialect.Dialect
-
getSequenceInformationExtractor
public org.hibernate.tool.schema.extract.spi.SequenceInformationExtractor getSequenceInformationExtractor()- Overrides:
getSequenceInformationExtractorin classorg.hibernate.dialect.Dialect
-
getForUpdateString
- Overrides:
getForUpdateStringin classorg.hibernate.dialect.Dialect
-
getLockingSupport
public org.hibernate.dialect.lock.spi.LockingSupport getLockingSupport()- Overrides:
getLockingSupportin classorg.hibernate.dialect.Dialect
-
getForUpdateSkipLockedString
- Overrides:
getForUpdateSkipLockedStringin classorg.hibernate.dialect.Dialect
-
getForUpdateSkipLockedString
-
getWriteLockString
-
getReadLockString
-
getWriteLockString
- Overrides:
getWriteLockStringin classorg.hibernate.dialect.Dialect
-
getReadLockString
- Overrides:
getReadLockStringin classorg.hibernate.dialect.Dialect
-
supportsExistsInSelect
public boolean supportsExistsInSelect()- Overrides:
supportsExistsInSelectin classorg.hibernate.dialect.Dialect
-
requiresCastForConcatenatingNonStrings
public boolean requiresCastForConcatenatingNonStrings()- Overrides:
requiresCastForConcatenatingNonStringsin classorg.hibernate.dialect.Dialect
-
getSelectClauseNullString
public String getSelectClauseNullString(int sqlType, org.hibernate.type.spi.TypeConfiguration typeConfiguration) - Overrides:
getSelectClauseNullStringin classorg.hibernate.dialect.Dialect
-
supportsRefCursors
- Overrides:
supportsRefCursorsin classorg.hibernate.dialect.Dialect
-
registerResultSetOutParameter
- Overrides:
registerResultSetOutParameterin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
registerResultSetOutParameter
public int registerResultSetOutParameter(CallableStatement statement, String name) throws SQLException - Overrides:
registerResultSetOutParameterin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
getResultSet
- Overrides:
getResultSetin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
getResultSet
- Overrides:
getResultSetin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
getResultSet
- Overrides:
getResultSetin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
supportsCommentOn
public boolean supportsCommentOn()- Overrides:
supportsCommentOnin classorg.hibernate.dialect.Dialect
-
getAlterColumnTypeString
-
supportsAlterColumnType
public boolean supportsAlterColumnType()- Overrides:
supportsAlterColumnTypein classorg.hibernate.dialect.Dialect
-
supportsIfExistsBeforeTableName
public boolean supportsIfExistsBeforeTableName()- Overrides:
supportsIfExistsBeforeTableNamein classorg.hibernate.dialect.Dialect
-
getFallbackSqmMutationStrategy
public org.hibernate.query.sqm.mutation.spi.SqmMultiTableMutationStrategy getFallbackSqmMutationStrategy(org.hibernate.metamodel.mapping.EntityMappingType rootEntityDescriptor, org.hibernate.metamodel.spi.RuntimeModelCreationContext runtimeModelCreationContext) - Overrides:
getFallbackSqmMutationStrategyin classorg.hibernate.dialect.Dialect
-
supportsIsTrue
public boolean supportsIsTrue()- Overrides:
supportsIsTruein classorg.hibernate.dialect.Dialect
-
getFallbackSqmInsertStrategy
public org.hibernate.query.sqm.mutation.spi.SqmMultiTableInsertStrategy getFallbackSqmInsertStrategy(org.hibernate.metamodel.mapping.EntityMappingType rootEntityDescriptor, org.hibernate.metamodel.spi.RuntimeModelCreationContext runtimeModelCreationContext) - Overrides:
getFallbackSqmInsertStrategyin classorg.hibernate.dialect.Dialect
-
getGlobalTemporaryTableStrategy
public @Nullable org.hibernate.dialect.temptable.TemporaryTableStrategy getGlobalTemporaryTableStrategy()- Overrides:
getGlobalTemporaryTableStrategyin classorg.hibernate.dialect.Dialect
-
getLocalTemporaryTableStrategy
public @Nullable org.hibernate.dialect.temptable.TemporaryTableStrategy getLocalTemporaryTableStrategy()- Overrides:
getLocalTemporaryTableStrategyin classorg.hibernate.dialect.Dialect
-
supportsCurrentTimestampSelection
public boolean supportsCurrentTimestampSelection()- Overrides:
supportsCurrentTimestampSelectionin classorg.hibernate.dialect.Dialect
-
getCurrentTimestampSelectString
- Overrides:
getCurrentTimestampSelectStringin classorg.hibernate.dialect.Dialect
-
doesRoundTemporalOnOverflow
public boolean doesRoundTemporalOnOverflow()- Overrides:
doesRoundTemporalOnOverflowin classorg.hibernate.dialect.Dialect
-
isCurrentTimestampSelectStringCallable
public boolean isCurrentTimestampSelectStringCallable()- Overrides:
isCurrentTimestampSelectStringCallablein classorg.hibernate.dialect.Dialect
-
supportsResultSetPositionQueryMethodsOnForwardOnlyCursor
public boolean supportsResultSetPositionQueryMethodsOnForwardOnlyCursor()- Overrides:
supportsResultSetPositionQueryMethodsOnForwardOnlyCursorin classorg.hibernate.dialect.Dialect
-
supportsLobValueChangePropagation
public boolean supportsLobValueChangePropagation()- Overrides:
supportsLobValueChangePropagationin classorg.hibernate.dialect.Dialect
-
useConnectionToCreateLob
public boolean useConnectionToCreateLob()- Overrides:
useConnectionToCreateLobin classorg.hibernate.dialect.Dialect
-
supportsNationalizedMethods
public boolean supportsNationalizedMethods()- Overrides:
supportsNationalizedMethodsin classorg.hibernate.dialect.Dialect
-
doesReadCommittedCauseWritersToBlockReaders
public boolean doesReadCommittedCauseWritersToBlockReaders()- Overrides:
doesReadCommittedCauseWritersToBlockReadersin classorg.hibernate.dialect.Dialect
-
supportsTupleDistinctCounts
public boolean supportsTupleDistinctCounts()- Overrides:
supportsTupleDistinctCountsin classorg.hibernate.dialect.Dialect
-
contributeTypes
public void contributeTypes(org.hibernate.boot.model.TypeContributions typeContributions, org.hibernate.service.ServiceRegistry serviceRegistry) - Overrides:
contributeTypesin classorg.hibernate.dialect.Dialect
-
getAggregateSupport
public org.hibernate.dialect.aggregate.AggregateSupport getAggregateSupport()- Overrides:
getAggregateSupportin classorg.hibernate.dialect.Dialect
-
getCallableStatementSupport
public org.hibernate.procedure.spi.CallableStatementSupport getCallableStatementSupport()- Overrides:
getCallableStatementSupportin classorg.hibernate.dialect.Dialect
-
appendBinaryLiteral
public void appendBinaryLiteral(org.hibernate.sql.ast.spi.SqlAppender appender, byte[] bytes) - Overrides:
appendBinaryLiteralin classorg.hibernate.dialect.Dialect
-
getViolatedConstraintNameExtractor
public org.hibernate.exception.spi.ViolatedConstraintNameExtractor getViolatedConstraintNameExtractor()- Specified by:
getViolatedConstraintNameExtractorin interfaceorg.hibernate.exception.spi.ConversionContext- Overrides:
getViolatedConstraintNameExtractorin classorg.hibernate.dialect.Dialect
-
buildSQLExceptionConversionDelegate
public org.hibernate.exception.spi.SQLExceptionConversionDelegate buildSQLExceptionConversionDelegate()- Overrides:
buildSQLExceptionConversionDelegatein classorg.hibernate.dialect.Dialect
-
getUniqueDelegate
public org.hibernate.dialect.unique.UniqueDelegate getUniqueDelegate()- Overrides:
getUniqueDelegatein classorg.hibernate.dialect.Dialect
-
getMaxIdentifierLength
public int getMaxIdentifierLength()- Overrides:
getMaxIdentifierLengthin classorg.hibernate.dialect.Dialect
-
getLimitHandler
public org.hibernate.dialect.pagination.LimitHandler getLimitHandler()- Overrides:
getLimitHandlerin classorg.hibernate.dialect.Dialect
-
supportsNullPrecedence
public boolean supportsNullPrecedence()- Overrides:
supportsNullPrecedencein classorg.hibernate.dialect.Dialect
-
getSqlAstTranslatorFactory
public org.hibernate.sql.ast.SqlAstTranslatorFactory getSqlAstTranslatorFactory()- Overrides:
getSqlAstTranslatorFactoryin classorg.hibernate.dialect.Dialect
-
getIdentityColumnSupport
public org.hibernate.dialect.identity.IdentityColumnSupport getIdentityColumnSupport()- Overrides:
getIdentityColumnSupportin classorg.hibernate.dialect.Dialect
-
supportsInsertReturning
public boolean supportsInsertReturning()- Overrides:
supportsInsertReturningin classorg.hibernate.dialect.Dialect- Returns:
truebecause we can useselect ... from new table (insert .... )
-
supportsInsertReturningRowId
public boolean supportsInsertReturningRowId()- Overrides:
supportsInsertReturningRowIdin classorg.hibernate.dialect.Dialect
-
supportsValuesList
public boolean supportsValuesList()- Overrides:
supportsValuesListin classorg.hibernate.dialect.Dialect
-
supportsPartitionBy
public boolean supportsPartitionBy()- Overrides:
supportsPartitionByin classorg.hibernate.dialect.Dialect
-
supportsNonQueryWithCTE
public boolean supportsNonQueryWithCTE()- Overrides:
supportsNonQueryWithCTEin classorg.hibernate.dialect.Dialect
-
supportsRecursiveCTE
public boolean supportsRecursiveCTE()- Overrides:
supportsRecursiveCTEin classorg.hibernate.dialect.Dialect
-
supportsOffsetInSubquery
public boolean supportsOffsetInSubquery()- Overrides:
supportsOffsetInSubqueryin classorg.hibernate.dialect.Dialect
-
supportsWindowFunctions
public boolean supportsWindowFunctions()- Overrides:
supportsWindowFunctionsin classorg.hibernate.dialect.Dialect
-
supportsLateral
public boolean supportsLateral()- Overrides:
supportsLateralin classorg.hibernate.dialect.Dialect
-
appendDatetimeFormat
- Overrides:
appendDatetimeFormatin classorg.hibernate.dialect.Dialect
-
translateExtractField
- Overrides:
translateExtractFieldin classorg.hibernate.dialect.Dialect
-
appendBooleanValueString
public void appendBooleanValueString(org.hibernate.sql.ast.spi.SqlAppender appender, boolean bool) - Overrides:
appendBooleanValueStringin classorg.hibernate.dialect.Dialect
-
extractPattern
- Overrides:
extractPatternin classorg.hibernate.dialect.Dialect
-
castPattern
public String castPattern(org.hibernate.query.sqm.CastType from, org.hibernate.query.sqm.CastType to) - Overrides:
castPatternin classorg.hibernate.dialect.Dialect
-
getInExpressionCountLimit
public int getInExpressionCountLimit()- Overrides:
getInExpressionCountLimitin classorg.hibernate.dialect.Dialect
-
generatedAs
-
buildIdentifierHelper
public org.hibernate.engine.jdbc.env.spi.IdentifierHelper buildIdentifierHelper(org.hibernate.engine.jdbc.env.spi.IdentifierHelperBuilder builder, DatabaseMetaData metadata) throws SQLException - Overrides:
buildIdentifierHelperin classorg.hibernate.dialect.Dialect- Throws:
SQLException
-
canDisableConstraints
public boolean canDisableConstraints()- Overrides:
canDisableConstraintsin classorg.hibernate.dialect.Dialect
-
getDisableConstraintStatement
-
getEnableConstraintStatement
-
getTruncateTableStatement
-
getCreateUserDefinedTypeExtensionsString
- Overrides:
getCreateUserDefinedTypeExtensionsStringin classorg.hibernate.dialect.Dialect
-
rowId
-
rowIdSqlType
public int rowIdSqlType()- Overrides:
rowIdSqlTypein classorg.hibernate.dialect.Dialect
-
getDmlTargetColumnQualifierSupport
public org.hibernate.dialect.DmlTargetColumnQualifierSupport getDmlTargetColumnQualifierSupport()- Overrides:
getDmlTargetColumnQualifierSupportin classorg.hibernate.dialect.Dialect
-
supportsFromClauseInUpdate
public boolean supportsFromClauseInUpdate()- Overrides:
supportsFromClauseInUpdatein classorg.hibernate.dialect.Dialect
-
getDual
- Overrides:
getDualin classorg.hibernate.dialect.Dialect
-
getFromDualForSelectOnly
- Overrides:
getFromDualForSelectOnlyin classorg.hibernate.dialect.Dialect
-
supportsRowValueConstructorSyntax
public boolean supportsRowValueConstructorSyntax()- Overrides:
supportsRowValueConstructorSyntaxin classorg.hibernate.dialect.Dialect
-
supportsWithClauseInSubquery
public boolean supportsWithClauseInSubquery()- Overrides:
supportsWithClauseInSubqueryin classorg.hibernate.dialect.Dialect
-
supportsRowValueConstructorSyntaxInQuantifiedPredicates
public boolean supportsRowValueConstructorSyntaxInQuantifiedPredicates()- Overrides:
supportsRowValueConstructorSyntaxInQuantifiedPredicatesin classorg.hibernate.dialect.Dialect
-
supportsRowValueConstructorSyntaxInInList
public boolean supportsRowValueConstructorSyntaxInInList()- Overrides:
supportsRowValueConstructorSyntaxInInListin classorg.hibernate.dialect.Dialect
-
supportsRowValueConstructorSyntaxInInSubQuery
public boolean supportsRowValueConstructorSyntaxInInSubQuery()- Overrides:
supportsRowValueConstructorSyntaxInInSubQueryin classorg.hibernate.dialect.Dialect
-