Package org.umlg.sqlg.dialect.impl
Class PostgresDialect
java.lang.Object
org.umlg.sqlg.sql.dialect.BaseSqlDialect
org.umlg.sqlg.dialect.impl.PostgresDialect
- All Implemented Interfaces:
SqlBulkDialect,SqlDialect,SqlSchemaChangeDialect
Date: 2014/07/16
Time: 1:42 PM
-
Field Summary
Fields inherited from class org.umlg.sqlg.sql.dialect.BaseSqlDialect
loggerFields inherited from interface org.umlg.sqlg.sql.dialect.SqlDialect
INDEX_POSTFIX -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionalterForeignKeyToDeferrable(String schema, String table, String foreignKeyName) voidalterSequenceCacheSize(SqlgGraph sqlgGraph, SchemaTable schemaTable, String sequence, int batchSize) voidassertTableName(String tableName) <L,R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable out, SchemaTable in, String edgeLabel, org.apache.commons.lang3.tuple.Pair<String, String> idFields, Collection<org.apache.commons.lang3.tuple.Pair<L, R>> uids, Map<String, PropertyDefinition> edgeColumns, Map<String, Object> edgePropertyMap) checkConstraintName(SqlgGraph sqlgGraph, String schema, String table, String column, String constraint) constructCompleteCopyCommandSqlEdge(SqlgGraph sqlgGraph, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap) constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, String schema, String table, Set<String> keys) constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) constructCompleteCopyCommandTemporarySqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) convertArray(PropertyType propertyType, Array array) createSchemaStatement(String schemaName) longcurrSequenceVal(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) drop(SqlgGraph sqlgGraph, String leafElementsToDelete, String edgesToDelete, LinkedList<SchemaTableTree> distinctQueryStack) drop(EdgeLabel edgeLabel, Collection<RecordId.ID> ids) drop(VertexLabel vertexLabel, Collection<RecordId.ID> ids) dropWithForeignKey(boolean out, EdgeLabel edgeLabel, VertexLabel vertexLabel, Collection<RecordId.ID> ids, boolean mutatingCallbacks) existIndexQuery(SchemaTable schemaTable, String prefix, String indexName) extractIndices(Connection conn, String catalog, String schema) voidflushEdgeCache(SqlgGraph sqlgGraph, Map<MetaEdge, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, org.apache.commons.lang3.tuple.Triple<SqlgVertex, SqlgVertex, Map<String, Object>>>>> edgeCache) voidflushEdgePropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) voidflushVertexCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) flushes the cache via the copy command.voidflushVertexPropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> schemaVertexPropertyCache) getArrayContainsQueryText(String column) getArrayDriverType(PropertyType propertyType) getArrayOverlapsQueryText(String column) getBlocked(int pid, Connection connection) intgetConnectionBackendPid(Connection connection) getFullTextQueryText(FullText fullText, String column) <X> XintintintintgetPartitions(Connection connection) intgetShardCount(SqlgGraph sqlgGraph, AbstractLabel label) voidvoidhandleOther(Map<String, Object> properties, String columnName, Object o, PropertyType propertyType) booleanbooleanisSystemIndex(String indexName) booleanisTimestampz(String typeName) voidvoidlockTable(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) booleanbooleanlongnextSequenceVal(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) intnotifyChange(SqlgGraph sqlgGraph, LocalDateTime timestamp, com.fasterxml.jackson.databind.JsonNode jsonNode) voidprepareDB(Connection conn) int[]propertyTypeToJavaSqlType(PropertyType propertyType) String[]propertyTypeToSqlDefinition(PropertyType propertyType) voidregisterListener(SqlgGraph sqlgGraph) voidregisterTypes(SqlgGraph sqlgGraph, int propertyTypeOrdinal) sequenceName(SqlgGraph sqlgGraph, SchemaTable outSchemaTable, String prefix) voidsetArray(PreparedStatement statement, int index, PropertyType type, Object[] values) voidsetGeographyPoint(PreparedStatement preparedStatement, int parameterStartIndex, Object point) voidsetJson(PreparedStatement preparedStatement, int parameterStartIndex, com.fasterxml.jackson.databind.JsonNode json) voidsetLineString(PreparedStatement preparedStatement, int parameterStartIndex, Object lineString) voidsetLquery(PreparedStatement preparedStatement, int parameterStartIndex, String path) voidsetLqueryArray(PreparedStatement preparedStatement, int parameterStartIndex, Array paths) voidsetLtree(PreparedStatement preparedStatement, int parameterStartIndex, String path) voidsetLtreeArray(PreparedStatement preparedStatement, int parameterStartIndex, Array paths) voidsetPoint(PreparedStatement preparedStatement, int parameterStartIndex, Object point) voidsetPolygon(PreparedStatement preparedStatement, int parameterStartIndex, Object polygon) sqlArrayTypeNameToPropertyType(String typeName, SqlgGraph sqlgGraph, String schema, String table, String columnName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) intsqlTruncate(SqlgGraph sqlgGraph, SchemaTable schemaTable) sqlTypeToPropertyType(SqlgGraph sqlgGraph, String schema, String table, String column, int sqlType, String typeName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) This is only used for upgrading from pre sqlg_schema sqlg to a sqlg_schemabooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleanbooleansupportsType(PropertyType propertyType) temporaryTableCopyCommandSqlVertex(SqlgGraph sqlgGraph, SchemaTable schemaTable, Set<String> keys) voidvoidvalidateColumnName(String column) voidvalidateProperty(Object key, Object value) voidvalidateSchemaName(String schema) voidvalidateTableName(String table) valueToValuesString(PropertyType propertyType, Object value) voidwriteStreamingEdge(Writer writer, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap, EdgeLabel edgeLabel) voidwriteStreamingVertex(Writer writer, Map<String, Object> keyValueMap, VertexLabel vertexLabel) voidwriteTemporaryStreamingVertex(Writer writer, Map<String, Object> keyValueMap) Methods inherited from class org.umlg.sqlg.sql.dialect.BaseSqlDialect
escapeQuotes, flushRemovedEdges, flushRemovedVertices, getEdgeTables, getIndexInfo, getPrimaryKeys, getSchemaNames, getTableColumns, getVertexTablesMethods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.umlg.sqlg.sql.dialect.SqlBulkDialect
flushRemovedEdges, flushRemovedVerticesMethods inherited from interface org.umlg.sqlg.sql.dialect.SqlDialect
addColumnStatement, addDbVersionToGraph, addNotNullConstraint, canUserCreateSchemas, createTableStatement, createTemporaryTableStatement, dropIndex, dropSchemaStatement, getDefaultFetchSize, getEdgeTables, getIndexInfo, getPrimaryKeys, getPrimaryKeyStartValue, getPublicSchema, getRangeClause, getSchemaNames, getSkipClause, getTableColumns, getVertexTables, hasContainerKeyToColumn, indexName, indexName, isH2, isHsqldb, isIndexPartOfCreateTable, isMariaDb, isMssqlServer, isMysql, maybeWrapInQoutes, needsSchemaCreationPrecommit, needsSchemaDropCascade, needsSemicolon, needsTemporaryTablePrefix, needsTemporaryTableSchema, putJsonMetaObject, putJsonObject, renameColumn, renameTable, requiresIndexLengthLimit, requiresIndexName, schemaExists, sqlgSqlgSchemaCreationScript, sqlInsertEmptyValues, sqlToTurnOffReferentialConstraintCheck, sqlToTurnOnReferentialConstraintCheck, supportsBigDecimal, supportsBigDecimalArrayValues, supportsBooleanArrayValues, supportsByteArrayValues, supportsByteValues, supportsCascade, supportsDoubleArrayValues, supportsDurationArrayValues, supportsFloatArrayValues, supportsFloatValues, supportsFullValueExpression, supportsIfExists, supportsIntegerArrayValues, supportsLocalDateArrayValues, supportsLocalDateTimeArrayValues, supportsLocalTimeArrayValues, supportsLongArrayValues, supportsPeriodArrayValues, supportsSchemaIfNotExists, supportsSchemas, supportsShortArrayValues, supportsStringArrayValues, supportsTemporaryTableOnCommitDrop, supportsTransactionalSchema, supportsUUID, supportsValuesExpression, supportsZonedDateTimeArrayValues, temporaryTablePrefix, toByteArray, toRDBSStringLiteral, toRDBSStringLiteral, toSelectString, uniqueIndexConsidersNullValuesEqual
-
Constructor Details
-
PostgresDialect
public PostgresDialect()
-
-
Method Details
-
supportsDistribution
public boolean supportsDistribution()- Specified by:
supportsDistributionin interfaceSqlDialect
-
dialectName
- Specified by:
dialectNamein interfaceSqlDialect
-
createSchemaStatement
- Specified by:
createSchemaStatementin interfaceSqlDialect
-
supportsBatchMode
public boolean supportsBatchMode()- Specified by:
supportsBatchModein interfaceSqlDialect
-
supportsStreamingBatchMode
public boolean supportsStreamingBatchMode()- Specified by:
supportsStreamingBatchModein interfaceSqlDialect
-
getInternalSchemas
- Specified by:
getInternalSchemasin interfaceSqlDialect
-
getSpacialRefTable
- Specified by:
getSpacialRefTablein interfaceSqlDialect
-
getGisSchemas
- Specified by:
getGisSchemasin interfaceSqlDialect
-
getForeignKeyTypeDefinition
- Specified by:
getForeignKeyTypeDefinitionin interfaceSqlDialect
-
getColumnEscapeKey
- Specified by:
getColumnEscapeKeyin interfaceSqlDialect
-
getPrimaryKeyType
- Specified by:
getPrimaryKeyTypein interfaceSqlDialect
-
getAutoIncrementPrimaryKeyConstruct
- Specified by:
getAutoIncrementPrimaryKeyConstructin interfaceSqlDialect
-
getAutoIncrement
- Specified by:
getAutoIncrementin interfaceSqlDialect
-
assertTableName
- Specified by:
assertTableNamein interfaceSqlDialect
-
getArrayDriverType
- Specified by:
getArrayDriverTypein interfaceSqlDialect
-
existIndexQuery
- Specified by:
existIndexQueryin interfaceSqlDialect
-
flushVertexCache
public void flushVertexCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) flushes the cache via the copy command.- Specified by:
flushVertexCachein interfaceSqlBulkDialect- Overrides:
flushVertexCachein classBaseSqlDialect- Parameters:
vertexCache- A rather complex object. The map's key is the vertex being cached. The Triple holds,- The in labels
- The out labels
- the properties as a map of key values
-
flushEdgeCache
public void flushEdgeCache(SqlgGraph sqlgGraph, Map<MetaEdge, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, org.apache.commons.lang3.tuple.Triple<SqlgVertex, SqlgVertex, Map<String, Object>>>>> edgeCache) - Specified by:
flushEdgeCachein interfaceSqlBulkDialect- Overrides:
flushEdgeCachein classBaseSqlDialect
-
flushVertexPropertyCache
public void flushVertexPropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> schemaVertexPropertyCache) - Specified by:
flushVertexPropertyCachein interfaceSqlBulkDialect- Overrides:
flushVertexPropertyCachein classBaseSqlDialect
-
flushEdgePropertyCache
public void flushEdgePropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) - Specified by:
flushEdgePropertyCachein interfaceSqlBulkDialect- Overrides:
flushEdgePropertyCachein classBaseSqlDialect
-
constructCompleteCopyCommandTemporarySqlVertex
public String constructCompleteCopyCommandTemporarySqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) - Specified by:
constructCompleteCopyCommandTemporarySqlVertexin interfaceSqlBulkDialect
-
constructCompleteCopyCommandSqlVertex
public String constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) - Specified by:
constructCompleteCopyCommandSqlVertexin interfaceSqlBulkDialect
-
constructCompleteCopyCommandSqlVertex
public String constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, String schema, String table, Set<String> keys) - Specified by:
constructCompleteCopyCommandSqlVertexin interfaceSqlBulkDialect
-
constructCompleteCopyCommandSqlEdge
public String constructCompleteCopyCommandSqlEdge(SqlgGraph sqlgGraph, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap) - Specified by:
constructCompleteCopyCommandSqlEdgein interfaceSqlBulkDialect
-
temporaryTableCopyCommandSqlVertex
public String temporaryTableCopyCommandSqlVertex(SqlgGraph sqlgGraph, SchemaTable schemaTable, Set<String> keys) - Specified by:
temporaryTableCopyCommandSqlVertexin interfaceSqlBulkDialect
-
writeStreamingVertex
public void writeStreamingVertex(Writer writer, Map<String, Object> keyValueMap, VertexLabel vertexLabel) - Specified by:
writeStreamingVertexin interfaceSqlBulkDialect
-
writeTemporaryStreamingVertex
- Specified by:
writeTemporaryStreamingVertexin interfaceSqlBulkDialect
-
writeStreamingEdge
public void writeStreamingEdge(Writer writer, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap, EdgeLabel edgeLabel) - Specified by:
writeStreamingEdgein interfaceSqlBulkDialect
-
getBatchNull
- Specified by:
getBatchNullin interfaceSqlBulkDialect
-
propertyTypeToSqlDefinition
- Specified by:
propertyTypeToSqlDefinitionin interfaceSqlDialect
-
sqlTypeToPropertyType
public PropertyType sqlTypeToPropertyType(SqlgGraph sqlgGraph, String schema, String table, String column, int sqlType, String typeName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) This is only used for upgrading from pre sqlg_schema sqlg to a sqlg_schema- Specified by:
sqlTypeToPropertyTypein interfaceSqlDialect
-
sqlArrayTypeNameToPropertyType
public PropertyType sqlArrayTypeNameToPropertyType(String typeName, SqlgGraph sqlgGraph, String schema, String table, String columnName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) - Specified by:
sqlArrayTypeNameToPropertyTypein interfaceSqlDialect
-
propertyTypeToJavaSqlType
- Specified by:
propertyTypeToJavaSqlTypein interfaceSqlDialect
-
validateProperty
- Specified by:
validatePropertyin interfaceSqlDialect
-
needForeignKeyIndex
public boolean needForeignKeyIndex()- Specified by:
needForeignKeyIndexin interfaceSqlDialect
-
supportsClientInfo
public boolean supportsClientInfo()- Specified by:
supportsClientInfoin interfaceSqlDialect
-
validateSchemaName
- Specified by:
validateSchemaNamein interfaceSqlDialect
-
validateTableName
- Specified by:
validateTableNamein interfaceSqlDialect
-
validateColumnName
- Specified by:
validateColumnNamein interfaceSqlDialect- Overrides:
validateColumnNamein classBaseSqlDialect
-
getMaximumSchemaNameLength
public int getMaximumSchemaNameLength()- Specified by:
getMaximumSchemaNameLengthin interfaceSqlDialect
-
getMaximumTableNameLength
public int getMaximumTableNameLength()- Specified by:
getMaximumTableNameLengthin interfaceSqlDialect
-
getMaximumColumnNameLength
public int getMaximumColumnNameLength()- Specified by:
getMaximumColumnNameLengthin interfaceSqlDialect
-
getMaximumIndexNameLength
public int getMaximumIndexNameLength()- Specified by:
getMaximumIndexNameLengthin interfaceSqlDialect
-
supportsILike
public boolean supportsILike()- Specified by:
supportsILikein interfaceSqlDialect
-
needsTimeZone
public boolean needsTimeZone()- Specified by:
needsTimeZonein interfaceSqlDialect
-
setJson
public void setJson(PreparedStatement preparedStatement, int parameterStartIndex, com.fasterxml.jackson.databind.JsonNode json) - Specified by:
setJsonin interfaceSqlDialect- Overrides:
setJsonin classBaseSqlDialect
-
setLtree
- Specified by:
setLtreein interfaceSqlDialect
-
setLquery
- Specified by:
setLqueryin interfaceSqlDialect
-
setLtreeArray
public void setLtreeArray(PreparedStatement preparedStatement, int parameterStartIndex, Array paths) - Specified by:
setLtreeArrayin interfaceSqlDialect
-
setLqueryArray
public void setLqueryArray(PreparedStatement preparedStatement, int parameterStartIndex, Array paths) - Specified by:
setLqueryArrayin interfaceSqlDialect
-
setPoint
- Specified by:
setPointin interfaceSqlDialect
-
setLineString
public void setLineString(PreparedStatement preparedStatement, int parameterStartIndex, Object lineString) - Specified by:
setLineStringin interfaceSqlDialect
-
setPolygon
public void setPolygon(PreparedStatement preparedStatement, int parameterStartIndex, Object polygon) - Specified by:
setPolygonin interfaceSqlDialect
-
setGeographyPoint
public void setGeographyPoint(PreparedStatement preparedStatement, int parameterStartIndex, Object point) - Specified by:
setGeographyPointin interfaceSqlDialect
-
registerTypes
- Specified by:
registerTypesin interfaceSqlDialect
-
handleOther
public void handleOther(Map<String, Object> properties, String columnName, Object o, PropertyType propertyType) - Specified by:
handleOtherin interfaceSqlDialect- Overrides:
handleOtherin classBaseSqlDialect
-
supportsJsonType
public boolean supportsJsonType()- Specified by:
supportsJsonTypein interfaceSqlDialect
-
supportsJsonArrayValues
public boolean supportsJsonArrayValues()- Specified by:
supportsJsonArrayValuesin interfaceSqlDialect
-
streamSql
- Specified by:
streamSqlin interfaceSqlBulkDialect
-
bulkAddEdges
public <L,R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable out, SchemaTable in, String edgeLabel, org.apache.commons.lang3.tuple.Pair<String, String> idFields, Collection<org.apache.commons.lang3.tuple.Pair<L, R>> uids, Map<String, PropertyDefinition> edgeColumns, Map<String, Object> edgePropertyMap) - Specified by:
bulkAddEdgesin interfaceSqlBulkDialect
-
lockTable
- Specified by:
lockTablein interfaceSqlDialect
-
alterSequenceCacheSize
public void alterSequenceCacheSize(SqlgGraph sqlgGraph, SchemaTable schemaTable, String sequence, int batchSize) - Specified by:
alterSequenceCacheSizein interfaceSqlDialect
-
nextSequenceVal
- Specified by:
nextSequenceValin interfaceSqlDialect
-
currSequenceVal
- Specified by:
currSequenceValin interfaceSqlDialect
-
sequenceName
- Specified by:
sequenceNamein interfaceSqlDialect
-
supportsBulkWithinOut
public boolean supportsBulkWithinOut()- Specified by:
supportsBulkWithinOutin interfaceSqlDialect
-
isPostgresql
public boolean isPostgresql()- Specified by:
isPostgresqlin interfaceSqlDialect
-
getGis
- Specified by:
getGisin interfaceSqlDialect
-
afterCreateTemporaryTableStatement
- Specified by:
afterCreateTemporaryTableStatementin interfaceSqlDialect
-
columnsToIgnore
- Specified by:
columnsToIgnorein interfaceSqlDialect
-
sqlgTopologyCreationScripts
- Specified by:
sqlgTopologyCreationScriptsin interfaceSqlDialect
-
sqlgCreateTopologyGraph
- Specified by:
sqlgCreateTopologyGraphin interfaceSqlDialect
-
sqlgAddIndexEdgeSequenceColumn
- Specified by:
sqlgAddIndexEdgeSequenceColumnin interfaceSqlDialect
-
addHashPartitionColumns
- Specified by:
addHashPartitionColumnsin interfaceSqlDialect
-
addPartitionSchemaAbstractLabelColumns
- Specified by:
addPartitionSchemaAbstractLabelColumnsin interfaceSqlDialect
-
addPartitionTables
- Specified by:
addPartitionTablesin interfaceSqlDialect
-
convertArray
- Specified by:
convertArrayin interfaceSqlDialect- Throws:
SQLException
-
setArray
public void setArray(PreparedStatement statement, int index, PropertyType type, Object[] values) throws SQLException - Specified by:
setArrayin interfaceSqlDialect- Throws:
SQLException
-
prepareDB
- Specified by:
prepareDBin interfaceSqlDialect
-
getConnectionBackendPid
- Specified by:
getConnectionBackendPidin interfaceSqlDialect
-
getBlocked
public org.apache.commons.lang3.tuple.Pair<Boolean,String> getBlocked(int pid, Connection connection) - Specified by:
getBlockedin interfaceSqlDialect
-
lock
- Specified by:
lockin interfaceSqlSchemaChangeDialect
-
registerListener
- Specified by:
registerListenerin interfaceSqlSchemaChangeDialect
-
unregisterListener
public void unregisterListener()- Specified by:
unregisterListenerin interfaceSqlSchemaChangeDialect
-
notifyChange
public int notifyChange(SqlgGraph sqlgGraph, LocalDateTime timestamp, com.fasterxml.jackson.databind.JsonNode jsonNode) - Specified by:
notifyChangein interfaceSqlSchemaChangeDialect
-
getFullTextQueryText
- Specified by:
getFullTextQueryTextin interfaceSqlDialect
-
getArrayContainsQueryText
- Specified by:
getArrayContainsQueryTextin interfaceSqlDialect
-
getArrayOverlapsQueryText
- Specified by:
getArrayOverlapsQueryTextin interfaceSqlDialect
-
extractIndices
public Map<String,Set<IndexRef>> extractIndices(Connection conn, String catalog, String schema) throws SQLException - Specified by:
extractIndicesin interfaceSqlDialect- Throws:
SQLException
-
isSystemIndex
- Specified by:
isSystemIndexin interfaceSqlDialect
-
valueToValuesString
- Specified by:
valueToValuesStringin interfaceSqlDialect
-
supportsType
- Specified by:
supportsTypein interfaceSqlDialect
-
sqlInParameterLimit
public int sqlInParameterLimit()- Specified by:
sqlInParameterLimitin interfaceSqlDialect- Overrides:
sqlInParameterLimitin classBaseSqlDialect
-
drop
public List<SqlgSqlExecutor.DropQuery> drop(SqlgGraph sqlgGraph, String leafElementsToDelete, String edgesToDelete, LinkedList<SchemaTableTree> distinctQueryStack) - Specified by:
dropin interfaceSqlDialect
-
drop
- Specified by:
dropin interfaceSqlDialect
-
drop
- Specified by:
dropin interfaceSqlDialect
-
dropWithForeignKey
public String dropWithForeignKey(boolean out, EdgeLabel edgeLabel, VertexLabel vertexLabel, Collection<RecordId.ID> ids, boolean mutatingCallbacks) - Specified by:
dropWithForeignKeyin interfaceSqlDialect
-
supportsDeferrableForeignKey
public boolean supportsDeferrableForeignKey()- Specified by:
supportsDeferrableForeignKeyin interfaceSqlDialect
-
sqlToGetAllForeignKeys
- Specified by:
sqlToGetAllForeignKeysin interfaceSqlDialect
-
alterForeignKeyToDeferrable
- Specified by:
alterForeignKeyToDeferrablein interfaceSqlDialect
-
sqlTruncate
- Specified by:
sqlTruncatein interfaceSqlDialect
-
supportsTruncateMultipleTablesTogether
public boolean supportsTruncateMultipleTablesTogether()- Specified by:
supportsTruncateMultipleTablesTogetherin interfaceSqlDialect
-
supportsPartitioning
public boolean supportsPartitioning()- Specified by:
supportsPartitioningin interfaceSqlDialect
-
getPartitions
- Specified by:
getPartitionsin interfaceSqlDialect
-
supportsSharding
public boolean supportsSharding()- Specified by:
supportsShardingin interfaceSqlDialect
-
getShardCount
- Specified by:
getShardCountin interfaceSqlDialect
-
grantReadOnlyUserPrivilegesToSqlgSchemas
- Specified by:
grantReadOnlyUserPrivilegesToSqlgSchemasin interfaceSqlDialect
-
isTimestampz
- Specified by:
isTimestampzin interfaceSqlDialect
-
addPropertyDefinitions
- Specified by:
addPropertyDefinitionsin interfaceSqlDialect
-
addOutEdgeDefinitions
- Specified by:
addOutEdgeDefinitionsin interfaceSqlDialect
-
addInEdgeDefinitions
- Specified by:
addInEdgeDefinitionsin interfaceSqlDialect
-
checkConstraintName
public String checkConstraintName(SqlgGraph sqlgGraph, String schema, String table, String column, String constraint) - Specified by:
checkConstraintNamein interfaceSqlDialect
-