Uses of Class
org.umlg.sqlg.structure.SqlgGraph
Package
Description
-
Uses of SqlgGraph in org.umlg.sqlg.sql.dialect
Modifier and TypeMethodDescriptiondefault String
SqlDialect.addNotNullConstraint
(SqlgGraph sqlgGraph, String schema, String table, String column, PropertyType propertyType) void
SqlDialect.alterSequenceCacheSize
(SqlgGraph sqlgGraph, SchemaTable schemaTable, String sequence, int batchSize) default <L,
R> void SqlBulkDialect.bulkAddEdges
(SqlgGraph sqlgGraph, SchemaTable in, SchemaTable out, 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) default boolean
SqlDialect.canUserCreateSchemas
(SqlgGraph sqlgGraph) This is only needed for Hsqldb where we are unable to check for the existence of Sqlg's schemasdefault String
SqlDialect.checkConstraintName
(SqlgGraph sqlgGraph, String schema, String table, String column, String constraint) default String
SqlBulkDialect.constructCompleteCopyCommandSqlEdge
(SqlgGraph sqlgGraph, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap) default String
SqlBulkDialect.constructCompleteCopyCommandSqlVertex
(SqlgGraph sqlgGraph, String schema, String table, Set<String> keys) default String
SqlBulkDialect.constructCompleteCopyCommandSqlVertex
(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) default String
SqlBulkDialect.constructCompleteCopyCommandTemporarySqlVertex
(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) long
SqlDialect.currSequenceVal
(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) default List<SqlgSqlExecutor.DropQuery>
SqlDialect.drop
(SqlgGraph sqlgGraph, String leafElementsToDelete, String edgesToDelete, LinkedList<SchemaTableTree> distinctQueryStack) if the query traverses edges then the deletion logic is non trivial.default String
SqlDialect.dropIndex
(SqlgGraph sqlgGraph, AbstractLabel parentLabel, String name) void
BaseSqlDialect.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) void
SqlBulkDialect.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) void
BaseSqlDialect.flushEdgePropertyCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) void
SqlBulkDialect.flushEdgePropertyCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) void
BaseSqlDialect.flushRemovedEdges
(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgEdge>> removeEdgeCache) default void
SqlBulkDialect.flushRemovedEdges
(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgEdge>> removeEdgeCache) void
BaseSqlDialect.flushRemovedVertices
(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgVertex>> removeVertexCache) void
SqlBulkDialect.flushRemovedVertices
(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgVertex>> removeVertexCache) void
BaseSqlDialect.flushVertexCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) void
SqlBulkDialect.flushVertexCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) void
BaseSqlDialect.flushVertexPropertyCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexPropertyCache) void
SqlBulkDialect.flushVertexPropertyCache
(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexPropertyCache) default <T> T
default int
SqlDialect.getShardCount
(SqlgGraph sqlgGraph, AbstractLabel label) default void
SqlDialect.grantReadOnlyUserPrivilegesToSqlgSchemas
(SqlgGraph sqlgGraph) default void
void
SqlDialect.lockTable
(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) long
SqlDialect.nextSequenceVal
(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) default int
SqlSchemaChangeDialect.notifyChange
(SqlgGraph sqlgGraph, LocalDateTime timestamp, com.fasterxml.jackson.databind.JsonNode jsonNode) default void
SqlSchemaChangeDialect.registerListener
(SqlgGraph sqlgGraph) SqlDialect.sequenceName
(SqlgGraph sqlgGraph, SchemaTable outSchemaTable, String prefix) SqlDialect.sqlArrayTypeNameToPropertyType
(String typeName, SqlgGraph sqlgGraph, String schema, String table, String columnName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) "TYPE_NAME" is column meta data returned by the jdbc driver.default List<SqlgSqlExecutor.DropQuery>
SqlDialect.sqlTruncate
(SqlgGraph sqlgGraph, SchemaTable schemaTable) SqlDialect.sqlTypeToPropertyType
(SqlgGraph sqlgGraph, String schema, String table, String column, int sqlType, String typeName, ListIterator<org.apache.commons.lang3.tuple.Triple<String, Integer, String>> metaDataIter) default Writer
default String
SqlBulkDialect.temporaryTableCopyCommandSqlVertex
(SqlgGraph sqlgGraph, SchemaTable schemaTable, Set<String> keys) -
Uses of SqlgGraph in org.umlg.sqlg.sql.parse
Modifier and TypeMethodDescriptionWhereClause.toSql
(SqlgGraph sqlgGraph, SchemaTableTree schemaTableTree, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer) WhereClause.toSql
(SqlgGraph sqlgGraph, SchemaTableTree schemaTableTree, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer, boolean isInAndOrHsContainer) WhereClause.toSql
(SqlgGraph sqlgGraph, SchemaTableTree schemaTableTree, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer, String prefix) WhereClause.toSql
(SqlgGraph sqlgGraph, SchemaTableTree schemaTableTree, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer, String prefix, boolean isInAndOrHsContainer) ModifierConstructorDescriptionColumnList
(SqlgGraph graph, boolean drop, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers, Map<String, Map<String, PropertyDefinition>> filteredAllTables) build a new empty column listGremlinParser
(SqlgGraph sqlgGraph) SchemaTableTree
(SqlgGraph sqlgGraph, SchemaTableTree parent, SchemaTable schemaTable, int stepDepth, List<org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer> hasContainers, List<AndOrHasContainer> andOrHasContainers, SqlgComparatorHolder sqlgComparatorHolder, List<org.javatuples.Pair<org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin<?, ?>, Comparator<?>>> dbComparators, SqlgRangeHolder sqlgRangeHolder, SchemaTableTree.STEP_TYPE stepType, boolean emit, boolean untilFirst, boolean optionalLeftJoin, boolean drop, int replacedStepDepth, Set<String> labels, org.apache.commons.lang3.tuple.Pair<String, List<String>> aggregateFunction, List<String> groupBy, boolean idOnly, RecursiveRepeatStepConfig recursiveRepeatStepConfig) This constructor is called for the root SchemaTableTree(s) -
Uses of SqlgGraph in org.umlg.sqlg.step
ModifierConstructorDescriptionSqlgGraphStep
(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.process.traversal.Traversal.Admin traversal, Class<E> returnClass, boolean isStart, Object... ids) -
Uses of SqlgGraph in org.umlg.sqlg.strategy
Modifier and TypeMethodDescriptionstatic void
SqlgSqlExecutor.executeDrop
(SqlgGraph sqlgGraph, String sql) static void
SqlgSqlExecutor.executeDropEdges
(SqlgGraph sqlgGraph, EdgeLabel edgeLabel, String sql, List<org.apache.tinkerpop.gremlin.process.traversal.step.util.event.EventCallback<org.apache.tinkerpop.gremlin.process.traversal.step.util.event.Event>> mutatingCallbacks) static void
SqlgSqlExecutor.executeDropQuery
(SqlgGraph sqlgGraph, SchemaTableTree rootSchemaTableTree, LinkedList<SchemaTableTree> distinctQueryStack) static org.apache.commons.lang3.tuple.Triple<ResultSet,
ResultSetMetaData, PreparedStatement> SqlgSqlExecutor.executeEmitQuery
(SqlgGraph sqlgGraph, SchemaTableTree rootSchemaTableTree, LinkedList<SchemaTableTree> leftJoinQuery) static org.apache.commons.lang3.tuple.Triple<ResultSet,
ResultSetMetaData, PreparedStatement> SqlgSqlExecutor.executeOptionalQuery
(SqlgGraph sqlgGraph, SchemaTableTree rootSchemaTableTree, org.apache.commons.lang3.tuple.Pair<LinkedList<SchemaTableTree>, Set<SchemaTableTree>> leftJoinQuery) static org.apache.commons.lang3.tuple.Triple<ResultSet,
ResultSetMetaData, PreparedStatement> SqlgSqlExecutor.executeRegularQuery
(SqlgGraph sqlgGraph, SchemaTableTree rootSchemaTableTree, LinkedList<SchemaTableTree> distinctQueryStack) -
Uses of SqlgGraph in org.umlg.sqlg.structure
Modifier and TypeMethodDescriptionstatic RecordId
static SchemaTable
static SchemaTable
static SqlgEdge
static SqlgEdge
static SqlgVertex
static SqlgVertex
static SqlgVertex
static SqlgVertex
SqlgVertex.of
(SqlgGraph sqlgGraph, List<Comparable> identifiers, String schema, String table, int columnCount) ModifierConstructorDescriptionSqlgCompiledResultIterator
(SqlgGraph sqlgGraph, Set<SchemaTableTree> rootSchemaTableTrees) SqlgCompiledResultIterator
(SqlgGraph sqlgGraph, Set<SchemaTableTree> rootSchemaTableTrees, boolean forParent) SqlgEdge
(SqlgGraph sqlgGraph, List<Comparable> identifiers, String schema, String table, int numberOfColumns) SqlgElement
(SqlgGraph sqlgGraph, Long id, String schema, String table) SqlgElement
(SqlgGraph sqlgGraph, Long id, String schema, String table, int columnCount) SqlgElement
(SqlgGraph sqlgGraph, String schema, String table) SqlgElement
(SqlgGraph sqlgGraph, List<Comparable> identifiers, String schema, String table) SqlgElement
(SqlgGraph sqlgGraph, List<Comparable> identifiers, String schema, String table, int columnCount) SqlgVertex
(SqlgGraph sqlgGraph, VertexLabel vertexLabel, String schema, String table, Map<String, Object> keyValueMap) SqlgVertex
(SqlgGraph sqlgGraph, VertexLabel vertexLabel, SchemaTable schemaTable, Map<String, Object> keyValueMap) Used for streamingVertex -
Uses of SqlgGraph in org.umlg.sqlg.structure.topology
Modifier and TypeMethodDescriptionstatic void
TopologyManager.addEdgeColumn
(SqlgGraph sqlgGraph, String schema, String prefixedTable, Map<String, PropertyDefinition> column, org.apache.commons.collections4.set.ListOrderedSet<String> primaryKeys) static org.apache.tinkerpop.gremlin.structure.Vertex
TopologyManager.addEdgeLabel
(SqlgGraph sqlgGraph, String prefixedTable, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addEdgeLabelPartition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static void
static void
TopologyManager.addIndex
(SqlgGraph sqlgGraph, String schema, String label, boolean vertex, String index, IndexType indexType, List<String> properties) add an index from information schemastatic void
static void
TopologyManager.addLabelToEdge
(SqlgGraph sqlgGraph, String schema, String prefixedTable, boolean in, SchemaTable foreignKey, EdgeDefinition edgeDefinition) static void
TopologyManager.addLabelToEdgeFromInformationSchema
(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.structure.Vertex edgeVertex, String schema, String prefixedTable, boolean in, SchemaTable foreignKey) static void
static void
TopologyManager.addSubPartition
(SqlgGraph sqlgGraph, boolean isSubSubPartition, boolean isVertexLabel, String schema, String abstractLabel, String partitionParent, String partitionName, PartitionType partitionType, String partitionExpression, String from, String to, String in, Integer modulus, Integer remainder) static void
TopologyManager.addSubPartition
(SqlgGraph sqlgGraph, Partition partition) Adds the partition to a partition.static void
TopologyManager.addVertexColumn
(SqlgGraph sqlgGraph, String schema, String prefixedTable, Map.Entry<String, PropertyDefinition> column) static void
TopologyManager.addVertexLabel
(SqlgGraph sqlgGraph, String schema, String tableName, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers) static void
TopologyManager.addVertexLabel
(SqlgGraph sqlgGraph, String schema, String tableName, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addVertexLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addVertexLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static void
TopologyManager.addVertexLabelPartition
(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static void
TopologyManager.removeEdgeColumn
(SqlgGraph sqlgGraph, String schema, String prefixedTable, String column) static void
TopologyManager.removeEdgeLabel
(SqlgGraph sqlgGraph, EdgeLabel edge) static void
TopologyManager.removeIndex
(SqlgGraph sqlgGraph, Index index) static void
TopologyManager.removeInEdgeRole
(SqlgGraph sqlgGraph, EdgeLabel edgeLabel, VertexLabel vertexLabel) static void
TopologyManager.removeOutEdgeRole
(SqlgGraph sqlgGraph, EdgeLabel edgeLabel, VertexLabel vertexLabel) static void
TopologyManager.removePartition
(SqlgGraph sqlgGraph, Partition partition) static void
TopologyManager.removeSchema
(SqlgGraph sqlgGraph, String schema) static void
TopologyManager.removeVertexColumn
(SqlgGraph sqlgGraph, String schema, String prefixedTable, String column) static void
TopologyManager.removeVertexLabel
(SqlgGraph sqlgGraph, VertexLabel vertexLabel) static void
TopologyManager.renameEdgeLabel
(SqlgGraph sqlgGraph, String schema, String oldEdgeLabel, String newEdgeLabel) static void
TopologyManager.renameVertexLabel
(SqlgGraph sqlgGraph, String schema, String oldVertexLabel, String newVertexLabel) static void
TopologyManager.updateEdgeLabelPartitionTypeAndExpression
(SqlgGraph sqlgGraph, String schema, String name, PartitionType partitionType, String partitionExpression) static String
TopologyManager.updateGraph
(SqlgGraph sqlgGraph, String version) Updates sqlg_schema.V_graph's version to the new version and returns the old version.static void
TopologyManager.updateVertexLabelPartitionTypeAndExpression
(SqlgGraph sqlgGraph, String schema, String name, PartitionType partitionType, String partitionExpression) ModifierConstructorDescriptionPartition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) Partition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) Partition
(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) Topology is a singleton created when theSqlgGraph
is opened. -
Uses of SqlgGraph in org.umlg.sqlg.util
Modifier and TypeMethodDescriptionstatic void
static boolean
SqlgUtil.isBulkWithin
(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer) static boolean
SqlgUtil.isBulkWithinAndOut
(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer) static List<Emit<SqlgElement>>
SqlgUtil.loadRecursiveIncludeEdgeResultSetIntoResultIterator
(SqlgGraph sqlgGraph, ResultSetMetaData resultSetMetaData, ResultSet resultSet, SchemaTableTree rootSchemaTableTree, List<LinkedList<SchemaTableTree>> subQueryStacks, boolean first, Map<String, Integer> idColumnCountMap, boolean forParent) static List<Emit<SqlgElement>>
SqlgUtil.loadRecursiveResultSetIntoResultIterator
(SqlgGraph sqlgGraph, ResultSetMetaData resultSetMetaData, ResultSet resultSet, SchemaTableTree rootSchemaTableTree, boolean first, Map<String, Integer> idColumnCountMap, boolean forParent) static List<Emit<SqlgElement>>
SqlgUtil.loadResultSetIntoResultIterator
(SqlgGraph sqlgGraph, ResultSetMetaData resultSetMetaData, ResultSet resultSet, SchemaTableTree rootSchemaTableTree, List<LinkedList<SchemaTableTree>> subQueryStacks, boolean first, Map<String, Integer> idColumnCountMap, boolean forParent) static int
SqlgUtil.setKeyValueAsParameter
(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, org.apache.commons.lang3.tuple.ImmutablePair<PropertyDefinition, Object> pair) static int
SqlgUtil.setKeyValuesAsParameter
(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, Collection<org.apache.commons.lang3.tuple.ImmutablePair<PropertyDefinition, Object>> typeAndValues) static int
SqlgUtil.setKeyValuesAsParameterUsingPropertyColumn
(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, Collection<org.apache.commons.lang3.tuple.Pair<PropertyDefinition, Object>> typeAndValues) static int
SqlgUtil.setKeyValuesAsParameterUsingPropertyColumn
(SqlgGraph sqlgGraph, int i, PreparedStatement preparedStatement, Map<String, org.apache.commons.lang3.tuple.Pair<PropertyDefinition, Object>> properties) static void
SqlgUtil.setParametersOnStatement
(SqlgGraph sqlgGraph, LinkedList<SchemaTableTree> schemaTableTreeStack, PreparedStatement preparedStatement, boolean includeAdditionalPartitionHasContainer)