Class CockroachDB202SpatialDialect
- java.lang.Object
-
- org.hibernate.dialect.Dialect
-
- org.hibernate.dialect.CockroachDB192Dialect
-
- org.hibernate.dialect.CockroachDB201Dialect
-
- org.hibernate.spatial.dialect.cockroachdb.CockroachDB202SpatialDialect
-
- All Implemented Interfaces:
java.io.Serializable,ConversionContext,CockroachSpatialDialectTrait,SpatialDialect
public class CockroachDB202SpatialDialect extends CockroachDB201Dialect implements CockroachSpatialDialectTrait
An @{code SpatialDialect} for CockroachDB 20.2 and later. CockroachDB's spatial features where introduced in that version.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.hibernate.dialect.Dialect
CLOSED_QUOTE, DEFAULT_BATCH_SIZE, LEGACY_LOB_MERGE_STRATEGY, NEW_LOCATOR_LOB_MERGE_STRATEGY, NO_BATCH, QUOTE, STANDARD_DEFAULT_BATCH_LOAD_SIZING_STRATEGY, STREAM_XFER_LOB_MERGE_STRATEGY, TWO_SINGLE_QUOTES_REPLACEMENT
-
Fields inherited from interface org.hibernate.spatial.dialect.cockroachdb.CockroachSpatialDialectTrait
DELEGATE
-
-
Constructor Summary
Constructors Constructor Description CockroachDB202SpatialDialect()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidcontributeTypes(TypeContributions typeContributions, ServiceRegistry serviceRegistry)Allows the Dialect to contribute additional typesbooleanequivalentTypes(int typeCode1, int typeCode2)Do the given JDBC type codes, as defined inTypesrepresent essentially the same type in this dialect of SQL? The default implementation treatsNUMERICandDECIMALas the same type, andFLOAT,REAL, andDOUBLEas essentially the same type, since the ANSI SQL specification fails to meaningfully distinguish them.-
Methods inherited from class org.hibernate.dialect.CockroachDB192Dialect
bindLimitParametersInReverseOrder, buildIdentifierHelper, buildSQLExceptionConversionDelegate, canCreateSchema, doesReadCommittedCauseWritersToBlockReaders, dropConstraints, getAddColumnString, getCascadeConstraintsString, getCaseInsensitiveLike, getCreateSequenceString, getCreateSequenceString, getCurrentTimestampSelectString, getDefaultMultiTableBulkIdStrategy, getDropSequenceString, getForUpdateNowaitString, getForUpdateNowaitString, getForUpdateSkipLockedString, getForUpdateSkipLockedString, getForUpdateString, getForUpdateString, getForUpdateString, getIdentityColumnSupport, getLimitHandler, getLimitString, getNameQualifierSupport, getNativeIdentifierGeneratorStrategy, getNoColumnsInsertString, getQuerySequencesString, getReadLockString, getReadLockString, getSelectClauseNullString, getSelectSequenceNextValString, getSequenceNextValString, getSqlTypeDescriptorOverride, getViolatedConstraintNameExtracter, getWriteLockString, getWriteLockString, isCurrentTimestampSelectStringCallable, qualifyIndexName, renderOrderByElement, requiresParensForTupleDistinctCounts, supportsCaseInsensitiveLike, supportsCommentOn, supportsCurrentTimestampSelection, supportsEmptyInList, supportsExpectedLobUsagePattern, supportsIfExistsAfterAlterTable, supportsIfExistsBeforeTableName, supportsJdbcConnectionLobCreation, supportsLimit, supportsLobValueChangePropogation, supportsLockTimeouts, supportsNationalizedTypes, supportsNonQueryWithCTE, supportsNoWait, supportsOuterJoinForUpdate, supportsPartitionBy, supportsPooledSequences, supportsRowValueConstructorSyntax, supportsRowValueConstructorSyntaxInInList, supportsSelectAliasInGroupByClause, supportsSequences, supportsSkipLocked, supportsUnboundedLobLocatorMaterialization, supportsUnionAll, supportsValuesList, toBooleanValueString, useInputStreamToInsertBlob
-
Methods inherited from class org.hibernate.dialect.Dialect
addSqlHintOrComment, appendLockHint, appendLockHint, applyLocksToSql, areStringComparisonsCaseInsensitive, augmentPhysicalTableTypes, augmentRecognizedTableTypes, bindLimitParametersFirst, buildSQLExceptionConverter, canCreateCatalog, cast, cast, cast, closeQuote, convertToFirstRowValue, createCaseFragment, createOuterJoinFragment, defaultScrollMode, doesRepeatableReadCauseReadersToBlockWriters, escapeComment, escapeLiteral, forceLimitUsage, forceLobAsLastValue, forUpdateOfColumns, getAddColumnSuffixString, getAddForeignKeyConstraintString, getAddForeignKeyConstraintString, getAddPrimaryKeyConstraintString, getAddUniqueConstraintString, getAlterTableString, getAuxiliaryDatabaseObjectExporter, getCallableStatementSupport, getCastTypeName, getColumnAliasExtractor, getColumnComment, getCreateCatalogCommand, getCreateMultisetTableString, getCreateSchemaCommand, getCreateSequenceStrings, getCreateSequenceStrings, getCreateTableString, getCreateTemporaryTableColumnAnnotation, getCrossJoinSeparator, getCurrentSchemaCommand, getCurrentTimestampSQLFunctionName, getDefaultBatchLoadSizingStrategy, getDefaultProperties, getDialect, getDialect, getDropCatalogCommand, getDropForeignKeyString, getDropSchemaCommand, getDropSequenceStrings, getDropTableString, getForeignKeyExporter, getForUpdateString, getForUpdateString, getFunctions, getHibernateTypeName, getHibernateTypeName, getIndexExporter, getInExpressionCountLimit, getKeywords, getLimitString, getLobMergeStrategy, getLockingStrategy, getLowercaseFunction, getMaxAliasLength, getNativeIdentifierGeneratorClass, getNotExpression, getNullColumnString, getQueryHintString, getQueryHintString, getResultSet, getResultSet, getResultSet, getSchemaNameResolver, getSelectGUIDString, getSequenceExporter, getSequenceInformationExtractor, getTableComment, getTableExporter, getTableTypeString, getTypeName, getTypeName, getUniqueDelegate, getUniqueKeyExporter, hasAlterTable, hasSelfReferentialForeignKeyBug, inlineLiteral, isJdbcLogWarningsEnabledByDefault, isLegacyLimitHandlerBehaviorEnabled, isLockTimeoutParameterized, isTypeNameRegistered, openQuote, prependComment, quote, registerColumnType, registerColumnType, registerFunction, registerHibernateType, registerHibernateType, registerKeyword, registerResultSetOutParameter, registerResultSetOutParameter, remapSqlTypeDescriptor, replaceResultVariableInOrderByClauseWithPosition, requiresCastingOfParametersInSelectClause, supportsBindAsCallableArgument, supportsCascadeDelete, supportsCircularCascadeDeleteConstraints, supportsColumnCheck, supportsExistsInSelect, supportsIfExistsAfterConstraintName, supportsIfExistsAfterTableName, supportsIfExistsBeforeConstraintName, supportsLimitOffset, supportsNamedParameters, supportsNoColumnsInsert, supportsNotNullUnique, supportsParametersInInsertSelect, supportsResultSetPositionQueryMethodsOnForwardOnlyCursor, supportsRowValueConstructorSyntaxInSet, supportsSubqueryOnMutatingTable, supportsSubselectAsInPredicateLHS, supportsTableCheck, supportsTupleCounts, supportsTupleDistinctCounts, supportsTuplesInSubqueries, supportsUnique, supportsUniqueConstraintInCreateAlterTable, supportsVariableLimit, toString, transformSelectString, useFollowOnLocking, useFollowOnLocking, useMaxForLimit
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.hibernate.spatial.dialect.cockroachdb.CockroachSpatialDialectTrait
delegateContributeTypes, functionsToRegister, getDWithinSQL, getHavingSridSQL, getIsEmptySQL, getSpatialAggregateSQL, getSpatialFilterExpression, getSpatialRelateSQL, isSpatial, supports, supportsFiltering
-
-
-
-
Method Detail
-
contributeTypes
public void contributeTypes(TypeContributions typeContributions, ServiceRegistry serviceRegistry)
Description copied from class:DialectAllows the Dialect to contribute additional types- Overrides:
contributeTypesin classCockroachDB192Dialect- Parameters:
typeContributions- Callback to contribute the typesserviceRegistry- The service registry
-
equivalentTypes
public boolean equivalentTypes(int typeCode1, int typeCode2)Description copied from class:DialectDo the given JDBC type codes, as defined inTypesrepresent essentially the same type in this dialect of SQL? The default implementation treatsNUMERICandDECIMALas the same type, andFLOAT,REAL, andDOUBLEas essentially the same type, since the ANSI SQL specification fails to meaningfully distinguish them.- Overrides:
equivalentTypesin classDialect- Parameters:
typeCode1- the first JDBC type codetypeCode2- the second JDBC type code- Returns:
trueif the two type codes are equivalent
-
-