Uses of Class
org.umlg.sqlg.structure.SqlgGraph
Packages that use SqlgGraph
Package
Description
- 
Uses of SqlgGraph in org.umlg.sqlg.sql.dialect
Methods in org.umlg.sqlg.sql.dialect with parameters of type SqlgGraphModifier and TypeMethodDescriptiondefault StringSqlDialect.addNotNullConstraint(SqlgGraph sqlgGraph, String schema, String table, String column, PropertyType propertyType) voidSqlDialect.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 booleanSqlDialect.canUserCreateSchemas(SqlgGraph sqlgGraph) This is only needed for Hsqldb where we are unable to check for the existence of Sqlg's schemasdefault StringSqlDialect.checkConstraintName(SqlgGraph sqlgGraph, String schema, String table, String column, String constraint) default StringSqlBulkDialect.constructCompleteCopyCommandSqlEdge(SqlgGraph sqlgGraph, SqlgEdge sqlgEdge, VertexLabel outVertexLabel, VertexLabel inVertexLabel, SqlgVertex outVertex, SqlgVertex inVertex, Map<String, Object> keyValueMap) default StringSqlBulkDialect.constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, String schema, String table, Set<String> keys) default StringSqlBulkDialect.constructCompleteCopyCommandSqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) default StringSqlBulkDialect.constructCompleteCopyCommandTemporarySqlVertex(SqlgGraph sqlgGraph, SqlgVertex vertex, Map<String, Object> keyValueMap) longSqlDialect.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 StringSqlDialect.dropIndex(SqlgGraph sqlgGraph, AbstractLabel parentLabel, String name) voidBaseSqlDialect.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) voidSqlBulkDialect.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) voidBaseSqlDialect.flushEdgePropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) voidSqlBulkDialect.flushEdgePropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgEdge, Map<String, Object>>>> edgePropertyCache) voidBaseSqlDialect.flushRemovedEdges(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgEdge>> removeEdgeCache) default voidSqlBulkDialect.flushRemovedEdges(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgEdge>> removeEdgeCache) voidBaseSqlDialect.flushRemovedVertices(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgVertex>> removeVertexCache) voidSqlBulkDialect.flushRemovedVertices(SqlgGraph sqlgGraph, Map<SchemaTable, List<SqlgVertex>> removeVertexCache) voidBaseSqlDialect.flushVertexCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) voidSqlBulkDialect.flushVertexCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexCache) voidBaseSqlDialect.flushVertexPropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexPropertyCache) voidSqlBulkDialect.flushVertexPropertyCache(SqlgGraph sqlgGraph, Map<SchemaTable, org.apache.commons.lang3.tuple.Pair<SortedSet<String>, Map<SqlgVertex, Map<String, Object>>>> vertexPropertyCache) default <T> Tdefault intSqlDialect.getShardCount(SqlgGraph sqlgGraph, AbstractLabel label) default voidSqlDialect.grantReadOnlyUserPrivilegesToSqlgSchemas(SqlgGraph sqlgGraph) default voidvoidSqlDialect.lockTable(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) longSqlDialect.nextSequenceVal(SqlgGraph sqlgGraph, SchemaTable schemaTable, String prefix) default intSqlSchemaChangeDialect.notifyChange(SqlgGraph sqlgGraph, LocalDateTime timestamp, com.fasterxml.jackson.databind.JsonNode jsonNode) default voidSqlSchemaChangeDialect.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 Writerdefault StringSqlBulkDialect.temporaryTableCopyCommandSqlVertex(SqlgGraph sqlgGraph, SchemaTable schemaTable, Set<String> keys)  - 
Uses of SqlgGraph in org.umlg.sqlg.sql.parse
Methods in org.umlg.sqlg.sql.parse with parameters of type SqlgGraphModifier 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) Constructors in org.umlg.sqlg.sql.parse with parameters of type SqlgGraphModifierConstructorDescriptionColumnList(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
Constructors in org.umlg.sqlg.step with parameters of type SqlgGraphModifierConstructorDescriptionSqlgGraphStep(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
Methods in org.umlg.sqlg.strategy with parameters of type SqlgGraphModifier and TypeMethodDescriptionstatic voidSqlgSqlExecutor.executeDrop(SqlgGraph sqlgGraph, String sql) static voidSqlgSqlExecutor.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 voidSqlgSqlExecutor.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
Methods in org.umlg.sqlg.structure with parameters of type SqlgGraphModifier and TypeMethodDescriptionstatic RecordIdstatic SchemaTablestatic SchemaTablestatic SqlgEdgestatic SqlgEdgestatic SqlgVertexstatic SqlgVertexstatic SqlgVertexstatic SqlgVertexSqlgVertex.of(SqlgGraph sqlgGraph, List<Comparable> identifiers, String schema, String table, int columnCount) Constructors in org.umlg.sqlg.structure with parameters of type SqlgGraphModifierConstructorDescriptionSqlgCompiledResultIterator(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
Methods in org.umlg.sqlg.structure.topology that return SqlgGraphMethods in org.umlg.sqlg.structure.topology with parameters of type SqlgGraphModifier and TypeMethodDescriptionstatic voidTopologyManager.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.VertexTopologyManager.addEdgeLabel(SqlgGraph sqlgGraph, String prefixedTable, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addEdgeLabelPartition(SqlgGraph sqlgGraph, AbstractLabel abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static voidstatic voidTopologyManager.addIndex(SqlgGraph sqlgGraph, String schema, String label, boolean vertex, String index, IndexType indexType, List<String> properties) add an index from information schemastatic voidstatic voidTopologyManager.addLabelToEdge(SqlgGraph sqlgGraph, String schema, String prefixedTable, boolean in, SchemaTable foreignKey, EdgeDefinition edgeDefinition) static voidTopologyManager.addLabelToEdgeFromInformationSchema(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.structure.Vertex edgeVertex, String schema, String prefixedTable, boolean in, SchemaTable foreignKey) static voidstatic voidTopologyManager.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 voidTopologyManager.addSubPartition(SqlgGraph sqlgGraph, Partition partition) Adds the partition to a partition.static voidTopologyManager.addVertexColumn(SqlgGraph sqlgGraph, String schema, String prefixedTable, Map.Entry<String, PropertyDefinition> column) static voidTopologyManager.addVertexLabel(SqlgGraph sqlgGraph, String schema, String tableName, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers) static voidTopologyManager.addVertexLabel(SqlgGraph sqlgGraph, String schema, String tableName, Map<String, PropertyDefinition> columns, org.apache.commons.collections4.set.ListOrderedSet<String> identifiers, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addVertexLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, Integer modulus, Integer remainder, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addVertexLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String from, String to, PartitionType partitionType, String partitionExpression) static voidTopologyManager.addVertexLabelPartition(SqlgGraph sqlgGraph, String schema, String abstractLabel, String name, String in, PartitionType partitionType, String partitionExpression) static voidTopologyManager.removeEdgeColumn(SqlgGraph sqlgGraph, String schema, String prefixedTable, String column) static voidTopologyManager.removeEdgeLabel(SqlgGraph sqlgGraph, EdgeLabel edge) static voidTopologyManager.removeIndex(SqlgGraph sqlgGraph, Index index) static voidTopologyManager.removeInEdgeRole(SqlgGraph sqlgGraph, EdgeLabel edgeLabel, VertexLabel vertexLabel) static voidTopologyManager.removeOutEdgeRole(SqlgGraph sqlgGraph, EdgeLabel edgeLabel, VertexLabel vertexLabel) static voidTopologyManager.removePartition(SqlgGraph sqlgGraph, Partition partition) static voidTopologyManager.removeSchema(SqlgGraph sqlgGraph, String schema) static voidTopologyManager.removeVertexColumn(SqlgGraph sqlgGraph, String schema, String prefixedTable, String column) static voidTopologyManager.removeVertexLabel(SqlgGraph sqlgGraph, VertexLabel vertexLabel) static voidTopologyManager.renameEdgeLabel(SqlgGraph sqlgGraph, String schema, String oldEdgeLabel, String newEdgeLabel) static voidTopologyManager.renameVertexLabel(SqlgGraph sqlgGraph, String schema, String oldVertexLabel, String newVertexLabel) static voidTopologyManager.updateEdgeLabelPartitionTypeAndExpression(SqlgGraph sqlgGraph, String schema, String name, PartitionType partitionType, String partitionExpression) static StringTopologyManager.updateGraph(SqlgGraph sqlgGraph, String version) Updates sqlg_schema.V_graph's version to the new version and returns the old version.static voidTopologyManager.updateVertexLabelPartitionTypeAndExpression(SqlgGraph sqlgGraph, String schema, String name, PartitionType partitionType, String partitionExpression) Constructors in org.umlg.sqlg.structure.topology with parameters of type SqlgGraphModifierConstructorDescriptionPartition(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 theSqlgGraphis opened. - 
Uses of SqlgGraph in org.umlg.sqlg.util
Methods in org.umlg.sqlg.util with parameters of type SqlgGraphModifier and TypeMethodDescriptionstatic voidstatic booleanSqlgUtil.isBulkWithin(SqlgGraph sqlgGraph, org.apache.tinkerpop.gremlin.process.traversal.step.util.HasContainer hasContainer) static booleanSqlgUtil.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 intSqlgUtil.setKeyValueAsParameter(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, org.apache.commons.lang3.tuple.ImmutablePair<PropertyDefinition, Object> pair) static intSqlgUtil.setKeyValuesAsParameter(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, Collection<org.apache.commons.lang3.tuple.ImmutablePair<PropertyDefinition, Object>> typeAndValues) static intSqlgUtil.setKeyValuesAsParameterUsingPropertyColumn(SqlgGraph sqlgGraph, boolean mod, int parameterStartIndex, PreparedStatement preparedStatement, Collection<org.apache.commons.lang3.tuple.Pair<PropertyDefinition, Object>> typeAndValues) static intSqlgUtil.setKeyValuesAsParameterUsingPropertyColumn(SqlgGraph sqlgGraph, int i, PreparedStatement preparedStatement, Map<String, org.apache.commons.lang3.tuple.Pair<PropertyDefinition, Object>> properties) static voidSqlgUtil.setParametersOnStatement(SqlgGraph sqlgGraph, LinkedList<SchemaTableTree> schemaTableTreeStack, PreparedStatement preparedStatement, boolean includeAdditionalPartitionHasContainer)