Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Z 

A

abbreviate(ChronoUnit) - Static method in class org.janusgraph.diskstorage.util.time.Durations
 
AbstractConfiguration - Class in org.janusgraph.diskstorage.configuration
 
AbstractConfiguration(ConfigNamespace) - Constructor for class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
AbstractEdge - Class in org.janusgraph.graphdb.relations
 
AbstractEdge(long, EdgeLabel, InternalVertex, InternalVertex) - Constructor for class org.janusgraph.graphdb.relations.AbstractEdge
 
AbstractElement - Class in org.janusgraph.graphdb.internal
AbstractElement is the base class for all elements in JanusGraph.
AbstractElement(long) - Constructor for class org.janusgraph.graphdb.internal.AbstractElement
 
AbstractIDAuthority - Class in org.janusgraph.diskstorage.idmanagement
Base Class for IDAuthority implementations.
AbstractIDAuthority(Configuration) - Constructor for class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
AbstractIndexSelectionStrategy - Class in org.janusgraph.graphdb.query.index
 
AbstractIndexSelectionStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
AbstractIndexStatusReport - Class in org.janusgraph.graphdb.database.management
 
AbstractIndexStatusReport(boolean, String, List<SchemaStatus>, Duration) - Constructor for class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
AbstractIndexStatusWatcher<R,S extends AbstractIndexStatusWatcher<R,S>> - Class in org.janusgraph.graphdb.database.management
 
AbstractIndexStatusWatcher(JanusGraph) - Constructor for class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
AbstractLocker<S extends LockStatus> - Class in org.janusgraph.diskstorage.locking
Abstract base class for building lockers.
AbstractLocker(StaticBuffer, TimestampProvider, ConsistentKeyLockerSerializer, LocalLockMediator<StoreTransaction>, LockerState<S>, Duration, Logger) - Constructor for class org.janusgraph.diskstorage.locking.AbstractLocker
 
AbstractLocker.Builder<S,B extends AbstractLocker.Builder<S,B>> - Class in org.janusgraph.diskstorage.locking
Abstract builder for this Locker implementation.
AbstractLongListUtil - Class in org.janusgraph.util.datastructures
Utility class for merging and sorting lists of longs
AbstractLongListUtil() - Constructor for class org.janusgraph.util.datastructures.AbstractLongListUtil
 
AbstractMessage - Class in org.janusgraph.diskstorage.log.util
Abstract implementation of Message which exposes the timestamp, sender, and payload of a message.
AbstractMessage(StaticBuffer, Instant, String) - Constructor for class org.janusgraph.diskstorage.log.util.AbstractMessage
 
AbstractScanJob - Class in org.janusgraph.graphdb.olap
 
AbstractScanJob(JanusGraph) - Constructor for class org.janusgraph.graphdb.olap.AbstractScanJob
 
AbstractScanJob(AbstractScanJob) - Constructor for class org.janusgraph.graphdb.olap.AbstractScanJob
 
AbstractStoreManager - Class in org.janusgraph.diskstorage.common
Abstract Store Manager used as the basis for concrete StoreManager implementations.
AbstractStoreManager(Configuration) - Constructor for class org.janusgraph.diskstorage.common.AbstractStoreManager
 
AbstractStoreTransaction - Class in org.janusgraph.diskstorage.common
Abstract implementation of StoreTransaction to be used as the basis for more specific implementations.
AbstractStoreTransaction(BaseTransactionConfig) - Constructor for class org.janusgraph.diskstorage.common.AbstractStoreTransaction
 
AbstractTypedRelation - Class in org.janusgraph.graphdb.relations
 
AbstractTypedRelation(long, RelationType) - Constructor for class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
AbstractVertex - Class in org.janusgraph.graphdb.vertices
 
AbstractVertex(StandardJanusGraphTx, long) - Constructor for class org.janusgraph.graphdb.vertices.AbstractVertex
 
AbstractVertexProperty<V> - Class in org.janusgraph.graphdb.relations
 
AbstractVertexProperty(long, PropertyKey, InternalVertex, Object) - Constructor for class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
accessEdges() - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.AccessCheck
 
accessProperties() - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.AccessCheck
 
accessSetProperty() - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.AccessCheck
 
acquireEdgeLock(StaticBuffer, StaticBuffer) - Method in class org.janusgraph.diskstorage.BackendTransaction
Acquires a lock for the key-column pair on the edge store which ensures that nobody else can take a lock on that respective entry for the duration of this lock (but somebody could potentially still overwrite the key-value entry without taking a lock).
acquireEdgeLock(StaticBuffer, Entry) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
acquireIndexLock(StaticBuffer, StaticBuffer) - Method in class org.janusgraph.diskstorage.BackendTransaction
Acquires a lock for the key-column pair on the property index which ensures that nobody else can take a lock on that respective entry for the duration of this lock (but somebody could potentially still overwrite the key-value entry without taking a lock).
acquireIndexLock(StaticBuffer, Entry) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Attempts to claim a lock on the value at the specified key and column pair.
acquireLock(StaticBuffer, StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Acquires a lock for the given key and expected value (null, if not value is expected).
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
Attempts to claim a lock on the value at the specified key and column pair.
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
acquireLock(InternalRelation, int, boolean) - Static method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
acquireLock(CompositeIndexType, boolean) - Static method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
action() - Method in class org.janusgraph.util.system.BackgroundThread
The action taken by this background thread when the wait condition is met.
add(String, String, IndexEntry, boolean) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
add(String, String, String, Object, boolean) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
add(StaticBuffer, Entry) - Method in class org.janusgraph.diskstorage.log.kcvs.ExternalCachePersistor
 
add(StaticBuffer, Entry) - Method in interface org.janusgraph.diskstorage.log.kcvs.ExternalPersistor
 
add(StaticBuffer) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
################################### Message Sending ###################################
add(StaticBuffer, StaticBuffer) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
add(StaticBuffer, StaticBuffer, ExternalPersistor) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
add(StaticBuffer) - Method in interface org.janusgraph.diskstorage.log.Log
Attempts to add the given content to the log and returns a Future for this action.
add(StaticBuffer, StaticBuffer) - Method in interface org.janusgraph.diskstorage.log.Log
Attempts to add the given content to the log and returns a Future for this action.
add(IndexSerializer.RecordEntry[]) - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexRecords
 
add(PropertyKey, Order) - Method in class org.janusgraph.graphdb.internal.OrderList
 
add(String, Object) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
add(Condition<E>) - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
add(MixedIndexType, IndexQuery) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
add(CompositeIndexType, MultiKeySliceQuery) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
add(JanusGraphVertex) - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
add(JanusGraphVertex) - Method in interface org.janusgraph.graphdb.query.vertex.VertexListInternal
Adds the provided vertex to this list.
add(JanusGraphVertex) - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
add(InternalRelation) - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
 
add(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
add(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
add(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
add(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
 
add(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.EmptyIndexCache
 
add(JanusGraphVertexProperty) - Method in interface org.janusgraph.graphdb.transaction.indexcache.IndexCache
 
add(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.SimpleIndexCache
 
add(InternalVertex, long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
add(InternalVertex, long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 
add(InternalVertex, long) - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
Adds the given vertex with the given id to the cache.
add(ConcurrentLRUCache.Stats) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
add(T) - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Adds an Object to a PriorityQueue in log(size) time.
addAll(VertexList) - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
addAll(VertexList) - Method in interface org.janusgraph.graphdb.query.vertex.VertexListInternal
Copies all vertices in the given vertex list into this list.
addAll(VertexList) - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
addAllVertices(Collection<? extends Vertex>) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Adds the given collection of vertices to the set of vertices against which to execute this query.
addAllVertices(Collection<? extends Vertex>) - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
addConnection(EdgeLabel, VertexLabel, VertexLabel) - Method in interface org.janusgraph.core.schema.SchemaManager
Add a constraint on which vertices the given edge label can connect.
addConnection(EdgeLabel, VertexLabel, VertexLabel) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
addConnection(EdgeLabel, VertexLabel, VertexLabel) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
addConnection(EdgeLabel, VertexLabel, VertexLabel) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addConsoleReporter(Duration) - Method in enum org.janusgraph.util.stats.MetricManager
Create a ConsoleReporter attached to the JanusGraph Metrics registry.
addCsvReporter(Duration, String) - Method in enum org.janusgraph.util.stats.MetricManager
Create a CsvReporter attached to the JanusGraph Metrics registry.
ADDED_RECORDS_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.IndexRepairJob
The number of composite-index entries modified or added to the storage backend by this job.
addEdge(String, Vertex, Object...) - Method in interface org.janusgraph.core.JanusGraphVertex
Creates a new edge incident on this vertex.
addEdge(JanusGraphVertex, JanusGraphVertex, EdgeLabel) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addEdge(Long, JanusGraphVertex, JanusGraphVertex, EdgeLabel) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addEdge(String, Vertex, Object...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
addEdge(String, Vertex, Object...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
addEdge(String, Vertex, Object...) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
AddedRelationsContainer - Interface in org.janusgraph.graphdb.transaction.addedrelations
 
addGraphiteReporter(String, int, String, Duration) - Method in enum org.janusgraph.util.stats.MetricManager
Create a GraphiteReporter attached to the JanusGraph Metrics registry.
addHasContainer(HasContainer) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
addHasContainer(HasContainer) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
addHasContainer(HasContainer) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
addHasContainer(HasContainer) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
addIndexKey(JanusGraphIndex, PropertyKey, Parameter...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
 
addIndexKey(JanusGraphIndex, PropertyKey, Parameter...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
addition(E) - Method in class org.janusgraph.diskstorage.Mutation
Adds a new entry as an addition to this mutation
addJmxReporter(String, String) - Method in enum org.janusgraph.util.stats.MetricManager
Create a JmxReporter attached to the JanusGraph Metrics registry.
addKey(PropertyKey) - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Adds the given key to the composite key of this index
addKey(PropertyKey, Parameter...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Adds the given key and associated parameters to the composite key of this index
addLocalHasContainersConvertingAndPContainers(TraversalParent, List<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
addLocalHasContainersConvertingAndPContainers(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
addLocalHasContainersConvertingAndPContainers(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
addLocalHasContainersConvertingAndPContainers(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
addLocalHasContainersSplittingAndPContainers(TraversalParent, Iterable<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
addLocalHasContainersSplittingAndPContainers(TraversalParent, Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
addLocalHasContainersSplittingAndPContainers(TraversalParent, Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
addLocalHasContainersSplittingAndPContainers(TraversalParent, Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
addLogProcessor(String) - Method in interface org.janusgraph.core.log.LogProcessorFramework
Returns a processor builder for the transaction log with the given log identifier.
addLogProcessor(String) - Method in class org.janusgraph.graphdb.log.StandardLogProcessorFramework
 
addMessage(M, MessageScope, Map<MessageScope, Integer>, MessageCombiner<M>) - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
addNested(String) - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
addNested(String, boolean) - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
addNested(String, boolean) - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
addNested(String, boolean) - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
addPadding(long) - Method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
 
addParameter(Parameter) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Adds the given parameter to the list of parameters of this query.
addParameter(Parameter) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
addParameters(Iterable<Parameter>) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Adds the given parameters to the list of parameters of this query.
addParameters(Parameter...) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Adds the given parameters to the list of parameters of this query.
addParameters(Iterable<Parameter>) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
addParameters(Parameter...) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
addPoint(T) - Method in class org.janusgraph.util.datastructures.PointInterval
 
addProcessor(ChangeProcessor) - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Adds a ChangeProcessor to this transaction log processor.
addProperties(VertexLabel, PropertyKey...) - Method in interface org.janusgraph.core.schema.SchemaManager
Add property constraints for a given vertex label.
addProperties(EdgeLabel, PropertyKey...) - Method in interface org.janusgraph.core.schema.SchemaManager
Add property constraints for a given edge label.
addProperties(VertexLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
addProperties(EdgeLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
addProperties(VertexLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
addProperties(EdgeLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
addProperties(VertexLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addProperties(EdgeLabel, PropertyKey...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addProperty(RelationType, Object) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
addProperty(JanusGraphVertex, PropertyKey, Object) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addProperty(JanusGraphVertex, PropertyKey, Object, Long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addProperty(VertexProperty.Cardinality, JanusGraphVertex, PropertyKey, Object) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addProperty(VertexProperty.Cardinality, JanusGraphVertex, PropertyKey, Object, Long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addQuery() - Method in class org.janusgraph.graphdb.olap.QueryContainer
 
addRelation(InternalRelation) - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Add a new relation to the vertex
addRelation(InternalRelation) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
addRelation(InternalRelation) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
addRelation(InternalRelation) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
addRelationTypePadding(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
addSchemaEdge(JanusGraphVertex, JanusGraphVertex, TypeDefinitionCategory, Object) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addSlf4jReporter(Duration, String) - Method in enum org.janusgraph.util.stats.MetricManager
Create a Slf4jReporter attached to the JanusGraph Metrics registry.
addToJointQuery(IndexCandidate, JointIndexQuery, IndexSerializer, OrderList) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
addToQueryCache(SliceQuery, EntryList) - Method in class org.janusgraph.graphdb.vertices.CacheVertex
 
addToQueryCache(SliceQuery, EntryList) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
addVertex(Vertex) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Adds the given vertex to the set of vertices against which to execute this query.
addVertex(Long, VertexLabel) - Method in interface org.janusgraph.core.JanusGraphTransaction
Creates a new vertex in the graph with the given vertex id and the given vertex label.
addVertex(String) - Method in interface org.janusgraph.core.Transaction
Creates a new vertex in the graph with the vertex label named by the argument.
addVertex(Object...) - Method in interface org.janusgraph.core.Transaction
 
addVertex(Vertex) - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
addVertex(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
addVertex(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
addVertex(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
Creates a new vertex in the graph with the given vertex id.
addVertex(Long, VertexLabel) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addVertex(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
addVertex(VertexLabel) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
adjacent(Vertex) - Method in interface org.janusgraph.core.BaseVertexQuery
Restricts this query to only those edges that point to the given vertex.
adjacent(Vertex) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
adjacent(Vertex) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
adjacent(Vertex) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
ADJACENT_ID - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
adjacentVertex - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The vertex to be used for the adjacent vertex constraint.
AdjacentVertexFilterOptimizerStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
AdjacentVertexHasIdOptimizerStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
AdjacentVertexHasUniquePropertyOptimizerStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
AdjacentVertexIsOptimizerStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
AdjacentVertexOptimizerStrategy<T extends org.apache.tinkerpop.gremlin.process.traversal.step.filter.FilterStep<?>> - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
AdjacentVertexOptimizerStrategy() - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy
 
AdjacentVertexOptimizerStrategy.OptimizablePosition - Enum in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
ADJUST_LIMIT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
adjustLimitForTxModifications(StandardJanusGraphTx, int, int) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
adjustQueryLimit() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
aggregateMessage(long, M, MessageScope) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
AllEdgesIterable - Class in org.janusgraph.graphdb.util
Deprecated.
AllEdgesIterator - Class in org.janusgraph.graphdb.util
Deprecated.
AllEdgesIterator(Iterator<? extends Vertex>) - Constructor for class org.janusgraph.graphdb.util.AllEdgesIterator
Deprecated.
Returns an iterator over all edges incident on the vertices returned by the given Iterable over vertices.
AllEdgesIterator(Set<? extends Vertex>) - Constructor for class org.janusgraph.graphdb.util.AllEdgesIterator
Deprecated.
Returns an iterator over all edges contained in the subgraph spanned by the given vertices.
ALLOW_ALL - Static variable in class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
 
ALLOW_SETTING_VERTEX_ID - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
ALLOW_STALE_CONFIG - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
ALLOW_UPGRADE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
allowVertexIdSetting() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
allRequiredRepresentatives(InternalVertex) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
And<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Combines multiple conditions under semantic AND, i.e.
And(Condition<E>...) - Constructor for class org.janusgraph.graphdb.query.condition.And
 
And() - Constructor for class org.janusgraph.graphdb.query.condition.And
 
And(int) - Constructor for class org.janusgraph.graphdb.query.condition.And
 
AND_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
AndJanusPredicate - Class in org.janusgraph.graphdb.predicate
 
AndJanusPredicate() - Constructor for class org.janusgraph.graphdb.predicate.AndJanusPredicate
 
AndJanusPredicate(List<JanusGraphPredicate>) - Constructor for class org.janusgraph.graphdb.predicate.AndJanusPredicate
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexFilterOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasIdOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasUniquePropertyOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexIsOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphIoRegistrationStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphLocalQueryOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMixedIndexCountStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMultiQueryStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphStepStrategy
 
applyPost() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasUniquePropertyOptimizerStrategy
 
applyPost() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy
 
applyPrior() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphLocalQueryOptimizerStrategy
 
applyPrior() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMixedIndexCountStrategy
 
applyPrior() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMultiQueryStrategy
 
applyQueryLimitAfterCount(long, Query) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
applyTTL(Collection<Entry>, int) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
ApproximateIndexSelectionStrategy - Class in org.janusgraph.graphdb.query.index
 
ApproximateIndexSelectionStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.query.index.ApproximateIndexSelectionStrategy
 
ARRAY_FACTORY - Static variable in interface org.janusgraph.diskstorage.StaticBuffer
 
ARRAYLIST_SIZE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
ArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
ArrayUtil - Class in org.janusgraph.diskstorage.util
 
ArrayUtil() - Constructor for class org.janusgraph.diskstorage.util.ArrayUtil
 
as(StaticBuffer.Factory<T>) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
as(StaticBuffer.Factory<T>) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
as(StaticBuffer.Factory<T>, int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
asByteBuffer() - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
asByteBuffer() - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
asIndexType() - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
asIndexType() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
asParameter() - Method in enum org.janusgraph.core.schema.Mapping
asReadBuffer() - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
asReadBuffer() - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
asReadConfiguration() - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
asRelative(StaticBuffer.Factory<T>) - Method in interface org.janusgraph.diskstorage.ReadBuffer
 
asRelative(StaticBuffer.Factory<T>) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
ASSIGN_TIMESTAMP - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
assignID(InternalRelation) - Method in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
assignID(InternalVertex, VertexLabel) - Method in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
assignID(InternalRelation) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
assignID(InternalVertex, VertexLabel) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
assignIDs(Iterable<InternalRelation>) - Method in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
assignTimestamp - Variable in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
attachClient(MultiQueriable) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
attachProperties(JanusGraphRelation, Object...) - Static method in class org.janusgraph.graphdb.util.ElementHelper
 
attachProperties(JanusGraphVertex, Object...) - Static method in class org.janusgraph.graphdb.util.ElementHelper
This is essentially an adjusted copy&paste from TinkerPop's ElementHelper class.
attachReferenceElements(Graph) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
ATTRIBUTE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
ATTRIBUTE_PREFIX - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
AttributeHandler - Interface in org.janusgraph.graphdb.database.serialize
 
attributeHandler - Variable in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
AttributeSerializer<V> - Interface in org.janusgraph.core.attribute
Allows custom serializer definitions for attribute values.
AUTH_PASSWORD - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
AUTH_USERNAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Username and password keys to be used to specify an access credential that may be needed to connect with a secured storage backend.
AUTO_TYPE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
awaitGraphIndexStatus(JanusGraph, String) - Static method in class org.janusgraph.graphdb.database.management.ManagementSystem
Returns a GraphIndexStatusWatcher configured to watch graphIndexName through graph g.
awaitGraphIndexUpdate(JanusGraph, String, long, TemporalUnit) - Static method in class org.janusgraph.core.util.ManagementUtil
This method blocks and waits until the provided index has been updated across the entire JanusGraph cluster and reached a stable state.
awaitRelationIndexStatus(JanusGraph, String, String) - Static method in class org.janusgraph.graphdb.database.management.ManagementSystem
Returns a RelationIndexStatusWatcher configured to watch the index specified by relationIndexName and relationIndexType through graph g.
awaitVertexIndexUpdate(JanusGraph, String, String, long, TemporalUnit) - Static method in class org.janusgraph.core.util.ManagementUtil
 

B

Backend - Class in org.janusgraph.diskstorage
Orchestrates and configures all backend systems: The primary backend storage (KeyColumnValueStore) and all external indexing providers (IndexProvider).
Backend(Configuration) - Constructor for class org.janusgraph.diskstorage.Backend
 
BACKEND_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
BackendCompression - Interface in org.janusgraph.diskstorage.util
 
BackendException - Exception in org.janusgraph.diskstorage
Exception thrown in the storage layer of the graph database.
BackendException(String) - Constructor for exception org.janusgraph.diskstorage.BackendException
 
BackendException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.BackendException
 
BackendException(Throwable) - Constructor for exception org.janusgraph.diskstorage.BackendException
Constructs an exception with a generic message
BackendOperation - Class in org.janusgraph.diskstorage.util
 
BackendOperation() - Constructor for class org.janusgraph.diskstorage.util.BackendOperation
 
BackendOperation.Transactional<R> - Interface in org.janusgraph.diskstorage.util
 
BackendOperation.TransactionalProvider - Interface in org.janusgraph.diskstorage.util
 
BackendQuery<Q extends BackendQuery> - Interface in org.janusgraph.graphdb.query
A BackendQuery is a query that can be updated to a new limit.
BackendQueryHolder<E extends BackendQuery<E>> - Class in org.janusgraph.graphdb.query
Holds a BackendQuery and captures additional information that pertains to its execution and to be used by a QueryExecutor: Whether the query is fitted, i.e., whether all results returned from executing the backend query are part of the result set or must be filtered in memory. Whether the query results will already be sorted in the user defined sort order or whether extra sorting is required. Additional execution info required by the query executor.
BackendQueryHolder(E, boolean, boolean, Object) - Constructor for class org.janusgraph.graphdb.query.BackendQueryHolder
 
BackendQueryHolder(E, boolean, boolean) - Constructor for class org.janusgraph.graphdb.query.BackendQueryHolder
 
BackendTransaction - Class in org.janusgraph.diskstorage
Bundles all storage/index transactions and provides a proxy for some of their methods for convenience.
BackendTransaction(CacheTransaction, BaseTransactionConfig, StoreFeatures, KCVSCache, KCVSCache, KCVSCache, Duration, Map<String, IndexTransaction>, Executor) - Constructor for class org.janusgraph.diskstorage.BackendTransaction
 
BackgroundThread - Class in org.janusgraph.util.system
 
BackgroundThread(String, boolean) - Constructor for class org.janusgraph.util.system.BackgroundThread
NEVER set daemon=true and override the cleanup() method.
backwardLength(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
base - Variable in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
BASE_ID - Static variable in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
BaseKey - Class in org.janusgraph.graphdb.types.system
 
BaseKeyColumnValueAdapter - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
 
BaseKeyColumnValueAdapter(KeyValueStore) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
BaseLabel - Class in org.janusgraph.graphdb.types.system
 
BaseQuery - Class in org.janusgraph.graphdb.query
Standard implementation of Query.
BaseQuery() - Constructor for class org.janusgraph.graphdb.query.BaseQuery
 
BaseQuery(int) - Constructor for class org.janusgraph.graphdb.query.BaseQuery
 
BaseRelationType - Class in org.janusgraph.graphdb.types.system
 
BaseTransaction - Interface in org.janusgraph.diskstorage
Represents a transaction for a particular storage backend.
BaseTransactionConfig - Interface in org.janusgraph.diskstorage
 
BaseTransactionConfigurable - Interface in org.janusgraph.diskstorage
An extension to the BaseTransaction interface that exposes a configuration object of type BaseTransactionConfig for this particular transaction.
BaseVertexCentricQuery - Class in org.janusgraph.graphdb.query.vertex
The base implementation for VertexCentricQuery which does not yet contain a reference to the base vertex of the query.
BaseVertexCentricQuery(Condition<JanusGraphRelation>, Direction, List<BackendQueryHolder<SliceQuery>>, OrderList, int) - Constructor for class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
BaseVertexCentricQuery(BaseVertexCentricQuery) - Constructor for class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
BaseVertexCentricQuery() - Constructor for class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
Construct an empty query
BaseVertexCentricQueryBuilder<Q extends BaseVertexQuery<Q>> - Class in org.janusgraph.graphdb.query.vertex
Builds a BaseVertexQuery, optimizes the query and compiles the result into a BaseVertexCentricQuery which is then executed by one of the extending classes.
BaseVertexCentricQueryBuilder(SchemaInspector) - Constructor for class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
BaseVertexLabel - Class in org.janusgraph.graphdb.types.system
 
BaseVertexLabel(String) - Constructor for class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
BaseVertexQuery<Q extends BaseVertexQuery<Q>> - Interface in org.janusgraph.core
BaseVertexQuery constructs and executes a query over incident edges or properties from the perspective of a vertex.
BASIC_METRICS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Whether to enable basic timing and operation count monitoring on backend methods using the com.codahale.metrics package.
BasicConfiguration - Class in org.janusgraph.diskstorage.configuration
 
BasicConfiguration(ConfigNamespace, ReadConfiguration, BasicConfiguration.Restriction) - Constructor for class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
BasicConfiguration.Restriction - Enum in org.janusgraph.diskstorage.configuration
 
BasicVertexCentricQueryBuilder<Q extends BaseVertexQuery<Q>> - Class in org.janusgraph.graphdb.query.vertex
Builds a BaseVertexQuery, optimizes the query and compiles the result into a BaseVertexCentricQuery which is then executed by one of the extending classes.
BasicVertexCentricQueryBuilder(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
BasicVertexCentricQueryBuilder.RelationConstructor - Class in org.janusgraph.graphdb.query.vertex
 
BasicVertexCentricQueryBuilder.ResultConstructor<Q> - Interface in org.janusgraph.graphdb.query.vertex
 
BasicVertexCentricQueryBuilder.VertexConstructor - Class in org.janusgraph.graphdb.query.vertex
 
BasicVertexCentricQueryBuilder.VertexIdConstructor - Class in org.janusgraph.graphdb.query.vertex
 
BATCH_PROPERTY_PREFETCHING - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
batchLoading - Variable in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
batchMutation(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
batchPropertyPrefetching() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
BB_FACTORY - Static variable in interface org.janusgraph.diskstorage.StaticBuffer
 
beginTransaction(TransactionConfiguration, KeyInformation.Retriever) - Method in class org.janusgraph.diskstorage.Backend
Opens a new transaction against all registered backend system wrapped in one BackendTransaction.
beginTransaction(BaseTransactionConfig) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Returns a transaction handle for a new index transaction.
beginTransaction(BaseTransactionConfig) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
beginTransaction(BaseTransactionConfig) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
beginTransaction(BaseTransactionConfig) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Returns a transaction handle for a new transaction according to the given configuration.
beginTransaction(BaseTransactionConfig) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
beginTransaction(BaseTransactionConfig) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
beginTransaction(BaseTransactionConfig) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
BitMap - Class in org.janusgraph.util.datastructures
Utility class for setting and reading individual bits in a byte.
BitMap() - Constructor for class org.janusgraph.util.datastructures.BitMap
 
BooleanArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
BooleanArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
BooleanSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
BooleanSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
BruteForceIndexSelectionStrategy - Class in org.janusgraph.graphdb.query.index
 
BruteForceIndexSelectionStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.query.index.BruteForceIndexSelectionStrategy
 
BUFFER_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Buffers graph mutations locally up to the specified number before persisting them against the storage backend.
BufferUtil - Class in org.janusgraph.diskstorage.util
Utility methods for dealing with ByteBuffer.
BufferUtil() - Constructor for class org.janusgraph.diskstorage.util.BufferUtil
 
build() - Static method in class org.janusgraph.core.JanusGraphFactory
Returns a JanusGraphFactory.Builder that allows to set the configuration options for opening a JanusGraph graph database.
build() - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Builds this transaction log processor and starts processing the log.
build(ExecutorServiceConfiguration) - Static method in class org.janusgraph.diskstorage.configuration.ExecutorServiceBuilder
 
build() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
build() - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner
 
build() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
build() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
build() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
build(ReadConfiguration) - Method in class org.janusgraph.graphdb.configuration.builder.GraphDatabaseConfigurationBuilder
 
buildCompositeIndex() - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Builds a composite index according to the specification
buildConfiguration(BackendOperation.TransactionalProvider, KeyColumnValueStore, String, Configuration) - Method in class org.janusgraph.diskstorage.configuration.backend.builder.KCVSConfigurationBuilder
 
buildEdgeIndex(EdgeLabel, String, Direction, PropertyKey...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
buildEdgeIndex(EdgeLabel, String, Direction, Order, PropertyKey...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Creates a RelationTypeIndex for the provided edge label.
buildEdgeIndex(EdgeLabel, String, Direction, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
buildEdgeIndex(EdgeLabel, String, Direction, Order, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
buildEdgeScanJob() - Method in class org.janusgraph.diskstorage.Backend
 
Builder() - Constructor for class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
Builder() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
Construct a Builder with everything disabled/unsupported/false/null.
Builder(StoreFeatures) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
Construct a Builder whose default values exactly match the values on the supplied template.
Builder() - Constructor for class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
Builder(KeyColumnValueStore, StoreManager) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
Builder() - Constructor for class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
Builder(BaseTransactionConfig) - Constructor for class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
Copies everything from template to this builder except for the commitTime.
buildGlobalConfiguration(BackendOperation.TransactionalProvider, KeyColumnValueStore, Configuration) - Method in class org.janusgraph.diskstorage.configuration.backend.builder.KCVSConfigurationBuilder
 
buildGlobalConfiguration(ReadConfiguration, BasicConfiguration, ModifiableConfiguration, KeyColumnValueStoreManager, ModifiableConfigurationBuilder, KCVSConfigurationBuilder) - Method in class org.janusgraph.diskstorage.configuration.builder.ReadConfigurationBuilder
 
buildGlobalGraphCentricQuery() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
buildGlobalWrite(WriteConfiguration) - Method in class org.janusgraph.diskstorage.configuration.builder.ModifiableConfigurationBuilder
 
buildGraphConfiguration() - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
buildGraphIndexScanJob() - Method in class org.janusgraph.diskstorage.Backend
 
buildIndex(String, Class<? extends Element>) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns an JanusGraphManagement.IndexBuilder to add a graph index to this JanusGraph graph.
buildIndex(String, Class<? extends Element>) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
buildMixedIndex(String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Builds a mixed index according to the specification against the backend index with the given name (i.e.
buildPropertyIndex(PropertyKey, String, PropertyKey...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
buildPropertyIndex(PropertyKey, String, Order, PropertyKey...) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Creates a RelationTypeIndex for the provided property key.
buildPropertyIndex(PropertyKey, String, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
buildPropertyIndex(PropertyKey, String, Order, PropertyKey...) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
buildStandaloneGlobalConfiguration(KeyColumnValueStoreManager, Configuration) - Method in class org.janusgraph.diskstorage.configuration.backend.builder.KCVSConfigurationBuilder
 
buildTransaction() - Method in interface org.janusgraph.core.JanusGraph
Returns a TransactionBuilder to construct a new thread-independent JanusGraphTransaction.
buildTransaction() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
BYTE_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
ByteArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ByteArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
BYTEBUFFER_RAW_SIZE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
ByteBufferUtil - Class in org.janusgraph.diskstorage.util
Utility methods for dealing with ByteBuffers in concurrent access environments, i.e.
ByteBufferUtil() - Constructor for class org.janusgraph.diskstorage.util.ByteBufferUtil
 
ByteSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ByteSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
ByteSize - Class in org.janusgraph.util.datastructures
 
ByteSize() - Constructor for class org.janusgraph.util.datastructures.ByteSize
 
bytesToHex(ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.janusgraph.diskstorage.util.Hex
 

C

CachableStaticBuffer - Interface in org.janusgraph.diskstorage.keycolumnvalue.cache
 
CACHE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
CACHED_THREAD_POOL_CLASS - Static variable in class org.janusgraph.diskstorage.configuration.ExecutorServiceBuilder
 
CacheEdge - Class in org.janusgraph.graphdb.relations
 
CacheEdge(long, EdgeLabel, InternalVertex, InternalVertex, Entry) - Constructor for class org.janusgraph.graphdb.relations.CacheEdge
 
CacheMetricsAction - Enum in org.janusgraph.diskstorage.util
 
CacheTransaction - Class in org.janusgraph.diskstorage.keycolumnvalue.cache
 
CacheTransaction(StoreTransaction, KeyColumnValueStoreManager, int, Duration, boolean) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
CacheTransaction(StoreTransaction, KeyColumnValueStoreManager, int, Duration, boolean, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
CacheVertex - Class in org.janusgraph.graphdb.vertices
 
CacheVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.vertices.CacheVertex
 
CacheVertexProperty - Class in org.janusgraph.graphdb.relations
 
CacheVertexProperty(long, PropertyKey, InternalVertex, Object, Entry) - Constructor for class org.janusgraph.graphdb.relations.CacheVertexProperty
 
call(StoreTransaction) - Method in interface org.janusgraph.diskstorage.util.BackendOperation.Transactional
 
call() - Method in interface org.janusgraph.diskstorage.util.IOCallable
 
call() - Method in interface org.janusgraph.diskstorage.util.StorageCallable
 
call() - Method in interface org.janusgraph.diskstorage.util.UncheckedCallable
 
call() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusWatcher
 
call() - Method in class org.janusgraph.graphdb.database.management.RelationIndexStatusWatcher
Poll a relation index until it has a certain SchemaStatus, or until a configurable timeout is exceeded.
call(int) - Method in interface org.janusgraph.graphdb.query.QueryUtil.IndexCall
 
Cardinality - Enum in org.janusgraph.core
The cardinality of the values associated with given key for a particular element.
cardinality() - Method in interface org.janusgraph.core.PropertyKey
The Cardinality of this property key.
cardinality(Cardinality) - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
Configures the Cardinality of this property key.
cardinality(VertexProperty.Cardinality) - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
Configures the VertexProperty.Cardinality of this property key.
cardinality(Cardinality) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
cardinality(VertexProperty.Cardinality) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
cardinality() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
cardinality() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
cardinality() - Method in class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
cardinalityIsSet() - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
This method allows to check if is set using method cardinality();
cardinalityIsSet() - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
cellTTL(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
Change - Enum in org.janusgraph.core.log
Identifies the type of change has undergone.
changeName(JanusGraphSchemaElement, String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Changes the name of a JanusGraphSchemaElement to the provided new name.
changeName(JanusGraphSchemaElement, String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
ChangeProcessor - Interface in org.janusgraph.core.log
Allows the user to define custom behavior to process those transactional changes that are recorded in a transaction log.
ChangeState - Interface in org.janusgraph.core.log
Container interface for a set of changes against the graph caused by a particular transaction.
char2short(char) - Static method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
CHAR_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
CharacterSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
CharacterSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
CharArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
CharArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
checkExternalVertexExistence(boolean) - Method in interface org.janusgraph.core.TransactionBuilder
Enables/disables checking whether the vertex with a user provided id indeed exists.
checkExternalVertexExistence(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
checkInternalVertexExistence(boolean) - Method in interface org.janusgraph.core.TransactionBuilder
Enables/disables checks that verify that each vertex actually exists in the underlying data store when it is retrieved.
checkInternalVertexExistence(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
checkKeyValidity(String) - Static method in interface org.janusgraph.diskstorage.indexing.IndexProvider
 
checkLocks(StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
 
checkLocks(StoreTransaction) - Method in interface org.janusgraph.diskstorage.locking.Locker
Verify that all previous Locker.writeLock(KeyColumn, StoreTransaction) calls with tx actually succeeded.
checkPropertyConstraintForEdgeOrCreatePropertyConstraint(StandardEdge, PropertyKey) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
checkSingleLock(KeyColumn, S, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
Try to verify that the lock identified by lockID is already held by tx.
checkSingleLock(KeyColumn, ConsistentKeyLockStatus, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker
 
CheckSocket - Class in org.janusgraph.util.system
 
CheckSocket() - Constructor for class org.janusgraph.util.system.CheckSocket
 
checkTypeName(JanusGraphSchemaCategory, String) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
chronoUnit(TimeUnit) - Static method in class org.janusgraph.diskstorage.util.time.Temporals
 
clean(KeyColumn, Instant, StoreTransaction) - Method in interface org.janusgraph.diskstorage.locking.consistentkey.LockCleanerService
 
clean(KeyColumn, Instant, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerService
 
cleanup() - Method in class org.janusgraph.util.system.BackgroundThread
Any clean up that needs to be done before this thread is closed down.
clear() - Method in enum org.janusgraph.diskstorage.locking.LocalLockMediators
Only use this in testing.
clear(String) - Method in enum org.janusgraph.diskstorage.locking.LocalLockMediators
Only use this in testing.
clear() - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
Clears the container which releases allocated memory.
clear() - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
clear() - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
clear() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
clear() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Removes all entries from the PriorityQueue.
clearCache() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
clearCache() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
clearCache() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
clearStorage() - Method in class org.janusgraph.diskstorage.Backend
Clears the storage of all registered backend data providers.
clearStorage() - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Clears the index and removes all entries in all stores.
clearStorage() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
clearStorage() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
clearStorage() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Deletes and clears all database in this storage manager.
clearStorage() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
clearStorage() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
clone() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
Returns a clone of this ScanJob.
clone() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
clone() - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
clone() - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
clone() - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob.Executor
 
clone() - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
clone() - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
 
clone() - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
clone() - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
clone() - Method in class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
clone() - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
clone() - Method in interface org.janusgraph.graphdb.olap.VertexScanJob
Returns a clone of this VertexScanJob.
clone() - Method in class org.janusgraph.graphdb.query.condition.And
 
clone() - Method in class org.janusgraph.graphdb.query.condition.Or
 
clone() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphEdgeVertexStep
 
clone() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
close(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Removes the graph corresponding to the supplied graphName from the JanusGraphManager graph reference tracker and returns the corresponding Graph, or null if it doesn't exist.
close() - Method in interface org.janusgraph.core.JanusGraph
Closes the graph database.
close(Graph) - Static method in class org.janusgraph.core.JanusGraphFactory
Removes Graph from JanusGraphManager graph reference tracker, if exists there.
close() - Method in interface org.janusgraph.core.Transaction
 
close() - Method in class org.janusgraph.diskstorage.Backend
 
close() - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
close() - Method in interface org.janusgraph.diskstorage.configuration.ReadConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
close() - Method in class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
Closes this configuration handler
close() - Method in interface org.janusgraph.diskstorage.IDAuthority
Closes the IDAuthority and any underlying storage backend.
close() - Method in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
close() - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Closes the index
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
close() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Closes this store
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
close() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Closes this store and releases its resources.
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner
 
close() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Closes the Storage Manager and all databases that have been opened.
close() - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
Closes the log by terminating all threads and waiting for their termination.
close() - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
 
close() - Method in interface org.janusgraph.diskstorage.log.Log
Closes this log and stops the reading process.
close() - Method in interface org.janusgraph.diskstorage.log.LogManager
Closes the log manager and all open logs (if they haven't already been explicitly closed)
close() - Method in interface org.janusgraph.diskstorage.util.BackendOperation.TransactionalProvider
 
close() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
close() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
 
close() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
 
close() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
close() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
close() - Method in interface org.janusgraph.graphdb.database.idassigner.IDPool
 
close() - Method in class org.janusgraph.graphdb.database.idassigner.StandardIDPool
 
close() - Method in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
close() - Method in class org.janusgraph.graphdb.database.RelationQueryCache
 
close() - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
close() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
close() - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
close() - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob.Executor
 
close() - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
 
close() - Method in class org.janusgraph.graphdb.olap.GraphProvider
 
close() - Method in class org.janusgraph.graphdb.query.LimitAdjustingIterator
 
close() - Method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
close() - Method in class org.janusgraph.graphdb.query.ResultSetIterator
 
close() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
close() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
close() - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
 
close() - Method in class org.janusgraph.graphdb.transaction.indexcache.EmptyIndexCache
 
close() - Method in interface org.janusgraph.graphdb.transaction.indexcache.IndexCache
Closes the cache which allows the cache to release allocated memory.
close() - Method in class org.janusgraph.graphdb.transaction.indexcache.SimpleIndexCache
 
close() - Method in class org.janusgraph.graphdb.transaction.subquerycache.EmptySubqueryCache
 
close() - Method in class org.janusgraph.graphdb.transaction.subquerycache.GuavaSubqueryCache
 
close() - Method in interface org.janusgraph.graphdb.transaction.subquerycache.SubqueryCache
Closes the cache which allows the cache to release allocated memory.
close() - Method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
close() - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 
close() - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
Closes the cache which allows the cache to release allocated memory.
close() - Method in class org.janusgraph.graphdb.util.MultiDistinctOrderedIterator
 
close() - Method in class org.janusgraph.graphdb.util.MultiDistinctUnorderedIterator
 
close() - Method in class org.janusgraph.graphdb.util.MultiIterator
 
close() - Method in class org.janusgraph.graphdb.util.ProfiledIterator
 
close() - Method in class org.janusgraph.graphdb.util.SubqueryIterator
Close the iterator, stop timer and update profiler.
close() - Method in class org.janusgraph.graphdb.util.WorkerPool
 
close(Duration) - Method in class org.janusgraph.util.system.BackgroundThread
 
CloseableAbstractIterator<T> - Class in org.janusgraph.graphdb.util
 
CloseableAbstractIterator() - Constructor for class org.janusgraph.graphdb.util.CloseableAbstractIterator
 
CloseableIteratorUtils - Class in org.janusgraph.graphdb.util
 
CloseableIteratorUtils() - Constructor for class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
CLOSEDSTAR_CHECK - Static variable in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
closeQuietly(Closeable) - Static method in class org.janusgraph.util.system.IOUtils
 
closeQuietly(AutoCloseable) - Static method in class org.janusgraph.util.system.IOUtils
 
closeTransaction(StandardJanusGraphTx) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
closeTx(Graph, Boolean) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
CLUSTER_MAX_PARTITIONS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
CLUSTER_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
CLUSTER_SIZE_DIVIDER - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
If KCVSLogManager.LOG_MAX_PARTITIONS isn't set explicitly, the number of partitions is derived by taking the configured GraphDatabaseConfiguration.CLUSTER_MAX_PARTITIONS and dividing the number by this constant.
CollectionsUtil - Class in org.janusgraph.graphdb.util
 
CollectionsUtil() - Constructor for class org.janusgraph.graphdb.util.CollectionsUtil
 
CombinerLock - Class in org.janusgraph.graphdb.transaction.lock
 
CombinerLock(TransactionLock, TransactionLock, TimestampProvider) - Constructor for class org.janusgraph.graphdb.transaction.lock.CombinerLock
 
commit() - Method in interface org.janusgraph.core.JanusGraphTransaction
Commits and closes the transaction.
commit() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Commits this management transaction and persists all schema changes.
commit() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
commit() - Method in interface org.janusgraph.diskstorage.BaseTransaction
Commits the transaction and persists all modifications to the backend.
commit() - Method in class org.janusgraph.diskstorage.common.AbstractStoreTransaction
 
commit() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
commit() - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
commit() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
commit() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
commit() - Method in class org.janusgraph.diskstorage.util.DefaultTransaction
 
commit() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
commit(Collection<InternalRelation>, Collection<InternalRelation>, StandardJanusGraphTx) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
commit(Set<String>) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
commit() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
commitAll() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
commitIndexes() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
commitOrRollback(Set<String>, Boolean) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
commitStorage() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
commitTime(Instant) - Method in interface org.janusgraph.core.TransactionBuilder
Sets the timestamp for this transaction.
commitTime(Instant) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
commitTime(Instant) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
CommonsConfiguration - Class in org.janusgraph.diskstorage.configuration.backend
ReadConfiguration wrapper for Apache Configuration
CommonsConfiguration() - Constructor for class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
CommonsConfiguration(Configuration) - Constructor for class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
compare(ByteBuffer, ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers according to their byte order (and not the byte value).
compare(long, TimeUnit, long, TimeUnit) - Static method in class org.janusgraph.diskstorage.util.time.Durations
 
compare(JanusGraphElement, JanusGraphElement) - Static method in class org.janusgraph.graphdb.internal.AbstractElement
 
compare(JanusGraphElement, JanusGraphElement) - Method in class org.janusgraph.graphdb.internal.OrderList
 
compare(JanusGraphElement, JanusGraphElement) - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
compare(InternalRelation, InternalRelation) - Method in class org.janusgraph.graphdb.relations.RelationComparator
 
compareTo(StaticBuffer) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
compareTo(StaticArrayBuffer) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
compareTo(byte[], int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
compareTo(int, StaticBuffer, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
compareTo(int, StaticArrayBuffer, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
compareTo(JanusGraphElement) - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
compareTo(IndexCandidateGroup) - Method in class org.janusgraph.graphdb.query.index.IndexCandidateGroup
Covering more clauses, using fewer indices, and getting higher score is better
compareValues(Object, Object, Order) - Static method in class org.janusgraph.graphdb.relations.RelationComparator
 
compareValues(Object, Object) - Static method in class org.janusgraph.graphdb.relations.RelationComparator
 
CompatibilityValidator - Class in org.janusgraph.graphdb.configuration.validator
Validator for checking backward compatibility with Titan
CompatibilityValidator() - Constructor for class org.janusgraph.graphdb.configuration.validator.CompatibilityValidator
 
complete(MapReduce<K, V, ?, ?, ?>) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMapEmitter
 
complete() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
complete(MapReduce<?, ?, OK, OV, ?>) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraReduceEmitter
 
completeIteration() - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
completeSubRound() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
CompositeIndexType - Interface in org.janusgraph.graphdb.types
 
CompositeIndexTypeWrapper - Class in org.janusgraph.graphdb.types.indextype
 
CompositeIndexTypeWrapper(SchemaSource) - Constructor for class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
compress(StaticBuffer) - Method in interface org.janusgraph.diskstorage.util.BackendCompression
 
compute(Class<C>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
compute() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
compute(Class<C>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
compute() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
computeNext() - Method in class org.janusgraph.graphdb.util.MultiDistinctUnorderedIterator
 
computeNext() - Method in class org.janusgraph.graphdb.util.MultiIterator
 
computeNext() - Method in class org.janusgraph.graphdb.util.ProfiledIterator
 
computeNext() - Method in class org.janusgraph.graphdb.util.SubqueryIterator
 
computeProperty(InternalElement) - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
COMPUTER_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
COMPUTER_RESULT_MODE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
concat(Iterator<T>...) - Static method in class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
concat(List<Iterator<T>>) - Static method in class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
CONCURRENT_PARTITIONS - Static variable in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
ConcurrentAddedRelations - Class in org.janusgraph.graphdb.transaction.addedrelations
 
ConcurrentAddedRelations() - Constructor for class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
ConcurrentIndexCache - Class in org.janusgraph.graphdb.transaction.indexcache
 
ConcurrentIndexCache() - Constructor for class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
 
ConcurrentLRUCache<V> - Class in org.janusgraph.graphdb.util
Deprecated.
ConcurrentLRUCache(int, int, int, int, boolean, boolean, ConcurrentLRUCache.EvictionListener<V>) - Constructor for class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
ConcurrentLRUCache(int, int) - Constructor for class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
ConcurrentLRUCache.EvictionListener<V> - Interface in org.janusgraph.graphdb.util
Deprecated.
 
ConcurrentLRUCache.Stats - Class in org.janusgraph.graphdb.util
Deprecated.
 
ConcurrentWriteConfiguration - Interface in org.janusgraph.diskstorage.configuration
 
Condition<E extends JanusGraphElement> - Interface in org.janusgraph.graphdb.query.condition
A logical condition which evaluates against a provided element to true or false.
condition - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
The condition of this query
Condition.Type - Enum in org.janusgraph.graphdb.query.condition
 
CONDITION_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
ConditionUtil - Class in org.janusgraph.graphdb.query.condition
Utility methods for transforming and inspecting Conditions.
ConditionUtil() - Constructor for class org.janusgraph.graphdb.query.condition.ConditionUtil
 
ConfigElement - Class in org.janusgraph.diskstorage.configuration
 
ConfigElement(ConfigNamespace, String, String) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigElement
 
ConfigElement.PathIdentifier - Class in org.janusgraph.diskstorage.configuration
 
ConfigNamespace - Class in org.janusgraph.diskstorage.configuration
 
ConfigNamespace(ConfigNamespace, String, String, boolean) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigNamespace
 
ConfigNamespace(ConfigNamespace, String, String) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigNamespace
 
ConfigOption<O> - Class in org.janusgraph.diskstorage.configuration
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, O) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, O, Predicate<O>) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, Predicate<O>) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O, Predicate<O>) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O, Predicate<O>, ConfigOption<?>) - Constructor for class org.janusgraph.diskstorage.configuration.ConfigOption
 
ConfigOption.Type - Enum in org.janusgraph.diskstorage.configuration
 
Configuration - Interface in org.janusgraph.diskstorage.configuration
 
configuration() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
configuration() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
ConfigurationFileFilter - Class in org.janusgraph.util.system
 
ConfigurationFileFilter() - Constructor for class org.janusgraph.util.system.ConfigurationFileFilter
 
ConfigurationLint - Class in org.janusgraph.util.system
 
ConfigurationLint() - Constructor for class org.janusgraph.util.system.ConfigurationLint
 
ConfigurationLint.Status - Class in org.janusgraph.util.system
 
ConfigurationManagementGraph - Class in org.janusgraph.graphdb.management
This class allows you to create/update/remove configuration objects used to open a graph.
ConfigurationManagementGraph(StandardJanusGraph) - Constructor for class org.janusgraph.graphdb.management.ConfigurationManagementGraph
This class allows you to create/update/remove configuration objects used to open a graph.
ConfigurationManagementGraphAlreadyInstantiatedException - Exception in org.janusgraph.graphdb.management.utils
 
ConfigurationManagementGraphAlreadyInstantiatedException(String) - Constructor for exception org.janusgraph.graphdb.management.utils.ConfigurationManagementGraphAlreadyInstantiatedException
 
ConfigurationManagementGraphNotEnabledException - Exception in org.janusgraph.graphdb.management.utils
 
ConfigurationManagementGraphNotEnabledException(String) - Constructor for exception org.janusgraph.graphdb.management.utils.ConfigurationManagementGraphNotEnabledException
 
ConfigurationPrinter - Class in org.janusgraph.util.system
Recursively dump the root configuration namespace to either System.out or the named file in a CSV-type format with configurable delimiter, header, and footer.
ConfigurationUtil - Class in org.janusgraph.util.system
 
ConfigurationUtil() - Constructor for class org.janusgraph.util.system.ConfigurationUtil
 
ConfiguredGraphFactory - Class in org.janusgraph.core
This class provides static methods to: 1) create graph references denoted by a graphName using a previously created template configuration using the ConfigurationManagementGraph or 2) open a graph reference denoted by a graphName for graphs that have been previously created or for graphs for which you have previously created a configuration using the ConfigurationManagementGraph.
ConfiguredGraphFactory() - Constructor for class org.janusgraph.core.ConfiguredGraphFactory
 
configureGremlinExecutor(GremlinExecutor) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
ConflictAvoidanceMode - Enum in org.janusgraph.diskstorage.idmanagement
Represents ID allocation strategies for avoiding contention between concurrent JanusGraph instances using a shared storage backend.
Connection - Class in org.janusgraph.core
Connection contains schema constraints from outgoing vertex to incoming vertex through an edge.
Connection(JanusGraphEdge) - Constructor for class org.janusgraph.core.Connection
 
Connection(String, VertexLabel, VertexLabel) - Constructor for class org.janusgraph.core.Connection
 
CONNECTION_TIMEOUT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Default timeout when connecting to a remote database instance
connectionTimeoutMS - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
ConnectiveJanusGraphP - Class in org.janusgraph.graphdb.predicate
 
ConnectiveJanusGraphP(ConnectiveJanusPredicate, List<Object>) - Constructor for class org.janusgraph.graphdb.predicate.ConnectiveJanusGraphP
 
ConnectiveJanusPredicate - Class in org.janusgraph.graphdb.predicate
 
ConnectiveJanusPredicate() - Constructor for class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
ConnectiveJanusPredicate(List<JanusGraphPredicate>) - Constructor for class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
consistencyChecks(boolean) - Method in interface org.janusgraph.core.TransactionBuilder
Enables/disables consistency checking and locking for this transaction.
consistencyChecks(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
ConsistencyModifier - Enum in org.janusgraph.core.schema
Used to control JanusGraph's consistency behavior on eventually consistent or other non-transactional backend systems.
ConsistentKeyIDAuthority - Class in org.janusgraph.diskstorage.idmanagement
IDAuthority implementation assuming that the backing store supports consistent key operations.
ConsistentKeyIDAuthority(KeyColumnValueStore, StoreManager, Configuration) - Constructor for class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
ConsistentKeyLocker - Class in org.janusgraph.diskstorage.locking.consistentkey
A global Locker that resolves inter-thread lock contention via AbstractLocker and resolves inter-process contention by reading and writing lock data using KeyColumnValueStore.
ConsistentKeyLocker.Builder - Class in org.janusgraph.diskstorage.locking.consistentkey
 
ConsistentKeyLockerSerializer - Class in org.janusgraph.diskstorage.locking.consistentkey
Translate locking coordinates and metadata (data keys, data columns, data values, timestamps, and rids) into keys, columns, and values compatible with ConsistentKeyLocker and vice-versa.
ConsistentKeyLockerSerializer() - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
ConsistentKeyLockStatus - Class in org.janusgraph.diskstorage.locking.consistentkey
The timestamps of a lock held by a ConsistentKeyLocker and whether the held lock has or has not been checked.
ConsistentKeyLockStatus(Instant, Instant) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
consistentScan(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
consolidate() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
consolidate() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
consolidate() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVMutation
 
consolidate() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
consolidate(Function<E, V>, Function<K, V>) - Method in class org.janusgraph.diskstorage.Mutation
Consolidates this mutation by removing redundant deletions.
consolidate() - Method in class org.janusgraph.diskstorage.Mutation
 
constraints - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The constraints added to this query.
constraints2QNF(StandardJanusGraphTx, List<PredicateCondition<String, E>>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
Prepares the constraints from the query builder into a QNF compliant condition.
CONSTRUCT_GRAPH_CENTRIC_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
constructIndex(JointIndexQuery, ElementCategory) - Method in class org.janusgraph.graphdb.query.graph.MixedIndexCountQueryBuilder
 
constructQuery(ElementCategory) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
constructQuery(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Constructs a VertexCentricQuery for this query builder.
constructQuery(RelationCategory) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
constructQueryWithoutProfile(ElementCategory) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
constructQueryWithoutProfile(RelationCategory) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
Container() - Constructor for class org.janusgraph.diskstorage.StoreMetaData.Container
 
Container(boolean) - Constructor for class org.janusgraph.diskstorage.StoreMetaData.Container
 
contains(StaticBuffer) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
contains(K) - Method in class org.janusgraph.diskstorage.StoreMetaData.Container
 
contains(int) - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
Returns true of the given partitionId lies within this partition id range, else false.
contains(long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
contains(long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 
contains(long) - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
Checks whether the cache contains a vertex with the given id
containsEdgeLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Checks whether an edge label of the given name has been defined in the JanusGraph schema.
containsEdgeLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsEdgeLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
containsEdgeLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
containsGraphIndex(String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Whether the graph has a graph index defined with the given name.
containsGraphIndex(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsIndex(String) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
containsKey(KeyColumnValueStore, StaticBuffer, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
containsKey(KeyColumnValueStore, StaticBuffer, int, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
containsKey(StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns true iff the store contains the given key, else false
containsKey(PropertyKey) - Method in class org.janusgraph.graphdb.internal.OrderList
 
containsKey(Long) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
containsKeyColumn(KeyColumnValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
Returns true if the specified key-column pair exists in the store.
containsPoint(T) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
containsPropertyKey(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Checks whether a property key of the given name has been defined in the JanusGraph schema.
containsPropertyKey(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsPropertyKey(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
containsPropertyKey(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
containsRelationIndex(RelationType, String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Whether a RelationTypeIndex with the given name has been defined for the provided RelationType
containsRelationIndex(RelationType, String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsRelationType(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Checks whether a type with the specified name exists.
containsRelationType(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsRelationType(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
containsRelationType(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
containsRelationType(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
containsRelationType(String) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
containsType(Condition<?>, Condition.Type) - Static method in class org.janusgraph.graphdb.query.condition.ConditionUtil
 
containsVertex(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
containsVertexLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Whether a vertex label with the given name exists in the graph.
containsVertexLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
containsVertexLabel(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
containsVertexLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
containsVertexLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
ConversionHelper - Class in org.janusgraph.util.encoding
 
ConversionHelper() - Constructor for class org.janusgraph.util.encoding.ConversionHelper
 
convert(Object) - Method in interface org.janusgraph.core.attribute.AttributeSerializer
Converts the given (not-null) value to the expected data type V.
convert(Object) - Method in class org.janusgraph.core.attribute.GeoshapeSerializer
 
convert() - Method in enum org.janusgraph.core.Cardinality
 
convert(VertexProperty.Cardinality) - Static method in enum org.janusgraph.core.Cardinality
 
convert(Cardinality) - Static method in enum org.janusgraph.core.Multiplicity
 
convert(VertexProperty.Cardinality) - Static method in enum org.janusgraph.core.Multiplicity
 
convert(ReadConfiguration) - Method in class org.janusgraph.diskstorage.configuration.converter.ReadConfigurationConverter
 
convert(RecordIterator<KeyValueEntry>) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
convert(Configuration) - Method in class org.janusgraph.graphdb.configuration.converter.RegisteredAttributeClassesConverter
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
convert(Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 
convert(Class<V>, Object) - Method in interface org.janusgraph.graphdb.database.serialize.AttributeHandler
Converts the given (not-null) value to the this datatype V.
convert(Class<V>, Object) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
convert(Order) - Static method in enum org.janusgraph.graphdb.internal.Order
 
convert(JanusGraph, VertexScanJob) - Static method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
convert(VertexScanJob) - Static method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
convert(BiPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
convert(HasContainer) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
convert(ConnectiveP<?>, ConnectiveJanusPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
convertInternal(BiPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
Convert Tinkerpop's comparison operators to JanusGraph's
convertLimit(long) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
copy() - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
copy() - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
copy() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
copy() - Method in interface org.janusgraph.diskstorage.configuration.WriteConfiguration
 
copy(D, byte[], int) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.DataHandler
 
copyTo(byte[], int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
count() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns the number of relations that match this query
create(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Creates a JanusGraph configuration stored in the ConfigurationManagementGraph graph and a JanusGraph graph reference according to the single Template Configuration previously created by the ConfigurationManagementGraph API; A configuration for this graph must not already exist, and a Template Configuration must exist.
create(String) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
 
createBaseConfiguration() - Static method in class org.janusgraph.util.system.ConfigurationUtil
Create a new BaseConfiguration object and set a comma delimiter handler, which interprets comma-delimited values as a list of values.
createConfiguration(Configuration) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Create a configuration according to the supplied Configuration; you must include the property "graph.graphname" with a value in the configuration; you can then open your graph using graph.graphname without having to supply the Configuration or File each time using the ConfiguredGraphFactory.
createConfiguration(Configuration) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Create a configuration according to the supplied Configuration; you must include the property "graph.graphname" with a value in the configuration; you can then open your graph using graph.graphname without having to supply the Configuration or File each time using the ConfiguredGraphFactory.
createIndexCandidate(IndexType, MultiCondition<JanusGraphElement>, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
Creates an IndexCandidate from a MultiCondition which it covers.
createIndexRawCandidates(MultiCondition<JanusGraphElement>, ElementCategory, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
createMapb(int) - Static method in class org.janusgraph.util.datastructures.BitMap
 
createTemplateConfiguration(Configuration) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Create a template configuration according to the supplied Configuration; if you already created a template configuration or the supplied Configuration contains the property "graph.graphname", we throw a RuntimeException; you can then use this template configuration to create a graph using the ConfiguredGraphFactory create signature and supplying a new graphName.
createTemplateConfiguration(Configuration) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Create a template configuration according to the supplied Configuration; if you already created a template configuration or the supplied Configuration contains the property "graph.graphname", we throw a RuntimeException; you can then use this template configuration to create a graph using the ConfiguredGraphFactory create signature and supplying a new graphName.
CURRENT_INSTANCE_SUFFIX - Static variable in class org.janusgraph.graphdb.database.management.ManagementSystem
 
currentMap - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
CUSTOM_ATTRIBUTE_CLASS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
CUSTOM_ATTRIBUTE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
CUSTOM_SERIALIZER_CLASS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
customCleaner(LockCleanerService) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
customOption(String, Object) - Method in interface org.janusgraph.core.TransactionBuilder
Configures a custom option on this transaction which will be passed through to the storage and indexing backends.
customOption(String, Object) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
customOptions(Configuration) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
customParameterName(String) - Static method in enum org.janusgraph.graphdb.types.ParameterType
 

D

DataOutput - Interface in org.janusgraph.graphdb.database.serialize
 
dataType() - Method in interface org.janusgraph.core.PropertyKey
Returns the data type for this property key.
dataType(Class<?>) - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
Configures the data type for this property key.
dataType() - Method in enum org.janusgraph.graphdb.database.log.LogTxMeta
 
dataType(Class<?>) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
dataType() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
dataType() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
dataType() - Method in class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
DateSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
DateSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
DB_CACHE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
DB_CACHE_CLEAN_WAIT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
How long the database level cache will keep keys expired while the mutations that triggered the expiration are being persisted.
DB_CACHE_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The size of the database level cache.
DB_CACHE_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The default expiration time for elements held in the database level cache.
decode(byte) - Static method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
decompress(StaticBuffer) - Method in interface org.janusgraph.diskstorage.util.BackendCompression
 
DEFAULT - Static variable in enum org.janusgraph.graphdb.internal.Order
The default order when none is specified
DEFAULT_CAPACITY - Static variable in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
DEFAULT_CHECK - Static variable in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
DEFAULT_HARD_QUERY_LIMIT - Static variable in class org.janusgraph.graphdb.olap.QueryContainer
 
DEFAULT_SLEEP_INTERVAL_MS - Static variable in class org.janusgraph.util.system.Threads
 
DEFAULT_VERTEXLABEL - Static variable in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
defaultPropertyCardinality(String) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
 
defaultPropertyCardinality(String) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
defaultPropertyCardinality(String) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
defaultPropertyCardinality(String) - Method in class org.janusgraph.core.schema.Tp3DefaultSchemaMaker
 
DefaultSchemaMaker - Interface in org.janusgraph.core.schema
When a graph is configured to automatically create vertex/edge labels and property keys when they are first used, a DefaultTypeMaker implementation is used to define them by invoking the DefaultSchemaMaker.makeVertexLabel(VertexLabelMaker), DefaultSchemaMaker.makeEdgeLabel(EdgeLabelMaker), or DefaultSchemaMaker.makePropertyKey(PropertyKeyMaker) methods respectively.
DefaultTransaction - Class in org.janusgraph.diskstorage.util
 
DefaultTransaction(BaseTransactionConfig) - Constructor for class org.janusgraph.diskstorage.util.DefaultTransaction
 
defaultValue(TypeDefinitionMap) - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
delete(String, String, String, Object, boolean) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
delete(StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Deletes the given key from the store.
DELETED_RECORDS_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
deleteDirectory(File, boolean) - Static method in class org.janusgraph.util.system.IOUtils
 
deleteFromDirectory(File) - Static method in class org.janusgraph.util.system.IOUtils
 
deleteLocks(StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
 
deleteLocks(StoreTransaction) - Method in interface org.janusgraph.diskstorage.locking.Locker
Release every lock currently held by tx.
deleteSingleLock(KeyColumn, S, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
Try to unlock/release/delete the lock identified by lockID and both held by and verified for tx.
deleteSingleLock(KeyColumn, ConsistentKeyLockStatus, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker
 
deletion(K) - Method in class org.janusgraph.diskstorage.Mutation
Adds a new key as a deletion to this mutation
delivered() - Method in class org.janusgraph.diskstorage.log.util.FutureMessage
This method should be called by Log implementations when the message was successfully added to the log.
destroy() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
determineClass(Object) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
determineTTL() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
determineTTL(List<IndexEntry>) - Static method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
dir - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The direction of this query.
directed() - Method in interface org.janusgraph.core.schema.EdgeLabelMaker
Configures the label to be directed.
directed() - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
direction(Direction) - Method in interface org.janusgraph.core.BaseVertexQuery
Query only for relations in the given direction.
direction(Vertex) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
direction(Direction) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
direction(Vertex) - Method in interface org.janusgraph.core.JanusGraphRelation
Returns the direction of this relation from the perspective of the specified vertex.
direction(Direction) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
direction(Vertex) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
direction(Direction) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
direction - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
The direction condition of this query.
direction(Direction) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
direction(Vertex) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
direction - Variable in class org.janusgraph.graphdb.relations.RelationCache
 
DirectionCondition<E extends JanusGraphRelation> - Class in org.janusgraph.graphdb.query.condition
 
DirectionCondition(JanusGraphVertex, Direction) - Constructor for class org.janusgraph.graphdb.query.condition.DirectionCondition
 
directory - Variable in class org.janusgraph.diskstorage.common.LocalStoreManager
 
DirectoryUtil - Class in org.janusgraph.diskstorage.util
Utility methods for dealing with directory structures that are not provided by Apache Commons.
DirectoryUtil() - Constructor for class org.janusgraph.diskstorage.util.DirectoryUtil
 
dirID - Variable in class org.janusgraph.graphdb.database.idhandling.IDHandler.RelationTypeParse
 
dirtyVertexSize(int) - Method in interface org.janusgraph.core.TransactionBuilder
Configures the initial size of the map of modified vertices held by this transaction.
dirtyVertexSize(int) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
disableBatchLoading() - Method in interface org.janusgraph.core.TransactionBuilder
Disables batch loading by ensuring that consistency checks are applied in this transaction.
disableBatchLoading() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
disableCache() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
DisableDefaultSchemaMaker - Class in org.janusgraph.core.schema
 
DisableDefaultSchemaMaker() - Constructor for class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
disableSmartLimit() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
disallowEmpty(Class<O>) - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
distributed(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
DistributedStoreManager - Class in org.janusgraph.diskstorage.common
Abstract class that handles configuration options shared by all distributed storage backends
DistributedStoreManager(Configuration, int) - Constructor for class org.janusgraph.diskstorage.common.DistributedStoreManager
 
DistributedStoreManager.Deployment - Enum in org.janusgraph.diskstorage.common
 
DistributedStoreManager.MaskedTimestamp - Class in org.janusgraph.diskstorage.common
Helper class to create the deletion and addition timestamps for a particular transaction.
DOCUMENT_UPDATES_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.IndexRepairJob
The number of mixed-index documents (or whatever idiom is equivalent to the document in the backend implementation) modified by this job
DOUBLE_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
DoubleArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
DoubleArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
DoubleSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
DoubleSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
doubleToSortableLong(double) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts a double value to a sortable signed long.
drop(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Drop graph database, deleting all data in storage and indexing backends.
drop(JanusGraph) - Static method in class org.janusgraph.core.JanusGraphFactory
Drop graph database, deleting all data in storage and indexing backends.
DROP_ON_CLEAR - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
Durations - Class in org.janusgraph.diskstorage.util.time
Utility methods for dealing with Duration
Durations() - Constructor for class org.janusgraph.diskstorage.util.time.Durations
 
DurationSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
DurationSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.DurationSerializer
 

E

E_FAILED - Static variable in class org.janusgraph.util.system.CheckSocket
 
E_USAGE - Static variable in class org.janusgraph.util.system.CheckSocket
 
edge() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
 
edgeCount() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns the number of edges that match this query
EdgeDirection - Class in org.janusgraph.graphdb.relations
IMPORTANT: The byte values of the proper directions must be sequential, i.e.
EdgeDirection() - Constructor for class org.janusgraph.graphdb.relations.EdgeDirection
 
EdgeLabel - Interface in org.janusgraph.core
EdgeLabel is an extension of RelationType for edges.
edgeLabel() - Method in interface org.janusgraph.core.JanusGraphEdge
Returns the edge label of this edge
EDGELABEL_DEFINITION_CATEGORIES - Static variable in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
EdgeLabelDefinition - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
EdgeLabelDefinition(String, long, Multiplicity, boolean) - Constructor for class org.janusgraph.graphdb.schema.EdgeLabelDefinition
Deprecated.
 
EdgeLabelDefinition(EdgeLabel) - Constructor for class org.janusgraph.graphdb.schema.EdgeLabelDefinition
Deprecated.
 
EdgeLabelMaker - Interface in org.janusgraph.core.schema
Used to define new EdgeLabels.
EdgeLabelVertex - Class in org.janusgraph.graphdb.types.vertices
 
EdgeLabelVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
edgeMultiQuery(LongArrayList, SliceQuery, BackendTransaction) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
edgeProcessor - Variable in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
edgeProcessorImpl - Variable in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
edgeQuery(long, SliceQuery, BackendTransaction) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
edges() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Deprecated.
edges() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Returns an iterable over all incident edges that match this query for each vertex
edges() - Method in interface org.janusgraph.core.JanusGraphQuery
Returns all edges that match the conditions.
edges() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns an iterable over all incident edges that match this query
edges(Traversal<Vertex, Edge>) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
edges() - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
edges() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
edges() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
Deprecated.
edges() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
edges() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
edges(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
edges(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
edges(Direction, String...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
edges(Direction, String...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
edges(Direction, String...) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
edges2VertexIds(Iterable<JanusGraphEdge>, JanusGraphVertex) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
edges2Vertices(Iterable<JanusGraphEdge>, JanusGraphVertex) - Static method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
EdgeSerializer - Class in org.janusgraph.graphdb.database
 
EdgeSerializer(Serializer) - Constructor for class org.janusgraph.graphdb.database.EdgeSerializer
 
edgeSerializer - Variable in class org.janusgraph.graphdb.database.StandardJanusGraph
 
EdgeSerializer.TypedInterval - Class in org.janusgraph.graphdb.database
 
EDGESTORE_CACHE_PERCENT - Static variable in class org.janusgraph.diskstorage.Backend
 
EDGESTORE_MAX_KEY - Static variable in class org.janusgraph.diskstorage.BackendTransaction
 
EDGESTORE_MIN_KEY - Static variable in class org.janusgraph.diskstorage.BackendTransaction
 
EDGESTORE_NAME - Static variable in class org.janusgraph.diskstorage.Backend
These are the names for the edge store and property index databases, respectively.
edgeStoreKeys(SliceQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
edgeStoreKeys(KeyRangeQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
edgeStoreMultiQuery(List<StaticBuffer>, SliceQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
edgeStoreQuery(KeySliceQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
edgeStream() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns all edges that match the query in the indexing backend.
edgeStream() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
edgeTotals() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns total edges that match the query in the indexing backend ignoring limit and offset.
edgeTotals() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
elapsed() - Method in class org.janusgraph.diskstorage.util.time.Timer
 
elapsed - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
element() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
element() - Method in interface org.janusgraph.core.JanusGraphVertexProperty
Returns the vertex on which this property is incident.
element - Variable in class org.janusgraph.diskstorage.configuration.ConfigElement.PathIdentifier
 
element() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
element() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
element() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
element2String(Object) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
ElementCategory - Enum in org.janusgraph.graphdb.internal
 
ElementHelper - Class in org.janusgraph.graphdb.util
 
ElementHelper() - Constructor for class org.janusgraph.graphdb.util.ElementHelper
 
ElementLifeCycle - Class in org.janusgraph.graphdb.internal
ElementLifeCycle enumerates all possible states of the lifecycle of a entity.
ElementLifeCycle() - Constructor for class org.janusgraph.graphdb.internal.ElementLifeCycle
 
ElementLifeCycle.Event - Enum in org.janusgraph.graphdb.internal
 
elementProcessor - Variable in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
elementProcessorImpl - Variable in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
ElementQuery<R extends JanusGraphElement,B extends BackendQuery<B>> - Interface in org.janusgraph.graphdb.query
A query that returns JanusGraphElements.
ElementUtils - Class in org.janusgraph.graphdb.tinkerpop
Created by bryn on 07/05/15.
ElementUtils() - Constructor for class org.janusgraph.graphdb.tinkerpop.ElementUtils
 
emit(K, V) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMapEmitter
 
emit(OK, OV) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraReduceEmitter
 
empty() - Static method in interface org.janusgraph.core.JanusGraphVertexProperty
 
EMPTY - Static variable in interface org.janusgraph.diskstorage.configuration.Configuration
 
EMPTY - Static variable in interface org.janusgraph.diskstorage.configuration.ReadConfiguration
 
EMPTY - Static variable in interface org.janusgraph.diskstorage.StoreMetaData
 
EMPTY - Static variable in interface org.janusgraph.graphdb.database.idassigner.placement.PartitionAssignment
Default assignment (when no id has been assigned yet)
EMPTY - Static variable in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
 
EMPTY_CLOSABLE_ITERATOR - Static variable in class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
EMPTY_ITERATOR - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
EMPTY_LIST - Static variable in interface org.janusgraph.diskstorage.EntryList
 
EMPTY_METADATA - Static variable in enum org.janusgraph.diskstorage.EntryMetaData
 
EMPTY_RETRIEVER - Static variable in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
EMPTY_SCHEMA - Static variable in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
EmptyAddedRelations - Class in org.janusgraph.graphdb.transaction.addedrelations
 
emptyBuffer() - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
EmptyIndexCache - Class in org.janusgraph.graphdb.transaction.indexcache
 
emptyIterable() - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
emptyIterator() - Static method in class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
EmptyJanusGraphVertexProperty<V> - Class in org.janusgraph.core
 
EmptyJanusGraphVertexProperty() - Constructor for class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
EmptyList() - Constructor for class org.janusgraph.diskstorage.EntryList.EmptyList
 
emptyQuery(ElementCategory) - Static method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
emptyQuery() - Static method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
emptyQuery(InternalVertex) - Static method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
EmptyRelationType - Class in org.janusgraph.graphdb.types.system
 
EmptyRelationType() - Constructor for class org.janusgraph.graphdb.types.system.EmptyRelationType
 
emptyResult() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
emptyResult() - Method in interface org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.ResultConstructor
 
emptyResult() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
emptyResult() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
emptyResults(List<StaticBuffer>) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
EmptySubqueryCache - Class in org.janusgraph.graphdb.transaction.subquerycache
 
EmptyVertex - Class in org.janusgraph.graphdb.types.system
 
EmptyVertex() - Constructor for class org.janusgraph.graphdb.types.system.EmptyVertex
 
EmptyVertexCache - Class in org.janusgraph.graphdb.transaction.vertexcache
 
enableBatchLoading() - Method in interface org.janusgraph.core.TransactionBuilder
Enabling batch loading disables a number of consistency checks inside JanusGraph to speed up the ingestion of data under the assumptions that inconsistencies are resolved prior to loading.
enableBatchLoading() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
enableCache() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
enableLogging(Boolean) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Enable/Disable logging in schema maker
enableLogging(Boolean) - Method in class org.janusgraph.core.schema.IgnorePropertySchemaMaker
 
enableLogging(Boolean) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
encode(boolean) - Static method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
endInclusive() - Method in interface org.janusgraph.util.datastructures.Interval
 
endInclusive() - Method in class org.janusgraph.util.datastructures.PointInterval
 
endInclusive() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
ensureAdditionalHasContainersCapacity(int) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
Optional method which provides a hint to future has containers additions.
ensureAdditionalHasContainersCapacity(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
ensureAdditionalHasContainersCapacity(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
ensureAdditionalHasContainersCapacity(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
Entry - Interface in org.janusgraph.diskstorage
An entry is the primitive persistence unit used in the graph database storage backend.
Entry(TransactionLogHeader, StaticBuffer, LogTxStatus, EnumMap<LogTxMeta, Object>) - Constructor for class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
Entry(SchemaSource, Object) - Constructor for class org.janusgraph.graphdb.types.SchemaSource.Entry
 
ENTRY2COLUMN_FCT - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
ENTRY_GETTER - Static variable in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
ENTRY_SIZE_ESTIMATE - Static variable in class org.janusgraph.diskstorage.util.EntryArrayList
 
EntryArrayList - Class in org.janusgraph.diskstorage.util
 
EntryArrayList() - Constructor for class org.janusgraph.diskstorage.util.EntryArrayList
 
EntryArrayList(Collection<? extends Entry>) - Constructor for class org.janusgraph.diskstorage.util.EntryArrayList
 
EntryList - Interface in org.janusgraph.diskstorage
 
EntryList.EmptyList - Class in org.janusgraph.diskstorage
 
EntryMetaData - Enum in org.janusgraph.diskstorage
 
EntryMetaData.Map - Class in org.janusgraph.diskstorage
EntryMetaData.Map extends EnumMap to add validation prior to invoking the superclass EnumMap::put(k,v) method.
EnumSerializer<E extends Enum> - Class in org.janusgraph.graphdb.database.serialize.attribute
 
EnumSerializer(Class<E>) - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.EnumSerializer
 
equals(Object) - Method in class org.janusgraph.core.schema.Parameter
 
equals(Object) - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
equals(Object) - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
equals(Object) - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
equals(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
equals(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
equals(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.MultiSlicesQuery
 
equals(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
equals(Object) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
equals(Object) - Method in class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
equals(Object) - Method in interface org.janusgraph.diskstorage.log.MessageReader
Need to override this method because the Log uses this comparison when un-registering readers
equals(Object) - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
equals(StaticBuffer, ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
Thread safe equals method for StaticBuffer - ByteBuffer equality comparison
equals(Object) - Method in class org.janusgraph.diskstorage.util.KeyColumn
 
equals(Object) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
equals(Object) - Method in class org.janusgraph.graphdb.configuration.RegisteredAttributeClass
 
equals(Object) - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
equals(Object) - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
equals(Object) - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
equals(Object) - Method in class org.janusgraph.graphdb.internal.OrderList
 
equals(Object) - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
equals(Object) - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
equals(Object) - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.DirectionCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.FixedCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.IncidenceCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.Not
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.RelationTypeCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.condition.VisibilityFilterCondition
 
equals(Object) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
equals(Object) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
equals(Object) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
equals(Object) - Method in class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
equals(Object) - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
equals(Object) - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
equals(Object) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
equals(Object) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
equals(Object) - Method in class org.janusgraph.graphdb.transaction.lock.IndexLockTuple
 
equals(Object) - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
equals(Object) - Method in class org.janusgraph.graphdb.types.IndexField
 
equals(Object) - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
equals(Object) - Method in class org.janusgraph.util.datastructures.PointInterval
 
equals(Object) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
evaluate(JanusGraphRelation) - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.And
 
evaluate(E) - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.DirectionCondition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.FixedCondition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.IncidenceCondition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.Not
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.Or
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.RelationTypeCondition
 
evaluate(E) - Method in class org.janusgraph.graphdb.query.condition.VisibilityFilterCondition
 
EVENT_NAMES - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
evictedEntry(Long, V) - Method in interface org.janusgraph.graphdb.util.ConcurrentLRUCache.EvictionListener
Deprecated.
 
evictGraphFromCache() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
Upon the open managementsystem's commit, this graph will be asynchronously evicted from the cache on all JanusGraph nodes in your cluster, once there are no open transactions on this graph on each respective JanusGraph node and assuming each node is correctly configured to use the JanusGraphManager.
evictGraphFromCache(Callable<Boolean>) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
Upon the open managementsystem's commit, this graph will be asynchronously evicted from the cache on all JanusGraph nodes in your cluster, once there are no open transactions on this graph on each respective JanusGraph node and assuming each node is correctly configured to use the JanusGraphManager.
ExceptionFactory - Class in org.janusgraph.graphdb.util
 
ExceptionFactory() - Constructor for class org.janusgraph.graphdb.util.ExceptionFactory
 
ExceptionUtil - Class in org.janusgraph.util.datastructures
Utility class for analyzing exceptions
ExceptionUtil() - Constructor for class org.janusgraph.util.datastructures.ExceptionUtil
 
ExceptionWrapper - Class in org.janusgraph.util.datastructures
 
ExceptionWrapper() - Constructor for class org.janusgraph.util.datastructures.ExceptionWrapper
 
execute() - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
execute(Callable<V>, Duration) - Static method in class org.janusgraph.diskstorage.util.BackendOperation
 
execute(BackendOperation.Transactional<R>, BackendOperation.TransactionalProvider, TimestampProvider) - Static method in class org.janusgraph.diskstorage.util.BackendOperation
 
execute(BackendOperation.Transactional<R>, BackendOperation.TransactionalProvider, TimestampProvider, Duration) - Static method in class org.janusgraph.diskstorage.util.BackendOperation
 
execute(BackendTransaction) - Method in class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
execute(Q, B, Object, QueryProfiler) - Method in class org.janusgraph.graphdb.query.MetricsQueryExecutor
 
execute(Q, B, Object, QueryProfiler) - Method in interface org.janusgraph.graphdb.query.QueryExecutor
Executes the given sub-query against a data store and returns an iterator over the results.
execute(RelationCategory, BasicVertexCentricQueryBuilder.ResultConstructor<Q>) - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
execute(RelationCategory, BasicVertexCentricQueryBuilder.ResultConstructor<Q>) - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
execute() - Method in interface org.janusgraph.util.system.ExecuteExceptionallyFunction
 
executeDirect(Callable<V>, Duration) - Static method in class org.janusgraph.diskstorage.util.BackendOperation
 
ExecuteExceptionallyFunction - Interface in org.janusgraph.util.system
 
executeImplicitKeyQuery(InternalVertex) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
If BaseVertexCentricQueryBuilder.isImplicitKeyQuery(org.janusgraph.graphdb.internal.RelationCategory) is true, this method provides the result set for the query based on the evaluation of the ImplicitKey.
executeImplicitKeyQuery() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
executeMultiQuery(Collection<InternalVertex>, SliceQuery, QueryProfiler) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
executeQuery(IndexQueryBuilder, ElementCategory, BackendTransaction, StandardJanusGraphTx) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
executeQuery(JanusGraphVertexQuery) - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
executeRelations(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
executeTotals() - Method in interface org.janusgraph.core.MixedIndexCountQuery
Fire a count query against index backend to retrieve total number of satisfying elements
executeTotals(IndexQueryBuilder, ElementCategory, BackendTransaction, StandardJanusGraphTx) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
executeTotals() - Method in class org.janusgraph.graphdb.query.graph.MixedIndexCountQueryBuilder
 
ExecuteUtil - Class in org.janusgraph.util.system
 
ExecuteUtil() - Constructor for class org.janusgraph.util.system.ExecuteUtil
 
executeVertexIds(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
executeVertices(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
executeWithCatching(ExecuteExceptionallyFunction, ExceptionWrapper) - Static method in class org.janusgraph.util.system.ExecuteUtil
 
ExecutorServiceBuilder - Class in org.janusgraph.diskstorage.configuration
 
ExecutorServiceConfiguration - Class in org.janusgraph.diskstorage.configuration
 
ExecutorServiceConfiguration() - Constructor for class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
ExecutorServiceConfiguration(String, Integer, Integer, Long, ThreadFactory) - Constructor for class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
ExecutorServiceInstrumentation - Class in org.janusgraph.diskstorage.configuration
 
exhaustedPartition(int) - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
Called when there are no more idAuthorities left in the given partition.
exhaustedPartition(int) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
exists() - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Checks whether the index exists.
exists() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
exists() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
exists() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Check whether database exists in this storage manager.
exists() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
exists() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
existsMatchingIndex(MultiCondition<JanusGraphElement>) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
existsMatchingIndex(MultiCondition<JanusGraphElement>, Predicate<IndexType>) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
ExpectedValueCheckingStore - Class in org.janusgraph.diskstorage.locking.consistentkey
A KeyColumnValueStore wrapper intended for non-transactional stores that forwards all but these two methods to an encapsulated store instance:
ExpectedValueCheckingStore(KeyColumnValueStore, Locker) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
 
ExpectedValueCheckingStoreManager - Class in org.janusgraph.diskstorage.locking.consistentkey
 
ExpectedValueCheckingStoreManager(KeyColumnValueStoreManager, String, LockerProvider, Duration) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
ExpectedValueCheckingTransaction - Class in org.janusgraph.diskstorage.locking.consistentkey
A StoreTransaction that supports locking via LocalLockMediator and writing and reading lock records in a ExpectedValueCheckingStore.
ExpectedValueCheckingTransaction(StoreTransaction, StoreTransaction, Duration) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
ExpirationKCVSCache - Class in org.janusgraph.diskstorage.keycolumnvalue.cache
 
ExpirationKCVSCache(KeyColumnValueStore, String, long, long, long) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
ExpiredLockException - Exception in org.janusgraph.diskstorage.locking.consistentkey
 
ExpiredLockException(String) - Constructor for exception org.janusgraph.diskstorage.locking.consistentkey.ExpiredLockException
 
ExpiredLockException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.consistentkey.ExpiredLockException
 
ExpiredLockException(Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.consistentkey.ExpiredLockException
 
expireSchemaElement(long) - Method in interface org.janusgraph.core.JanusGraphTransaction
 
expireSchemaElement(long) - Method in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
expireSchemaElement(long) - Method in interface org.janusgraph.graphdb.database.cache.SchemaCache
 
expireSchemaElement(long) - Method in class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
expireSchemaElement(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
ExternalCachePersistor - Class in org.janusgraph.diskstorage.log.kcvs
 
ExternalCachePersistor(KCVSCache, CacheTransaction) - Constructor for class org.janusgraph.diskstorage.log.kcvs.ExternalCachePersistor
 
ExternalPersistor - Interface in org.janusgraph.diskstorage.log.kcvs
 
extractOrCondition(Or<JanusGraphRelation>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 

F

failed(Throwable) - Method in class org.janusgraph.diskstorage.log.util.FutureMessage
This method should be called by Log implementations when the message could not be added to the log with the respective exception object.
FAILED_TX - Static variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
failedIndexes - Variable in class org.janusgraph.graphdb.database.log.TransactionLogHeader.SecondaryFailures
 
FakeLock - Class in org.janusgraph.graphdb.transaction.lock
 
features(MixedIndexType) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
features() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
features() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
features() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
field - Variable in class org.janusgraph.diskstorage.indexing.IndexEntry
 
fillBuffer(int, byte) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
filter(Iterator<T>, Predicate<? super T>) - Static method in class org.janusgraph.graphdb.util.CloseableIteratorUtils
 
filter(String, String) - Static method in class org.janusgraph.util.system.ConfigurationFileFilter
 
finalize() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
findEdge(RelationIdentifier, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
findEdgeRelations(JanusGraphVertex, RelationType, RelationIdentifier, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
findParameter(Parameter[], V) - Method in enum org.janusgraph.graphdb.types.ParameterType
 
findProperty(RelationIdentifier, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
findRelation(RelationIdentifier, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
FITTED_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
FIXED_THREAD_POOL_CLASS - Static variable in class org.janusgraph.diskstorage.configuration.ExecutorServiceBuilder
 
FixedCondition<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
A fixed valued literal, which always returns either true or false irrespective of the element which is evaluated.
FixedCondition(boolean) - Constructor for class org.janusgraph.graphdb.query.condition.FixedCondition
 
flatMap(Traverser.Admin<Element>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
flatMap(Traverser.Admin<Vertex>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
FLOAT_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
FloatArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
FloatArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
FloatSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
FloatSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
floatToSortableInt(float) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts a float value to a sortable signed int.
foldableHasContainerNoLimit(FlatMapStep<?, ?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
foldInHasContainer(HasStepFolder, Traversal.Admin<?, ?>, Traversal<?, ?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
foldInHasFilter(Traversal.Admin<?, ?>, TraversalFilterStep<?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
Convert a TraversalFilterStep that is essentially "has(key)" into a normal HasStep
foldInIds(HasStepFolder, Traversal.Admin<?, ?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
foldInOrder(HasStepFolder, Step<?, ?>, Traversal.Admin<?, ?>, Traversal<?, ?>, boolean, List<HasContainer>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
foldInRange(HasStepFolder, Step<?, ?>, Traversal.Admin<?, ?>, List<HasContainer>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
FORCE_INDEX_USAGE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
forceCloseInstance(String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Forcefully removes a JanusGraph instance from this graph cluster as identified by its name.
forceCloseInstance(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
freezeConfiguration() - Method in class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
fromConfig(Configuration) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
fromIdentifierOrNow(String) - Static method in class org.janusgraph.diskstorage.log.ReadMarker
Like ReadMarker.fromIdentifierOrTime(String id, Instant timestamp) but uses the current time point as the starting timestamp if the log has no record of the id.
fromIdentifierOrTime(String, Instant) - Static method in class org.janusgraph.diskstorage.log.ReadMarker
Starts reading the log from the last recorded point in the log for the given id.
fromLockColumn(StaticBuffer, TimestampProvider) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
fromNow() - Static method in class org.janusgraph.diskstorage.log.ReadMarker
Starts reading the log such that it will start with the first entry written after now.
fromPosition(int) - Static method in class org.janusgraph.graphdb.relations.EdgeDirection
 
fromTime(Instant) - Static method in class org.janusgraph.diskstorage.log.ReadMarker
Starts reading the log from the given timestamp onward.
fromVertexId(long) - Static method in class org.janusgraph.core.util.JanusGraphId
fromVertexID(JanusGraphVertex) - Static method in class org.janusgraph.core.util.JanusGraphId
fromVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
Converts a JanusGraph vertex id to the user provided id as the inverse mapping of IDManager.toVertexId(long).
FROZEN_KEY - Static variable in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
FulgoraElementTraversal<S,E> - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraGraphComputer - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraGraphComputer(StandardJanusGraph, Configuration) - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
FulgoraMapEmitter<K,V> - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraMapEmitter(boolean) - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraMapEmitter
 
FulgoraMemory - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraMemory(VertexProgram<?>, Set<MapReduce>) - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
FulgoraReduceEmitter<OK,OV> - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraReduceEmitter() - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraReduceEmitter
 
FulgoraUtil - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraUtil() - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraUtil
 
FulgoraVertexMemory<M> - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraVertexMemory(int, IDManager, VertexProgram<M>) - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
FulgoraVertexProperty<V> - Class in org.janusgraph.graphdb.olap.computer
 
FulgoraVertexProperty(VertexMemoryHandler, JanusGraphVertex, String, V) - Constructor for class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
FULLSCAN_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
FutureMessage<M extends Message> - Class in org.janusgraph.diskstorage.log.util
Implementation of a Future for Messages that are being added to the Log via Log.add(org.janusgraph.diskstorage.StaticBuffer).
FutureMessage(M) - Constructor for class org.janusgraph.diskstorage.log.util.FutureMessage
 

G

g - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
GeoshapeSerializer - Class in org.janusgraph.core.attribute
Geoshape attribute serializer for JanusGraph.
GeoshapeSerializer() - Constructor for class org.janusgraph.core.attribute.GeoshapeSerializer
 
get(String) - Method in interface org.janusgraph.core.schema.JanusGraphConfiguration
Returns a string representation of the provided configuration option or namespace for inspection.
get(int) - Method in interface org.janusgraph.core.VertexList
Returns the vertex at a given position in the list.
get(String, Class<O>) - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
get(String, Class<O>) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
Reads the configuration property for this StoreManager
get(ConfigOption<O>, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
get(Object) - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
get(ConfigOption<O>, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
get(ConfigOption<O>, boolean, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
get(ConfigOption<O>, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
get(ConfigOption<O>, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
get(String, Class<O>) - Method in interface org.janusgraph.diskstorage.configuration.ReadConfiguration
 
get(String, Class<O>) - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
get(String) - Method in class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
 
get(int) - Method in class org.janusgraph.diskstorage.EntryList.EmptyList
 
get(String, String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.IndexRetriever
Returns the KeyInformation for a particular key in a given store.
get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.IndexRetriever
Returns a KeyInformation.StoreRetriever for the given store on this IndexRetriever
get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.Retriever
Returns the KeyInformation.IndexRetriever for a given index.
get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.StoreRetriever
Returns the KeyInformation for a particular key for this store
get(KeyColumnValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
Retrieves the value for the specified column and key under the given transaction from the store if such exists, otherwise returns NULL
get(StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns the value associated with the given key.
get(ScanMetrics.Metric) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics
Get the value of a standard counter.
get(ScanMetrics.Metric) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
get(String, TimestampProvider) - Method in interface org.janusgraph.diskstorage.locking.LocalLockMediatorProvider
Returns a the single LocalLockMediator responsible for the specified namespace.
get(String, TimestampProvider) - Method in enum org.janusgraph.diskstorage.locking.LocalLockMediators
 
get(byte[], int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer.Factory
 
get(K) - Method in class org.janusgraph.diskstorage.StoreMetaData.Container
 
get() - Method in enum org.janusgraph.diskstorage.util.HashUtility
 
get(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
get(String) - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexInfoRetriever
 
get(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
get(String) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
get() - Method in class org.janusgraph.graphdb.olap.GraphProvider
 
get(int) - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
get(int) - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
get(long) - Method in class org.janusgraph.graphdb.relations.RelationCache
 
get(InternalRelation) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
get(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
get(Object, PropertyKey) - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
 
get(Object, PropertyKey) - Method in class org.janusgraph.graphdb.transaction.indexcache.EmptyIndexCache
 
get(Object, PropertyKey) - Method in interface org.janusgraph.graphdb.transaction.indexcache.IndexCache
 
get(Object, PropertyKey) - Method in class org.janusgraph.graphdb.transaction.indexcache.SimpleIndexCache
 
get(int) - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
get(JointIndexQuery.Subquery, Callable<? extends List<Object>>) - Method in class org.janusgraph.graphdb.transaction.subquerycache.EmptySubqueryCache
 
get(JointIndexQuery.Subquery) - Method in class org.janusgraph.graphdb.transaction.subquerycache.GuavaSubqueryCache
 
get(JointIndexQuery.Subquery, Callable<? extends List<Object>>) - Method in interface org.janusgraph.graphdb.transaction.subquerycache.SubqueryCache
Returns a list of results.
get(JointIndexQuery.Subquery) - Method in class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
get(JointIndexQuery.Subquery, Callable<? extends List<Object>>) - Method in class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
get(long, Retriever<Long, InternalVertex>) - Method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
get(long, Retriever<Long, InternalVertex>) - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 
get(long, Retriever<Long, InternalVertex>) - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
Returns the vertex with the given id or null if it is not in the cache
get(Long) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
get(I) - Method in interface org.janusgraph.util.datastructures.Retriever
 
getActualStatus() - Method in class org.janusgraph.graphdb.database.management.RelationIndexStatusReport
 
getAddedRelations(Predicate<InternalRelation>) - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Returns an iterable over all newly added relations incident on this vertex that match the given predicate
getAddedRelations(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
getAddedRelations(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
getAddedRelations(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
getAdditions() - Method in class org.janusgraph.diskstorage.Mutation
Returns the list of additions in this mutation
getAdditionTime(TimestampProvider) - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getAdditionTimeInstant(TimestampProvider) - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getAll() - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
getAll() - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
This method returns all relations in this container.
getAll() - Method in class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
getAll() - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
getAll() - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
getAll() - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
getAllContainedIDs() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getAllManagerClasses() - Static method in enum org.janusgraph.diskstorage.StandardStoreManager
 
getAllMultiQueryPositionsForMultiQueriable(Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
Backtraces the traversal for the position where a MultiQueriable step would expect its corresponding JanusGraphMultiQueryStep(s).
getAllNew() - Method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
getAllNew() - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 
getAllNew() - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
Returns an iterable over all new vertices in the cache
getAllProviderClasses() - Static method in enum org.janusgraph.diskstorage.StandardIndexProvider
 
getAllRepresentatives(JanusGraphVertex, boolean) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getAllShorthands() - Static method in enum org.janusgraph.diskstorage.StandardIndexProvider
 
getAllShorthands() - Static method in enum org.janusgraph.diskstorage.StandardStoreManager
 
getAnnotation(String) - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
getAnnotations() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
getApplicableStatus() - Method in enum org.janusgraph.core.schema.SchemaAction
 
getArity() - Method in interface org.janusgraph.graphdb.internal.InternalRelation
Number of vertices on this relation.
getArity() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
getArity() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
getArray(int) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
getAsBindings() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
Get the Graph and TraversalSource list as a set of bindings.
getAsciiByteLength(String) - Static method in class org.janusgraph.util.encoding.StringEncoding
 
getAt(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRange
 
getAutoSchemaMaker() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getAutoSchemaMaker() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
 
getBackend() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getBackend() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getBackendDescription() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getBackendQuery() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
getBackingIndex() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns the name of the backing index.
getBackingIndex() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
getBackingIndexName() - Method in interface org.janusgraph.graphdb.types.IndexType
 
getBackingIndexName() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getBaseTransactionConfig() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
getBaseType() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getBaseType() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getBaseType(InternalRelationType) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
getBaseType() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getBlockSize(int) - Method in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
Returns the block size of the specified partition as determined by the configured IDBlockSizer.
getBlockSize(int) - Method in interface org.janusgraph.graphdb.database.idassigner.IDBlockSizer
The size of the id block to be returned by calls IDAuthority.getIDBlock(int, int, Duration) for the given id namespace.
getBlockSize(int) - Method in class org.janusgraph.graphdb.database.idassigner.StaticIDBlockSizer
 
getBoolean() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getBoolean(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getBoolean() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getBoolean(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getBounds(RelationCategory, boolean) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
getByClazz(Class<? extends Element>) - Static method in enum org.janusgraph.graphdb.internal.ElementCategory
 
getByName(String) - Static method in enum org.janusgraph.graphdb.internal.ElementCategory
 
getByte() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getByte(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getByte() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getByte(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getByteLength(V) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntryList.MetaDataSerializer
 
getBytes(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getBytes(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getBytes(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getBytes(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getByteSize() - Method in class org.janusgraph.diskstorage.EntryList.EmptyList
 
getByteSize() - Method in interface org.janusgraph.diskstorage.EntryList
Returns the total amount of bytes this entry consumes on the heap - including all object headers.
getByteSize() - Method in class org.janusgraph.diskstorage.util.EntryArrayList
This implementation is an inexact estimate.
getByteSize() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
getCache() - Method in interface org.janusgraph.diskstorage.Entry
Returns the cached parsed representation of this Entry if it exists, else NULL
getCache() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
getCacheMarker() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.cache.CachableStaticBuffer
 
getCanonicalId(long) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getCanonicalVertex(InternalVertex) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getCanonicalVertexId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
getCanonicalVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getCardinality() - Method in enum org.janusgraph.core.Multiplicity
 
getCardinality() - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation
Returns the Cardinality for this key.
getCardinality() - Method in class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
getCardinality() - Method in class org.janusgraph.graphdb.schema.RelationTypeDefinition
Deprecated.
 
getCardinality() - Method in interface org.janusgraph.graphdb.types.CompositeIndexType
 
getCardinality() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getCategory() - Method in enum org.janusgraph.graphdb.database.management.ModifierType
 
getCategory() - Method in class org.janusgraph.graphdb.types.TypeDefinitionDescription
 
getChar() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getChar(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getChar() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getChar(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getChars(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getChars(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getChars(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getChars(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getChild(String) - Method in class org.janusgraph.diskstorage.configuration.ConfigNamespace
 
getChild() - Method in class org.janusgraph.graphdb.query.condition.Not
 
getChildren() - Method in class org.janusgraph.diskstorage.configuration.ConfigNamespace
 
getChildren() - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
getChildren() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
getChildren() - Method in class org.janusgraph.graphdb.query.condition.Literal
 
getChildren() - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
getChildren() - Method in class org.janusgraph.graphdb.query.condition.Not
 
getClientSteps() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
getColumn() - Method in interface org.janusgraph.diskstorage.Entry
 
getColumn() - Method in class org.janusgraph.diskstorage.util.KeyColumn
 
getColumn(E) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.GetColVal
 
getColumnAs(StaticBuffer.Factory<T>) - Method in interface org.janusgraph.diskstorage.Entry
 
getCommitTime() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Returns the commit time of this transaction which is either a custom timestamp provided by the user, the commit time as set by the enclosing operation, or the first time this method is called.
getCommitTime() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
getCommitTime() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getCommonConfiguration() - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
getCommonOrder() - Method in class org.janusgraph.graphdb.internal.OrderList
 
getCompareId() - Method in class org.janusgraph.graphdb.internal.AbstractElement
Long identifier used to compare elements.
getCompareId(Element) - Static method in class org.janusgraph.graphdb.util.ElementHelper
 
getCompareId() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
getComponents(String) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getCompositeQuery() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
getCondition() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
getCondition() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getCondition() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getConditionBasicScore(Condition) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
getConfiguration(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Get Configuration according to supplied graphName mapped to a specific Graph; if does not exist, return null.
getConfiguration() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfigurable
Get the configuration for this transaction
getConfiguration() - Method in class org.janusgraph.diskstorage.common.AbstractStoreTransaction
 
getConfiguration() - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
getConfiguration() - Method in class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
getConfiguration() - Method in class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
Returns the backing configuration as a ReadConfiguration that can be used to create and configure a JanusGraph graph.
getConfiguration() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
getConfiguration() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getConfiguration() - Method in class org.janusgraph.diskstorage.util.DefaultTransaction
 
getConfiguration() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getConfiguration() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getConfiguration(String) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Get Configuration according to supplied graphName mapped to a specific Graph; if does not exist, return null.
getConfiguration() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getConfigurationAtOpen() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getConfigurationClass() - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
getConfigurations() - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Get a list of all Configurations, excluding the template configuration; if none exist, return an empty list
getConfigurations() - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Get a list of all Configurations, excluding the template configuration; if none exist, return an empty list
getConnectionEdge() - Method in class org.janusgraph.core.Connection
 
getConsistency(JanusGraphSchemaElement) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Retrieves the consistency modifier for the given JanusGraphSchemaElement.
getConsistency(JanusGraphSchemaElement) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
Retrieves the consistency level for a schema element (types and internal indexes)
getConsistencyModifier() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getConsistencyModifier() - Method in interface org.janusgraph.graphdb.types.CompositeIndexType
 
getConsistencyModifier() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getConsistencyModifier() - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
getConsistencyModifier() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
getConsistencyModifier(SchemaSource) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
getConsistencyModifier() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getConsistentTx() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getConstraints() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
getContainedNamespaces(ReadConfiguration, ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
getContent() - Method in interface org.janusgraph.diskstorage.log.Message
Returns the content of the message
getContent() - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
getContent() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getContentAsModifications(Serializer) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getContentAsSecondaryFailures(Serializer) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getConvergedKeys() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusReport
 
getConversionFunction(ElementCategory) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getCorePoolSize() - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
getCounter(String) - Method in enum org.janusgraph.util.stats.MetricManager
 
getCounter(String, String...) - Method in enum org.janusgraph.util.stats.MetricManager
 
getCoveredClauses() - Method in class org.janusgraph.graphdb.query.index.IndexCandidateGroup
 
getCumulativeEvictions() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCumulativeHits() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCumulativeLookups() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCumulativeMisses() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCumulativeNonLivePuts() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCumulativePuts() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCurrentSize() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
getCurrentThreadTx() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getCustom(String) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics
Get the value of a custom counter.
getCustom(String) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
getCustomOption(ConfigOption<V>) - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Get an arbitrary transaction-specific option.
getCustomOption(ConfigOption<V>) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
getCustomOption(ConfigOption<V>) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getCustomOptions() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Return any transaction-specific options.
getCustomOptions() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
getCustomOptions() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getCustomParameters(Parameter[]) - Static method in enum org.janusgraph.graphdb.types.ParameterType
 
getDataOutput(int) - Method in interface org.janusgraph.graphdb.database.serialize.Serializer
 
getDataOutput(int) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
getDataSerializer() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getDatatype() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getDataType() - Method in enum org.janusgraph.diskstorage.EntryMetaData
 
getDatatype() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
getDataType() - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation
Returns the data type of the key's values.
getDataType() - Method in class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
getDataType() - Method in interface org.janusgraph.diskstorage.StoreMetaData
 
getDataType() - Method in enum org.janusgraph.diskstorage.StoreMetaData.TTLImpl
 
getDataType() - Method in class org.janusgraph.graphdb.schema.PropertyKeyDefinition
Deprecated.
 
getDataType() - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
getDefaultFieldName(PropertyKey, Parameter[], String) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getDefaultMediator() - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
Get the default LocalLockMediator for Locker being built.
getDefaultMediator() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
getDefaultSchemaMaker() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getDefaultStringMapping() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
getDefaultValue() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getDefinition() - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
getDefinition() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getDeletions() - Method in class org.janusgraph.diskstorage.Mutation
Returns the list of deletions in this mutation.
getDeletionTime(TimestampProvider) - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getDeployment() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
Returns the DistributedStoreManager.Deployment mode of this connection to the storage backend
getDeprecationReplacement() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getDescription() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getDirection() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
Returns the direction on which this index is installed.
getDirection() - Method in enum org.janusgraph.graphdb.database.idhandling.IDHandler.DirectionID
 
getDirection() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getDirection() - Method in class org.janusgraph.graphdb.query.condition.DirectionCondition
 
getDirection() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getDirtyVertexSize() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getDirtyVertexSize() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
The initial size of the dirty (modified) vertex map used by a transaction.
getDouble() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getDouble(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getDouble() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getDouble(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getDoubles(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getDoubles(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getDoubles(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getDoubles(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getEdgeId(Object) - Static method in class org.janusgraph.graphdb.tinkerpop.ElementUtils
 
getEdgeLabel() - Method in class org.janusgraph.core.Connection
 
getEdgeLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the edge label with the given name.
getEdgeLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getEdgeLabel(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getEdgeLabel(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
Deprecated.
 
getEdgeLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getEdgeLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getEdgeLabels() - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getEdges(RelationIdentifier...) - Method in interface org.janusgraph.core.JanusGraphTransaction
 
getEdges(Vertex, Change, Direction, String...) - Method in interface org.janusgraph.core.log.ChangeState
Returns all edges incident on the given vertex in the given direction that match the provided change state and edge labels.
getEdges(StandardJanusGraphTx, PropertyKey, Object) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
getEdges(StandardJanusGraphTx, String, Object) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
getEdges(RelationIdentifier...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getEdges(TypeDefinitionCategory, Direction) - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getEdges(TypeDefinitionCategory, Direction, JanusGraphSchemaVertex) - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getEdgeSerializer() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getEdgeSerializer() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getElapsed() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
getElement() - Method in exception org.janusgraph.core.InvalidElementException
Returns the element causing the exception
getElement() - Method in interface org.janusgraph.core.JanusGraphIndexQuery.Result
Returns the element that matches the query
getElement() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
getElement() - Method in interface org.janusgraph.graphdb.types.IndexType
 
getElement() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getElementType() - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
getEnd() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRange
 
getEnd() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getEnd() - Method in interface org.janusgraph.util.datastructures.Interval
 
getEnd() - Method in class org.janusgraph.util.datastructures.PointInterval
 
getEnd() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
getEntries() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyIterator
Returns an iterator over all entries associated with the current key that match the column range specified in the query.
getEntries() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeySlicesIterator
Returns map of iterators over all entries associated with the current key that match the column range specified in the queries.
getEntries() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
 
getEntries() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
 
getEntry() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
getEnumValue(String, Class<E>) - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getErrorSettingCount() - Method in class org.janusgraph.util.system.ConfigurationLint.Status
 
getExecutionInfo() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
getExistingEdgeLabel(long) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
getExistingPropertyKey(long) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
getExistingRelationType(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getExistingRelationType(long) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
getExistingVertexLabel(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getExistingVertexLabel(long) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
getExpirationTimestamp() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
getExpirationTimestamp() - Method in interface org.janusgraph.diskstorage.locking.LockStatus
Returns the moment at which this lock expires (inclusive).
getFailureStatus() - Method in enum org.janusgraph.core.schema.SchemaAction
 
getFeatures() - Method in interface org.janusgraph.diskstorage.indexing.IndexInformation
The features of this index
getFeatures() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getFeatures() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getFeatures() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Returns the features supported by this storage manager
getFeatures() - Method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
getFeatures() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
getFeatures() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
getFeatures() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
getFeatures(StandardJanusGraph, StoreFeatures) - Static method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
 
getField(PropertyKey) - Method in interface org.janusgraph.graphdb.types.IndexType
 
getField(PropertyKey) - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getField(PropertyKey) - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
getField(PropertyKey) - Method in interface org.janusgraph.graphdb.types.MixedIndexType
 
getFieldKey() - Method in class org.janusgraph.graphdb.types.IndexField
 
getFieldKeys() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns the indexed keys of this index.
getFieldKeys() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
getFieldKeys() - Method in interface org.janusgraph.graphdb.types.CompositeIndexType
 
getFieldKeys() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getFieldKeys() - Method in interface org.janusgraph.graphdb.types.IndexType
 
getFieldKeys() - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
getFieldKeys() - Method in interface org.janusgraph.graphdb.types.MixedIndexType
 
getFirstStoreShorthand() - Method in enum org.janusgraph.diskstorage.StandardStoreManager
 
getFloat() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getFloat(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getFloat() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getFloat(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getFloats(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getFloats(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getFloats(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getFloats(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getFromCache(SliceQuery) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
getGlobalRange(int) - Static method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getGlobalSystemConfig() - Method in class org.janusgraph.diskstorage.Backend
 
getGraph(String) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
getGraph() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraElementTraversal
 
getGraph() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
Returns the graph that this transaction is based on
getGraph() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getGraphIndex(String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns the graph index with the given name or null if it does not exist
getGraphIndex(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getGraphIndexDirect(String, StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getGraphIndexes(Class<? extends Element>) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns all graph indexes that index the given element type.
getGraphIndexes(Class<? extends Element>) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getGraphName() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getGraphName() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getGraphNames() - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Get a Set of the graphNames that exist in your configuration management graph
getGraphNames() - Static method in class org.janusgraph.core.JanusGraphFactory
Return a Set of graph names stored in the JanusGraphManager
getGraphNames() - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Get a set of all graph names, excluding the template configuration; if none exist, return an empty set
getGraphNames() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
getGroupName() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Returns the (possibly null) group name for this transaction.
getGroupName() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
getGroupName() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
getGroupName() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getHadoopManager() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Returns org.janusgraph.hadoop.HadoopStoreManager
getHadoopManager() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
getHardMaxLimit() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getHasContainers() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getHeader() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getHeapArray() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
This method returns the internal heap array as Object[].
getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
getHighLimit() - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
getHistogram(String) - Method in enum org.janusgraph.util.stats.MetricManager
 
getHistogram(String, String...) - Method in enum org.janusgraph.util.stats.MetricManager
 
getID(int) - Method in interface org.janusgraph.core.VertexList
Returns the id of the vertex at the specified position
getId(long) - Method in interface org.janusgraph.diskstorage.IDBlock
Returns the id at the given index.
getId() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
getID(int) - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
getID(int) - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
getID() - Method in interface org.janusgraph.graphdb.types.CompositeIndexType
 
getID() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getIDAssigner(Backend) - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getIDAuthority() - Method in class org.janusgraph.diskstorage.Backend
Returns the configured IDAuthority.
getIDBlock(int, int, Duration) - Method in interface org.janusgraph.diskstorage.IDAuthority
Returns a block of new ids in the form of IDBlock.
getIDBlock(int, int, Duration) - Method in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
getIdentifier() - Method in class org.janusgraph.diskstorage.log.ReadMarker
Returns the configured identifier of this marker or throws an exception if none exists.
getIdInspector() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getIDManager() - Method in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
getIDManager() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getIdMap(Iterable<K>) - Static method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getIDRanges(int, List<KeyRange>) - Static method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getIDs() - Method in interface org.janusgraph.core.VertexList
Returns a list of ids of all vertices in this list of vertices in the same order of the original vertex list.
getIDs() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
getIDs() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
getIdUpperBound(int) - Method in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
getIdUpperBound(int) - Method in interface org.janusgraph.graphdb.database.idassigner.IDBlockSizer
Returns the upper bound for any id block returned by IDAuthority.getIDBlock(int, int, Duration) for the given id namespace.
getIdUpperBound() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getIdUpperBound(int) - Method in class org.janusgraph.graphdb.database.idassigner.StaticIDBlockSizer
 
getIfPresent(JointIndexQuery.Subquery) - Method in class org.janusgraph.graphdb.transaction.subquerycache.EmptySubqueryCache
 
getIfPresent(JointIndexQuery.Subquery) - Method in interface org.janusgraph.graphdb.transaction.subquerycache.SubqueryCache
Return a list of results if given query exists in cache, otherwise return null
getIfPresent(JointIndexQuery.Subquery) - Method in class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
getImplementationClass(Configuration, String, Map<String, String>) - Static method in class org.janusgraph.diskstorage.Backend
 
getIncomingVertexLabel() - Method in class org.janusgraph.core.Connection
 
getInconsistentTx() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getIndex() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
getIndex() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getIndex() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
getIndex() - Method in class org.janusgraph.graphdb.query.index.IndexCandidate
 
getIndex() - Method in class org.janusgraph.graphdb.transaction.lock.IndexLockTuple
 
getIndexCacheWeight() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getIndexCacheWeight() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
The maximum weight for the index cache store used in this particular transaction
getIndexCandidates() - Method in class org.janusgraph.graphdb.query.index.IndexCandidateGroup
 
getIndexedElement() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns which element type is being indexed by this index (vertex, edge, or property)
getIndexedElement() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
getIndexedKeys(IndexType) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
getIndexFeatures() - Method in class org.janusgraph.diskstorage.Backend
Returns the IndexFeatures of all configured index backends
getIndexIdFromKey(StaticBuffer) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getIndexInfoRetriever(StandardJanusGraphTx) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getIndexInformation() - Method in class org.janusgraph.diskstorage.Backend
Get information about all registered IndexProviders.
getIndexJobStatus(Index) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
If an index update job was triggered through JanusGraphManagement.updateIndex(Index, SchemaAction) with schema actions SchemaAction.REINDEX or SchemaAction.REMOVE_INDEX then this method can be used to track the status of this asynchronous process.
getIndexJobStatus(Index) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getIndexName() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
getIndexOnlyConstraint(String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns the indexOnly constraint for the index with given name or null if such constraint does not exist
getIndexOnlyConstraint(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getIndexQuery() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getIndexSelectionStrategy() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getIndexSelector() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getIndexSerializer() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getIndexStatus(PropertyKey) - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns the status of this index with respect to the provided PropertyKey.
getIndexStatus() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
Returns the status of this index
getIndexStatus(PropertyKey) - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
getIndexStatus() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getIndexTransaction(String) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
getIndexTypeScore(IndexType) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
getIndexUpdates(InternalRelation) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getIndexUpdates(InternalVertex, Collection<InternalRelation>) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getInstance() - Static method in class org.janusgraph.core.JanusGraphManagerUtility
 
getInstance() - Static method in class org.janusgraph.diskstorage.configuration.converter.ReadConfigurationConverter
 
getInstance() - Static method in class org.janusgraph.graphdb.configuration.converter.RegisteredAttributeClassesConverter
 
getInstance() - Static method in class org.janusgraph.graphdb.idmanagement.UniqueInstanceIdRetriever
 
getInstance() - Static method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
If one of your "graphs" key was equivalent to "ConfigurationManagementGraph" in your YAML file supplied at server start, then we return the ConfigurationManagementGraph Singleton-- otherwise we throw a ConfigurationManagementGraphNotEnabledException exception.
getInstance() - Static method in class org.janusgraph.graphdb.management.JanusGraphManager
 
getInstance() - Static method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
getInstance() - Static method in class org.janusgraph.graphdb.transaction.indexcache.EmptyIndexCache
 
getInstance() - Static method in class org.janusgraph.graphdb.transaction.subquerycache.EmptySubqueryCache
 
getInstance() - Static method in class org.janusgraph.graphdb.transaction.vertexcache.EmptyVertexCache
 
getInstanceId() - Method in interface org.janusgraph.core.log.TransactionId
Returns the unique id of the JanusGraph graph instance which executed the transaction.
getInstanceId() - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
getInt() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getInt(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getInt() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getInt(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getInt(byte[], int) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getIntBuffer(int) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
getIntBuffer(int[]) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
getIntermediateResult() - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexJobFuture
Returns a set of potentially incomplete and still-changing metrics for this job.
getInternalVertex(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getInternalVertex(long) - Method in interface org.janusgraph.graphdb.transaction.VertexFactory
 
getInts(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getInts(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getInts(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getInts(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getIteration() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
getJanusGraph(Traversal.Admin<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getJanusGraphTx(Traversal.Admin<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getJanusGraphVertex(Element) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getJanusGraphVertex(Traverser<? extends Element>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getJobConfiguration() - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
getJobId() - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
getKCVSLogManager(String) - Method in class org.janusgraph.diskstorage.Backend
 
getKeepAliveTime() - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
getKey() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
getKey() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
getKey() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
getKey(HashingUtil.HashLength, StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.HashingUtil
 
getKey() - Method in class org.janusgraph.diskstorage.util.KeyColumn
 
getKey() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
getKey(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getKey(int) - Method in class org.janusgraph.graphdb.internal.OrderList
 
getKey() - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
getKey() - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
getKeyConsistentTxConfig() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getKeyConsistentTxConfig() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration that enforces key consistency.
getKeyEnd() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
getKeyFilter() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
A predicate that determines whether ScanJob.process(org.janusgraph.diskstorage.StaticBuffer, java.util.Map, ScanMetrics) should be invoked for the given key.
getKeyFilter() - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
getKeyFilter() - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
getKeyID(StaticBuffer) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getKeyIndexes() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getKeyIndexes() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
getKeyIndexes() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getKeyIndexes() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getKeys(String) - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
getKeys(String) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
getKeys(String) - Method in interface org.janusgraph.diskstorage.configuration.ReadConfiguration
 
getKeys(String) - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getKeys(SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getKeys(MultiSlicesQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getKeys(KeyColumnValueStore, StoreFeatures, int, int, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
getKeys(KeyColumnValueStore, SliceQuery, StoreFeatures, int, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Returns a KeyIterator over all keys that fall within the key-range specified by the given query and have one or more columns matching the column-range.
getKeys(SliceQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Returns a KeyIterator over all keys in the store that have one or more columns matching the column-range.
getKeys(MultiSlicesQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Returns a KeySlicesIterator over all keys in the store that have one or more columns matching the column-range.
getKeys(KeyRangeQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getKeys(SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getKeys(MultiSlicesQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getKeys(SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getKeys(MultiSlicesQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getKeySelector() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getKeyStart() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
getLatestAccessedItems(int) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
getLen() - Method in interface org.janusgraph.graphdb.internal.InternalRelation
Number of vertices on this relation that are aware of its existence.
getLen() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
getLen() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
getLength(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
getLifeCycle() - Method in interface org.janusgraph.graphdb.internal.InternalElement
 
getLifeCycle() - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
getLifeCycle() - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
getLifeCycle() - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
getLifeCycle() - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
getLifeCycle() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
getLifeCycle() - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
getLimit() - Method in class org.janusgraph.graphdb.query.BaseQuery
 
getLimit() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
getLimit() - Method in interface org.janusgraph.graphdb.query.Query
 
getLoadedProperties() - Method in class org.janusgraph.graphdb.olap.computer.PartitionVertexAggregate
 
getLocalAddress() - Static method in class org.janusgraph.util.system.NetworkUtil
 
getLocalConfiguration() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getLocalHighLimit(TraversalParent, List<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
getLocalHighLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
getLocalHighLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getLocalHighLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
getLocalHost() - Static method in class org.janusgraph.util.system.NetworkUtil
 
getLocalHostName() - Static method in class org.janusgraph.util.system.NetworkUtil
 
getLocalIDPartition() - Method in interface org.janusgraph.diskstorage.IDAuthority
Returns the lower and upper limits of the key range assigned to this local machine as an array with two entries.
getLocalIDPartition() - Method in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
getLocalKeyConsistentTxConfig() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getLocalKeyConsistentTxConfig() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration that enforces local key consistency.
getLocalKeyPartition() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getLocalKeyPartition() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getLocalKeyPartition() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Returns KeyRanges locally hosted on this machine.
getLocalKeyPartition() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
getLocalLowLimit(TraversalParent, List<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
getLocalLowLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
getLocalLowLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getLocalLowLimit(TraversalParent, List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
getLocalMultiQueryPositionForStep(Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
For a MultiQuery compatible step, this method searches the correct position in the step's traversal at which a JanusGraphMultiQueryStep should be inserted.
getLock() - Static method in class org.janusgraph.diskstorage.util.NoLock
 
getLocker(String) - Method in class org.janusgraph.diskstorage.Backend
 
getLocker(String) - Method in interface org.janusgraph.diskstorage.locking.LockerProvider
 
getLocksForTx(StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.LockerState
 
getLogIdentifier() - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Returns the identifier of the transaction log to be processed by this processor.
getLogIdentifier() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getLogIdentifier() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
The name of the log to be used for logging the mutations in this transaction.
getLogKey() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
getLogManager(String) - Method in class org.janusgraph.diskstorage.Backend
 
getLong() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getLong(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getLong() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getLong(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getLong(byte[], int) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getLongBuffer(long) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
getLongId() - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
getLongs(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getLongs(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getLongs(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getLongs(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getLoopbackAddress() - Static method in class org.janusgraph.util.system.NetworkUtil
 
getLowerID() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
getLowLimit() - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
getManagedTypes() - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getManagerClass() - Method in enum org.janusgraph.diskstorage.StandardStoreManager
 
getMap() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
getMapping(KeyInformation) - Static method in enum org.janusgraph.core.schema.Mapping
 
getMapping(String, String, KeyInformation.IndexRetriever) - Static method in enum org.janusgraph.core.schema.Mapping
 
getMatchingIndexes(MultiCondition<JanusGraphElement>) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
getMatchingIndexes(MultiCondition<JanusGraphElement>, Predicate<IndexType>) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
getMaxCommitTime() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getMaxPoolSize() - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
getMaxWriteTime() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getMemoryKeys() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getMessage() - Method in class org.janusgraph.diskstorage.log.util.FutureMessage
Returns the actual message that was added to the log
getMessage(MessageScope, Map<MessageScope, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
getMetaData() - Method in class org.janusgraph.diskstorage.indexing.IndexEntry
 
getMetaData() - Method in interface org.janusgraph.diskstorage.MetaAnnotated
 
getMetaData(E, EntryMetaData) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.GetColVal
 
getMetaData() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
getMetadata() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getMetaDataSchema(String) - Method in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
getMetaSchema(E) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.GetColVal
 
getMetrics() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem.IndexJobStatus
 
getMetrics() - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
getMetricsPrefix() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getMixedIndexCountQuery() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
getMixedQuery() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
getModifier() - Method in class org.janusgraph.graphdb.types.SchemaSource.Entry
 
getModifier() - Method in class org.janusgraph.graphdb.types.TypeDefinitionDescription
 
getMultiplicity() - Method in class org.janusgraph.graphdb.schema.RelationTypeDefinition
Deprecated.
 
getMultiplicity() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
getMutableVertexProperties() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getName() - Method in interface org.janusgraph.core.schema.RelationTypeMaker
Returns the name of this configured relation type.
getName() - Method in interface org.janusgraph.core.schema.VertexLabelMaker
Returns the name of the to-be-build vertex label
getName() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getName() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getName() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getName() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Returns the name of this store.
getName() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
getName() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns the name of this store
getName() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getName() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreManager
Return an identifier for the StoreManager.
getName() - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
getName() - Method in interface org.janusgraph.diskstorage.log.Log
Returns the name of this log
getName() - Method in enum org.janusgraph.diskstorage.util.CacheMetricsAction
 
getName() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getName() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
getName() - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
getName(String) - Static method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
getName() - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
getName() - Method in interface org.janusgraph.graphdb.types.IndexType
 
getName() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getName() - Method in enum org.janusgraph.graphdb.types.ParameterType
 
getName() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
getName() - Method in class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
getNamespace() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getNew(Q) - Method in class org.janusgraph.graphdb.query.MetricsQueryExecutor
 
getNew(Q) - Method in interface org.janusgraph.graphdb.query.QueryExecutor
Returns all newly created elements in a transactional context that match the given query.
getNewIterator(int) - Method in class org.janusgraph.graphdb.query.LimitAdjustingIterator
This returns the wrapped iterator with up to the specified number of elements.
getNextNonIdentityStep(Step) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getNextTx() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getNoCombinedQueries() - Method in interface org.janusgraph.core.QueryDescription
Returns how many individual queries are combined into this query, meaning, how many queries will be executed in one batch.
getNoSubQueries() - Method in interface org.janusgraph.core.QueryDescription
Returns the number of sub-queries this query is comprised of.
getNotConvergedKeys() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusReport
 
getNumProcessed() - Method in class org.janusgraph.core.schema.JobStatus
 
getOffset() - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
getOffset() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getOldestAccessedItems(int) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
Returns 'n' number of oldest accessed entries present in this cache.
getOpenInstances() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns a set of unique instance ids for all JanusGraph instances that are currently part of this graph cluster.
getOpenInstances() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getOpenInstancesInternal() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getOpenTransactions() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getOptionForShorthand(String) - Static method in class org.janusgraph.diskstorage.Backend
 
getOrCreateDataDirectory(String) - Static method in class org.janusgraph.diskstorage.util.DirectoryUtil
 
getOrCreateDataDirectory(String, String) - Static method in class org.janusgraph.diskstorage.util.DirectoryUtil
 
getOrCreateEdgeLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the edge label with the given name.
getOrCreateEdgeLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getOrCreateEdgeLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getOrCreateEdgeLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOrCreatePropertyKey(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the property key with the given name.
getOrCreatePropertyKey(String, Object) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the property key with the given name.
getOrCreatePropertyKey(String, Object, VertexProperty.Cardinality) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the property key with the given name.
getOrCreatePropertyKey(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getOrCreatePropertyKey(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getOrCreatePropertyKey(String, Object) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOrCreatePropertyKey(String, Object, VertexProperty.Cardinality) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOrCreatePropertyKey(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOrCreateVertexLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the vertex label with the given name.
getOrCreateVertexLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getOrCreateVertexLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getOrCreateVertexLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOrDefault(ConfigOption<O>, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
getOrder() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
getOrder() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
getOrder(int) - Method in class org.janusgraph.graphdb.internal.OrderList
 
getOrder() - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
getOrder() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getOrders() - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
getOrders() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getOrders() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getOrders() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
getOrders() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
getOrGenerateUniqueInstanceId(Configuration) - Method in class org.janusgraph.graphdb.idmanagement.UniqueInstanceIdRetriever
 
getOtherPartitionVertex(JanusGraphVertex, long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getOtherVertexId() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
getOutgoingVertexLabel() - Method in class org.janusgraph.core.Connection
 
getPageSize() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
Returns the default configured page size for this storage backend.
getParameter(V) - Method in enum org.janusgraph.graphdb.types.ParameterType
 
getParameters() - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation
Returns the parameters of the key's configuration.
getParameters() - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
getParameters() - Method in class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
getParameters() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getParameters() - Method in class org.janusgraph.graphdb.types.ParameterIndexField
 
getParametersFor(PropertyKey) - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns the parameters associated with an indexed key of this index.
getParametersFor(PropertyKey) - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
getPartition(InternalElement) - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
Individually assigns an id to the given vertex or relation.
getPartition(InternalElement) - Method in class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
getPartition(InternalElement) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
getPartitionBound() - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getPartitionedVertexId(long, long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getPartitionedVertexRepresentatives(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getPartitionHashForId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getPartitionID() - Method in interface org.janusgraph.graphdb.database.idassigner.placement.PartitionAssignment
Returns the assigned partition id
getPartitionID() - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
getPartitionId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getPartitionKey(int) - Method in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
Returns a byte buffer representation for the given partition id
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
Bulk assignment of idAuthorities to vertices.
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
getPath(ConfigElement, String...) - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
getPath(ConfigElement, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
getPath(ConfigElement, String...) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getPath(ConfigElement, boolean, String...) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getPoints() - Method in interface org.janusgraph.util.datastructures.Interval
 
getPoints() - Method in class org.janusgraph.util.datastructures.PointInterval
 
getPoints() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
getPosition() - Method in interface org.janusgraph.diskstorage.ReadBuffer
 
getPosition() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getPosition() - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
getPosition() - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
getPowerOf2(long) - Static method in class org.janusgraph.util.stats.NumberUtil
Returns an integer X such that 2^X=value.
getPredicate() - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
getPreferredTimestamps() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getPreferredTimestamps() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
If this storage backend supports one particular type of data timestamp/version better than others.
getPrefix() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getPreviousID() - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
getPreviousID() - Method in interface org.janusgraph.graphdb.relations.StandardRelation
 
getPreviousID() - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
getPreviousScopes() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getPreviousStepOfClass(Class<S>, Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
Starting at the given step, this method searches the traversal backwards to find the most recent step which matches the given class.
getProfiler() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
getProfiler() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getProfiler() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
getProfiler() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
getProfiler() - Method in class org.janusgraph.graphdb.query.graph.MixedIndexCountQueryBuilder
 
getProfiler() - Method in interface org.janusgraph.graphdb.query.profile.ProfileObservable
 
getProfiler() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getProperties(Vertex, Change, String...) - Method in interface org.janusgraph.core.log.ChangeState
Returns all properties incident for the given vertex that match the provided change state and property keys.
getProperty(long, String) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
getProperty(String, Map<String, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.PartitionVertexAggregate
 
getProperty(String, Map<String, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
getPropertyKey(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the property key with the given name.
getPropertyKey(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getPropertyKey(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getPropertyKey(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
Deprecated.
 
getPropertyKey(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getPropertyKey(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getPropertyKeys() - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getPropertyKeys(JanusGraphVertex) - Static method in class org.janusgraph.graphdb.util.ElementHelper
 
getPropertyKeysDirect() - Method in interface org.janusgraph.graphdb.internal.InternalRelation
 
getPropertyKeysDirect() - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
getPropertyKeysDirect() - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
getPropertyKeysDirect() - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
getPropertyKeysDirect() - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
getProtectedConstructor(Class, Class...) - Static method in class org.janusgraph.diskstorage.util.Hex
Used to get access to protected/private constructor of the specified class
getProviderName() - Method in enum org.janusgraph.diskstorage.StandardIndexProvider
 
getQueries() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
Returns one or more SliceQuery instances belonging to this ScanJob.
getQueries() - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob.Executor
 
getQueries(QueryContainer) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
getQueries() - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
 
getQueries(QueryContainer) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
getQueries() - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
getQueries() - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
getQueries(QueryContainer) - Method in class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
getQueries() - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
getQueries(QueryContainer) - Method in interface org.janusgraph.graphdb.olap.VertexScanJob
Specify the queries for the data to be loaded into the vertices prior to processing.
getQueries() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getQuery() - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
getQuery(RelationCategory, boolean) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
getQuery(InternalRelationType, Direction, EdgeSerializer.TypedInterval[]) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
getQuery(CompositeIndexType, List<Object[]>) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getQuery(MixedIndexType, Condition, OrderList) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
getQuery(RelationCategory) - Method in class org.janusgraph.graphdb.database.RelationQueryCache
 
getQuery(InternalRelationType, Direction) - Method in class org.janusgraph.graphdb.database.RelationQueryCache
 
getQuery() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getQuery(int) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
getQuery() - Method in class org.janusgraph.graphdb.query.index.IndexSelectionStrategy.SelectedIndexQuery
 
getQuery(CompositeIndexType, Object[], StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.util.IndexHelper
 
getQueryCacheSize() - Method in class org.janusgraph.graphdb.vertices.CacheVertex
 
getQueryResults(CompositeIndexType, Object[], StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.util.IndexHelper
 
getRandomID() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
Returns a random partition id that lies within this partition id range.
getRecordValues() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexRecords
 
getRegistry() - Method in enum org.janusgraph.util.stats.MetricManager
Return the JanusGraph Metrics registry.
getRelated(TypeDefinitionCategory, Direction) - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
getRelated(TypeDefinitionCategory, Direction) - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getRelationCategory() - Method in enum org.janusgraph.graphdb.database.idhandling.IDHandler.DirectionID
 
getRelationCountBound() - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getRelationID(long, long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getRelationIndex(RelationType, String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns the RelationTypeIndex with the given name for the provided RelationType or null if it does not exist
getRelationIndex(RelationType, String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getRelationIndexes(RelationType) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns an Iterable over all RelationTypeIndexes defined for the provided RelationType
getRelationIndexes(RelationType) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getRelationIndexes() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getRelationIndexes() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getRelationIndexes() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getRelations(Change, RelationType...) - Method in interface org.janusgraph.core.log.ChangeState
Returns all relations that match the change state and any of the provided relation types.
getRelationType(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the type with the given name.
getRelationType(long, IDHandler.DirectionID, boolean) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
getRelationType(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getRelationType(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getRelationType(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
Deprecated.
 
getRelationType(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getRelationType(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getRelationType(String) - Method in interface org.janusgraph.graphdb.types.TypeInspector
 
getRelationTypeName() - Method in class org.janusgraph.graphdb.database.management.RelationIndexStatusReport
 
getRelationTypeName(String) - Static method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
getRelationTypes(Class<T>) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns an iterable over all defined types that have the given clazz (either EdgeLabel which returns all labels, PropertyKey which returns all keys, or RelationType which returns all types).
getRelationTypes(Class<T>) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getRemover(VertexProperty.Cardinality, Object) - Static method in interface org.janusgraph.core.JanusGraphVertexProperty
 
getRestrictedPartitions() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getRestrictedPartitions() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Querying of partitioned vertices is restricted to the partitions returned by this method.
getResult() - Method in class org.janusgraph.diskstorage.indexing.RawQuery.Result
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in interface org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.ResultConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
getResultSize() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
getResultType() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getReverseElementTraversal(MessageScope.Local<?>, Vertex, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.olap.computer.FulgoraUtil
 
getReverseJanusGraphVertexStep(MessageScope.Local<?>, JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.olap.computer.FulgoraUtil
 
getRid() - Method in class org.janusgraph.diskstorage.locking.consistentkey.TimestampRid
 
getRoot() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
getRootNamespace() - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
getRunningJob(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner
 
getRuntime() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
getScanJobStatus(Object) - Method in class org.janusgraph.diskstorage.Backend
 
getScanTxConfig() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getScanTxConfig() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration suitable for reading data into a ScanJob.
getSchemaBase() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getSchemaCache() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getSchemaCountBound() - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getSchemaElement(long) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getSchemaId(String) - Method in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
getSchemaId(String) - Method in interface org.janusgraph.graphdb.database.cache.SchemaCache
 
getSchemaId(String) - Method in class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
getSchemaId(IDManager.VertexIDType, long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getSchemaName(String) - Method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in interface org.janusgraph.graphdb.database.cache.SchemaCache
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
getSchemaType() - Method in class org.janusgraph.graphdb.types.SchemaSource.Entry
 
getSchemaTypeConstraint() - Method in interface org.janusgraph.graphdb.types.IndexType
 
getSchemaTypeConstraint() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
getSchemaVertex(JanusGraphSchemaElement) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getSchemaVertex(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getScore() - Method in interface org.janusgraph.core.JanusGraphIndexQuery.Result
Returns the score of the result with respect to the query (if available)
getScore() - Method in class org.janusgraph.diskstorage.indexing.RawQuery.Result
 
getScore() - Method in class org.janusgraph.graphdb.query.index.IndexCandidate
 
getSenderId() - Method in interface org.janusgraph.diskstorage.log.Message
Returns the unique identifier for the sender of the message
getSenderId() - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
getSentinelObject() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
This method can be overridden by extending classes to return a sentinel object which will be used by the PriorityQueue(int,boolean) constructor to fill the queue, so that the code which uses that queue can always assume it's full and only change the top without attempting to insert any new object.
Those sentinel values should always compare worse than any non-sentinel value (i.e., PriorityQueue.lessThan(T, T) should always favor the non-sentinel values).
By default, this method returns false, which means the queue will not be filled with sentinel values.
getSeparatedName(String...) - Static method in class org.janusgraph.graphdb.internal.Token
 
getSerializer(EntryMetaData) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
getSerializer() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getSerializer(Configuration) - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getShort() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getShort(int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getShort() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getShort(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getShorthands() - Method in enum org.janusgraph.diskstorage.StandardIndexProvider
 
getShorthands() - Method in enum org.janusgraph.diskstorage.StandardStoreManager
 
getShorts(int) - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
getShorts(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
getShorts(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
getShorts(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
getSignature() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getSignature() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
getSignature() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getSignature() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getSingleHostname() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
Returns a randomly chosen host name.
getSingleType() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getSize(D) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.DataHandler
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
getSlice(KeySliceQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Retrieves the list of entries (i.e.
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Retrieves the list of entries (i.e.
getSlice(OrderedKeyValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
getSlice(OrderedKeyValueStore, StaticBuffer, StaticBuffer, int, StoreTransaction) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
getSlice(KVQuery, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Returns a list of all Key-value pairs (KeyValueEntry where the keys satisfy the given KVQuery.
getSlice(KeySliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
getSliceEnd() - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
The end of the slice is considered to be exclusive
getSliceNoCache(KeySliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
getSliceNoCache(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
getSliceQueries() - Method in class org.janusgraph.graphdb.olap.QueryContainer
 
getSlices(List<KVQuery>, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Like OrderedKeyValueStore.getSlice(KVQuery, org.janusgraph.diskstorage.keycolumnvalue.StoreTransaction) but executes all of the given queries at once and returns a map of all the result sets of each query.
getSliceStart() - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
The start of the slice is considered to be inclusive
getSortKey() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
Returns the (composite) sort key for this index.
getSortKey() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getSortKey() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getSortKey() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getSortKey() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getSortOrder() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
Returns the sort order of this index.
getSortOrder() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getSortOrder() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getSortOrder() - Method in interface org.janusgraph.graphdb.query.ElementQuery
Returns the expected sort order of this query if any was specified.
getSortOrder() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getSortOrder() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
getSortOrder() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getSortOrder() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getStart() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRange
 
getStart() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getStart() - Method in interface org.janusgraph.util.datastructures.Interval
 
getStart() - Method in class org.janusgraph.util.datastructures.PointInterval
 
getStart() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
getStartTime(TimestampProvider) - Method in class org.janusgraph.diskstorage.log.ReadMarker
Returns the start time of this marker if such has been defined or the current time if not
getStartTime() - Method in class org.janusgraph.diskstorage.util.time.Timer
 
getState() - Method in class org.janusgraph.core.schema.JobStatus
 
getStaticBuffer() - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
getStaticBuffer() - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
getStaticBufferFlipBytes(int, int) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
getStaticBufferFlipBytes(int, int) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
getStatistics() - Method in class org.janusgraph.graphdb.log.StandardTransactionLogProcessor
 
getStats() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
getStatus() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
getStatus() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getStatus() - Method in interface org.janusgraph.graphdb.types.CompositeIndexType
 
getStatus() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getStatus() - Method in class org.janusgraph.graphdb.types.ParameterIndexField
 
getStatus() - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
getStatus() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getStatus() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getSteps(Predicate<Step>, Traversal.Admin<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
Returns a list of steps from the traversal, which match a given predicate.
getStorageConfig() - Method in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
getStorageManager(Configuration) - Static method in class org.janusgraph.diskstorage.Backend
 
getStore() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
getStore() - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
getStoreFeatures() - Method in class org.janusgraph.diskstorage.Backend
Returns the StoreFeatures of the configured backend storage engine.
getStoreFeatures() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getStoreManager() - Method in class org.janusgraph.diskstorage.Backend
 
getStoreManagerClass() - Method in class org.janusgraph.diskstorage.Backend
 
getStoreName() - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
getStoreName() - Method in interface org.janusgraph.graphdb.types.MixedIndexType
 
getStoreTransaction() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
getSubCondition() - Method in class org.janusgraph.graphdb.query.index.IndexCandidate
 
getSubCover() - Method in class org.janusgraph.graphdb.query.index.IndexCandidate
 
getSubQueries() - Method in interface org.janusgraph.core.QueryDescription
Returns a list of all sub-queries that comprise this query
getSubQuery(int) - Method in interface org.janusgraph.graphdb.query.ElementQuery
Returns the backend query at the given position that comprises this ElementQuery
getSubQuery(int) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
getSubQuery(int) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
getSubset(ReadConfiguration, ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
getSubset(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
getSubset(ConfigNamespace, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
getSubset(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
getSubset(ConfigNamespace, String...) - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
getSubset(SliceQuery, EntryList) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
getSucceeded() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
getSystemMgmtLog() - Method in class org.janusgraph.diskstorage.Backend
 
getSystemTxLog() - Method in class org.janusgraph.diskstorage.Backend
 
getSystemType(long) - Static method in class org.janusgraph.graphdb.types.system.SystemTypeManager
 
getSystemType(String) - Static method in class org.janusgraph.graphdb.types.system.SystemTypeManager
 
getTargetStatuses() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
getTemplateConfiguration() - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Get template configuration if exists, else return null.
getTemplateConfiguration() - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Get template configuration if exists, else return null.
getTemporaryRelationID(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getTemporaryVertexID(IDManager.VertexIDType, long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getThis() - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
getThis() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getThis() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
getThis() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
getThreadFactory() - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
getThrowable() - Method in class org.janusgraph.util.datastructures.ExceptionWrapper
 
getTime() - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Returns the current time based on this timestamp provider as a Instant.
getTime(long) - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Returns the given time as a Instant based off of this timestamp providers units
getTime(Instant) - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Returns the scalar value for this instant given the configured time unit
getTimer() - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Returns a Timer based on this timestamp provider
getTimer() - Method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
 
getTimer(String) - Method in enum org.janusgraph.util.stats.MetricManager
 
getTimer(String, String...) - Method in enum org.janusgraph.util.stats.MetricManager
 
getTimestamp() - Method in class org.janusgraph.diskstorage.locking.consistentkey.TimestampRid
 
getTimestamp() - Method in interface org.janusgraph.diskstorage.log.Message
Returns the timestamp of this message in the specified time unit.
getTimestamp() - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
getTimestamp() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
getTimestampProvider() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Returns the timestamp provider of this transaction.
getTimestampProvider() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
getTimestampProvider() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
getTimestampProvider() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getTimestampProvider() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getTotalMutations() - Method in class org.janusgraph.diskstorage.Mutation
 
getTotalScore() - Method in class org.janusgraph.graphdb.query.index.IndexCandidateGroup
 
getTotalSettingCount() - Method in class org.janusgraph.util.system.ConfigurationLint.Status
 
getTotalTime() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
getTP() - Method in enum org.janusgraph.graphdb.internal.Order
 
getTransaction() - Method in class org.janusgraph.graphdb.olap.QueryContainer
 
getTransactionId() - Method in interface org.janusgraph.core.log.TransactionId
Returns the unique transaction id within a particular JanusGraph instance.
getTransactionId() - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
getTransactionTime() - Method in interface org.janusgraph.core.log.TransactionId
Returns the time of the transaction
getTransactionTime() - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
getTraversalSource(String) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
getTraversalSourceNames() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
getTTL(JanusGraphSchemaType) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Retrieves the time-to-live for the given JanusGraphSchemaType as a Duration.
getTtl() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
getTTL(JanusGraphSchemaType) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getTTL(InternalRelation) - Static method in class org.janusgraph.graphdb.database.StandardJanusGraph
The TTL of a relation (edge or property) is the minimum of: 1) The TTL configured of the relation type (if exists) 2) The TTL configured for the label any of the relation end point vertices (if exists)
getTTL(InternalVertex) - Static method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getTTL() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
getTTL() - Method in interface org.janusgraph.graphdb.internal.InternalVertexLabel
 
getTTL() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
getTTL() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
getTTL(SchemaSource) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
getTTL() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
getTTL() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
getTTLSeconds(Duration) - Static method in class org.janusgraph.util.encoding.ConversionHelper
 
getTTLSeconds(long, TemporalUnit) - Static method in class org.janusgraph.util.encoding.ConversionHelper
 
getTx(Traversal.Admin<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
getTxDirtyVertexSize() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getTxHandle() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getTxLogPersistor() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
getTxVertexCacheSize() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getType() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
getType() - Method in interface org.janusgraph.core.JanusGraphRelation
Returns the type of this relation.
getType() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
Returns the RelationType on which this index is installed.
getType() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
getType() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
getType() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getType() - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
getType() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
getType() - Method in class org.janusgraph.graphdb.query.condition.And
 
getType() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
getType() - Method in class org.janusgraph.graphdb.query.condition.Literal
 
getType() - Method in class org.janusgraph.graphdb.query.condition.Not
 
getType() - Method in class org.janusgraph.graphdb.query.condition.Or
 
getType(StandardJanusGraphTx, String) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
getType() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
getTypeCache(SchemaCache.StoreRetrieval) - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getUniqueGraphId() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getUniqueID() - Method in interface org.janusgraph.diskstorage.IDAuthority
Return the globally unique string used by this IDAuthority instance to recognize its ID allocations and distinguish its allocations from those belonging to other IDAuthority instances.
getUniqueID() - Method in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
getUniqueIndexes(PropertyKey) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
getUniquePrefixes(Configuration) - Static method in class org.janusgraph.util.system.ConfigurationUtil
 
getUnit() - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Return the units of TimestampProvider.getTime().
getUnknownIndexKeyName() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
getUnknownKeyName() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
getUpperID() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
getUserConfiguration() - Method in class org.janusgraph.diskstorage.Backend
 
getUserLog(String) - Method in class org.janusgraph.diskstorage.Backend
 
getUserLogName(String) - Static method in class org.janusgraph.diskstorage.Backend
 
getValue() - Method in interface org.janusgraph.diskstorage.Entry
 
getValue() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
getValue(E) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntry.GetColVal
 
getValue(TransactionConfiguration) - Method in enum org.janusgraph.graphdb.database.log.LogTxMeta
 
getValue() - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
getValue() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
getValue(TypeDefinitionCategory) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
 
getValue(TypeDefinitionCategory, Class<O>) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
 
getValueAs(StaticBuffer.Factory<T>) - Method in interface org.janusgraph.diskstorage.Entry
 
getValueDirect(PropertyKey) - Method in interface org.janusgraph.graphdb.internal.InternalRelation
 
getValueDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
getValueDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
getValueDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
getValueDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
getValuePosition() - Method in interface org.janusgraph.diskstorage.Entry
 
getValues(JanusGraphElement, PropertyKey) - Static method in class org.janusgraph.graphdb.util.ElementHelper
 
getVertex(long) - Method in interface org.janusgraph.core.JanusGraphTransaction
Retrieves the vertex for the specified id.
getVertex(int) - Method in interface org.janusgraph.graphdb.internal.InternalRelation
Returns the vertex at the given position (0=OUT, 1=IN) of this relation
getVertex(long) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getVertex(long) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
getVertex() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
getVertex(int) - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
getVertex(int) - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
getVertex(long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getVertexCacheSize() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
getVertexCacheSize() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
The maximum number of recently-used vertices to cache in this transaction.
getVertexCentricDirection() - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
getVertexCountBound() - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getVertexID() - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
getVertexID(long, long, IDManager.VertexIDType) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
getVertexId(StaticBuffer) - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
getVertexId(Object) - Static method in class org.janusgraph.graphdb.tinkerpop.ElementUtils
 
getVertexIDs(BackendTransaction) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
getVertexLabel(String) - Method in interface org.janusgraph.core.schema.SchemaInspector
Returns the vertex label with the given name.
getVertexLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getVertexLabel(String) - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getVertexLabel(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
Deprecated.
 
getVertexLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
getVertexLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getVertexLabelInternal() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
getVertexLabelInternal() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
getVertexLabels() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Returns an Iterable over all defined VertexLabels.
getVertexLabels() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getVertexLabels() - Method in class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
getVertexMapJob(StandardJanusGraph, FulgoraVertexMemory, Map<MapReduce, FulgoraMapEmitter>) - Static method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
getVertexProgramScanJob(StandardJanusGraph, FulgoraMemory, FulgoraVertexMemory, VertexProgram<M>) - Static method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
getVertices(long...) - Method in interface org.janusgraph.core.JanusGraphTransaction
 
getVertices(Change) - Method in interface org.janusgraph.core.log.ChangeState
Returns all added, removed, or modified vertices when the change argument is Change.ADDED, Change.REMOVED, or Change.ANY respectively.
getVertices(StandardJanusGraphTx, PropertyKey, Object) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
getVertices(StandardJanusGraphTx, String, Object) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
getVertices(long...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
getView(Predicate<InternalRelation>) - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
 
getView(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
getView(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
getView(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
getWildcardField() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
getWrappedTransaction() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
getWrappedTx() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
getWrappedType() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
getWriteTimestamp() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
GHOST_PARTITION_VERTEX - Static variable in class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
GHOST_VERTEX_COUNT - Static variable in class org.janusgraph.graphdb.olap.VertexJobConverter
 
GhostVertexRemover - Class in org.janusgraph.graphdb.olap.job
 
GhostVertexRemover(JanusGraph) - Constructor for class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
GhostVertexRemover() - Constructor for class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
GhostVertexRemover(GhostVertexRemover) - Constructor for class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
GLOBAL_PREFIX - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
gracefulExecutorServiceShutdown(ExecutorService, long) - Static method in class org.janusgraph.util.system.ExecuteUtil
 
graph() - Method in interface org.janusgraph.core.JanusGraphElement
 
graph() - Method in interface org.janusgraph.core.JanusGraphVertexProperty
 
graph() - Method in interface org.janusgraph.graphdb.internal.InternalElement
 
graph - Variable in class org.janusgraph.graphdb.olap.AbstractScanJob
 
graph - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
graph() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
graph() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
 
GRAPH_CENTRIC_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
GRAPH_NAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
GRAPH_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
GraphCacheEvictionAction - Enum in org.janusgraph.graphdb.database.management
 
GraphCentricQuery - Class in org.janusgraph.graphdb.query.graph
An executable ElementQuery for JanusGraphQuery.
GraphCentricQuery(ElementCategory, Condition<JanusGraphElement>, OrderList, BackendQueryHolder<JointIndexQuery>, int) - Constructor for class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
GraphCentricQueryBuilder - Class in org.janusgraph.graphdb.query.graph
Builds a JanusGraphQuery, optimizes the query and compiles the result into a GraphCentricQuery which is then executed through a QueryProcessor.
GraphCentricQueryBuilder(StandardJanusGraphTx, IndexSerializer, IndexSelectionStrategy) - Constructor for class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
GraphDatabaseConfiguration - Class in org.janusgraph.graphdb.configuration
Provides functionality to configure a JanusGraph INSTANCE.
GraphDatabaseConfiguration(ReadConfiguration, ModifiableConfiguration, String, Configuration) - Constructor for class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
GraphDatabaseConfigurationBuilder - Class in org.janusgraph.graphdb.configuration.builder
GraphDatabaseConfigurationBuilder() - Constructor for class org.janusgraph.graphdb.configuration.builder.GraphDatabaseConfigurationBuilder
 
GraphIndexStatusReport - Class in org.janusgraph.graphdb.database.management
 
GraphIndexStatusReport(boolean, String, List<SchemaStatus>, Map<String, SchemaStatus>, Map<String, SchemaStatus>, Duration) - Constructor for class org.janusgraph.graphdb.database.management.GraphIndexStatusReport
 
GraphIndexStatusWatcher - Class in org.janusgraph.graphdb.database.management
 
GraphIndexStatusWatcher(JanusGraph, String) - Constructor for class org.janusgraph.graphdb.database.management.GraphIndexStatusWatcher
 
GRAPHITE_HOST - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The hostname to receive Graphite plaintext protocol metric data.
GRAPHITE_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds to wait between sending Metrics data to the host specified GraphDatabaseConfiguration.GRAPHITE_HOST.
GRAPHITE_PORT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The port to which Graphite data are sent.
GRAPHITE_PREFIX - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
A Graphite-specific prefix for reported metrics.
GraphOfTheGodsFactory - Class in org.janusgraph.example
Example Graph factory that creates a JanusGraph based on roman mythology.
GraphOfTheGodsFactory() - Constructor for class org.janusgraph.example.GraphOfTheGodsFactory
 
GraphProvider - Class in org.janusgraph.graphdb.olap
 
GraphProvider() - Constructor for class org.janusgraph.graphdb.olap.GraphProvider
 
graphShutdown() - Static method in class org.janusgraph.graphdb.util.ExceptionFactory
 
GREMLIN_GRAPH - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
GREMLIN_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
groupName(String) - Method in interface org.janusgraph.core.TransactionBuilder
Sets the group name for this transaction which provides a way for gathering reporting on multiple transactions into one group.
groupName(String) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
groupName(String) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
growSpace(int, int) - Static method in class org.janusgraph.diskstorage.util.ArrayUtil
Given an old capacity of an array, generate the new capacity that is larger than or equal to minimum required capacity.
GUAVA_CACHE_ENTRY_SIZE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
GUAVA_CACHE_SOFT_ENTRY_SIZE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
GuavaSubqueryCache - Class in org.janusgraph.graphdb.transaction.subquerycache
 
GuavaSubqueryCache(int, long) - Constructor for class org.janusgraph.graphdb.transaction.subquerycache.GuavaSubqueryCache
 
GuavaVertexCache - Class in org.janusgraph.graphdb.transaction.vertexcache
 
GuavaVertexCache(long, int, int) - Constructor for class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
 

H

HARD_MAX_LIMIT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
has(String, Object) - Method in interface org.janusgraph.core.BaseVertexQuery
Query only for edges or properties that have an incident property or unidirected edge matching the given value.
has(String) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for edges or properties that have defined property with the given key
has(String, JanusGraphPredicate, Object) - Method in interface org.janusgraph.core.BaseVertexQuery
 
has(String, Object) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
has(String) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
has(String, JanusGraphPredicate, Object) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
has(String, JanusGraphPredicate, Object) - Method in interface org.janusgraph.core.JanusGraphQuery
The returned element must have a property for the given key that matches the condition according to the specified relation
has(String) - Method in interface org.janusgraph.core.JanusGraphQuery
 
has(String, Object) - Method in interface org.janusgraph.core.JanusGraphQuery
 
has(String, Object) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
has(String) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
has(String, JanusGraphPredicate, Object) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
has(ConfigOption, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
has(ConfigOption, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
has(ConfigOption, boolean, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
has(ConfigOption, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
has(ConfigOption, boolean, String...) - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
has(StoreTransaction, KeyColumn) - Method in class org.janusgraph.diskstorage.locking.LockerState
 
has(String, Object) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
has(String) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
has(String, JanusGraphPredicate, Object) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
has(String, JanusGraphPredicate, Object) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
has(PropertyKey, JanusGraphPredicate, Object) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String, Object) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String, Object) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
has(String) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
has(String, JanusGraphPredicate, Object) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasAcquiredLock() - Method in class org.janusgraph.diskstorage.BackendTransaction
 
hasAcquireLocks() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasAcquireLocks() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether the persistence layer should acquire locks for this transaction during persistence.
hasAddedRelations(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
hasAddedRelations() - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Whether this vertex has added relations
hasAddedRelations() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
hasAddedRelations() - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
hasAddedRelations() - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
hasAdditions() - Method in class org.janusgraph.diskstorage.Mutation
Whether this mutation has additions
hasAllCanonicalTypes() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasAnyIndex(PropertyKey) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
hasAssignIDsImmediately() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasAssignIDsImmediately() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
 
hasAuthentication() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
Whether authentication is enabled for this storage backend
hasBatchMutation() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasBatchMutation() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports batch mutations via KeyColumnValueStoreManager.mutateMany(java.util.Map, StoreTransaction).
hasCellTTL() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasCellTTL() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend support time-to-live (TTL) settings for column-value entries.
hasChildren() - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
hasChildren() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
hasChildren() - Method in class org.janusgraph.graphdb.query.condition.Literal
 
hasChildren() - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
hasChildren() - Method in class org.janusgraph.graphdb.query.condition.Not
 
hasCommitTime() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Returns true if a commit time has been set on this transaction.
hasCommitTime() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
hasCommitTime() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasCommonOrder() - Method in class org.janusgraph.graphdb.internal.OrderList
Whether all individual orders are the same
hasConsistentScan() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasConsistentScan() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports a consistent key order among different scans.
hasContent() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
 
hasDataType() - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
hasDefaultConfiguration() - Method in interface org.janusgraph.graphdb.internal.InternalVertexLabel
 
hasDefaultConfiguration() - Method in class org.janusgraph.graphdb.schema.VertexLabelDefinition
Deprecated.
 
hasDefaultConfiguration() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
hasDefaultConfiguration() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
hasDeletions() - Method in class org.janusgraph.diskstorage.Mutation
Whether this mutation has deletions
hasDeletions(Q) - Method in class org.janusgraph.graphdb.query.MetricsQueryExecutor
 
hasDeletions(Q) - Method in interface org.janusgraph.graphdb.query.QueryExecutor
Whether the transactional context contains any deletions that could potentially affect the result set of the given query.
hasDisabledSchemaConstraints() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
hasDisabledSchemaConstraints() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasDisabledSchemaConstraints() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Allows to disable schema constraints.
hasDuplicateResults() - Method in interface org.janusgraph.graphdb.query.ElementQuery
Whether the combination of the individual sub-queries can result in duplicate results.
hasDuplicateResults() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
hasDuplicateResults() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
hasEnabledBatchLoading() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasEnabledBatchLoading() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction should be optimized for batch-loading, i.e.
hasFailed() - Method in class org.janusgraph.core.schema.JobStatus
 
hasFlushIDs() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
hasForceIndexUsage() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
hasForceIndexUsage() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasForceIndexUsage() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction should throw an exception when a graph query is issued that cannot be answered with any existing index but instead requires a full graph-scan.
hasGenericDataType(PropertyKey) - Static method in class org.janusgraph.graphdb.database.serialize.InternalAttributeUtil
 
hasGroupName() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
True when BaseTransactionConfig.getGroupName() is non-null, false when null.
hasGroupName() - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
hasGroupName() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hashCode() - Method in class org.janusgraph.core.schema.Parameter
 
hashCode() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
hashCode() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
hashCode() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
hashCode() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
hashCode() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
hashCode() - Method in class org.janusgraph.diskstorage.keycolumnvalue.MultiSlicesQuery
 
hashCode() - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
hashCode() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
hashCode() - Method in class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
hashCode() - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
hashCode() - Method in class org.janusgraph.diskstorage.util.KeyColumn
 
hashCode() - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
Thread-safe hashcode method for StaticBuffer written according to Effective Java 2e by Josh Bloch.
hashCode(int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
hashCode() - Method in class org.janusgraph.graphdb.configuration.RegisteredAttributeClass
 
hashCode() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
hashCode() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
hashCode() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
hashCode() - Method in class org.janusgraph.graphdb.internal.OrderList
 
hashCode() - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
hashCode() - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
hashCode() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.DirectionCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.FixedCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.IncidenceCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.Not
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.RelationTypeCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.condition.VisibilityFilterCondition
 
hashCode() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
hashCode() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
hashCode() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
hashCode() - Method in class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
hashCode() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
hashCode() - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
hashCode() - Method in class org.janusgraph.graphdb.transaction.lock.IndexLockTuple
 
hashCode() - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
hashCode() - Method in class org.janusgraph.graphdb.types.IndexField
 
hashCode() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
hashCode() - Method in class org.janusgraph.util.datastructures.PointInterval
 
hashCode() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
HashingUtil - Class in org.janusgraph.diskstorage.util
 
HashingUtil() - Constructor for class org.janusgraph.diskstorage.util.HashingUtil
 
HashingUtil.HashLength - Enum in org.janusgraph.diskstorage.util
 
hashPrefixKey(HashingUtil.HashLength, StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.HashingUtil
 
HashUtility - Enum in org.janusgraph.diskstorage.util
 
hasId() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
hasId() - Method in interface org.janusgraph.core.JanusGraphElement
Checks whether this entity has a unique identifier.
hasId() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
hasId() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
hasId() - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
hasId() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
hasId() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
hasIdentifier() - Method in class org.janusgraph.diskstorage.log.ReadMarker
Whether this read marker has a configured identifier
hasIndexTransaction(String) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
hasLimit() - Method in class org.janusgraph.graphdb.query.BaseQuery
 
hasLimit() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
hasLimit() - Method in interface org.janusgraph.graphdb.query.Query
Whether this query has a defined limit
hasLoadedRelations(SliceQuery) - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Returns true if the results for the given query have already been loaded for this vertex and are locally cached.
hasLoadedRelations(SliceQuery) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
hasLoadedRelations(SliceQuery) - Method in class org.janusgraph.graphdb.vertices.CacheVertex
 
hasLoadedRelations(SliceQuery) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
hasLoadedRelations(SliceQuery) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
hasLocalAddress(Collection<String>) - Static method in class org.janusgraph.util.system.NetworkUtil
 
hasLocalKeyPartition() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasLocalKeyPartition() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend has a (possibly improper) subset of the its accessible data stored locally, that is, partially available for I/O operations without necessarily going over the network.
hasLocking() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasLocking() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
hasLogTransactions() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
hasMetaData() - Method in class org.janusgraph.diskstorage.indexing.IndexEntry
 
hasMetaData() - Method in interface org.janusgraph.diskstorage.MetaAnnotated
 
hasMetaData() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
hasModifications() - Method in interface org.janusgraph.core.JanusGraphTransaction
Checks whether any changes to the graph database have been made in this transaction.
hasModifications() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
hasMultiQuery() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasMultiQuery() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports query operations on multiple keys via KeyColumnValueStore.getSlice(java.util.List, SliceQuery, StoreTransaction)
hasMutations() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
hasName() - Method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
hasNegation() - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
hasNext() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
 
hasNext() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
 
hasNext() - Method in class org.janusgraph.graphdb.query.LimitAdjustingIterator
 
hasNext() - Method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
hasNext() - Method in class org.janusgraph.graphdb.query.ResultSetIterator
 
hasNext() - Method in class org.janusgraph.graphdb.util.AllEdgesIterator
Deprecated.
 
hasNext() - Method in class org.janusgraph.graphdb.util.MultiDistinctOrderedIterator
 
hasNext() - Method in class org.janusgraph.graphdb.vertices.RemovableRelationIterator
Deprecated.
 
hasNot(String) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for edges or properties that DO NOT have a defined property with the given key
hasNot(String, Object) - Method in interface org.janusgraph.core.BaseVertexQuery
Identical to BaseVertexQuery.has(String, Object) but negates the condition, i.e.
hasNot(String) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
hasNot(String, Object) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
hasNot(String) - Method in interface org.janusgraph.core.JanusGraphQuery
 
hasNot(String, Object) - Method in interface org.janusgraph.core.JanusGraphQuery
 
hasNot(String) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
hasNot(String, Object) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
hasNot(String, Object) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
hasNot(String) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
hasNot(String) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
hasNot(String, Object) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
hasNot(String, Object) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasNot(String) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasOptimisticLocking() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasOptimisticLocking() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether the store will commit pending mutations optimistically and make other pending changes to the same cells fail on tx.commit() (true) or will fail pending mutations pessimistically on tx.commit() if other parallel transactions have already marked the relevant cells dirty.
hasOrderedScan() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasOrderedScan() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports global key scans via KeyColumnValueStore.getKeys(KeyRangeQuery, StoreTransaction).
hasParameter(Parameter[]) - Method in enum org.janusgraph.graphdb.types.ParameterType
 
hasParameters() - Method in class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
hasPreloadedData() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasPreloadedData() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether the incident relation data on vertices is being externally pre-loaded.
hasProperties() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
hasPropertyPrefetching() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
hasPropertyPrefetching() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasPropertyPrefetching() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction loads all properties on a vertex when a single property is requested.
hasQueryOnlyGivenVertex() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasQueryOnlyLoaded() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasRemaining() - Method in interface org.janusgraph.diskstorage.ScanBuffer
 
hasRemaining() - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
hasRemovedRelations(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
hasRemovedRelations() - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Whether this vertex has removed relations
hasRemovedRelations() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
hasRemovedRelations() - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
hasRemovedRelations() - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
hasRestrictedPartitions() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasRestrictedPartitions() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Returns true if the queried partitions should be restricted in this transaction
hasScan() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasScan() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
hasSchemaTypeConstraint() - Method in interface org.janusgraph.graphdb.types.IndexType
 
hasSchemaTypeConstraint() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
hasSimpleInternalVertexKeyIndex(JanusGraphRelation) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
hasSimpleInternalVertexKeyIndex(JanusGraphVertexProperty) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
hasSimpleInternalVertexKeyIndex(PropertyKey) - Static method in class org.janusgraph.graphdb.types.TypeUtil
 
hasSingleType() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasSortKey() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
hasStartTime() - Method in class org.janusgraph.diskstorage.log.ReadMarker
 
HasStepFolder<S,E> - Interface in org.janusgraph.graphdb.tinkerpop.optimize.step
 
HasStepFolder.OrderEntry - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
 
hasStoreTTL() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasStoreTTL() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend supports time-to-live (TTL) settings on a per-store basis.
hasTimestamps() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasTimestamps() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Returns true if column-value entries in this storage backend are annotated with a timestamp, else false.
hasTxIsolation() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasTxIsolation() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend's transactions support isolation.
hasTypes() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasUmbrella() - Method in class org.janusgraph.diskstorage.configuration.ConfigNamespace
Whether this namespace or any parent namespace is an umbrella namespace.
hasUmbrellaElements() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement.PathIdentifier
 
hasUnorderedScan() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasUnorderedScan() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports global key scans via KeyColumnValueStore.getKeys(SliceQuery, StoreTransaction).
hasValidateKeysOnly() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
hasValue() - Method in interface org.janusgraph.diskstorage.Entry
 
hasVerifyExternalVertexExistence() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyExternalVertexExistence() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether the graph transaction is configured to verify that a vertex with the id GIVEN BY THE USER actually exists in the database or not.
hasVerifyInternalVertexExistence() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyInternalVertexExistence() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether the graph transaction is configured to verify that a vertex with the id actually exists in the database or not on every retrieval.
hasVerifyUniqueness() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyUniqueness() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether the graph transaction is configured to verify that an added key does not yet exist in the database.
hasVisibility() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasVisibility() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend supports entry-level visibility by attaching a visibility or authentication token to each column-value entry in the data store and limited retrievals to "visible" entries.
Hex - Class in org.janusgraph.diskstorage.util
Utility methods for hexadecimal representation of bytes
Hex() - Constructor for class org.janusgraph.diskstorage.util.Hex
 
hexToBytes(String) - Static method in class org.janusgraph.diskstorage.util.Hex
 
hide() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
hostnames - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 

I

id() - Method in interface org.janusgraph.core.JanusGraphElement
Returns a unique identifier for this entity.
id() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
id() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
ID - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
id() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
idApplicationWaitMS - Variable in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
IDAuthority - Interface in org.janusgraph.diskstorage
Handles the unique allocation of ids.
IDAUTHORITY_CAV_BITS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configures the number of bits of JanusGraph assigned ids that are reserved for a unique id marker that allows the id allocation to be scaled over multiple sub-clusters and to reduce race-conditions when a lot of JanusGraph instances attempt to allocate ids at the same time (e.g.
IDAUTHORITY_CAV_RETRIES - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
When JanusGraph allocates IDs with ConflictAvoidanceMode.GLOBAL_AUTO configured, it picks a random unique ID marker and attempts to allocate IDs from a partition using the marker.
IDAUTHORITY_CAV_TAG - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Unique id marker to be used by this JanusGraph instance when allocating ids.
IDAUTHORITY_CONFLICT_AVOIDANCE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Sets the strategy used by ConsistentKeyIDAuthority to avoid contention in ID block allocation between JanusGraph instances concurrently sharing a single distributed storage backend.
IDAUTHORITY_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
IDAUTHORITY_WAIT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds the system waits for an id block application to be acknowledged by the storage backend.
IDBlock - Interface in org.janusgraph.diskstorage
Represents a block of ids.
IDBlockSizer - Interface in org.janusgraph.graphdb.database.idassigner
 
Idfiable - Interface in org.janusgraph.core
Represents an entity that can be uniquely identified by a long id.
IDHandler - Class in org.janusgraph.graphdb.database.idhandling
 
IDHandler() - Constructor for class org.janusgraph.graphdb.database.idhandling.IDHandler
 
IDHandler.DirectionID - Enum in org.janusgraph.graphdb.database.idhandling
 
IDHandler.RelationTypeParse - Class in org.janusgraph.graphdb.database.idhandling
 
IDInspector - Interface in org.janusgraph.graphdb.idmanagement
Interface for determining the type of element a particular id refers to.
IDManager - Class in org.janusgraph.graphdb.idmanagement
Handles the allocation of ids based on the type of element Responsible for the bit-wise pattern of JanusGraph's internal id scheme.
IDManager(long) - Constructor for class org.janusgraph.graphdb.idmanagement.IDManager
 
IDManager() - Constructor for class org.janusgraph.graphdb.idmanagement.IDManager
 
IDManager.VertexIDType - Enum in org.janusgraph.graphdb.idmanagement
bit mask- Description (+ indicates defined type, * indicates proper & defined type) 0 - + User created Vertex 000 - * Normal vertices 010 - * Partitioned vertices 100 - * Unmodifiable (e.g.
IDPlacementStrategy - Interface in org.janusgraph.graphdb.database.idassigner.placement
Determines how vertices are placed in individual graph partitions.
IDPool - Interface in org.janusgraph.graphdb.database.idassigner
 
IDPoolExhaustedException - Exception in org.janusgraph.graphdb.database.idassigner
 
IDPoolExhaustedException(String) - Constructor for exception org.janusgraph.graphdb.database.idassigner.IDPoolExhaustedException
 
IDPoolExhaustedException(String, Throwable) - Constructor for exception org.janusgraph.graphdb.database.idassigner.IDPoolExhaustedException
 
IDPoolExhaustedException(Throwable) - Constructor for exception org.janusgraph.graphdb.database.idassigner.IDPoolExhaustedException
 
IDS_BLOCK_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Size of the block to be acquired.
IDS_FLUSH - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
If flush ids is enabled, vertices and edges are assigned ids immediately upon creation.
IDS_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
IDS_RENEW_BUFFER_PERCENTAGE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configures when the id pool manager will attempt to allocate a new id block.
IDS_RENEW_TIMEOUT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds that the JanusGraph id pool manager will wait before giving up on allocating a new block of ids.
IDS_STORE_NAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The name of the ID store.
IGNORE_UNKNOWN_INDEX_FIELD - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
IgnorePropertySchemaMaker - Class in org.janusgraph.core.schema
 
IgnorePropertySchemaMaker() - Constructor for class org.janusgraph.core.schema.IgnorePropertySchemaMaker
 
ignoreUndefinedQueryTypes() - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Whether to ignore undefined types occurring in a query.
ignoreUndefinedQueryTypes() - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
ignoreUndefinedQueryTypes() - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
ignoreUndefinedQueryTypes() - Method in class org.janusgraph.core.schema.Tp3DefaultSchemaMaker
 
ILLEGAL_CHARS - Static variable in class org.janusgraph.diskstorage.configuration.ConfigElement
 
ImplicitKey - Class in org.janusgraph.graphdb.types.system
 
impliedBy(Direction, Direction) - Static method in class org.janusgraph.graphdb.relations.EdgeDirection
 
incActionBy(int, CacheMetricsAction, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
IncidenceCondition<E extends JanusGraphRelation> - Class in org.janusgraph.graphdb.query.condition
 
IncidenceCondition(JanusGraphVertex, JanusGraphVertex) - Constructor for class org.janusgraph.graphdb.query.condition.IncidenceCondition
 
include(StaticBuffer) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
increment(ScanMetrics.Metric) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics
Increment a standard counter by 1.
increment(ScanMetrics.Metric) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
incrementCustom(String, long) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics
Increment a custom counter by delta.
incrementCustom(String) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics
Like ScanMetrics.incrementCustom(String, long), except the delta is 1.
incrementCustom(String, long) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
incrementCustom(String) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
incrIteration() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
Index - Interface in org.janusgraph.core.schema
Schema Elements that represent an index in the graph
index - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
INDEX_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
INDEX_BACKEND - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Define the indexing backed to use for index support
INDEX_CONF_FILE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_DEFINITION_CATEGORIES - Static variable in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
INDEX_DIRECTORY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_HOSTS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_JOB_NS - Static variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
INDEX_MAX_RESULT_SET_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NAME - Static variable in class org.janusgraph.example.GraphOfTheGodsFactory
 
INDEX_NAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NAME - Static variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
INDEX_NAME_MAPPING - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_PORT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_RELATION_TYPE - Static variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
INDEX_SELECT_BRUTE_FORCE_THRESHOLD - Static variable in class org.janusgraph.graphdb.query.index.ThresholdBasedIndexSelectionStrategy
 
INDEX_SELECT_STRATEGY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
IndexCache - Interface in org.janusgraph.graphdb.transaction.indexcache
 
IndexCandidate - Class in org.janusgraph.graphdb.query.index
 
IndexCandidate(IndexType, Set<Condition>, Object) - Constructor for class org.janusgraph.graphdb.query.index.IndexCandidate
 
IndexCandidateGroup - Class in org.janusgraph.graphdb.query.index
 
IndexCandidateGroup(Set<IndexCandidate>) - Constructor for class org.janusgraph.graphdb.query.index.IndexCandidateGroup
 
indexCoversOrder(MixedIndexType, OrderList) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
IndexEntry - Class in org.janusgraph.diskstorage.indexing
An index entry is a key-value pair (or field-value pair).
IndexEntry(String, Object) - Constructor for class org.janusgraph.diskstorage.indexing.IndexEntry
 
IndexEntry(String, Object, Map<EntryMetaData, Object>) - Constructor for class org.janusgraph.diskstorage.indexing.IndexEntry
 
indexesKey(PropertyKey) - Method in interface org.janusgraph.graphdb.types.IndexType
 
indexesKey(PropertyKey) - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
IndexFeatures - Class in org.janusgraph.diskstorage.indexing
Characterizes the features that a particular IndexProvider implementation supports
IndexFeatures(boolean, Mapping, Set<Mapping>, String, Set<Cardinality>, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.janusgraph.diskstorage.indexing.IndexFeatures
 
IndexFeatures.Builder - Class in org.janusgraph.diskstorage.indexing
 
IndexField - Class in org.janusgraph.graphdb.types
 
IndexHelper - Class in org.janusgraph.graphdb.util
 
IndexHelper() - Constructor for class org.janusgraph.graphdb.util.IndexHelper
 
IndexInformation - Interface in org.janusgraph.diskstorage.indexing
An IndexInformation gives basic information on what a particular IndexProvider supports.
IndexJobStatus(JobStatus.State, ScanMetrics) - Constructor for class org.janusgraph.graphdb.database.management.ManagementSystem.IndexJobStatus
 
IndexLockTuple - Class in org.janusgraph.graphdb.transaction.lock
 
IndexLockTuple(CompositeIndexType, Object...) - Constructor for class org.janusgraph.graphdb.transaction.lock.IndexLockTuple
 
indexMatch(JanusGraphRelation, CompositeIndexType) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
indexMatches(JanusGraphVertex, CompositeIndexType) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
indexMatches(JanusGraphVertex, CompositeIndexType, PropertyKey, Object) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
IndexMutation - Class in org.janusgraph.diskstorage.indexing
An index mutation contains the field updates (additions and deletions) for a particular index entry.
IndexMutation(KeyInformation.StoreRetriever, List<IndexEntry>, List<IndexEntry>, boolean, boolean) - Constructor for class org.janusgraph.diskstorage.indexing.IndexMutation
 
IndexMutation(KeyInformation.StoreRetriever, boolean, boolean) - Constructor for class org.janusgraph.diskstorage.indexing.IndexMutation
 
indexName - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
indexName - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
indexOnly(JanusGraphSchemaType) - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Restricts this index to only those elements that have the provided schemaType.
IndexProvider - Interface in org.janusgraph.diskstorage.indexing
External index for querying.
indexQuery(String, String) - Method in interface org.janusgraph.core.Transaction
Returns a JanusGraphIndexQuery to query for vertices or edges against the specified indexing backend using the given query string.
indexQuery(KeySliceQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
indexQuery(String, IndexQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
IndexQuery - Class in org.janusgraph.diskstorage.indexing
An external index query executed on an IndexProvider.
IndexQuery(String, Condition, ImmutableList<IndexQuery.OrderEntry>, int) - Constructor for class org.janusgraph.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition, ImmutableList<IndexQuery.OrderEntry>) - Constructor for class org.janusgraph.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition) - Constructor for class org.janusgraph.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition, int) - Constructor for class org.janusgraph.diskstorage.indexing.IndexQuery
 
indexQuery(String, String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
indexQuery(String, String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
IndexQuery.OrderEntry - Class in org.janusgraph.diskstorage.indexing
 
IndexQueryBuilder - Class in org.janusgraph.graphdb.query.graph
Implementation of JanusGraphIndexQuery for string based queries that are issued directly against the specified indexing backend.
IndexQueryBuilder(StandardJanusGraphTx, IndexSerializer) - Constructor for class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
indexQueryCount(String, IndexQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
IndexRecords() - Constructor for class org.janusgraph.graphdb.database.IndexSerializer.IndexRecords
 
indexRelationType - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
indexRelationTypeName - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
IndexRemoveJob - Class in org.janusgraph.graphdb.olap.job
 
IndexRemoveJob() - Constructor for class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
IndexRemoveJob(IndexRemoveJob) - Constructor for class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
IndexRemoveJob(JanusGraph, String, String) - Constructor for class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
IndexRepairJob - Class in org.janusgraph.graphdb.olap.job
 
IndexRepairJob() - Constructor for class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
IndexRepairJob(IndexRepairJob) - Constructor for class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
IndexRepairJob(String, String) - Constructor for class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
IndexSelectionStrategy - Interface in org.janusgraph.graphdb.query.index
 
IndexSelectionStrategy.SelectedIndexQuery - Class in org.janusgraph.graphdb.query.index
 
IndexSelectionUtil - Class in org.janusgraph.graphdb.query.index
 
IndexSelectionUtil() - Constructor for class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
IndexSerializer - Class in org.janusgraph.graphdb.database
 
IndexSerializer(Configuration, Serializer, Map<String, ? extends IndexInformation>, boolean) - Constructor for class org.janusgraph.graphdb.database.IndexSerializer
 
indexSerializer - Variable in class org.janusgraph.graphdb.database.StandardJanusGraph
 
indexSerializer - Variable in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
IndexSerializer.IndexInfoRetriever - Class in org.janusgraph.graphdb.database
 
IndexSerializer.IndexRecords - Class in org.janusgraph.graphdb.database
 
IndexSerializer.IndexUpdate<K,E> - Class in org.janusgraph.graphdb.database
 
INDEXSTORE_CACHE_PERCENT - Static variable in class org.janusgraph.diskstorage.Backend
 
INDEXSTORE_NAME - Static variable in class org.janusgraph.diskstorage.Backend
 
IndexTransaction - Class in org.janusgraph.diskstorage.indexing
Wraps the transaction handle of an index and buffers all mutations against an index for efficiency.
IndexTransaction(IndexProvider, KeyInformation.IndexRetriever, BaseTransactionConfig, Duration) - Constructor for class org.janusgraph.diskstorage.indexing.IndexTransaction
 
IndexType - Interface in org.janusgraph.graphdb.types
 
IndexTypeWrapper - Class in org.janusgraph.graphdb.types.indextype
 
IndexTypeWrapper(SchemaSource) - Constructor for class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
IndexUpdateJob - Class in org.janusgraph.graphdb.olap.job
 
IndexUpdateJob() - Constructor for class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
IndexUpdateJob(IndexUpdateJob) - Constructor for class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
IndexUpdateJob(String, String) - Constructor for class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
INITIAL_JANUSGRAPH_VERSION - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
INITIAL_STORAGE_VERSION - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
initialize(Configuration) - Method in class org.janusgraph.diskstorage.Backend
Initializes this backend with the given configuration.
initializeGraph(Configuration) - Method in class org.janusgraph.graphdb.olap.GraphProvider
 
injectIDManager(IDManager) - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
After construction, the IDManager used by this graph instance is injected into this IDPlacementStrategy so that the id pattern of vertices can be inspected.
injectIDManager(IDManager) - Method in class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
injectIDManager(IDManager) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
insert(StaticBuffer, StaticBuffer, StoreTransaction, Integer) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Inserts the given key-value pair into the store.
insertWithOverflow(T) - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Adds an Object to a PriorityQueue in log(size) time.
instance() - Static method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
INSTANCE - Static variable in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
INSTANCE - Static variable in class org.janusgraph.core.schema.IgnorePropertySchemaMaker
 
INSTANCE - Static variable in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
INSTANCE - Static variable in class org.janusgraph.core.schema.Tp3DefaultSchemaMaker
 
INSTANCE - Static variable in class org.janusgraph.diskstorage.util.NoLock
 
INSTANCE - Static variable in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexFilterOptimizerStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasIdOptimizerStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasUniquePropertyOptimizerStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexIsOptimizerStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphIoRegistrationStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphLocalQueryOptimizerStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMixedIndexCountStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphMultiQueryStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphStepStrategy
 
instance() - Static method in class org.janusgraph.graphdb.tinkerpop.plugin.JanusGraphGremlinPlugin
 
INSTANCE - Static variable in class org.janusgraph.graphdb.transaction.lock.FakeLock
 
instanceConnectiveJanusPredicate(P<?>) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
instantiate(String) - Static method in class org.janusgraph.util.system.ConfigurationUtil
 
instantiate(String, Object[], Class[]) - Static method in class org.janusgraph.util.system.ConfigurationUtil
 
InstantSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
InstantSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.InstantSerializer
 
instrument(String, String, ExecutorService) - Static method in class org.janusgraph.diskstorage.configuration.ExecutorServiceInstrumentation
 
instrument(String, String, ThreadFactory) - Static method in class org.janusgraph.diskstorage.configuration.ExecutorServiceInstrumentation
 
INT_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
IntArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
IntArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
IntegerSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
IntegerSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
INTERNAL_INDEX_NAME - Static variable in class org.janusgraph.graphdb.internal.Token
 
InternalAttributeUtil - Class in org.janusgraph.graphdb.database.serialize
 
InternalAttributeUtil() - Constructor for class org.janusgraph.graphdb.database.serialize.InternalAttributeUtil
 
InternalElement - Interface in org.janusgraph.graphdb.internal
Internal Element interface adding methods that should only be used by JanusGraph
InternalRelation - Interface in org.janusgraph.graphdb.internal
Internal Relation interface adding methods that should only be used by JanusGraph.
InternalRelationType - Interface in org.janusgraph.graphdb.internal
Internal Type interface adding methods that should only be used by JanusGraph
internalState(LockerState<S>) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
This method is only intended for testing.
InternalVertex - Interface in org.janusgraph.graphdb.internal
Internal Vertex interface adding methods that should only be used by JanusGraph
InternalVertexLabel - Interface in org.janusgraph.graphdb.internal
 
intersect(Interval<T>) - Method in interface org.janusgraph.util.datastructures.Interval
 
intersect(Interval<T>) - Method in class org.janusgraph.util.datastructures.PointInterval
 
intersect(Interval<T>) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
interval(String, T, T) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for those edges or properties that have a property for the given key whose values lies in the interval by [start,end).
interval(String, T, T) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
interval(String, T, T) - Method in interface org.janusgraph.core.JanusGraphQuery
 
interval(String, T, T) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
interval - Variable in class org.janusgraph.graphdb.database.EdgeSerializer.TypedInterval
 
interval(String, T, T) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
interval(String, T, T) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
interval(String, T, T) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
Interval<T> - Interface in org.janusgraph.util.datastructures
 
intSize - Static variable in class org.janusgraph.diskstorage.util.BufferUtil
 
inUse() - Method in class org.janusgraph.graphdb.transaction.lock.CombinerLock
 
inUse() - Method in class org.janusgraph.graphdb.transaction.lock.FakeLock
 
inUse() - Method in class org.janusgraph.graphdb.transaction.lock.ReentrantTransactionLock
 
inUse() - Method in interface org.janusgraph.graphdb.transaction.lock.TransactionLock
 
invalidate(String) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
invalidate(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.IndexRetriever
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
InvalidElementException - Exception in org.janusgraph.core
Exception thrown when an element is invalid for the executing operation or when an operation could not be performed on an element.
InvalidElementException(String, JanusGraphElement) - Constructor for exception org.janusgraph.core.InvalidElementException
 
InvalidIDException - Exception in org.janusgraph.core
JanusGraph represents element identifiers as longs, but not all numbers in the representable space of longs are valid.
InvalidIDException(String) - Constructor for exception org.janusgraph.core.InvalidIDException
 
InvalidIDException(String, Throwable) - Constructor for exception org.janusgraph.core.InvalidIDException
 
InvalidIDException(Throwable) - Constructor for exception org.janusgraph.core.InvalidIDException
 
inVertex() - Method in interface org.janusgraph.core.JanusGraphEdge
 
invisible() - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
invisible() - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
invisible() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
io(Io.Builder<I>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
io(Io.Builder<I>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
IOCallable<T> - Interface in org.janusgraph.diskstorage.util
 
IOUtils - Class in org.janusgraph.util.system
IO Utility class
IOUtils() - Constructor for class org.janusgraph.util.system.IOUtils
 
is(long) - Method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
 
isAddition() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
isApplicableStatus(SchemaStatus) - Method in enum org.janusgraph.core.schema.SchemaAction
 
isArrayOf(Object, Class) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
isAsciiString(String) - Static method in class org.janusgraph.util.encoding.StringEncoding
 
isAssignTimestamp() - Method in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
isBatchLoading() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
isCanonicalVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isCausedBy(Class<?>) - Method in exception org.janusgraph.core.JanusGraphException
Checks whether this exception is cause by an exception of the given type.
isCausedBy(Throwable, Class<?>) - Static method in class org.janusgraph.util.datastructures.ExceptionUtil
 
isChecked() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
isClosed() - Method in interface org.janusgraph.core.JanusGraph
Checks whether the graph is closed.
isClosed() - Method in interface org.janusgraph.core.JanusGraphTransaction
Checks whether the transaction has been closed.
isClosed() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
isClosed() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
isClosed() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
isCompatible(ReadMarker) - Method in class org.janusgraph.diskstorage.log.ReadMarker
 
isCompositeIndex() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Whether this is a composite index
isCompositeIndex() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
isCompositeIndex() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
isCompositeIndex() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
isCompositeIndex() - Method in interface org.janusgraph.graphdb.types.IndexType
 
isCompositeIndex() - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
isConsolidated() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
isConsolidated() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
isConsolidated() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVMutation
 
isConsolidated() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
isConsolidated(Function<E, V>, Function<K, V>) - Method in class org.janusgraph.diskstorage.Mutation
Checks whether this mutation is consolidated in the sense of Mutation.consolidate(Function, Function).
isConsolidated() - Method in class org.janusgraph.diskstorage.Mutation
 
isConstrained() - Method in enum org.janusgraph.core.Multiplicity
Whether this multiplicity imposes any constraint on the number of edges that may exist between a pair of vertices.
isConstrained(Direction) - Method in enum org.janusgraph.core.Multiplicity
 
isDeleted() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
isDeleted(Q, R) - Method in class org.janusgraph.graphdb.query.MetricsQueryExecutor
 
isDeleted(Q, R) - Method in interface org.janusgraph.graphdb.query.QueryExecutor
Whether the given result entry has been deleted in the transactional context and should hence be removed from the result set.
isDeletion() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
isDeprecated() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isDirected() - Method in interface org.janusgraph.core.EdgeLabel
Checks whether this labels is defined as directed.
isDirected() - Method in class org.janusgraph.graphdb.schema.EdgeLabelDefinition
Deprecated.
 
isDirected() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
isDirected() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
isDistributed() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isDistributed() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend writes and reads data from more than one machine.
isDone() - Method in class org.janusgraph.core.schema.JobStatus
 
isEdge() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isEdge() - Method in interface org.janusgraph.core.JanusGraphRelation
Checks whether this relation is an edge.
isEdge() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isEdge() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
isEdge() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
isEdge() - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
isEdgeLabel() - Method in interface org.janusgraph.core.RelationType
Checks if this relation type is an edge label
isEdgeLabel() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
isEdgeLabel() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
isEdgeLabel() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
isEdgeLabel() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
isEdgeLabel() - Method in class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
isEdgeLabelId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isEdgeLabelId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isEdgeReturnStep(JanusGraphVertexStep) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
isEmpty() - Method in class org.janusgraph.diskstorage.Mutation
 
isEmpty() - Method in class org.janusgraph.diskstorage.StoreMetaData.Container
 
isEmpty() - Method in class org.janusgraph.graphdb.internal.OrderList
 
isEmpty() - Method in interface org.janusgraph.graphdb.query.ElementQuery
Whether the result set of this query is empty
isEmpty() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
isEmpty() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
isEmpty(Condition<?>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
isEmpty() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
isEmpty() - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
 
isEmpty() - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
isEmpty() - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
isEmpty() - Method in interface org.janusgraph.util.datastructures.Interval
 
isEmpty() - Method in class org.janusgraph.util.datastructures.PointInterval
 
isEmpty() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
isExhaustedPartition(int) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
isExistsStep(Step<?, ?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
Check if a given step is an "exists" step, i.e.
isFitted() - Method in interface org.janusgraph.core.QueryDescription.SubQuery
Whether this query is fitted, i.e.
isFitted() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
isFixed() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isFrozen() - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
isGenericSchemaVertexId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isGenericSchemaVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isGhostVertex(long, EntryList) - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
isGlobal() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isGlobalGraphIndex() - Method in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
isHidden() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isIdentifying() - Method in enum org.janusgraph.diskstorage.EntryMetaData
 
isImmutable() - Method in class org.janusgraph.graphdb.internal.OrderList
 
isImplicitKeyQuery(RelationCategory) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
Whether this query is asking for the value of an ImplicitKey.
isIncidentOn(Vertex) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isIncidentOn(Vertex) - Method in interface org.janusgraph.core.JanusGraphRelation
Checks whether this relation is incident on the specified vertex.
isIncidentOn(Vertex) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isIncidentOn(Vertex) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
isIndexSatisfiedByGivenKeys(IndexType, Collection<String>) - Static method in class org.janusgraph.graphdb.query.index.IndexSelectionUtil
 
isInitialIteration() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
isInstance(JanusGraphElement) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
isInvisible() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
isInvisible() - Method in interface org.janusgraph.graphdb.internal.InternalElement
Whether this element is invisible and should only be returned to queries that explicitly ask for invisible elements.
isInvisible() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
isInvisible() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
isInvisible() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
isInvisibleType() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
isInvisibleType() - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
isInvisibleType() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
isInvisibleType() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
isIterableOf(Object, Class) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
isKeyConsistent() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isKeyConsistent() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend provides strong consistency within each key/row.
isKeyOrdered() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isKeyOrdered() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend preserves key locality.
isLegalMultiQueryPosition(Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
This method closely matches the behavior implemented in LazyBarrierStrategy which ensures that no NoOpBarrierSteps are inserted if path labels are required.
isLimitBatchSize() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
isLoaded() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isLoaded() - Method in interface org.janusgraph.core.JanusGraphElement
Checks whether this entity has been loaded into the current transaction and not yet modified.
isLoaded() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
isLoaded(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
isLoaded() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isLoaded() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
isLocal() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isLocalConnection(String) - Static method in class org.janusgraph.util.system.NetworkUtil
 
isLoop() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isLoop() - Method in interface org.janusgraph.core.JanusGraphRelation
Checks whether this relation is a loop.
isLoop() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isLoop() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
isManaged() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
Returns true on config options whose values are not local or maskable, that is, cluster-wide options that are either fixed or which can be changed only by using the ManagementSystem (and not by editing the local config).
isMixedIndex() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Whether this is a mixed index
isMixedIndex() - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
isMixedIndex() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
isMixedIndex() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
isMixedIndex() - Method in interface org.janusgraph.graphdb.types.IndexType
 
isMixedIndex() - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
isModified() - Method in interface org.janusgraph.core.JanusGraphVertex
Checks whether this entity has been loaded into the current transaction and modified.
isModified(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
isModified() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
isModified() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
isMultiQueryCompatibleParent(Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
Checks whether this step is a traversal parent for which a preceding JanusGraphMultiQueryStep can have a positive impact on the step's child traversals.
isMultiQueryCompatibleStep(Step<?, ?>) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
Checks whether a step can profit of a preceding JanusGraphMultiQueryStep.
isMutationStarted() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
Tells whether this transaction has been used in a ExpectedValueCheckingStore.mutate(StaticBuffer, List, List, StoreTransaction) call.
isNamespace() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
isNew() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isNew() - Method in interface org.janusgraph.core.JanusGraphElement
Checks whether this entity has been newly created in the current transaction.
isNew() - Method in interface org.janusgraph.core.schema.JanusGraphSchemaType
Checks whether this schema type has been newly created in the current transaction.
isNew() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
isNew() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
isNew(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
isNew() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isNew() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
isOpen() - Method in interface org.janusgraph.core.JanusGraph
Checks whether the graph is open.
isOpen() - Method in interface org.janusgraph.core.JanusGraphTransaction
Checks whether the transaction is still open.
isOpen() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Whether this management transaction is open or has been closed (i.e.
isOpen() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
isOpen() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
isOpen() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
isOption() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
isOption() - Method in class org.janusgraph.diskstorage.configuration.ConfigNamespace
 
isOption() - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
isOrderPreservingDatatype(Class<?>) - Method in interface org.janusgraph.graphdb.database.serialize.AttributeHandler
 
isOrderPreservingDatatype(Class<?>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
isPartitioned() - Method in interface org.janusgraph.core.VertexLabel
Whether vertices with this label are partitioned.
isPartitioned() - Method in class org.janusgraph.graphdb.schema.VertexLabelDefinition
Deprecated.
 
isPartitioned() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
isPartitioned() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
isPartitionedVertex(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isPartitionedVertex(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isPartitionedVertex(InternalVertex) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
isPartitionedVertex(JanusGraphVertex) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
isPoints() - Method in interface org.janusgraph.util.datastructures.Interval
 
isPoints() - Method in class org.janusgraph.util.datastructures.PointInterval
 
isPoints() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
isPowerOf2(long) - Static method in class org.janusgraph.util.stats.NumberUtil
 
isPresent() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isPresent() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isPresent() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
isPresent() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
isPrimarySuccess() - Method in enum org.janusgraph.graphdb.database.log.LogTxStatus
 
isProper() - Method in enum org.janusgraph.core.log.Change
 
isProper() - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
isProperDirection(Direction) - Static method in class org.janusgraph.graphdb.relations.EdgeDirection
 
isProperty() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isProperty() - Method in interface org.janusgraph.core.JanusGraphRelation
Checks whether this relation is a property.
isProperty() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isProperty() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
isProperty() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
isProperty() - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
isPropertyKey() - Method in interface org.janusgraph.core.RelationType
Checks if this relation type is a property key
isPropertyKey() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
isPropertyKey() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
isPropertyKey() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
isPropertyKey() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
isPropertyKey() - Method in class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
isPropertyKeyId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isPropertyKeyId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isProvided() - Method in class org.janusgraph.graphdb.olap.GraphProvider
 
isQNF() - Method in class org.janusgraph.graphdb.predicate.AndJanusPredicate
 
isQNF() - Method in class org.janusgraph.graphdb.predicate.OrJanusPredicate
 
isQueryNormalForm(Condition<?>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
Query-normal-form (QNF) for JanusGraph is a variant of CNF (conjunctive normal form) with negation inlined where possible
isReadOnly() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
isReadOnly() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
isReadOnly() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Checks whether the graph transaction is configured as read-only.
isRelation() - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
isRelationType() - Method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
isRelationTypeId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isRelationTypeId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isRelationTypeIndex() - Method in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
isRemoved() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
isRemoved() - Method in interface org.janusgraph.core.JanusGraphElement
Checks whether this entity has been deleted into the current transaction.
isRemoved() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
isRemoved(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
isRemoved() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
isRemoved() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
isRemovedRelation(Long) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
isRoot() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
isRunning() - Method in class org.janusgraph.core.schema.JobStatus
 
isSchemaVertexId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isSchemaVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isSimple() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
A query is considered 'simple' if it is comprised of just one sub-query and that query is fitted (i.e.
isSingleThreaded() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
isSingleThreaded() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction is only accessed by a single thread.
isSmallerOrEqualThan(ByteBuffer, ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers and checks whether the first ByteBuffer is smaller than or equal to the second.
isSmallerThan(ByteBuffer, ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers and checks whether the first ByteBuffer is smaller than the second.
isSorted() - Method in interface org.janusgraph.core.QueryDescription.SubQuery
Whether this query respects the sort order of parent query or requires sorting in-memory.
isSorted() - Method in interface org.janusgraph.core.VertexList
Whether this list of vertices is sorted by id in increasing order.
isSorted() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
isSorted() - Method in interface org.janusgraph.graphdb.query.ElementQuery
Whether this query expects the results to be in a particular sort order.
isSorted() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
isSorted() - Method in class org.janusgraph.graphdb.query.index.IndexSelectionStrategy.SelectedIndexQuery
 
isSorted() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
isSorted() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
isSorted() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
isSorted(LongArrayList, boolean) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
 
isSorted(LongArrayList) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
 
isStable() - Method in enum org.janusgraph.core.schema.SchemaStatus
 
isStatic() - Method in interface org.janusgraph.core.VertexLabel
Whether vertices with this label are static, that is, immutable beyond the transaction in which they were created.
isStatic() - Method in class org.janusgraph.graphdb.schema.VertexLabelDefinition
Deprecated.
 
isStatic() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
isStatic() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
isSubType(IDManager.VertexIDType) - Method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
 
isSuccess() - Method in enum org.janusgraph.graphdb.database.log.LogTxStatus
 
isSystemName(String) - Static method in class org.janusgraph.graphdb.internal.Token
 
isSystemRelationTypeId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isSystemRelationTypeId(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isSystemType(String) - Static method in class org.janusgraph.graphdb.types.system.SystemTypeManager
 
isTemporary(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isTemporaryId(long) - Static method in class org.janusgraph.graphdb.internal.AbstractElement
 
isThreadBound() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
isThreadBound() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction is bound to a running thread.
isTxOpen() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
isUmbrella() - Method in class org.janusgraph.diskstorage.configuration.ConfigNamespace
Whether this namespace is an umbrella namespace, that is, is expects immediate sub-namespaces which are user defined.
isUnidirected() - Method in interface org.janusgraph.core.EdgeLabel
Checks whether this labels is defined as unidirected.
isUnidirected(Direction) - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
isUnidirected() - Method in class org.janusgraph.graphdb.schema.EdgeLabelDefinition
Deprecated.
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.EdgeLabelDefinition
Deprecated.
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.PropertyKeyDefinition
Deprecated.
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.RelationTypeDefinition
Deprecated.
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
isUnidirected() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
isUnidirected() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
isUnidirected(Direction) - Method in class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
isUnique(Direction) - Method in enum org.janusgraph.core.Multiplicity
If this multiplicity implies edge uniqueness in the given direction for any given vertex.
isUnique() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Whether this is a unique index, i.e.
isUnique() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
isUnmodifiableVertex(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isUnmodifiableVertex(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isUpgradeAllowed(String) - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
isUserVertexId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isUserVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isValid(byte) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
isValidCondition(Object) - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
isValidConstraint(JanusGraphSchemaType) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
isValidData(Object) - Method in enum org.janusgraph.diskstorage.EntryMetaData
Validates a datum according to the metadata type.
isValidDefinition(Set<TypeDefinitionCategory>) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
 
isValidIdMap(Map<?, Integer>) - Static method in class org.janusgraph.graphdb.olap.computer.VertexState
 
isValidStep(HasStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasIdOptimizerStrategy
 
isValidStep(HasStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasUniquePropertyOptimizerStrategy
Determines whether this HasStep can be answered by a unique index and thus, returns either 0 or 1 match
isValidStep(IsStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexIsOptimizerStrategy
 
isValidStep(T) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy
 
isValidTypeModifierDefinition(Set<TypeDefinitionCategory>) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
 
isValidValueType(Class<?>) - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
isVertexLabelVertexId(long) - Method in interface org.janusgraph.graphdb.idmanagement.IDInspector
 
isVertexLabelVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
 
isVertexReturnStep(JanusGraphVertexStep) - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
it() - Method in interface org.janusgraph.graphdb.internal.InternalElement
Returns this element in the context of the current transaction.
it() - Method in interface org.janusgraph.graphdb.internal.InternalRelation
Returns this relation in the current transactional context
it() - Method in interface org.janusgraph.graphdb.internal.InternalVertex
 
it() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
it() - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
it() - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
it() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
it() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
iterables(GraphCentricQuery, Class<E>) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
IterablesUtil - Class in org.janusgraph.util.datastructures
Utility class for interacting with Iterable.
IterablesUtil() - Constructor for class org.janusgraph.util.datastructures.IterablesUtil
 
iterator() - Method in class org.janusgraph.graphdb.internal.OrderList
 
iterator() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
iterator() - Method in class org.janusgraph.graphdb.query.QueryProcessor
 
iterator() - Method in class org.janusgraph.graphdb.query.vertex.SimpleVertexQueryProcessor
 
iterator() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
iterator() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
iterator() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
iterator() - Method in class org.janusgraph.graphdb.transaction.VertexIterable
 
iterator() - Method in class org.janusgraph.graphdb.util.StreamIterable
 
iterator() - Method in class org.janusgraph.graphdb.util.VertexCentricEdgeIterable
 
iterator() - Method in class org.janusgraph.graphdb.vertices.RemovableRelationIterable
Deprecated.
 
iterator() - Method in class org.janusgraph.util.datastructures.PowerSet
 

J

JANUS_GRAPH_MANAGER_EXPECTED_STATE_MSG - Static variable in class org.janusgraph.graphdb.management.JanusGraphManager
 
JanusGraph - Interface in org.janusgraph.core
JanusGraph graph database implementation of the Blueprint's interface.
JANUSGRAPH_ID_STORE_NAME - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
Name of the ids.store-name used by JanusGraph which is configurable
JANUSGRAPH_PROPERTIES_FILE - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
 
JanusGraphBlueprintsGraph - Class in org.janusgraph.graphdb.tinkerpop
Blueprints specific implementation for JanusGraph.
JanusGraphBlueprintsGraph() - Constructor for class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
JanusGraphBlueprintsTransaction - Class in org.janusgraph.graphdb.tinkerpop
Blueprints specific implementation of JanusGraphTransaction.
JanusGraphBlueprintsTransaction() - Constructor for class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
JanusGraphComputer - Interface in org.janusgraph.core
 
JanusGraphComputer.ResultMode - Enum in org.janusgraph.core
 
JanusGraphConfiguration - Interface in org.janusgraph.core.schema
Used to read and change the global JanusGraph configuration.
JanusGraphConfigurationException - Exception in org.janusgraph.core
Exception thrown due to invalid configuration options or when errors occur during the configuration and initialization of JanusGraph.
JanusGraphConfigurationException(String) - Constructor for exception org.janusgraph.core.JanusGraphConfigurationException
 
JanusGraphConfigurationException(String, Throwable) - Constructor for exception org.janusgraph.core.JanusGraphConfigurationException
 
JanusGraphConfigurationException(Throwable) - Constructor for exception org.janusgraph.core.JanusGraphConfigurationException
Constructs an exception with a generic message
JanusGraphConstants - Class in org.janusgraph.graphdb.configuration
Collection of constants used throughput the JanusGraph codebase.
JanusGraphConstants() - Constructor for class org.janusgraph.graphdb.configuration.JanusGraphConstants
 
JanusGraphDefaultSchemaMaker - Class in org.janusgraph.core.schema
DefaultSchemaMaker implementation for Blueprints graphs
JanusGraphEdge - Interface in org.janusgraph.core
A JanusGraphEdge connects two JanusGraphVertex.
JanusGraphEdgeVertexStep - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
A JanusGraphEdgeVertexStep is identical to a EdgeVertexStep.
JanusGraphEdgeVertexStep(EdgeVertexStep, int) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphEdgeVertexStep
 
JanusGraphElement - Interface in org.janusgraph.core
JanusGraphElement represents the abstract concept of an entity in the graph and specifies basic methods for interacting with entities.
JanusGraphException - Exception in org.janusgraph.core
Most general type of exception thrown by the JanusGraph graph database.
JanusGraphException(String) - Constructor for exception org.janusgraph.core.JanusGraphException
 
JanusGraphException(String, Throwable) - Constructor for exception org.janusgraph.core.JanusGraphException
 
JanusGraphException(Throwable) - Constructor for exception org.janusgraph.core.JanusGraphException
Constructs an exception with a generic message
JanusGraphFactory - Class in org.janusgraph.core
JanusGraphFactory is used to open or instantiate a JanusGraph graph database.
JanusGraphFactory() - Constructor for class org.janusgraph.core.JanusGraphFactory
 
JanusGraphFactory.Builder - Class in org.janusgraph.core
 
JanusGraphFeatures - Class in org.janusgraph.graphdb.tinkerpop
Blueprint's features of a JanusGraph.
JanusGraphGremlinPlugin - Class in org.janusgraph.graphdb.tinkerpop.plugin
 
JanusGraphGremlinPlugin() - Constructor for class org.janusgraph.graphdb.tinkerpop.plugin.JanusGraphGremlinPlugin
 
JanusGraphGremlinPlugin(String, Customizer...) - Constructor for class org.janusgraph.graphdb.tinkerpop.plugin.JanusGraphGremlinPlugin
 
JanusGraphId - Class in org.janusgraph.core.util
Deprecated.
This class does not produce valid JanusGraph vertex ids as it does not take into account partitioning bits used in vertex id assignment. Use IDManager, which can be obtained through StandardJanusGraph.getIDManager() and includes methods for converting a user id to (IDManager.toVertexId(long)) and from (IDManager.fromVertexId(long)) JanusGraph vertex id.

 IDManager idManager = ((StandardJanusGraph) graph).getIDManager();
 
JanusGraphId() - Constructor for class org.janusgraph.core.util.JanusGraphId
Deprecated.
 
JANUSGRAPHID - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
JanusGraphIndex - Interface in org.janusgraph.core.schema
A JanusGraphIndex is an index installed on the graph in order to be able to efficiently retrieve graph elements by their properties.
JanusGraphIndexQuery - Interface in org.janusgraph.core
A GraphQuery that queries for graph elements directly against a particular indexing backend and hence allows this query mechanism to exploit the full range of features and functionality of the indexing backend.
JanusGraphIndexQuery.Result<V extends org.apache.tinkerpop.gremlin.structure.Element> - Interface in org.janusgraph.core
Container of a query result with its score.
JanusGraphIndexWrapper - Class in org.janusgraph.graphdb.database.management
 
JanusGraphIndexWrapper(IndexType) - Constructor for class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
JanusGraphIoRegistrationStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
JanusGraphIoRegistrationStrategy registers the JanusGraphIoRegistry for the IoStep:
JanusGraphIoRegistrationStrategy() - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.strategy.JanusGraphIoRegistrationStrategy
 
JanusGraphLocalQueryOptimizerStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
JanusGraphManagement - Interface in org.janusgraph.core.schema
The JanusGraphManagement interface provides methods to define, update, and inspect the schema of a JanusGraph graph.
JanusGraphManagement.IndexBuilder - Interface in org.janusgraph.core.schema
Builder for JanusGraphIndex.
JanusGraphManagement.IndexJobFuture - Interface in org.janusgraph.core.schema
 
JanusGraphManager - Class in org.janusgraph.graphdb.management
This class adheres to the TinkerPop graphManager specifications.
JanusGraphManager(Settings) - Constructor for class org.janusgraph.graphdb.management.JanusGraphManager
This class adheres to the TinkerPop graphManager specifications.
JanusGraphManagerException - Exception in org.janusgraph.graphdb.management.utils
 
JanusGraphManagerException(String) - Constructor for exception org.janusgraph.graphdb.management.utils.JanusGraphManagerException
 
JanusGraphManagerUtility - Class in org.janusgraph.core
This class allows an access point to the JanusGraphManager Singleton without throwing a NoClassDefFoundError if the server has not been configured to use the org.apache.tinkerpop:gremlin-server dependency, since this dependency is optional.
JanusGraphManagerUtility() - Constructor for class org.janusgraph.core.JanusGraphManagerUtility
 
JanusGraphMixedIndexCountStep<S> - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
A custom count step similar to CountGlobalStep but uses mixed index query to directly fetch number of satisfying elements without actually fetching the elements.
JanusGraphMixedIndexCountStep(JanusGraphStep, Traversal.Admin<?, ?>) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
JanusGraphMixedIndexCountStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
If the query can be satisfied by a single mixed index query, and the query is followed by a count step, then this strategy replaces original step with JanusGraphMixedIndexCountStep, which fires a count query against mixed index backend without retrieving all elements
JanusGraphMultiQueryStep - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
This step can be injected before a traversal parent, such as a union, and will cache the starts sent to the parent.
JanusGraphMultiQueryStep(Traversal.Admin, boolean) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
JanusGraphMultiQueryStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
JanusGraphMultiVertexQuery<Q extends JanusGraphMultiVertexQuery<Q>> - Interface in org.janusgraph.core
A MultiVertexQuery is identical to a JanusGraphVertexQuery but executed against a set of vertices simultaneously.
JanusGraphPredicateUtils - Class in org.janusgraph.graphdb.query
 
JanusGraphPredicateUtils() - Constructor for class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
JanusGraphPropertiesStep<E> - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
 
JanusGraphPropertiesStep(PropertiesStep<E>) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
JanusGraphProperty<V> - Interface in org.janusgraph.core
 
JanusGraphQuery<Q extends JanusGraphQuery<Q>> - Interface in org.janusgraph.core
Constructs a query against a mixed index to retrieve all elements (either vertices or edges) that match all conditions.
JanusGraphRelation - Interface in org.janusgraph.core
JanusGraphRelation is the most abstract form of a relation between a vertex and some other entity, where relation is understood in its mathematical sense.
JanusGraphSchemaCategory - Enum in org.janusgraph.graphdb.internal
 
JanusGraphSchemaElement - Interface in org.janusgraph.core.schema
Marks any element that is part of a JanusGraph Schema.
JanusGraphSchemaType - Interface in org.janusgraph.core.schema
A JanusGraphSchemaType is a JanusGraphSchemaElement that represents a label or key used in the graph.
JanusGraphSchemaVertex - Class in org.janusgraph.graphdb.types.vertices
 
JanusGraphSchemaVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
JanusGraphStep<S,E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
 
JanusGraphStep(GraphStep<S, E>) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
JanusGraphStepStrategy - Class in org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
JanusGraphTransaction - Interface in org.janusgraph.core
JanusGraphTransaction defines a transactional context for a JanusGraph.
JanusGraphTraversalUtil - Class in org.janusgraph.graphdb.tinkerpop.optimize
 
JanusGraphTraversalUtil() - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphTraversalUtil
 
JanusGraphVariables - Class in org.janusgraph.graphdb.tinkerpop
 
JanusGraphVariables(WriteConfiguration) - Constructor for class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
JanusGraphVertex - Interface in org.janusgraph.core
JanusGraphVertex is the basic unit of a JanusGraph.
JanusGraphVertexProperty<V> - Interface in org.janusgraph.core
JanusGraphProperty is a JanusGraphRelation connecting a vertex to a value.
JanusGraphVertexQuery<Q extends JanusGraphVertexQuery<Q>> - Interface in org.janusgraph.core
A JanusGraphVertexQuery is a VertexQuery executed for a single vertex.
JanusGraphVertexStep<E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in org.janusgraph.graphdb.tinkerpop.optimize.step
 
JanusGraphVertexStep(VertexStep<E>) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
job - Variable in class org.janusgraph.graphdb.olap.VertexJobConverter
 
JOB_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
JOB_START_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
jobStartTime - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
JobStatus - Class in org.janusgraph.core.schema
 
JobStatus(JobStatus.State, long) - Constructor for class org.janusgraph.core.schema.JobStatus
 
JobStatus.State - Enum in org.janusgraph.core.schema
 
JointIndexQuery - Class in org.janusgraph.graphdb.query.graph
A component/sub-query of a GraphCentricQuery that gets executed against an indexing backend or the index store by the query processor of the enclosing transaction.
JointIndexQuery() - Constructor for class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
JointIndexQuery.Subquery - Class in org.janusgraph.graphdb.query.graph
 
JsonSerializer<T extends org.apache.tinkerpop.shaded.jackson.databind.JsonNode> - Class in org.janusgraph.graphdb.database.serialize.attribute
Serializes implementation of JsonNode by using StringSerializer for JSON string serialization.
JsonSerializer(Class<T>) - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 

K

KCVEntryMutation - Class in org.janusgraph.diskstorage.keycolumnvalue.cache
 
KCVEntryMutation(List<Entry>, List<Entry>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
KCVMutation - Class in org.janusgraph.diskstorage.keycolumnvalue
KCVMutation(List<Entry>, List<StaticBuffer>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KCVMutation
 
KCVMutation(Supplier<List<Entry>>, Supplier<List<StaticBuffer>>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KCVMutation
 
KCVSCache - Class in org.janusgraph.diskstorage.keycolumnvalue.cache
 
KCVSCache(KeyColumnValueStore, String) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
KCVSConfiguration - Class in org.janusgraph.diskstorage.configuration.backend
 
KCVSConfiguration(BackendOperation.TransactionalProvider, Configuration, KeyColumnValueStore, String) - Constructor for class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
KCVSConfigurationBuilder - Class in org.janusgraph.diskstorage.configuration.backend.builder
Builder to build KCVSConfiguration instances
KCVSConfigurationBuilder() - Constructor for class org.janusgraph.diskstorage.configuration.backend.builder.KCVSConfigurationBuilder
 
KCVSLog - Class in org.janusgraph.diskstorage.log.kcvs
Implementation of Log wrapped around a KeyColumnValueStore.
KCVSLog(String, KCVSLogManager, KeyColumnValueStore, Configuration) - Constructor for class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
KCVSLogManager - Class in org.janusgraph.diskstorage.log.kcvs
Implementation of LogManager against an arbitrary KeyColumnValueStoreManager.
KCVSLogManager(KeyColumnValueStoreManager, Configuration) - Constructor for class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
Opens a log manager against the provided KCVS store with the given configuration.
KCVSLogManager(KeyColumnValueStoreManager, Configuration, int[]) - Constructor for class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
Opens a log manager against the provided KCVS store with the given configuration.
KCVSManagerProxy - Class in org.janusgraph.diskstorage.keycolumnvalue
 
KCVSManagerProxy(KeyColumnValueStoreManager) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
KCVSMessage - Class in org.janusgraph.diskstorage.log.kcvs
Implementation of AbstractMessage for KCVSLog.
KCVSMessage(StaticBuffer, Instant, String) - Constructor for class org.janusgraph.diskstorage.log.kcvs.KCVSMessage
 
KCVSProxy - Class in org.janusgraph.diskstorage.keycolumnvalue
Wraps a KeyColumnValueStore as a proxy as a basis for other wrappers
KCVSProxy(KeyColumnValueStore) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
KCVSUtil - Class in org.janusgraph.diskstorage.keycolumnvalue
Contains static utility methods for operating on KeyColumnValueStore.
KCVSUtil() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
key() - Method in interface org.janusgraph.core.JanusGraphProperty
 
key() - Method in class org.janusgraph.core.schema.Parameter
 
key - Variable in class org.janusgraph.graphdb.database.EdgeSerializer.TypedInterval
 
key() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
key - Variable in class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
KEY - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
key2Field(MixedIndexType, PropertyKey) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
KeyColumn - Class in org.janusgraph.diskstorage.util
Class representing a (key, column) pair.
KeyColumn(StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.util.KeyColumn
 
KeyColumnValueStore - Interface in org.janusgraph.diskstorage.keycolumnvalue
Interface to a data store that has a BigTable like representation of its data.
KeyColumnValueStoreManager - Interface in org.janusgraph.diskstorage.keycolumnvalue
KeyColumnValueStoreManager provides the persistence context to the graph database storage backend.
keyConsistent(Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
keyConsistent(Configuration, Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
KeyInformation - Interface in org.janusgraph.diskstorage.indexing
Helper class that provides information on the data type and additional parameters that form the definition of a key in an index.
KeyInformation.IndexRetriever - Interface in org.janusgraph.diskstorage.indexing
 
KeyInformation.Retriever - Interface in org.janusgraph.diskstorage.indexing
 
KeyInformation.StoreRetriever - Interface in org.janusgraph.diskstorage.indexing
 
KeyIterator - Interface in org.janusgraph.diskstorage.keycolumnvalue
 
keyOrdered(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
KeyRange - Class in org.janusgraph.diskstorage.keycolumnvalue
A range of bytes between start and end where start is inclusive and end is exclusive.
KeyRange(StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KeyRange
 
KeyRangeQuery - Class in org.janusgraph.diskstorage.keycolumnvalue
Extends a SliceQuery to express a range for columns and a range for keys.
KeyRangeQuery(StaticBuffer, StaticBuffer, StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
KeyRangeQuery(StaticBuffer, StaticBuffer, SliceQuery) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
keys(String...) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for only those properties having one of the given property keys.
keys(String...) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
keys(String...) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
keys() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
keys(String...) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
keys(String...) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
keys() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
KeySelector - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
A KeySelector utility that can be generated out of a given KVQuery
KeySelector(Predicate<StaticBuffer>, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
KeySliceQuery - Class in org.janusgraph.diskstorage.keycolumnvalue
Extends SliceQuery by a key that identifies the location of the slice in the key-ring.
KeySliceQuery(StaticBuffer, StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
KeySliceQuery(StaticBuffer, SliceQuery) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
KeySlicesIterator - Interface in org.janusgraph.diskstorage.keycolumnvalue
 
KeyValueEntry - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
Representation of a (key,value) pair.
KeyValueEntry(StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
KeyValueStore - Interface in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
Interface for a data store that represents data in the simple key->value data model where each key is uniquely associated with a value.
KeyValueStoreManager - Interface in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
KVMutation - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
KVMutation(List<KeyValueEntry>, List<StaticBuffer>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
KVMutation() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
KVQuery - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
A query against a OrderedKeyValueStore.
KVQuery(StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
KVQuery(StaticBuffer, StaticBuffer, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
KVQuery(StaticBuffer, StaticBuffer, Predicate<StaticBuffer>, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
KVUtil - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
Utility methods for interacting with KeyValueStore.
KVUtil() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
 

L

label() - Method in interface org.janusgraph.core.JanusGraphVertex
Returns the name of the vertex label for this vertex.
label() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
label() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
LABEL - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
label() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
labels(String...) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for only those edges matching one of the given edge labels.
labels(String...) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
labels(String...) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
labels(String...) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
labels(String...) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
lastIsUmbrella - Variable in class org.janusgraph.diskstorage.configuration.ConfigElement.PathIdentifier
 
launder(String) - Static method in class org.janusgraph.util.encoding.StringEncoding
 
length() - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
length() - Method in enum org.janusgraph.diskstorage.util.HashingUtil.HashLength
 
length() - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
length(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
lessThan(T, T) - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Determines the ordering of objects in this priority queue.
limit(int) - Method in interface org.janusgraph.core.BaseVertexQuery
Sets the retrieval limit for this query.
limit(int) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Specifies the maximum number of elements to return
limit(int) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
limit(int) - Method in interface org.janusgraph.core.JanusGraphQuery
Limits the size of the returned result set
limit(int) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
limit(int) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
limit(int) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
limit(int) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
limit - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The limit of this query.
limit(int) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
LIMIT_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
LIMIT_BATCH_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LimitAdjustingIterator<R> - Class in org.janusgraph.graphdb.query
An iterator implementation that wraps around another iterator to iterate it up to a given limit.
LimitAdjustingIterator(int, int) - Constructor for class org.janusgraph.graphdb.query.LimitAdjustingIterator
Initializes this iterator with the current limit and the maximum number of elements that may be retrieved from the wrapped iterator.
limitBatchSize() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
limitedIterable(Iterable<O>, int) - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
Literal<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Abstract literal condition.
Literal() - Constructor for class org.janusgraph.graphdb.query.condition.Literal
 
literalTransformation(Condition<E>, Function<Condition<E>, Condition<E>>) - Static method in class org.janusgraph.graphdb.query.condition.ConditionUtil
 
llm - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
llm - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
Resolves lock contention by multiple threads.
load(JanusGraph) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
 
load(JanusGraph, String, boolean) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
 
loadAll(Class<?>) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
Reflectively load types at most once over the life of this class.
Loaded - Static variable in class org.janusgraph.graphdb.internal.ElementLifeCycle
The entity has been loaded from the database and has not changed after initial loading.
loadMapConfiguration(Map<String, Object>) - Static method in class org.janusgraph.util.system.ConfigurationUtil
Load properties from a map object and return a MapConfiguration object.
loadPropertiesConfig(String) - Static method in class org.janusgraph.util.system.ConfigurationUtil
Load properties from a given file name and return a PropertiesConfiguration object.
loadPropertiesConfig(String, boolean) - Static method in class org.janusgraph.util.system.ConfigurationUtil
Load properties from a given file name and return a PropertiesConfiguration object.
loadPropertiesConfig(File) - Static method in class org.janusgraph.util.system.ConfigurationUtil
Load properties from a given file object and return a PropertiesConfiguration object.
loadRelations(SliceQuery, Retriever<SliceQuery, EntryList>) - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Returns all relations that match the given query.
loadRelations(SliceQuery, Retriever<SliceQuery, EntryList>) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
loadRelations(SliceQuery, Retriever<SliceQuery, EntryList>) - Method in class org.janusgraph.graphdb.vertices.CacheVertex
 
loadRelations(SliceQuery, Retriever<SliceQuery, EntryList>) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
loadRelations(SliceQuery, Retriever<SliceQuery, EntryList>) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
loadStandard(Class<?>) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
loadWithoutMixedIndex(JanusGraph, boolean) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
 
localFoldInHasContainer(HasStepFolder, Step<?, ?>, Traversal.Admin<?, ?>, Traversal<?, ?>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
localKeyPartition(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
LocalLockMediator<T> - Class in org.janusgraph.diskstorage.locking
This class resolves lock contention between two transactions on the same JVM.
LocalLockMediator(String, TimestampProvider) - Constructor for class org.janusgraph.diskstorage.locking.LocalLockMediator
 
LocalLockMediatorProvider - Interface in org.janusgraph.diskstorage.locking
Service provider interface for LocalLockMediators.
LocalLockMediators - Enum in org.janusgraph.diskstorage.locking
A singleton maintaining a globally unique map of LocalLockMediator instances.
localOrderBy(TraversalParent, List<HasContainer>, String, Order) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
localOrderBy(TraversalParent, List<HasContainer>, String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
localOrderBy(TraversalParent, List<HasContainer>, String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
localOrderBy(TraversalParent, List<HasContainer>, String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
LocalStoreManager - Class in org.janusgraph.diskstorage.common
Abstract Store Manager used as the basis for local StoreManager implementations.
LocalStoreManager(Configuration) - Constructor for class org.janusgraph.diskstorage.common.LocalStoreManager
 
lock(KeyColumn, T, Instant) - Method in class org.janusgraph.diskstorage.locking.LocalLockMediator
Acquire the lock specified by kc.
lock() - Method in class org.janusgraph.diskstorage.util.NoLock
 
lock(Duration) - Method in class org.janusgraph.graphdb.transaction.lock.CombinerLock
 
lock(Duration) - Method in class org.janusgraph.graphdb.transaction.lock.FakeLock
 
lock(Duration) - Method in class org.janusgraph.graphdb.transaction.lock.ReentrantTransactionLock
 
lock(Duration) - Method in interface org.janusgraph.graphdb.transaction.lock.TransactionLock
 
LOCK_BACKEND - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Locker type to use.
LOCK_CLEAN_EXPIRED - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Whether to attempt to delete expired locks from the storage backend.
LOCK_COL_END - Static variable in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker
 
LOCK_COL_START - Static variable in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker
 
LOCK_EXPIRE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Number of milliseconds after which a lock is considered to have expired.
LOCK_LOCAL_MEDIATOR_GROUP - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configuration setting key for the local lock mediator prefix
LOCK_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOCK_RETRY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Number of times the system attempts to acquire a lock before giving up and throwing an exception.
LOCK_STORE_SUFFIX - Static variable in class org.janusgraph.diskstorage.Backend
 
LOCK_WAIT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LockCleanerService - Interface in org.janusgraph.diskstorage.locking.consistentkey
 
Locker - Interface in org.janusgraph.diskstorage.locking
Threadsafe discretionary locking within and between processes JanusGraph.
LockerProvider - Interface in org.janusgraph.diskstorage.locking
 
LockerState<S> - Class in org.janusgraph.diskstorage.locking
A store for LockStatus objects.
LockerState() - Constructor for class org.janusgraph.diskstorage.locking.LockerState
 
LockerState(ConcurrentMap<StoreTransaction, Map<KeyColumn, S>>) - Constructor for class org.janusgraph.diskstorage.locking.LockerState
 
lockExpire - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
lockExpire(Duration) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
lockExpire - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
The amount of time, in AbstractLocker.times.getUnit(), that may pass after writing a lock before it is considered to be invalid and automatically unlocked.
locking(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
lockInterruptibly() - Method in class org.janusgraph.diskstorage.util.NoLock
 
lockRetryCount(int) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
lockState - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
lockState - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
Stores all information about all locks this implementation has taken on behalf of any StoreTransaction.
LockStatus - Interface in org.janusgraph.diskstorage.locking
A single held lock's expiration time.
LockTuple - Class in org.janusgraph.graphdb.transaction.lock
 
LockTuple(Object...) - Constructor for class org.janusgraph.graphdb.transaction.lock.LockTuple
 
lockWait(Duration) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
log - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
log - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
 
Log - Interface in org.janusgraph.diskstorage.log
Represents a log that allows content to be added to it in the form of messages and to read messages and their content from the log via registered MessageReaders.
log - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
LOG_BACKEND - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_FIXED_PARTITION - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
 
LOG_KEY_CONSISTENT - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
LOG_MAX_PARTITIONS - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
 
LOG_MAX_READ_TIME - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
LOG_MAX_WRITE_TIME - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
LOG_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_NUM_BUCKETS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_READ_BATCH_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_READ_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_READ_LAG_TIME - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
LOG_READ_THREADS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_SEND_BATCH_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_SEND_DELAY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LOG_STORE_TTL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
LoggableTransaction - Interface in org.janusgraph.diskstorage
 
logger(Logger) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
LoggerUtil - Class in org.janusgraph.util.system
 
LoggerUtil() - Constructor for class org.janusgraph.util.system.LoggerUtil
 
logIdentifier(String) - Method in interface org.janusgraph.core.TransactionBuilder
Name of the log to be used for logging the mutations in this transaction.
logIdentifier(String) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
LogManager - Interface in org.janusgraph.diskstorage.log
Manager interface for opening Logs against a particular Log implementation.
logMutations(DataOutput) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
logMutations(DataOutput) - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
logMutations(DataOutput) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
logMutations(DataOutput) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
logMutations(DataOutput) - Method in interface org.janusgraph.diskstorage.LoggableTransaction
 
LogProcessorBuilder - Interface in org.janusgraph.core.log
Builder for assembling a processor that processes a particular transaction log.
LogProcessorFramework - Interface in org.janusgraph.core.log
Framework for processing transaction logs.
LogTxMeta - Enum in org.janusgraph.graphdb.database.log
 
LogTxStatus - Enum in org.janusgraph.graphdb.database.log
 
LONG_COMPRESSION_THRESHOLD - Static variable in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
LONG_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
LongArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
LongArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
longId() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
longId() - Method in interface org.janusgraph.core.Idfiable
Unique identifier for this entity.
longId() - Method in interface org.janusgraph.core.JanusGraphElement
Unique identifier for this entity.
longId() - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
longId() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
longId() - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
longId() - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
longId() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
longId() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
LongSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
LongSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
longSize - Static variable in class org.janusgraph.diskstorage.util.BufferUtil
 

M

M_ACQUIRE_LOCK - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_CALLS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_CALLS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_CLOSE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_CLOSE_MANAGER - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
M_CONTAINS_KEY - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_ENTRIES_COUNT - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_ENTRIES_HISTO - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_EXCEPTIONS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_EXCEPTIONS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_GET_KEYS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_GET_PART - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_GET_SLICE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_ITERATOR - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_MIXED_COUNT_QUERY - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_MUTATE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_MUTATE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_OPEN_DATABASE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
M_QUERY - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_RAW_QUERY - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_RESTORE - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_START_TX - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
M_TIME - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
M_TIME - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
M_TOTALS - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
main(String[]) - Static method in interface org.janusgraph.core.JanusGraph
 
main(String[]) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
Calls JanusGraphFactory.open(String), passing the JanusGraph configuration file path which must be the sole element in the args array, then calls GraphOfTheGodsFactory.load(org.janusgraph.core.JanusGraph) on the opened graph, then calls JanusGraph.close() and returns.
main(String[]) - Static method in class org.janusgraph.util.system.CheckSocket
 
main(String[]) - Static method in class org.janusgraph.util.system.ConfigurationFileFilter
 
main(String[]) - Static method in class org.janusgraph.util.system.ConfigurationLint
 
main(String[]) - Static method in class org.janusgraph.util.system.ConfigurationPrinter
 
make() - Method in interface org.janusgraph.core.schema.EdgeLabelMaker
Defines the EdgeLabel specified by this EdgeLabelMaker and returns the resulting label
make() - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
Defines the PropertyKey specified by this PropertyKeyMaker and returns the resulting key.
make() - Method in interface org.janusgraph.core.schema.RelationTypeMaker
Builds the configured relation type
make() - Method in interface org.janusgraph.core.schema.VertexLabelMaker
Creates a VertexLabel according to the specifications of this builder.
make() - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
make() - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
make() - Method in class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
makeConnectionConstraint(EdgeLabel, VertexLabel, VertexLabel, SchemaManager) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Add a constraint on which vertices the given edge label can connect using the schema manager.
makeConnectionConstraint(EdgeLabel, VertexLabel, VertexLabel, SchemaManager) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makeConnectionConstraint(EdgeLabel, VertexLabel, VertexLabel, SchemaManager) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makeDefinition() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
makeEdgeLabel(EdgeLabelMaker) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Creates a new edge label with default settings against the provided EdgeLabelMaker.
makeEdgeLabel(EdgeLabelMaker) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makeEdgeLabel(EdgeLabelMaker) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makeEdgeLabel(String) - Method in interface org.janusgraph.core.schema.SchemaManager
Returns a EdgeLabelMaker instance to define a new EdgeLabel with the given name.
makeEdgeLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
makeEdgeLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
makeEdgeLabel(String, TypeDefinitionMap) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
makeEdgeLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
makeFilterByAdjacentIdStep(Traversal.Admin<?, ?>, HasStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasIdOptimizerStrategy
 
makeFilterByAdjacentIdStep(Traversal.Admin<?, ?>, HasStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexHasUniquePropertyOptimizerStrategy
 
makeFilterByAdjacentIdStep(Traversal.Admin<?, ?>, IsStep<?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexIsOptimizerStrategy
 
makeFilterByAdjacentIdStep(Traversal.Admin<?, ?>, T) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy
 
makeImmutable() - Method in class org.janusgraph.graphdb.internal.OrderList
 
makePropertyConstraintForEdge(EdgeLabel, PropertyKey, SchemaManager) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Add property constraints for a given edge label using the schema manager.
makePropertyConstraintForEdge(EdgeLabel, PropertyKey, SchemaManager) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makePropertyConstraintForEdge(EdgeLabel, PropertyKey, SchemaManager) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makePropertyConstraintForVertex(VertexLabel, PropertyKey, SchemaManager) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Add property constraints for a given vertex label using the schema manager.
makePropertyConstraintForVertex(VertexLabel, PropertyKey, SchemaManager) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makePropertyConstraintForVertex(VertexLabel, PropertyKey, SchemaManager) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makePropertyKey(PropertyKeyMaker) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Creates a new property key with default settings against the provided PropertyKeyMaker.
makePropertyKey(PropertyKeyMaker, Object) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Creates a new property key with default settings against the provided PropertyKeyMaker and value.
makePropertyKey(PropertyKeyMaker) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makePropertyKey(PropertyKeyMaker) - Method in class org.janusgraph.core.schema.IgnorePropertySchemaMaker
 
makePropertyKey(PropertyKeyMaker) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makePropertyKey(PropertyKeyMaker, Object) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makePropertyKey(String) - Method in interface org.janusgraph.core.schema.SchemaManager
Returns a PropertyKeyMaker instance to define a new PropertyKey with the given name.
makePropertyKey(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
makePropertyKey(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
makePropertyKey(String, TypeDefinitionMap) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
makePropertyKey(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
makeQuery(Q) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
makeSchemaVertex(JanusGraphSchemaCategory, String, TypeDefinitionMap) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
makeSystemName(String) - Static method in class org.janusgraph.graphdb.internal.Token
 
makeVertexLabel(VertexLabelMaker) - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
Creates a new vertex label with the default settings against the provided VertexLabelMaker.
makeVertexLabel(VertexLabelMaker) - Method in class org.janusgraph.core.schema.DisableDefaultSchemaMaker
 
makeVertexLabel(VertexLabelMaker) - Method in class org.janusgraph.core.schema.JanusGraphDefaultSchemaMaker
 
makeVertexLabel(String) - Method in interface org.janusgraph.core.schema.SchemaManager
Returns a VertexLabelMaker to define a new vertex label with the given name.
makeVertexLabel(String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
makeVertexLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
makeVertexLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
MANAGEMENT_LOG - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
ManagementLogger - Class in org.janusgraph.graphdb.database.management
 
ManagementLogger(StandardJanusGraph, Log, SchemaCache, TimestampProvider) - Constructor for class org.janusgraph.graphdb.database.management.ManagementLogger
 
ManagementSystem - Class in org.janusgraph.graphdb.database.management
 
ManagementSystem(StandardJanusGraph, KCVSConfiguration, Log, ManagementLogger, SchemaCache) - Constructor for class org.janusgraph.graphdb.database.management.ManagementSystem
 
managementSystem - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
ManagementSystem.IndexJobStatus - Class in org.janusgraph.graphdb.database.management
 
ManagementUtil - Class in org.janusgraph.core.util
 
ManagementUtil() - Constructor for class org.janusgraph.core.util.ManagementUtil
 
manager - Variable in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
Map() - Constructor for class org.janusgraph.diskstorage.EntryMetaData.Map
 
MAP_JOB_FAILURE - Static variable in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
MAP_JOB_SUCCESS - Static variable in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
mapKey2Field(String, KeyInformation) - Method in interface org.janusgraph.diskstorage.indexing.IndexInformation
Adjusts the name of the key so that it is a valid field name that can be used in the index.
mapKey2Field(String, KeyInformation) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
mappedConnections() - Method in interface org.janusgraph.core.EdgeLabel
Collects all connection constraints.
mappedConnections() - Method in interface org.janusgraph.core.VertexLabel
Collects all connection constraints.
mappedConnections() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
mappedConnections() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
mappedConnections() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
mappedConnections() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
mappedProperties() - Method in interface org.janusgraph.core.EdgeLabel
Collects all property constraints.
mappedProperties() - Method in interface org.janusgraph.core.VertexLabel
Collects all property constraints.
mappedProperties() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
mappedProperties() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
mappedProperties() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
 
mappedProperties() - Method in class org.janusgraph.graphdb.types.vertices.EdgeLabelVertex
 
Mapping - Enum in org.janusgraph.core.schema
Used to change the default mapping of an indexed key by providing the mapping explicitly as a parameter to JanusGraphManagement.addIndexKey(JanusGraphIndex, org.janusgraph.core.PropertyKey, Parameter[]).
mapQueue - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraMapEmitter
 
mapReduce(MapReduce) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
MAPREDUCE_CHECK - Static variable in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
MaskedTimestamp(Instant) - Constructor for class org.janusgraph.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
MaskedTimestamp(StoreTransaction) - Constructor for class org.janusgraph.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
matches(SliceQuery, StaticBuffer) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
matches(KeyRangeQuery, StaticBuffer, StaticBuffer) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSUtil
 
matches(R) - Method in interface org.janusgraph.graphdb.query.ElementQuery
Whether the given element matches the conditions of this query.
matches(JanusGraphElement) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
matches(JanusGraphRelation) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
matchesConstraint(JanusGraphSchemaType, JanusGraphElement) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
MAX_BUFFER_CAPACITY - Static variable in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
MAX_CACHED_TYPES_DEFAULT - Static variable in class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
MAX_COMMIT_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
MAX_KEY - Static variable in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
MAX_LENGTH - Static variable in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
MAX_PADDING_BITWIDTH - Static variable in class org.janusgraph.graphdb.idmanagement.IDManager
The maximum number of padding bits of any type
maxVariableKeyLength - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
mediator(LocalLockMediator<StoreTransaction>) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
mediatorName(String) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
Retrieve the mediator associated with name via LocalLockMediators.get(String, TimestampProvider).
memoryKeys - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
merge(IndexMutation) - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
merge(Mutation<E, K>) - Method in class org.janusgraph.diskstorage.Mutation
Merges another mutation into this mutation.
MergedConfiguration - Class in org.janusgraph.diskstorage.configuration
 
MergedConfiguration(Configuration, Configuration) - Constructor for class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
mergeHighLimits(int, int) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
mergeJoin(LongArrayList, LongArrayList, boolean) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
 
mergeLowLimits(int, int) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
mergeSort(Iterable<R>, Iterable<R>, Comparator<R>, boolean) - Static method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
mergeSort(LongArrayList, LongArrayList) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
 
mergeSort(Collection<E>, Collection<E>, Comparator<E>) - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
Message - Interface in org.janusgraph.diskstorage.log
Messages which are added to and received from the Log.
MessageReader - Interface in org.janusgraph.diskstorage.log
Implementations of this interface are used to process messages read from the log.
MetaAnnotatable - Interface in org.janusgraph.diskstorage
 
MetaAnnotated - Interface in org.janusgraph.diskstorage
 
MetaData2ImplicitKey - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
MetricInstrumentedIndexProvider - Class in org.janusgraph.diskstorage.util
 
MetricInstrumentedIndexProvider(IndexProvider, String) - Constructor for class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
MetricInstrumentedIterator - Class in org.janusgraph.diskstorage.util
This class is used by MetricInstrumentedStore to measure wall clock time, method invocation counts, and exceptions thrown by the methods on RecordIterator instances returned from MetricInstrumentedStore.getSlice(org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery, org.janusgraph.diskstorage.keycolumnvalue.StoreTransaction).
MetricInstrumentedSchemaCache - Class in org.janusgraph.graphdb.database.cache
 
MetricInstrumentedSchemaCache(SchemaCache.StoreRetrieval) - Constructor for class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
MetricInstrumentedSlicesIterator - Class in org.janusgraph.diskstorage.util
This class is used by MetricInstrumentedStore to measure wall clock time, method invocation counts, and exceptions thrown by the methods on RecordIterator instances returned from MetricInstrumentedStore.getSlice(org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery, org.janusgraph.diskstorage.keycolumnvalue.StoreTransaction).
MetricInstrumentedStore - Class in org.janusgraph.diskstorage.util
This class instruments an arbitrary KeyColumnValueStore backend with Metrics.
MetricInstrumentedStore(KeyColumnValueStore, String) - Constructor for class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
MetricInstrumentedStoreManager - Class in org.janusgraph.diskstorage.util
 
MetricInstrumentedStoreManager(KeyColumnValueStoreManager, String, boolean, String) - Constructor for class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
MetricManager - Enum in org.janusgraph.util.stats
Singleton that contains and configures JanusGraph's MetricRegistry.
METRICS_CACHE_SUFFIX - Static variable in class org.janusgraph.diskstorage.Backend
 
METRICS_CONSOLE_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Metrics console reporter interval in milliseconds.
METRICS_CONSOLE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_CSV_DIR - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Metrics CSV output directory.
METRICS_CSV_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Metrics CSV reporter interval in milliseconds.
METRICS_CSV_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_GRAPHITE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The configuration namespace within GraphDatabaseConfiguration.METRICS_NS for Graphite.
METRICS_INDEX_PROVIDER_NAME - Static variable in class org.janusgraph.diskstorage.Backend
 
METRICS_JMX_AGENTID - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The JMX agentId through which to report Metrics.
METRICS_JMX_DOMAIN - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The JMX domain in which to report Metrics.
METRICS_JMX_ENABLED - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Whether to report Metrics through a JMX MBean.
METRICS_JMX_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_MERGE_STORES - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Whether to aggregate measurements for the edge store, vertex index, edge index, and ID store.
METRICS_MERGED_CACHE - Static variable in class org.janusgraph.diskstorage.Backend
 
METRICS_MERGED_STORE - Static variable in class org.janusgraph.diskstorage.Backend
 
METRICS_NAME - Static variable in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
METRICS_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configuration key prefix for Metrics.
METRICS_PREFIX - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The default name prefix for Metrics reported by JanusGraph.
METRICS_PREFIX_DEFAULT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
This is the prefix used outside of a graph database configuration, or for operations where a system-internal transaction is necessary as an implementation detail.
METRICS_RELATIONS - Static variable in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
METRICS_SCHEMA_PREFIX_DEFAULT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_SLF4J_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Metrics Slf4j reporter interval in milliseconds.
METRICS_SLF4J_LOGGER - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
The complete name of the Logger through which Metrics will report via Slf4j.
METRICS_SLF4J_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_STOREMANAGER_NAME - Static variable in class org.janusgraph.diskstorage.Backend
 
METRICS_SYSTEM_PREFIX_DEFAULT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_TYPENAME - Static variable in class org.janusgraph.graphdb.database.cache.MetricInstrumentedSchemaCache
 
metricsPrefix - Variable in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
MetricsQueryExecutor<Q extends ElementQuery,R extends JanusGraphElement,B extends BackendQuery> - Class in org.janusgraph.graphdb.query
Wraps a QueryExecutor to gather metrics on the query execution and forward them to METRICS.
MetricsQueryExecutor(String, String, QueryExecutor<Q, R, B>) - Constructor for class org.janusgraph.graphdb.query.MetricsQueryExecutor
 
MgmtLogType - Enum in org.janusgraph.graphdb.database.management
 
min(Duration, Duration) - Static method in class org.janusgraph.diskstorage.util.time.Durations
 
MIN_KEY - Static variable in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
MIN_TASKS_TO_PARALLELIZE - Static variable in class org.janusgraph.diskstorage.BackendTransaction
 
MIXED_INEX_COUNT_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
MixedConfiguration - Class in org.janusgraph.diskstorage.configuration
 
MixedConfiguration(ConfigNamespace, ReadConfiguration, ReadConfiguration) - Constructor for class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
MixedIndexCountQuery - Interface in org.janusgraph.core
 
mixedIndexCountQuery() - Method in interface org.janusgraph.core.Transaction
 
mixedIndexCountQuery() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
mixedIndexCountQuery() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
MixedIndexCountQueryBuilder - Class in org.janusgraph.graphdb.query.graph
Builds a MixedIndexCountQuery, which contains a single query against a mixed index.
MixedIndexCountQueryBuilder(IndexSerializer, BackendTransaction) - Constructor for class org.janusgraph.graphdb.query.graph.MixedIndexCountQueryBuilder
 
MixedIndexType - Interface in org.janusgraph.graphdb.types
 
MixedIndexTypeWrapper - Class in org.janusgraph.graphdb.types.indextype
 
MixedIndexTypeWrapper(SchemaSource) - Constructor for class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
ModifiableConfiguration - Class in org.janusgraph.diskstorage.configuration
 
ModifiableConfiguration(ConfigNamespace, WriteConfiguration, BasicConfiguration.Restriction) - Constructor for class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
ModifiableConfigurationBuilder - Class in org.janusgraph.diskstorage.configuration.builder
ModifiableConfigurationBuilder() - Constructor for class org.janusgraph.diskstorage.configuration.builder.ModifiableConfigurationBuilder
 
ModificationDeserializer - Class in org.janusgraph.graphdb.log
 
ModificationDeserializer() - Constructor for class org.janusgraph.graphdb.log.ModificationDeserializer
 
ModifierType - Enum in org.janusgraph.graphdb.database.management
 
modulateNaturalOrder(int) - Method in enum org.janusgraph.graphdb.internal.Order
Modulates the result of a Comparable.compareTo(Object) execution for this specific order, i.e.
movePositionTo(int) - Method in interface org.janusgraph.diskstorage.ReadBuffer
 
movePositionTo(int) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
MSG_USAGE - Static variable in class org.janusgraph.util.system.CheckSocket
 
MultiCondition<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Abstract condition element that combines multiple conditions (for instance, AND, OR).
MultiDistinctOrderedIterator<E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in org.janusgraph.graphdb.util
 
MultiDistinctOrderedIterator(Integer, Integer, List<Iterator<E>>, List<HasStepFolder.OrderEntry>) - Constructor for class org.janusgraph.graphdb.util.MultiDistinctOrderedIterator
 
MultiDistinctUnorderedIterator<E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in org.janusgraph.graphdb.util
 
MultiDistinctUnorderedIterator(int, int, List<Iterator<E>>) - Constructor for class org.janusgraph.graphdb.util.MultiDistinctUnorderedIterator
 
MultiIterator<E> - Class in org.janusgraph.graphdb.util
 
MultiIterator(Collection<Iterator<E>>) - Constructor for class org.janusgraph.graphdb.util.MultiIterator
 
MultiKeySliceQuery - Class in org.janusgraph.graphdb.query.graph
 
MultiKeySliceQuery(List<KeySliceQuery>) - Constructor for class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
multiplicity() - Method in interface org.janusgraph.core.EdgeLabel
The Multiplicity for this edge label.
Multiplicity - Enum in org.janusgraph.core
The multiplicity of edges between vertices for a given label.
multiplicity(Multiplicity) - Method in interface org.janusgraph.core.schema.EdgeLabelMaker
Sets the multiplicity of this label.
multiplicity() - Method in interface org.janusgraph.graphdb.internal.InternalRelationType
 
multiplicity(Multiplicity) - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
multiplicity - Variable in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
multiplicity(Multiplicity) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
multiplicity() - Method in class org.janusgraph.graphdb.types.system.BaseKey
 
multiplicity() - Method in class org.janusgraph.graphdb.types.system.BaseLabel
 
multiplicity() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
multiplicity() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
MULTIPREFETCH_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
MultiQueriable<S,E> - Interface in org.janusgraph.graphdb.tinkerpop.optimize.step
 
multiQuery(JanusGraphVertex...) - Method in interface org.janusgraph.core.Transaction
 
multiQuery(Collection<JanusGraphVertex>) - Method in interface org.janusgraph.core.Transaction
 
multiQuery(boolean) - Method in interface org.janusgraph.core.TransactionBuilder
Enable or disable multi-query, i.e.
multiQuery(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
multiQuery(JanusGraphVertex...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
multiQuery(Collection<JanusGraphVertex>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
multiQuery(JanusGraphVertex...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
multiQuery(Collection<JanusGraphVertex>) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
multiQuery(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
MULTIQUERY_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
MultiSlicesQuery - Class in org.janusgraph.diskstorage.keycolumnvalue
Queries for a list of slices of data, each identified by a start points (inclusive) and end points (exclusive).
MultiSlicesQuery(List<SliceQuery>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.MultiSlicesQuery
 
MultiVertexCentricQueryBuilder - Class in org.janusgraph.graphdb.query.vertex
MultiVertexCentricQueryBuilder(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
mutate(Map<String, Map<String, IndexMutation>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Mutates the index (adds and removes fields or entire documents)
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
Verifies acquisition of locks txh from previous calls to KeyColumnValueStore.acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) , then writes supplied additions and/or deletions to key in the underlying data store.
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVS
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
Verifies acquisition of locks txh from previous calls to KeyColumnValueStore.acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) , then writes supplied additions and/or deletions to key in the underlying data store.
mutate(Map<String, Map<String, IndexMutation>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
mutateEdges(StaticBuffer, List<Entry>, List<Entry>) - Method in class org.janusgraph.diskstorage.BackendTransaction
Applies the specified insertion and deletion mutations on the edge store to the provided key.
mutateEntries(StaticBuffer, List<Entry>, List<Entry>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
mutateIndex(StaticBuffer, List<Entry>, List<Entry>) - Method in class org.janusgraph.diskstorage.BackendTransaction
Applies the specified insertion and deletion mutations on the property index to the provided key.
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Executes multiple mutations at once.
mutateMany(Map<String, KVMutation>, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManager
Executes multiple mutations at once.
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
Mutation<E,K> - Class in org.janusgraph.diskstorage
Container for collection mutations against a data store.
Mutation(List<E>, List<K>) - Constructor for class org.janusgraph.diskstorage.Mutation
 
Mutation(Supplier<List<E>>, Supplier<List<K>>) - Constructor for class org.janusgraph.diskstorage.Mutation
 
Mutation() - Constructor for class org.janusgraph.diskstorage.Mutation
 

N

name() - Method in interface org.janusgraph.core.Namifiable
Returns the unique name of this entity.
name() - Method in interface org.janusgraph.core.schema.JanusGraphIndex
Returns the name of the index
name() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
name() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
NAME - Static variable in class org.janusgraph.graphdb.query.index.ApproximateIndexSelectionStrategy
 
NAME - Static variable in class org.janusgraph.graphdb.query.index.BruteForceIndexSelectionStrategy
 
NAME - Static variable in class org.janusgraph.graphdb.query.index.ThresholdBasedIndexSelectionStrategy
 
name() - Method in interface org.janusgraph.graphdb.types.SchemaSource
 
name(String) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
name(String) - Method in class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
name() - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
name() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
name() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
name() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
NAME_PREFIX - Static variable in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
Namifiable - Interface in org.janusgraph.core
Represents an entity that can be uniquely identified by a String name.
negate() - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
NetworkUtil - Class in org.janusgraph.util.system
 
NetworkUtil() - Constructor for class org.janusgraph.util.system.NetworkUtil
 
New - Static variable in class org.janusgraph.graphdb.internal.ElementLifeCycle
The entity has been newly created and not yet persisted.
newCondition() - Method in class org.janusgraph.diskstorage.util.NoLock
 
newThreadBoundTransaction() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
newThreadBoundTransaction() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
newTransaction() - Method in interface org.janusgraph.core.JanusGraph
Opens a new thread-independent JanusGraphTransaction.
newTransaction() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
newTransaction(TransactionConfiguration) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
next() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
 
next() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
 
next() - Method in class org.janusgraph.graphdb.query.LimitAdjustingIterator
 
next() - Method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
next() - Method in class org.janusgraph.graphdb.query.ResultSetIterator
 
next() - Method in class org.janusgraph.graphdb.util.AllEdgesIterator
Deprecated.
 
next() - Method in class org.janusgraph.graphdb.util.MultiDistinctOrderedIterator
 
next() - Method in class org.janusgraph.graphdb.vertices.RemovableRelationIterator
Deprecated.
 
nextBiggerBuffer(StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
nextBiggerBufferAllowOverflow(StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
nextID() - Method in interface org.janusgraph.graphdb.database.idassigner.IDPool
 
nextID() - Method in class org.janusgraph.graphdb.database.idassigner.StandardIDPool
 
nextInternal() - Method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
NO_ADDITIONS - Static variable in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
 
NO_COMPRESSION - Static variable in interface org.janusgraph.diskstorage.util.BackendCompression
 
NO_DELETIONS - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
NO_DELETIONS - Static variable in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStore
 
NO_FILTER - Static variable in class org.janusgraph.util.datastructures.IterablesUtil
 
NO_LIMIT - Static variable in interface org.janusgraph.graphdb.query.Query
 
NO_OP - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
NO_ORDER - Static variable in class org.janusgraph.diskstorage.indexing.IndexQuery
 
NO_ORDER - Static variable in class org.janusgraph.graphdb.internal.OrderList
 
noFilter() - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
NoKCVSCache - Class in org.janusgraph.diskstorage.keycolumnvalue.cache
 
NoKCVSCache(KeyColumnValueStore) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
NoLock - Class in org.janusgraph.diskstorage.util
Implementation of a lock that has no effect, i.e.
NONEXISTENT_TYPE - Static variable in class org.janusgraph.graphdb.internal.Token
 
nonnegativeInt() - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
noPartitionRestriction() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Removes any query partition restriction for this query
Not<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Negates the wrapped condition, i.e.
Not(Condition<E>) - Constructor for class org.janusgraph.graphdb.query.condition.Not
 
notKeyConsistent() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
NumberUtil - Class in org.janusgraph.util.stats
 
NumberUtil() - Constructor for class org.janusgraph.util.stats.NumberUtil
 
numChildren() - Method in enum org.janusgraph.graphdb.internal.RelationCategory
 
numChildren() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
numChildren() - Method in class org.janusgraph.graphdb.query.condition.Literal
 
numChildren() - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
numChildren() - Method in class org.janusgraph.graphdb.query.condition.Not
 
NumericUtils - Class in org.janusgraph.util.encoding
This file is copied verbatim from Apache Lucene NumericUtils.java Only the double/float to sortable long/int conversions are retained.
numIds() - Method in interface org.janusgraph.diskstorage.IDBlock
Number of ids in this block.
numProperties() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
numSubQueries() - Method in interface org.janusgraph.graphdb.query.ElementQuery
Returns the number of sub-queries this query is comprised of.
numSubQueries() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
numSubQueries() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
NUMVERTICES_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 

O

OBJECT_HEADER - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
OBJECT_REFERENCE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
ObjectSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ObjectSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ObjectSerializer
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.graph.MixedIndexCountQueryBuilder
 
observeWith(QueryProfiler) - Method in interface org.janusgraph.graphdb.query.profile.ProfileObservable
 
observeWith(QueryProfiler, boolean) - Method in interface org.janusgraph.graphdb.query.profile.ProfileObservable
 
observeWith(QueryProfiler, boolean) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
of(String, V) - Static method in class org.janusgraph.core.schema.Parameter
 
of(int) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
of(Iterator<? extends Entry>) - Static method in class org.janusgraph.diskstorage.util.EntryArrayList
 
of(Iterable<? extends Entry>) - Static method in class org.janusgraph.diskstorage.util.EntryArrayList
 
of(KeyIterator, String...) - Static method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
If the iterator argument is non-null, then return a new MetricInstrumentedIterator wrapping it.
of(KeySlicesIterator, String...) - Static method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
If the iterator argument is non-null, then return a new MetricInstrumentedIterator wrapping it.
of(TimestampProvider) - Static method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
of(TimestampProvider, Configuration) - Static method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
of(byte[]) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
of(ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
of(StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
of(StaticBuffer, StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
of(Entry...) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
of(Iterable<Entry>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
of(JanusGraphTransaction) - Static method in class org.janusgraph.graphdb.olap.computer.FulgoraElementTraversal
 
of(Condition<E>...) - Static method in class org.janusgraph.graphdb.query.condition.And
 
of(Condition<E>) - Static method in class org.janusgraph.graphdb.query.condition.Not
 
of(Condition<E>...) - Static method in class org.janusgraph.graphdb.query.condition.Or
 
of(K, JanusGraphPredicate, Object) - Static method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
of(PropertyKey) - Static method in class org.janusgraph.graphdb.types.IndexField
 
of(PropertyKey, Parameter...) - Static method in class org.janusgraph.graphdb.types.ParameterIndexField
 
of(TypeDefinitionCategory) - Static method in class org.janusgraph.graphdb.types.TypeDefinitionDescription
 
of(Iterable<? extends Vertex>) - Static method in class org.janusgraph.graphdb.util.AllEdgesIterable
Deprecated.
Returns an iterable over all edges incident on the vertices returned by the given Iterable over vertices.
of(Set<? extends Vertex>) - Static method in class org.janusgraph.graphdb.util.AllEdgesIterable
Deprecated.
Returns an iterable over all edges contained in the subgraph spanned by the given vertices.
ofByteBuffer(E, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
ofByteBuffer(Iterable<E>, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
ofByteBuffer(Iterator<E>, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
ofBytes(E, StaticArrayEntry.GetColVal<E, byte[]>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
ofBytes(Iterable<E>, StaticArrayEntry.GetColVal<E, byte[]>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
offset(int) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Specifies the offset of the query.
offset(int) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
ofStaticBuffer(E, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
ofStaticBuffer(Iterable<E>, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
ofStaticBuffer(Iterator<E>, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
oneAlive(Thread[]) - Static method in class org.janusgraph.util.system.Threads
 
oneBuffer(int) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
oneByteBuffer(int) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
 
open(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Open a JanusGraph using a previously created Configuration using the ConfigurationManagementGraph API.
open() - Method in class org.janusgraph.core.JanusGraphFactory.Builder
Opens a JanusGraph graph with the previously configured options.
open(String) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database.
open(String, String) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database.
open(Configuration) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database configured according to the provided configuration.
open(BasicConfiguration) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database configured according to the provided configuration.
open(ReadConfiguration) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database configured according to the provided configuration.
open(ReadConfiguration, String) - Static method in class org.janusgraph.core.JanusGraphFactory
Opens a JanusGraph database configured according to the provided configuration.
open(Configuration) - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
openDatabase(String, StoreMetaData.Container) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSManagerProxy
 
openDatabase(String) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Opens an ordered database by the given name.
openDatabase(String, StoreMetaData.Container) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Opens an ordered database by the given name.
openDatabase(String) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueStoreManager
Opens a key-value database by the given name.
openDatabase(String) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManager
Opens an ordered database by the given name.
openDatabase(String) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
openDatabase(String, StoreMetaData.Container) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
openDatabase(String) - Method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
openDatabase(String, StoreMetaData.Container) - Method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
openDatabase(String) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
openDatabase(String, StoreMetaData.Container) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
 
openGraph(String, Function<String, Graph>) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
openLog(String) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLogManager
 
openLog(String) - Method in interface org.janusgraph.diskstorage.log.LogManager
Opens a log for the given name.
openManagement() - Method in interface org.janusgraph.core.JanusGraph
Returns the management system for this graph instance.
openManagement() - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
OPENSTAR_CHECK - Static variable in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
openTransactionLog(JanusGraph) - Static method in class org.janusgraph.core.JanusGraphFactory
Returns a LogProcessorFramework for processing transaction log entries against the provided graph instance.
openTx() - Method in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
openTx() - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
openTx() - Method in interface org.janusgraph.diskstorage.util.BackendOperation.TransactionalProvider
 
OPERATION_NAMES - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
OPERATION_NAMES - Static variable in class org.janusgraph.diskstorage.util.MetricInstrumentedStore
 
optimisticLocking(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
OPTIMIZATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
OPTIMIZER_BACKEND_ACCESS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
optimizerBackendAccess() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
optimizeStep(T) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy
 
or(Collection<Q>) - Method in interface org.janusgraph.core.JanusGraphQuery
 
Or<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Combines multiple conditions under semantic OR, i.e.
Or(Condition<E>...) - Constructor for class org.janusgraph.graphdb.query.condition.Or
 
Or(int) - Constructor for class org.janusgraph.graphdb.query.condition.Or
 
Or() - Constructor for class org.janusgraph.graphdb.query.condition.Or
 
or(Collection<GraphCentricQueryBuilder>) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
OR_QUERY - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
Order - Enum in org.janusgraph.graphdb.internal
Constants to specify the ordering of a result set in queries.
order - Variable in class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
orderBy(String, Order) - Method in interface org.janusgraph.core.BaseVertexQuery
Orders the relation results of this query according to their property for the given key in the given order (increasing/decreasing).
orderBy(String, Order) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Orders the element results of this query according to their property for the given key in the given order (increasing/decreasing).
orderBy(String, Order) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
orderBy(String, Order) - Method in interface org.janusgraph.core.JanusGraphQuery
Orders the element results of this query according to their property for the given key in the given order (increasing/decreasing).
orderBy(String, Order) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
orderBy(String, Order) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
orderBy(String, Order) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
ORDERED_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
OrderedKeyValueStore - Interface in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
A KeyValueStore where the keys are ordered such that keys can be retrieved in order.
OrderedKeyValueStoreAdapter - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
Wraps a OrderedKeyValueStore and exposes it as a KeyColumnValueStore.
OrderedKeyValueStoreAdapter(OrderedKeyValueStore) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
OrderedKeyValueStoreAdapter(OrderedKeyValueStore, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
OrderedKeyValueStoreManager - Interface in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
A KeyValueStoreManager where the stores maintain keys in their natural order.
OrderedKeyValueStoreManagerAdapter - Class in org.janusgraph.diskstorage.keycolumnvalue.keyvalue
OrderedKeyValueStoreManagerAdapter(OrderedKeyValueStoreManager) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
OrderedKeyValueStoreManagerAdapter(OrderedKeyValueStoreManager, Map<String, Integer>) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
orderedScan(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
OrderEntry(String, Order, Class<?>) - Constructor for class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
OrderEntry(PropertyKey, Order) - Constructor for class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
OrderEntry(String, Order) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
OrderList - Class in org.janusgraph.graphdb.internal
 
OrderList() - Constructor for class org.janusgraph.graphdb.internal.OrderList
 
OrderList.OrderEntry - Class in org.janusgraph.graphdb.internal
 
OrderPreservingSerializer<V> - Interface in org.janusgraph.graphdb.database.serialize
Interface that extends AttributeSerializer to provide a serialization that is byte order preserving, i.e.
orders - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The order in which the relations should be returned.
ORDERS_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
org.janusgraph.core - package org.janusgraph.core
 
org.janusgraph.core.attribute - package org.janusgraph.core.attribute
 
org.janusgraph.core.log - package org.janusgraph.core.log
 
org.janusgraph.core.schema - package org.janusgraph.core.schema
 
org.janusgraph.core.util - package org.janusgraph.core.util
 
org.janusgraph.diskstorage - package org.janusgraph.diskstorage
 
org.janusgraph.diskstorage.common - package org.janusgraph.diskstorage.common
 
org.janusgraph.diskstorage.configuration - package org.janusgraph.diskstorage.configuration
 
org.janusgraph.diskstorage.configuration.backend - package org.janusgraph.diskstorage.configuration.backend
 
org.janusgraph.diskstorage.configuration.backend.builder - package org.janusgraph.diskstorage.configuration.backend.builder
 
org.janusgraph.diskstorage.configuration.builder - package org.janusgraph.diskstorage.configuration.builder
 
org.janusgraph.diskstorage.configuration.converter - package org.janusgraph.diskstorage.configuration.converter
 
org.janusgraph.diskstorage.idmanagement - package org.janusgraph.diskstorage.idmanagement
 
org.janusgraph.diskstorage.indexing - package org.janusgraph.diskstorage.indexing
 
org.janusgraph.diskstorage.keycolumnvalue - package org.janusgraph.diskstorage.keycolumnvalue
 
org.janusgraph.diskstorage.keycolumnvalue.cache - package org.janusgraph.diskstorage.keycolumnvalue.cache
 
org.janusgraph.diskstorage.keycolumnvalue.keyvalue - package org.janusgraph.diskstorage.keycolumnvalue.keyvalue
 
org.janusgraph.diskstorage.keycolumnvalue.scan - package org.janusgraph.diskstorage.keycolumnvalue.scan
 
org.janusgraph.diskstorage.keycolumnvalue.ttl - package org.janusgraph.diskstorage.keycolumnvalue.ttl
 
org.janusgraph.diskstorage.locking - package org.janusgraph.diskstorage.locking
 
org.janusgraph.diskstorage.locking.consistentkey - package org.janusgraph.diskstorage.locking.consistentkey
 
org.janusgraph.diskstorage.log - package org.janusgraph.diskstorage.log
 
org.janusgraph.diskstorage.log.kcvs - package org.janusgraph.diskstorage.log.kcvs
 
org.janusgraph.diskstorage.log.util - package org.janusgraph.diskstorage.log.util
 
org.janusgraph.diskstorage.util - package org.janusgraph.diskstorage.util
 
org.janusgraph.diskstorage.util.time - package org.janusgraph.diskstorage.util.time
 
org.janusgraph.example - package org.janusgraph.example
 
org.janusgraph.graphdb.configuration - package org.janusgraph.graphdb.configuration
 
org.janusgraph.graphdb.configuration.builder - package org.janusgraph.graphdb.configuration.builder
 
org.janusgraph.graphdb.configuration.converter - package org.janusgraph.graphdb.configuration.converter
 
org.janusgraph.graphdb.configuration.validator - package org.janusgraph.graphdb.configuration.validator
 
org.janusgraph.graphdb.database - package org.janusgraph.graphdb.database
 
org.janusgraph.graphdb.database.cache - package org.janusgraph.graphdb.database.cache
 
org.janusgraph.graphdb.database.idassigner - package org.janusgraph.graphdb.database.idassigner
 
org.janusgraph.graphdb.database.idassigner.placement - package org.janusgraph.graphdb.database.idassigner.placement
 
org.janusgraph.graphdb.database.idhandling - package org.janusgraph.graphdb.database.idhandling
 
org.janusgraph.graphdb.database.log - package org.janusgraph.graphdb.database.log
 
org.janusgraph.graphdb.database.management - package org.janusgraph.graphdb.database.management
 
org.janusgraph.graphdb.database.serialize - package org.janusgraph.graphdb.database.serialize
 
org.janusgraph.graphdb.database.serialize.attribute - package org.janusgraph.graphdb.database.serialize.attribute
 
org.janusgraph.graphdb.idmanagement - package org.janusgraph.graphdb.idmanagement
 
org.janusgraph.graphdb.internal - package org.janusgraph.graphdb.internal
 
org.janusgraph.graphdb.log - package org.janusgraph.graphdb.log
 
org.janusgraph.graphdb.management - package org.janusgraph.graphdb.management
 
org.janusgraph.graphdb.management.utils - package org.janusgraph.graphdb.management.utils
 
org.janusgraph.graphdb.olap - package org.janusgraph.graphdb.olap
 
org.janusgraph.graphdb.olap.computer - package org.janusgraph.graphdb.olap.computer
 
org.janusgraph.graphdb.olap.job - package org.janusgraph.graphdb.olap.job
 
org.janusgraph.graphdb.predicate - package org.janusgraph.graphdb.predicate
 
org.janusgraph.graphdb.query - package org.janusgraph.graphdb.query
 
org.janusgraph.graphdb.query.condition - package org.janusgraph.graphdb.query.condition
 
org.janusgraph.graphdb.query.graph - package org.janusgraph.graphdb.query.graph
 
org.janusgraph.graphdb.query.index - package org.janusgraph.graphdb.query.index
 
org.janusgraph.graphdb.query.profile - package org.janusgraph.graphdb.query.profile
 
org.janusgraph.graphdb.query.vertex - package org.janusgraph.graphdb.query.vertex
 
org.janusgraph.graphdb.relations - package org.janusgraph.graphdb.relations
 
org.janusgraph.graphdb.schema - package org.janusgraph.graphdb.schema
 
org.janusgraph.graphdb.tinkerpop - package org.janusgraph.graphdb.tinkerpop
 
org.janusgraph.graphdb.tinkerpop.optimize - package org.janusgraph.graphdb.tinkerpop.optimize
 
org.janusgraph.graphdb.tinkerpop.optimize.step - package org.janusgraph.graphdb.tinkerpop.optimize.step
 
org.janusgraph.graphdb.tinkerpop.optimize.strategy - package org.janusgraph.graphdb.tinkerpop.optimize.strategy
 
org.janusgraph.graphdb.tinkerpop.plugin - package org.janusgraph.graphdb.tinkerpop.plugin
 
org.janusgraph.graphdb.tinkerpop.profile - package org.janusgraph.graphdb.tinkerpop.profile
 
org.janusgraph.graphdb.transaction - package org.janusgraph.graphdb.transaction
 
org.janusgraph.graphdb.transaction.addedrelations - package org.janusgraph.graphdb.transaction.addedrelations
 
org.janusgraph.graphdb.transaction.indexcache - package org.janusgraph.graphdb.transaction.indexcache
 
org.janusgraph.graphdb.transaction.lock - package org.janusgraph.graphdb.transaction.lock
 
org.janusgraph.graphdb.transaction.subquerycache - package org.janusgraph.graphdb.transaction.subquerycache
 
org.janusgraph.graphdb.transaction.vertexcache - package org.janusgraph.graphdb.transaction.vertexcache
 
org.janusgraph.graphdb.types - package org.janusgraph.graphdb.types
 
org.janusgraph.graphdb.types.indextype - package org.janusgraph.graphdb.types.indextype
 
org.janusgraph.graphdb.types.system - package org.janusgraph.graphdb.types.system
 
org.janusgraph.graphdb.types.vertices - package org.janusgraph.graphdb.types.vertices
 
org.janusgraph.graphdb.util - package org.janusgraph.graphdb.util
 
org.janusgraph.graphdb.vertices - package org.janusgraph.graphdb.vertices
 
org.janusgraph.util.datastructures - package org.janusgraph.util.datastructures
 
org.janusgraph.util.encoding - package org.janusgraph.util.encoding
 
org.janusgraph.util.stats - package org.janusgraph.util.stats
 
org.janusgraph.util.system - package org.janusgraph.util.system
 
OrJanusPredicate - Class in org.janusgraph.graphdb.predicate
 
OrJanusPredicate() - Constructor for class org.janusgraph.graphdb.predicate.OrJanusPredicate
 
OrJanusPredicate(List<JanusGraphPredicate>) - Constructor for class org.janusgraph.graphdb.predicate.OrJanusPredicate
 
otherVertex(Vertex) - Method in interface org.janusgraph.core.JanusGraphEdge
Returns the vertex at the opposite end of the edge.
otherVertex(Vertex) - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
outVertex() - Method in interface org.janusgraph.core.JanusGraphEdge
 
outVertexId - Variable in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Modification
 

P

padBuffer(StaticBuffer, int) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
PAGE_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Default number of results to pull over the wire when iterating over a distributed storage backend.
pageSize - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
PARALLEL_BACKEND_EXECUTOR_SERVICE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_EXECUTOR_SERVICE_CLASS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_EXECUTOR_SERVICE_CORE_POOL_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_EXECUTOR_SERVICE_KEEP_ALIVE_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_EXECUTOR_SERVICE_MAX_POOL_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_EXECUTOR_SERVICE_MAX_SHUTDOWN_WAIT_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
PARALLEL_BACKEND_OPS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
If enabled, JanusGraph attempts to parallelize storage operations against the storage backend using a fixed thread pool shared across the entire JanusGraph graph database instance.
Parameter<V> - Class in org.janusgraph.core.schema
Simple class to represent arbitrary parameters as key-value pairs.
Parameter(String, V) - Constructor for class org.janusgraph.core.schema.Parameter
 
ParameterArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ParameterArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
ParameterIndexField - Class in org.janusgraph.graphdb.types
 
ParameterSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ParameterSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ParameterSerializer
 
ParameterType - Enum in org.janusgraph.graphdb.types
 
parse(ConfigNamespace, String) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
parse(String) - Static method in class org.janusgraph.diskstorage.util.time.Durations
 
parse(StaticBuffer, Serializer, TimestampProvider) - Static method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
parseDirection(Entry) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
parseRelation(Entry, boolean, TypeInspector) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
parseRelation(Entry, boolean, TypeInspector) - Method in interface org.janusgraph.graphdb.database.RelationReader
 
parseRelation(TransactionLogHeader.Modification, StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.log.ModificationDeserializer
 
partition() - Method in interface org.janusgraph.core.schema.VertexLabelMaker
Enables partitioning for this vertex label.
partition() - Method in class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
PARTITION_FINDING_ATTEMPTS - Static variable in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
PARTITION_KEY - Static variable in class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
PARTITION_VERTEX_POSTFAIL - Static variable in class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PARTITION_VERTEX_POSTSUCCESS - Static variable in class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PartitionAssignment - Interface in org.janusgraph.graphdb.database.idassigner.placement
Utility interface used in IDPlacementStrategy to hold the partition assignment of a vertex (if it is already assigned a partition) or to be assigned a partition id.
PARTITIONED_VERTEX_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
PARTITIONED_VERTEX_PARTITION - Static variable in class org.janusgraph.graphdb.idmanagement.IDManager
 
PartitionedVertexProgramExecutor<M> - Class in org.janusgraph.graphdb.olap.computer
 
PartitionedVertexProgramExecutor(StandardJanusGraph, FulgoraMemory, FulgoraVertexMemory, VertexProgram<M>) - Constructor for class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PartitionIDRange - Class in org.janusgraph.graphdb.database.idassigner.placement
An instance of this class describes a range of partition ids.
PartitionIDRange(int, int, int) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
PartitionVertexAggregate<M> - Class in org.janusgraph.graphdb.olap.computer
 
PartitionVertexAggregate(Map<MessageScope, Integer>) - Constructor for class org.janusgraph.graphdb.olap.computer.PartitionVertexAggregate
 
password - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
PermanentBackendException - Exception in org.janusgraph.diskstorage
This exception signifies a permanent exception in a JanusGraph storage backend, that is, an exception that is due to a permanent failure while persisting data.
PermanentBackendException(String) - Constructor for exception org.janusgraph.diskstorage.PermanentBackendException
 
PermanentBackendException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.PermanentBackendException
 
PermanentBackendException(Throwable) - Constructor for exception org.janusgraph.diskstorage.PermanentBackendException
Constructs an exception with a generic message
PermanentLockingException - Exception in org.janusgraph.diskstorage.locking
This exception signifies a failure to lock based on durable state.
PermanentLockingException(String) - Constructor for exception org.janusgraph.diskstorage.locking.PermanentLockingException
 
PermanentLockingException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.PermanentLockingException
 
PermanentLockingException(Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.PermanentLockingException
Constructs an exception with a generic message
persist(GraphComputer.Persist) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
persists(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
PLACEMENT_STRATEGY - Static variable in class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
PointInterval<T> - Class in org.janusgraph.util.datastructures
 
PointInterval(T) - Constructor for class org.janusgraph.util.datastructures.PointInterval
 
PointInterval(T...) - Constructor for class org.janusgraph.util.datastructures.PointInterval
 
PointInterval(Iterable<T>) - Constructor for class org.janusgraph.util.datastructures.PointInterval
 
pointRange(StaticBuffer) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
poll - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
pollInterval(long, TemporalUnit) - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
Set the index information polling interval.
pop() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Removes and returns the least element of the PriorityQueue in log(size) time.
port - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
position(Direction) - Static method in class org.janusgraph.graphdb.relations.EdgeDirection
 
positiveBackwardLength(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
positiveBuffer(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
positiveBuffer(long[]) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
positiveInt() - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
positiveLength(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
positiveLong() - Static method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
positiveWithPrefixLength(long, int) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
PowerSet<T> - Class in org.janusgraph.util.datastructures
 
PowerSet(Set<T>) - Constructor for class org.janusgraph.util.datastructures.PowerSet
 
preBuild() - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
Inspect and modify this builder's state after the client has called build(), but before a return object has been instantiated.
PredicateCondition<K,E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
 
PredicateCondition(K, JanusGraphPredicate, Object) - Constructor for class org.janusgraph.graphdb.query.condition.PredicateCondition
 
preferredTimestamps(TimestampProviders) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
preFetch() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Makes a call to properties to pre-fetch the properties into the vertex cache
preFetch() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
PreInitializeConfigOptions - Annotation Type in org.janusgraph.graphdb.configuration
 
PreloadedVertex - Class in org.janusgraph.graphdb.vertices
 
PreloadedVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.vertices.PreloadedVertex
 
PreloadedVertex.AccessCheck - Interface in org.janusgraph.graphdb.vertices
 
PreloadedVertex.PropertyMixing - Interface in org.janusgraph.graphdb.vertices
 
prepareCommit(Collection<InternalRelation>, Collection<InternalRelation>, Predicate<InternalRelation>, BackendTransaction, StandardJanusGraphTx, boolean) - Method in class org.janusgraph.graphdb.database.StandardJanusGraph
 
previousMap - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
printEdgeLabels() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Prints out schema information related to edge labels.
printEdgeLabels() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
printIndexes() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Prints out schema information related to indexes
printIndexes() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
printPropertyKeys() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Prints out schema information related to property keys.
printPropertyKeys() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
printSchema() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Prints out schema information related to vertex and edge labels, indexes, and property keys.
printSchema() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
printVertexLabels() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Prints out schema information related to vertex labels.
printVertexLabels() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
PriorityQueue<T> - Class in org.janusgraph.graphdb.util
Deprecated.
PriorityQueue(int) - Constructor for class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
 
PriorityQueue(int, boolean) - Constructor for class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
 
process(JanusGraphTransaction, TransactionId, ChangeState) - Method in interface org.janusgraph.core.log.ChangeProcessor
Process the changes caused by the transaction identified by txId within a newly opened transaction tx.
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
Run this ScanJob's computation on the supplied row-key and entries.
process(JanusGraphVertex, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
process(JanusGraphVertex, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
process(JanusGraphVertex, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
process(JanusGraphVertex, ScanMetrics) - Method in interface org.janusgraph.graphdb.olap.VertexScanJob
Process the given vertex with its adjacency list and properties pre-loaded.
processIntersectingRetrievals(List<QueryUtil.IndexCall<R>>, int) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
ProcessMessageJob - Class in org.janusgraph.diskstorage.log.util
Helper class for processing read messages with the registered message readers.
ProcessMessageJob(Message, MessageReader) - Constructor for class org.janusgraph.diskstorage.log.util.ProcessMessageJob
 
processNextStart() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphEdgeVertexStep
 
processNextStart() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
processNextStart() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
profile(QueryProfiler, Q, Function<Q, R>) - Static method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
profile(QueryProfiler, Q, boolean, Function<Q, R>) - Static method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
profile(String, QueryProfiler, Q, boolean, Function<Q, R>) - Static method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
ProfiledIterator<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.util
 
ProfiledIterator(QueryProfiler, Supplier<Iterator<E>>) - Constructor for class org.janusgraph.graphdb.util.ProfiledIterator
 
ProfileObservable - Interface in org.janusgraph.graphdb.query.profile
 
profiler(QueryProfiler) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
profiler - Variable in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
The query profiler used to observe this query
profiler(QueryProfiler) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Sets the query profiler to observe this query.
program(VertexProgram) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
projectTraverser(Traverser.Admin<S>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
PROPER_DIRS - Static variable in class org.janusgraph.graphdb.relations.EdgeDirection
 
properties(String...) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
properties() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Deprecated.
properties() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Returns an iterable over all incident properties that match this query for each vertex
properties() - Method in interface org.janusgraph.core.JanusGraphQuery
Returns all properties that match the conditions
properties() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns an iterable over all incident properties that match this query
properties(String...) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
properties - Variable in class org.janusgraph.graphdb.olap.computer.VertexState
 
properties() - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
properties() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
properties() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
Deprecated.
properties() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
properties() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
properties(String...) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
properties(String...) - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
properties(String...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
properties(String...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
properties(String...) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
properties(String...) - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.PropertyMixing
 
property(String, V) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
property(String, V) - Method in interface org.janusgraph.core.JanusGraphElement
Sets the value for the given key on this element.
property(String, V) - Method in interface org.janusgraph.core.JanusGraphVertex
Creates a new property for this vertex and given key with the specified value.
property(String, V, Object...) - Method in interface org.janusgraph.core.JanusGraphVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in interface org.janusgraph.core.JanusGraphVertex
 
property(String, A) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
property(String, V) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
property(String, V, Object...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
property(String, V, Object...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
property(String, V, Object...) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
property(VertexProperty.Cardinality, String, V) - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.PropertyMixing
 
PROPERTY_CREATED_USING_TEMPLATE - Static variable in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
 
PROPERTY_GRAPH_NAME - Static variable in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
 
PROPERTY_PREFETCHING - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
propertyCount() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns the number of properties that match this query
propertyIterator() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
propertyKey() - Method in interface org.janusgraph.core.JanusGraphProperty
 
propertyKey() - Method in interface org.janusgraph.core.JanusGraphVertexProperty
 
PropertyKey - Interface in org.janusgraph.core
PropertyKey is an extension of RelationType for properties.
propertyKey() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
PROPERTYKEY_DEFINITION_CATEGORIES - Static variable in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
PropertyKeyDefinition - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
PropertyKeyDefinition(String, long, Cardinality, Class) - Constructor for class org.janusgraph.graphdb.schema.PropertyKeyDefinition
Deprecated.
 
PropertyKeyDefinition(String, long, Multiplicity, Class) - Constructor for class org.janusgraph.graphdb.schema.PropertyKeyDefinition
Deprecated.
 
PropertyKeyDefinition(PropertyKey) - Constructor for class org.janusgraph.graphdb.schema.PropertyKeyDefinition
Deprecated.
 
PropertyKeyMaker - Interface in org.janusgraph.core.schema
Used to define new PropertyKeys.
PropertyKeyVertex - Class in org.janusgraph.graphdb.types.vertices
 
PropertyKeyVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.types.vertices.PropertyKeyVertex
 
PropertyPlacementStrategy - Class in org.janusgraph.graphdb.database.idassigner.placement
 
PropertyPlacementStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
PropertyPlacementStrategy(String, int) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
propertyPrefetching(boolean) - Method in interface org.janusgraph.core.TransactionBuilder
Enable or disable property pre-fetching, i.e.
propertyPrefetching(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
propertyStream() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns all properties that match the query in the indexing backend.
propertyStream() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
propertyTotals() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns total properties that match the query in the indexing backend ignoring limit and offset.
propertyTotals() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
put(EntryMetaData, Object) - Method in class org.janusgraph.diskstorage.EntryMetaData.Map
 
put(K, V) - Method in class org.janusgraph.diskstorage.StoreMetaData.Container
 
put(WriteBuffer, byte[]) - Static method in class org.janusgraph.diskstorage.util.WriteBufferUtil
 
put(WriteBuffer, StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.WriteBufferUtil
 
put(JointIndexQuery.Subquery, List<Object>) - Method in class org.janusgraph.graphdb.transaction.subquerycache.EmptySubqueryCache
 
put(JointIndexQuery.Subquery, SubsetSubqueryCache.SubqueryResult) - Method in class org.janusgraph.graphdb.transaction.subquerycache.GuavaSubqueryCache
 
put(JointIndexQuery.Subquery, List<Object>) - Method in interface org.janusgraph.graphdb.transaction.subquerycache.SubqueryCache
Add given values into cache
put(JointIndexQuery.Subquery, SubsetSubqueryCache.SubqueryResult) - Method in class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
put(JointIndexQuery.Subquery, List<Object>) - Method in class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
put(Long, V) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
putBoolean(boolean) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putBoolean(boolean) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putByte(byte) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putByte(byte) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putByte(byte) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putBytes(byte[]) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putBytes(StaticBuffer) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putBytes(byte[]) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putBytes(StaticBuffer) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putBytes(byte[]) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putBytes(StaticBuffer) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putChar(char) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putChar(char) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putChar(char) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putDouble(double) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putDouble(double) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putDouble(double) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putFloat(float) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putFloat(float) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putFloat(float) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putGraph(String, Graph) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
putIfAbsent(Long, V) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
putInt(byte[], int, int) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
putInt(int) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putInt(int) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putInt(int) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putLong(byte[], int, long) - Static method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
putLong(long) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putLong(long) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putLong(long) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putShort(short) - Method in class org.janusgraph.diskstorage.util.WriteByteBuffer
 
putShort(short) - Method in interface org.janusgraph.diskstorage.WriteBuffer
 
putShort(short) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
putTraversalSource(String, TraversalSource) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 

Q

queries - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
The individual component SliceQuery of this query.
query() - Method in interface org.janusgraph.core.JanusGraphVertex
Starts a new JanusGraphVertexQuery for this vertex.
query() - Method in interface org.janusgraph.core.Transaction
 
query(IndexQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Executes the given query against the index.
query(RawQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Executes the given raw query against the index
query(IndexQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
query(RawQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
query(IndexQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
query(RawQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
query(JointIndexQuery.Subquery, BackendTransaction) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
query() - Method in interface org.janusgraph.graphdb.internal.InternalVertex
 
Query - Interface in org.janusgraph.graphdb.query
Standard Query interface specifying that a query may have a limit.
query() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
query(JanusGraphVertex) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
query() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
query() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
query() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
query() - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
QUERY_ANNOTATION - Static variable in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
QUERY_NAME_PREFIX - Static variable in class org.janusgraph.graphdb.olap.QueryContainer
 
QUERY_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
queryCache - Variable in class org.janusgraph.graphdb.vertices.CacheVertex
 
QueryContainer - Class in org.janusgraph.graphdb.olap
 
QueryContainer(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.olap.QueryContainer
 
QueryContainer.QueryBuilder - Class in org.janusgraph.graphdb.olap
 
queryCount(IndexQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
 
queryCount(IndexQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
queryCount(IndexQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
queryCount(JointIndexQuery.Subquery, BackendTransaction) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
QueryDescription - Interface in org.janusgraph.core
 
QueryDescription.SubQuery - Interface in org.janusgraph.core
Represents one sub-query of this query.
QueryException - Exception in org.janusgraph.core
Exception thrown when a user defined query (e.g.
QueryException(String) - Constructor for exception org.janusgraph.core.QueryException
 
QueryException(String, Throwable) - Constructor for exception org.janusgraph.core.QueryException
 
QueryException(Throwable) - Constructor for exception org.janusgraph.core.QueryException
Constructs an exception with a generic message
QueryExecutor<Q extends ElementQuery,R extends JanusGraphElement,B extends BackendQuery> - Interface in org.janusgraph.graphdb.query
Executes a given query and its subqueries against an underlying data store and transaction.
QueryInfo - Class in org.janusgraph.graphdb.tinkerpop.optimize
 
QueryInfo(List<HasStepFolder.OrderEntry>, int, int) - Constructor for class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
queryOnlyGivenVertex() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
queryOnlyLoaded() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Calling this method will cause this query to only included loaded (i.e.
QueryProcessor<Q extends ElementQuery<R,B>,R extends JanusGraphElement,B extends BackendQuery<B>> - Class in org.janusgraph.graphdb.query
Executes a given ElementQuery against a provided QueryExecutor to produce the result set of elements.
QueryProcessor(Q, QueryExecutor<Q, R, B>) - Constructor for class org.janusgraph.graphdb.query.QueryProcessor
 
QueryProfiler - Interface in org.janusgraph.graphdb.query.profile
 
queryStream(IndexQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
queryStream(RawQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
QueryUtil - Class in org.janusgraph.graphdb.query
Utility methods used in query optimization and processing.
QueryUtil() - Constructor for class org.janusgraph.graphdb.query.QueryUtil
 
QueryUtil.IndexCall<R> - Interface in org.janusgraph.graphdb.query
 

R

randomUniqueIDLimit - Variable in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
RangeInterval<T> - Class in org.janusgraph.util.datastructures
 
RangeInterval() - Constructor for class org.janusgraph.util.datastructures.RangeInterval
 
RangeInterval(T, T) - Constructor for class org.janusgraph.util.datastructures.RangeInterval
 
rawQuery(String, RawQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
RawQuery - Class in org.janusgraph.diskstorage.indexing
 
RawQuery(String, String, Parameter[]) - Constructor for class org.janusgraph.diskstorage.indexing.RawQuery
 
RawQuery(String, String, ImmutableList<IndexQuery.OrderEntry>, Parameter[]) - Constructor for class org.janusgraph.diskstorage.indexing.RawQuery
 
RawQuery.Result<O> - Class in org.janusgraph.diskstorage.indexing
 
reachedLimit() - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
read(ScanBuffer) - Method in interface org.janusgraph.core.attribute.AttributeSerializer
Reads an attribute from the given ReadBuffer.
read(ScanBuffer) - Method in class org.janusgraph.core.attribute.GeoshapeSerializer
 
read(Message) - Method in interface org.janusgraph.diskstorage.log.MessageReader
Processes the given message.
read(byte[], int) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntryList.MetaDataSerializer
 
read(ScanBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
read(Message) - Method in class org.janusgraph.graphdb.database.management.ManagementLogger
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DurationSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.EnumSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.InstantSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ObjectSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.SerializableSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 
ReadArrayBuffer - Class in org.janusgraph.diskstorage.util
Implementation of ReadBuffer against a byte array.
ReadArrayBuffer(byte[]) - Constructor for class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
ReadArrayBuffer(byte[], int) - Constructor for class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
readAsciiString(byte[], int) - Static method in class org.janusgraph.util.encoding.StringEncoding
 
readBackward(ReadBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
readBitb(byte, int) - Static method in class org.janusgraph.util.datastructures.BitMap
 
ReadBuffer - Interface in org.janusgraph.diskstorage
A Buffer that allows sequential reads and static reads.
readBuffer(ScanBuffer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.EnumSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
readByteOrder(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 
readByteOrder(ScanBuffer) - Method in interface org.janusgraph.graphdb.database.serialize.OrderPreservingSerializer
Reads an attribute from the given ReadBuffer assuming it was written in byte order.
readClassAndObject(ScanBuffer) - Method in interface org.janusgraph.graphdb.database.serialize.Serializer
 
readClassAndObject(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
ReadConfiguration - Interface in org.janusgraph.diskstorage.configuration
 
ReadConfigurationBuilder - Class in org.janusgraph.diskstorage.configuration.builder
Builder to build ReadConfiguration instance of global configuration
ReadConfigurationBuilder() - Constructor for class org.janusgraph.diskstorage.configuration.builder.ReadConfigurationBuilder
 
ReadConfigurationConverter - Class in org.janusgraph.diskstorage.configuration.converter
Converter from ReadConfiguration into BaseConfiguration
readEntry(ReadBuffer, Serializer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
readInlineRelationType(ReadBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
ReadMarker - Class in org.janusgraph.diskstorage.log
 
readObject(ScanBuffer, Class<T>) - Method in interface org.janusgraph.graphdb.database.serialize.Serializer
 
readObject(ScanBuffer, Class<T>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
readObjectByteOrder(ScanBuffer, Class<T>) - Method in interface org.janusgraph.graphdb.database.serialize.Serializer
 
readObjectByteOrder(ScanBuffer, Class<T>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
readObjectNotNull(ScanBuffer, Class<T>) - Method in interface org.janusgraph.graphdb.database.serialize.Serializer
 
readObjectNotNull(ScanBuffer, Class<T>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
readOnly() - Method in interface org.janusgraph.core.TransactionBuilder
Makes the transaction read only.
readOnly() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
readOnlyOLAP() - Method in interface org.janusgraph.core.TransactionBuilder
A shortcut for a number of configs that are commonly used by read-only OLAP jobs.
readOnlyOLAP() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
ReadOnlyTransactionException - Exception in org.janusgraph.core
 
ReadOnlyTransactionException(String) - Constructor for exception org.janusgraph.core.ReadOnlyTransactionException
 
ReadOnlyTransactionException(String, Throwable) - Constructor for exception org.janusgraph.core.ReadOnlyTransactionException
 
readPositive(ScanBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
readPositiveBackward(ReadBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
readPositiveWithPrefix(ReadBuffer, int) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
readRelation(Entry, boolean, TypeInspector) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
readRelation(InternalVertex, Iterable<Entry>, StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.transaction.RelationConstructor
 
readRelation(InternalVertex, Entry, StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.transaction.RelationConstructor
 
readRelation(InternalVertex, Entry, EdgeSerializer, TypeInspector, VertexFactory) - Static method in class org.janusgraph.graphdb.transaction.RelationConstructor
 
readRelationCache(Entry, StandardJanusGraphTx) - Static method in class org.janusgraph.graphdb.transaction.RelationConstructor
 
readRelationType(ReadBuffer) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
ReassignableRelation - Interface in org.janusgraph.graphdb.relations
 
RecordIterator<T> - Interface in org.janusgraph.diskstorage.util
Iterator over records in the storage backend.
reduceMap - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraMapEmitter
 
reduceQueue - Variable in class org.janusgraph.graphdb.olap.computer.FulgoraReduceEmitter
 
ReentrantTransactionLock - Class in org.janusgraph.graphdb.transaction.lock
 
ReentrantTransactionLock() - Constructor for class org.janusgraph.graphdb.transaction.lock.ReentrantTransactionLock
 
ReflectiveConfigOptionLoader - Enum in org.janusgraph.core.util
This class supports iteration over JanusGraph's ConfigNamespaces at runtime.
refresh() - Method in class org.janusgraph.graphdb.vertices.CacheVertex
 
register(String, String, KeyInformation, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
This method registers a new key for the specified index store with the given data type.
register(String, String, KeyInformation) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
register(String, String, KeyInformation, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
register(MixedIndexType, PropertyKey, BackendTransaction) - Static method in class org.janusgraph.graphdb.database.IndexSerializer
 
registerClass(int, Class<T>, AttributeSerializer<T>) - Method in interface org.janusgraph.graphdb.database.serialize.AttributeHandler
 
registerClass(int, Class<V>, AttributeSerializer<V>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
registerClassInternal(int, Class<? extends V>, AttributeSerializer<V>) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
REGISTERED_LOG_MANAGERS - Static variable in class org.janusgraph.diskstorage.Backend
 
RegisteredAttributeClass<T> - Class in org.janusgraph.graphdb.configuration
Helper class for registering data types with JanusGraph
RegisteredAttributeClass(int, Class<T>, AttributeSerializer<T>) - Constructor for class org.janusgraph.graphdb.configuration.RegisteredAttributeClass
 
RegisteredAttributeClassesConverter - Class in org.janusgraph.graphdb.configuration.converter
Converter which converts Configuration into a List of RegisteredAttributeClass
registerFutureVertexForPrefetching(Vertex) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
registerFutureVertexForPrefetching(Vertex) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
registerFutureVertexForPrefetching(Vertex) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.MultiQueriable
Registers a vertex which will pass this step at some point in the future.
registerReader(ReadMarker, MessageReader...) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
################################### Message Reading ###################################
registerReader(ReadMarker, MessageReader...) - Method in interface org.janusgraph.diskstorage.log.Log
 
registerReaders(ReadMarker, Iterable<MessageReader>) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
registerReaders(ReadMarker, Iterable<MessageReader>) - Method in interface org.janusgraph.diskstorage.log.Log
Registers the given readers with this log.
REGISTRATION_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
REGISTRATION_TIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
reindexElement(JanusGraphElement, MixedIndexType, Map<String, Map<String, List<IndexEntry>>>) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
reindexElement(JanusGraphElement, CompositeIndexType) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
RELATION_INDEX_SEPARATOR - Static variable in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
RelationCache - Class in org.janusgraph.graphdb.relations
Immutable map from long key ids to objects.
RelationCache(Direction, long, long, Object, LongObjectHashMap<Object>) - Constructor for class org.janusgraph.graphdb.relations.RelationCache
 
RelationCache(Direction, long, long, Object) - Constructor for class org.janusgraph.graphdb.relations.RelationCache
 
RelationCategory - Enum in org.janusgraph.graphdb.internal
 
RelationComparator - Class in org.janusgraph.graphdb.relations
A Comparator for JanusGraphRelation that uses a defined order to compare the relations with or otherwise uses the natural order of relations.
RelationComparator(InternalVertex) - Constructor for class org.janusgraph.graphdb.relations.RelationComparator
 
RelationComparator(InternalVertex, OrderList) - Constructor for class org.janusgraph.graphdb.relations.RelationComparator
 
RelationConstructor() - Constructor for class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
RelationConstructor - Class in org.janusgraph.graphdb.transaction
 
RelationConstructor() - Constructor for class org.janusgraph.graphdb.transaction.RelationConstructor
 
relationEntry - Variable in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Modification
 
RelationFactory - Interface in org.janusgraph.graphdb.database
 
relationId - Variable in class org.janusgraph.graphdb.relations.RelationCache
 
RelationIdentifierUtils - Class in org.janusgraph.graphdb.relations
 
RelationIdentifierUtils() - Constructor for class org.janusgraph.graphdb.relations.RelationIdentifierUtils
 
RelationIndexStatusReport - Class in org.janusgraph.graphdb.database.management
 
RelationIndexStatusReport(boolean, String, String, SchemaStatus, List<SchemaStatus>, Duration) - Constructor for class org.janusgraph.graphdb.database.management.RelationIndexStatusReport
 
RelationIndexStatusWatcher - Class in org.janusgraph.graphdb.database.management
 
RelationIndexStatusWatcher(JanusGraph, String, String) - Constructor for class org.janusgraph.graphdb.database.management.RelationIndexStatusWatcher
 
RelationQueryCache - Class in org.janusgraph.graphdb.database
 
RelationQueryCache(EdgeSerializer) - Constructor for class org.janusgraph.graphdb.database.RelationQueryCache
 
RelationQueryCache(EdgeSerializer, int) - Constructor for class org.janusgraph.graphdb.database.RelationQueryCache
 
RelationReader - Interface in org.janusgraph.graphdb.database
 
relations() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Returns an iterable over all incident relations that match this query for each vertex
relations() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Returns an iterable over all incident relations that match this query
relations() - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
relations() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
relations() - Method in class org.janusgraph.graphdb.query.vertex.SimpleVertexQueryProcessor
Converts the entries from this query result into actual JanusGraphRelation.
relations() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
RelationType - Interface in org.janusgraph.core
RelationType defines the schema for JanusGraphRelation.
RelationTypeCondition<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
 
RelationTypeCondition(RelationType) - Constructor for class org.janusgraph.graphdb.query.condition.RelationTypeCondition
 
RelationTypeDefinition - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
RelationTypeDefinition(String, long, Multiplicity) - Constructor for class org.janusgraph.graphdb.schema.RelationTypeDefinition
Deprecated.
 
RelationTypeIndex - Interface in org.janusgraph.core.schema
A RelationTypeIndex is an index installed on a RelationType to speed up vertex-centric indexes for that type.
RelationTypeIndexWrapper - Class in org.janusgraph.graphdb.database.management
 
RelationTypeIndexWrapper(InternalRelationType) - Constructor for class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
relationTypeLength(long) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
RelationTypeMaker - Interface in org.janusgraph.core.schema
RelationTypeMaker is a factory for RelationTypes.
RelationTypeParse(long, IDHandler.DirectionID) - Constructor for class org.janusgraph.graphdb.database.idhandling.IDHandler.RelationTypeParse
 
RelationTypeVertex - Class in org.janusgraph.graphdb.types.vertices
 
RelationTypeVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
release(StoreTransaction, KeyColumn) - Method in class org.janusgraph.diskstorage.locking.LockerState
 
Removable - Interface in org.janusgraph.util.datastructures
Interface to decorate elements that can be removed
RemovableRelationIterable<O extends JanusGraphRelation> - Class in org.janusgraph.graphdb.vertices
Deprecated.
RemovableRelationIterable(Iterable<InternalRelation>) - Constructor for class org.janusgraph.graphdb.vertices.RemovableRelationIterable
Deprecated.
 
RemovableRelationIterator<O extends JanusGraphRelation> - Class in org.janusgraph.graphdb.vertices
Deprecated.
RemovableRelationIterator(Iterator<InternalRelation>) - Constructor for class org.janusgraph.graphdb.vertices.RemovableRelationIterator
Deprecated.
 
remove() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
remove() - Method in interface org.janusgraph.core.JanusGraphElement
Deletes this entity and any incident edges or properties from the graph.
remove(String) - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
remove(String) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
remove(ConfigOption<O>, String...) - Method in class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
remove(String) - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
remove(String) - Method in interface org.janusgraph.diskstorage.configuration.WriteConfiguration
 
remove() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
 
remove() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedSlicesIterator
 
remove() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
remove() - Method in class org.janusgraph.graphdb.query.LimitAdjustingIterator
 
remove() - Method in class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
remove() - Method in class org.janusgraph.graphdb.query.ResultSetIterator
 
remove() - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
remove() - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
remove() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
remove() - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
remove() - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
remove(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
remove(InternalRelation) - Method in interface org.janusgraph.graphdb.transaction.addedrelations.AddedRelationsContainer
 
remove(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
remove(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.EmptyAddedRelations
 
remove(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
remove(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
 
remove(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.EmptyIndexCache
 
remove(JanusGraphVertexProperty) - Method in interface org.janusgraph.graphdb.transaction.indexcache.IndexCache
 
remove(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.SimpleIndexCache
 
remove() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
remove() - Method in class org.janusgraph.graphdb.util.AllEdgesIterator
Deprecated.
Removing edges is not supported!
remove(Long) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
remove() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
remove() - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
remove() - Method in class org.janusgraph.graphdb.vertices.RemovableRelationIterator
Deprecated.
 
remove() - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
remove() - Method in interface org.janusgraph.util.datastructures.Removable
 
remove(String) - Method in enum org.janusgraph.util.stats.MetricManager
 
removeAllReporters() - Method in enum org.janusgraph.util.stats.MetricManager
Remove all JanusGraph Metrics reporters previously configured through the add* methods on this class.
removeConfiguration(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Remove Configuration according to graphName
removeConfiguration(String) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Remove Configuration according to graphName
removeConsoleReporter() - Method in enum org.janusgraph.util.stats.MetricManager
Stop a ConsoleReporter previously created by a call to MetricManager.addConsoleReporter(Duration) and release it for GC.
removeCsvReporter() - Method in enum org.janusgraph.util.stats.MetricManager
Stop a CsvReporter previously created by a call to MetricManager.addCsvReporter(Duration, String) and release it for GC.
Removed - Static variable in class org.janusgraph.graphdb.internal.ElementLifeCycle
The entity has been deleted but not yet erased from the database.
REMOVED_RELATION_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
REMOVED_VERTEX_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
removedException(JanusGraphElement) - Static method in exception org.janusgraph.core.InvalidElementException
 
removeElement(Object, MixedIndexType, Map<String, Map<String, List<IndexEntry>>>) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
removeGraph(String) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
removeGraphiteReporter() - Method in enum org.janusgraph.util.stats.MetricManager
Stop a GraphiteReporter previously created by a call to MetricManager.addGraphiteReporter(String, int, String, Duration) and release it for GC.
removeJmxReporter() - Method in enum org.janusgraph.util.stats.MetricManager
Stop a JmxReporter previously created by a call to MetricManager.addJmxReporter(String, String) and release it for GC.
removeLogProcessor(String) - Method in interface org.janusgraph.core.log.LogProcessorFramework
Removes the log processor for the given identifier and closes the associated log.
removeLogProcessor(String) - Method in class org.janusgraph.graphdb.log.StandardLogProcessorFramework
 
removePadding(long) - Method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
 
removePropertyDirect(PropertyKey) - Method in interface org.janusgraph.graphdb.internal.InternalRelation
 
removePropertyDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
removePropertyDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
removePropertyDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
removePropertyDirect(PropertyKey) - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
removeRelation(InternalRelation) - Method in interface org.janusgraph.graphdb.internal.InternalVertex
Deleted relation e from the adjacency list of this vertex and updates the state of the vertex to reflect the modification.
removeRelation(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
removeRelation(InternalRelation) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
removeRelation(InternalRelation) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
removeRelation(InternalRelation) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
removeSlf4jReporter() - Method in enum org.janusgraph.util.stats.MetricManager
Stop a Slf4jReporter previously created by a call to MetricManager.addSlf4jReporter(Duration, String) and release it for GC.
removeTemplateConfiguration() - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Remove template configuration
removeTemplateConfiguration() - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Remove template configuration
removeTraversalSource(String) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
REPLACE_INSTANCE_IF_EXISTS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
replaceIllegalChars(String) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
REPLACEMENT_CHAR - Static variable in interface org.janusgraph.diskstorage.indexing.IndexProvider
 
requireRestart() - Method in class org.janusgraph.graphdb.tinkerpop.plugin.JanusGraphGremlinPlugin
 
reset() - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
reset() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphEdgeVertexStep
 
reset() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMultiQueryStep
 
resetCache() - Method in class org.janusgraph.graphdb.types.indextype.CompositeIndexTypeWrapper
 
resetCache() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
resetCache() - Method in class org.janusgraph.graphdb.types.indextype.MixedIndexTypeWrapper
 
resetCache() - Method in interface org.janusgraph.graphdb.types.IndexType
Resets the internal caches used to speed up lookups on this index.
resetCache() - Method in interface org.janusgraph.graphdb.types.SchemaSource
Resets the internal caches used to speed up lookups on this schema source.
resetCache() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
Resets the internal caches used to speed up lookups on this index type.
resetCache() - Method in class org.janusgraph.graphdb.types.vertices.RelationTypeVertex
 
resetDelete() - Method in class org.janusgraph.diskstorage.indexing.IndexMutation
 
resetInstance() - Static method in class org.janusgraph.graphdb.management.JanusGraphManager
 
ResourceUnavailableException - Exception in org.janusgraph.diskstorage
This exception is thrown if a resource is being accessed that is unavailable.
ResourceUnavailableException(String) - Constructor for exception org.janusgraph.diskstorage.ResourceUnavailableException
 
ResourceUnavailableException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.ResourceUnavailableException
 
ResourceUnavailableException(Throwable) - Constructor for exception org.janusgraph.diskstorage.ResourceUnavailableException
Constructs an exception with a generic message
restore(Map<String, Map<String, List<IndexEntry>>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Restores the index to the state of the primary data store as given in the documents variable.
restore(Map<String, Map<String, List<IndexEntry>>>) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
restore(Map<String, Map<String, List<IndexEntry>>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
restrictedPartitions(int[]) - Method in interface org.janusgraph.core.TransactionBuilder
Configures this transaction such that queries against partitioned vertices are restricted to the given partitions.
restrictedPartitions(int[]) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
restrictTo(Configuration, String...) - Static method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
restrictTo(String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
restrictTo(String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
 
restrictTo(String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
 
restrictTo(String...) - Method in class org.janusgraph.diskstorage.configuration.MixedConfiguration
 
restrictTo(String...) - Method in interface org.janusgraph.diskstorage.configuration.SystemConfiguration
 
Result(O, double) - Constructor for class org.janusgraph.diskstorage.indexing.RawQuery.Result
 
result(GraphComputer.ResultGraph) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
ResultMergeSortIterator<R> - Class in org.janusgraph.graphdb.query
 
ResultMergeSortIterator(Iterator<R>, Iterator<R>, Comparator<R>, boolean) - Constructor for class org.janusgraph.graphdb.query.ResultMergeSortIterator
 
resultMode(JanusGraphComputer.ResultMode) - Method in interface org.janusgraph.core.JanusGraphComputer
 
ResultSetIterator<R extends JanusGraphElement> - Class in org.janusgraph.graphdb.query
Wraps around a result set iterator to return up to the specified limit number of elements and implement the Iterator.remove() method based on element's remove method.
ResultSetIterator(Iterator<R>, int) - Constructor for class org.janusgraph.graphdb.query.ResultSetIterator
 
retrieve(Object, JanusGraphTransaction) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
retrievePartitionAggregates() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
Retriever<I,O> - Interface in org.janusgraph.util.datastructures
Interface for the Retriever design pattern.
retrieveSchemaByName(String) - Method in interface org.janusgraph.graphdb.database.cache.SchemaCache.StoreRetrieval
 
retrieveSchemaRelations(long, BaseRelationType, Direction) - Method in interface org.janusgraph.graphdb.database.cache.SchemaCache.StoreRetrieval
 
retrieveSliceQuery() - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.AccessCheck
 
reuseIterator() - Method in class org.janusgraph.diskstorage.EntryList.EmptyList
 
reuseIterator() - Method in interface org.janusgraph.diskstorage.EntryList
Returns the same iterator as List.iterator() with the only difference that it reuses Entry objects when calling Iterator.next().
reuseIterator() - Method in class org.janusgraph.diskstorage.util.EntryArrayList
 
reuseIterator() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
rid - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
rid(StaticBuffer) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
rid - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
Uniquely identifies a process within a domain (or across all domains, though only intra-domain uniqueness is required)
rollback() - Method in interface org.janusgraph.core.JanusGraphTransaction
Aborts and closes the transaction.
rollback() - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Closes this management transaction and discards all changes.
rollback() - Method in class org.janusgraph.diskstorage.BackendTransaction
Rolls back all transactions and makes sure that this does not get cut short by exceptions.
rollback() - Method in interface org.janusgraph.diskstorage.BaseTransaction
Aborts (or rolls back) the transaction.
rollback() - Method in class org.janusgraph.diskstorage.common.AbstractStoreTransaction
 
rollback() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
rollback() - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
rollback() - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.CacheTransaction
 
rollback() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
rollback() - Method in class org.janusgraph.diskstorage.util.DefaultTransaction
 
rollback() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
rollback(Set<String>) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
rollback() - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
rollbackAll() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
 
rollbackQuietly(JanusGraphTransaction) - Static method in class org.janusgraph.util.system.TXUtils
 
ROOT_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
run() - Method in class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
run() - Method in class org.janusgraph.diskstorage.log.util.ProcessMessageJob
 
run() - Method in interface org.janusgraph.diskstorage.util.StorageRunnable
 
run(int, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
run() - Method in class org.janusgraph.util.system.BackgroundThread
 

S

sanitizeAndLaunder(Object) - Static method in class org.janusgraph.util.system.LoggerUtil
Encode newline characters and launder string to mitigate log forging vulnerability.
ScanBuffer - Interface in org.janusgraph.diskstorage
A Buffer that allows sequential reads.
ScanJob - Interface in org.janusgraph.diskstorage.keycolumnvalue.scan
A global computation over
ScanMetrics - Interface in org.janusgraph.diskstorage.keycolumnvalue.scan
Counters associated with a ScanJob.
ScanMetrics.Metric - Enum in org.janusgraph.diskstorage.keycolumnvalue.scan
An enum of standard counters.
scanTxConfig(Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
SCHEMA_CONSTRAINTS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SCHEMA_MAKER_LOGGING - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SCHEMA_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SCHEMA_PARTITION - Static variable in class org.janusgraph.graphdb.idmanagement.IDManager
Id of the partition that schema elements are assigned to
SchemaAction - Enum in org.janusgraph.core.schema
SchemaCache - Interface in org.janusgraph.graphdb.database.cache
This interface defines the methods that a SchemaCache must implement.
SchemaCache.StoreRetrieval - Interface in org.janusgraph.graphdb.database.cache
 
SchemaCategory - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
SchemaContainer - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
SchemaContainer(JanusGraph) - Constructor for class org.janusgraph.graphdb.schema.SchemaContainer
Deprecated.
 
SchemaDefinitionDesc - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
SchemaDefinitionEdge - Static variable in class org.janusgraph.graphdb.types.system.BaseLabel
 
SchemaDefinitionProperty - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
SchemaElementDefinition - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
SchemaElementDefinition(String, long) - Constructor for class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
SchemaInspector - Interface in org.janusgraph.core.schema
 
SchemaManager - Interface in org.janusgraph.core.schema
 
SchemaName - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
SchemaProvider - Interface in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
SchemaSource - Interface in org.janusgraph.graphdb.types
 
SchemaSource.Entry - Class in org.janusgraph.graphdb.types
 
SchemaStatus - Enum in org.janusgraph.core.schema
Designates the status of a Index in a graph.
SchemaUpdateTime - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
SchemaViolationException - Exception in org.janusgraph.core
Thrown to indicate that schema is violated.
SchemaViolationException(String) - Constructor for exception org.janusgraph.core.SchemaViolationException
 
SchemaViolationException(String, Object...) - Constructor for exception org.janusgraph.core.SchemaViolationException
 
SelectedIndexQuery(JointIndexQuery, boolean) - Constructor for class org.janusgraph.graphdb.query.index.IndexSelectionStrategy.SelectedIndexQuery
 
selectIndices(ElementCategory, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.AbstractIndexSelectionStrategy
 
selectIndices(Set<IndexType>, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.ApproximateIndexSelectionStrategy
Iterate over all potential indexes and compute a score based on how many clauses this index covers.
selectIndices(Set<IndexType>, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.BruteForceIndexSelectionStrategy
Determine the best jointIndexQuery by enumerating all possibilities with exponential time complexity.
selectIndices(Set<IndexType>, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in interface org.janusgraph.graphdb.query.index.IndexSelectionStrategy
 
selectIndices(ElementCategory, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in interface org.janusgraph.graphdb.query.index.IndexSelectionStrategy
 
selectIndices(Set<IndexType>, MultiCondition<JanusGraphElement>, Set<Condition>, OrderList, IndexSerializer) - Method in class org.janusgraph.graphdb.query.index.ThresholdBasedIndexSelectionStrategy
 
self() - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
Concrete subclasses should just "return this;".
self() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
self() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
self() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusWatcher
 
self() - Method in class org.janusgraph.graphdb.database.management.RelationIndexStatusWatcher
 
sendCacheEviction(Set<JanusGraphSchemaVertex>, boolean, List<Callable<Boolean>>, Set<String>) - Method in class org.janusgraph.graphdb.database.management.ManagementLogger
 
SEPARATOR - Static variable in class org.janusgraph.diskstorage.configuration.ConfigElement
 
SEPARATOR_CHAR - Static variable in class org.janusgraph.graphdb.internal.Token
 
SerializableSerializer<T extends Serializable> - Class in org.janusgraph.graphdb.database.serialize.attribute
Serializes Serializable objects.
SerializableSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.SerializableSerializer
 
serializeModifications(Serializer, LogTxStatus, StandardJanusGraphTx, Collection<InternalRelation>, Collection<InternalRelation>) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
serializePrimary(Serializer, LogTxStatus) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
serializer - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
serializer(ConsistentKeyLockerSerializer) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
serializer - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
This is sort-of Cassandra/HBase specific.
Serializer - Interface in org.janusgraph.graphdb.database.serialize
 
serializer - Variable in class org.janusgraph.graphdb.database.StandardJanusGraph
 
SerializerInjected - Interface in org.janusgraph.graphdb.database.serialize
Marks a AttributeSerializer that requires a Serializer to serialize the internal state.
serializeSecondary(Serializer, LogTxStatus, Map<String, Throwable>, boolean) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
serializeUserLog(Serializer, TransactionLogHeader.Entry, StandardTransactionId) - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
set(String, Object) - Method in class org.janusgraph.core.JanusGraphFactory.Builder
Configures the provided configuration path to the given value.
set(String, Object) - Method in interface org.janusgraph.core.schema.JanusGraphConfiguration
Sets the configuration option identified by the provided path to the given value.
set(String, O) - Method in class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
 
set(String, O, O) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
set(String, O) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
Sets a configuration property for this StoreManager.
set(String, O, O, boolean) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
set(String, O, O) - Method in interface org.janusgraph.diskstorage.configuration.ConcurrentWriteConfiguration
 
set(ConfigOption<O>, O, String...) - Method in class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
set(String, O) - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
set(String, Object) - Method in class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
 
set(String, O) - Method in interface org.janusgraph.diskstorage.configuration.WriteConfiguration
 
set(String, Object) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
set(String, Object) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
set(String, Object) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
setAccessCheck(PreloadedVertex.AccessCheck) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
setAlive(boolean) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
setAll(Map<ConfigElement.PathIdentifier, Object>) - Method in class org.janusgraph.diskstorage.configuration.ModifiableConfiguration
 
setAnnotation(String, Object) - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
setAnnotation(String, Object) - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
setAnnotation(String, Object) - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
setArray(Object, int, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
setBackendTransaction(BackendTransaction) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
setBatchPropertyPrefetching(boolean) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setBitb(byte, int) - Static method in class org.janusgraph.util.datastructures.BitMap
 
setCache(RelationCache) - Method in interface org.janusgraph.diskstorage.Entry
Sets the cached parsed representation of this Entry.
setCache(RelationCache) - Method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
setChecked() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
setCommitTime(Instant) - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
Sets the commit time of this transaction.
setCommitTime(Instant) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig
 
setCommitTime(Instant) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
setConfigurationClass(String) - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
setConsistency(JanusGraphSchemaElement, ConsistencyModifier) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Sets the consistency modifier for the given JanusGraphSchemaElement.
setConsistency(JanusGraphSchemaElement, ConsistencyModifier) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
Sets the consistency level for those schema elements that support it (types and internal indexes)
setCorePoolSize(Integer) - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
setDefaultStringMapping(Mapping) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
setDirection(Direction) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
setElementIdentifier(String) - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Sets the element identifier string that is used by this query builder as the token to identifier key references in the query string.
setElementIdentifier(String) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
setEnabled(boolean) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
setEnd(T, boolean) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
setEndInclusive(boolean) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
setFinishJob(Consumer<ScanMetrics>) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setFrozen() - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
setGraph(JanusGraph) - Method in class org.janusgraph.graphdb.olap.GraphProvider
 
setGraphConfiguration(Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setHighLimit(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
setId(long) - Method in class org.janusgraph.graphdb.internal.AbstractElement
 
setId(long) - Method in interface org.janusgraph.graphdb.internal.InternalElement
 
setId(long) - Method in class org.janusgraph.graphdb.types.system.BaseRelationType
 
setId(long) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
setId(long) - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
setIDBlockSizer(IDBlockSizer) - Method in interface org.janusgraph.diskstorage.IDAuthority
Sets the IDBlockSizer to be used by this IDAuthority.
setIDBlockSizer(IDBlockSizer) - Method in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
setIndex(String) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
setIteration(int) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
setJob(ScanJob) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setJobConfiguration(Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setJobId(Object) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setKeepAliveTime(Long) - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
setLimit(int) - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
setLimit(int) - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
setLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
setLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
setLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
setLimit(int) - Method in class org.janusgraph.graphdb.query.BaseQuery
Sets the limit of the query if it wasn't specified in the constructor
setLimit(int, int) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setLoadedProperties(long, EntryList) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
setLoadedProperties(EntryList) - Method in class org.janusgraph.graphdb.olap.computer.PartitionVertexAggregate
 
setLocalLimit(TraversalParent, List<HasContainer>, int, int) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
setLocalLimit(TraversalParent, List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
setLocalLimit(TraversalParent, List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
setLocalLimit(TraversalParent, List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setLocalPartitionBounds(List<PartitionIDRange>) - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
If JanusGraph is embedded, this method is used to indicate to the placement strategy which part of the partition id space is hosted locally so that vertex and edge placements can be made accordingly (i.e.
setLocalPartitionBounds(List<PartitionIDRange>) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
setLowLimit(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
 
setMaxOperationWaitTime(Duration) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
 
setMaxPoolSize(Integer) - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
setMessage(M, MessageScope, Map<MessageScope, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
setMetaData(EntryMetaData, Object) - Method in class org.janusgraph.diskstorage.indexing.IndexEntry
 
setMetaData(EntryMetaData, Object) - Method in interface org.janusgraph.diskstorage.MetaAnnotatable
 
setMetaData(EntryMetaData, Object) - Method in class org.janusgraph.diskstorage.util.StaticArrayEntry
 
setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphEdgeVertexStep
 
setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setNumProcessingThreads(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setOffset(int) - Method in class org.janusgraph.diskstorage.indexing.RawQuery
 
setOtherVertexID(long) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
setPartitionID(int) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
setPartitionKey(String) - Method in class org.janusgraph.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
setPoint(T) - Method in class org.janusgraph.util.datastructures.PointInterval
 
setPreferredClassLoaders(List<ClassLoader>) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
setPreloadedData(boolean) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
setPreviousID(long) - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
setPreviousID(long) - Method in interface org.janusgraph.graphdb.relations.StandardRelation
 
setPreviousID(long) - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
setProcessorIdentifier(String) - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Sets the identifier of this processor.
setProperty(long, String, V) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
 
setProperty(String, V, Map<String, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.PartitionVertexAggregate
 
setProperty(String, V, Map<String, Integer>) - Method in class org.janusgraph.graphdb.olap.computer.VertexState
 
setPropertyDirect(PropertyKey, Object) - Method in interface org.janusgraph.graphdb.internal.InternalRelation
 
setPropertyDirect(PropertyKey, Object) - Method in class org.janusgraph.graphdb.relations.CacheEdge
 
setPropertyDirect(PropertyKey, Object) - Method in class org.janusgraph.graphdb.relations.CacheVertexProperty
 
setPropertyDirect(PropertyKey, Object) - Method in class org.janusgraph.graphdb.relations.StandardEdge
 
setPropertyDirect(PropertyKey, Object) - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
 
setPropertyMixing(PreloadedVertex.PropertyMixing) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
 
setQuery(String) - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
setRelationID(long) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
setResultSize(long) - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
setResultSize(long) - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
setResultSize(long) - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
setRetryAttempts(int) - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Sets how often this log processor should attempt to retry executing a contained ChangeProcessor in case of failure.
setRuntime(long) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
setScore(double) - Method in class org.janusgraph.graphdb.query.index.IndexCandidate
 
setSerializer(Serializer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
setSerializer(Serializer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterSerializer
 
setSerializer(Serializer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.SerializableSerializer
 
setSerializer(Serializer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
setSerializer(Serializer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
setSerializer(Serializer) - Method in interface org.janusgraph.graphdb.database.serialize.SerializerInjected
 
setStart(T, boolean) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
setStartInclusive(boolean) - Method in class org.janusgraph.util.datastructures.RangeInterval
 
setStartTime(Instant) - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Sets the time at which this log processor should start processing transaction log entries
setStartTimeNow() - Method in interface org.janusgraph.core.log.LogProcessorBuilder
Indicates that the transaction log processor should process newly added events.
setStatic() - Method in interface org.janusgraph.core.schema.VertexLabelMaker
Makes this vertex label static, which means that vertices of this label cannot be modified outside of the transaction in which they were created.
setStatic() - Method in class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
setStoreName(String) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setThreadFactory(ThreadFactory) - Method in class org.janusgraph.diskstorage.configuration.ExecutorServiceConfiguration
 
setThrowable(Throwable) - Method in class org.janusgraph.util.datastructures.ExceptionWrapper
 
setTimestampProvider(TimestampProvider) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setTTL(JanusGraphSchemaType, Duration) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Sets the time-to-live for the given JanusGraphSchemaType.
setTTL(Integer) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
setTTL(int) - Method in class org.janusgraph.graphdb.database.IndexSerializer.IndexUpdate
 
setTTL(JanusGraphSchemaType, Duration) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
Sets time-to-live for those schema types that support it
setTxVertexCacheSize(int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setType(RelationType) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
SETUP_WAITTIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Time in milliseconds for backend manager to wait for the storage backends to become available when JanusGraph is run in server mode.
setUpsert(boolean) - Method in class org.janusgraph.graphdb.relations.StandardVertexProperty
Mark this property as 'upsert', i.e.
setUseCallerLoader(boolean) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
setUseMultiQuery(boolean) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
setUseMultiQuery(boolean) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
setUseMultiQuery(boolean) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.MultiQueriable
 
setUseThreadContextLoader(boolean) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
 
setValue(TransactionBuilder, Object) - Method in enum org.janusgraph.graphdb.database.log.LogTxMeta
 
setValue(Object) - Method in interface org.janusgraph.graphdb.database.RelationFactory
 
setValue(TypeDefinitionCategory, Object) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
 
setVertexAt(int, InternalVertex) - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
setVertexAt(int, InternalVertex) - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
setVertexAt(int, InternalVertex) - Method in interface org.janusgraph.graphdb.relations.ReassignableRelation
 
setWildcardField(String) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
setWorkBlockSize(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
short2char(short) - Static method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
SHORT_LEN - Static variable in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
ShortArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ShortArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
ShortSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
ShortSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
shutdown() - Method in interface org.janusgraph.core.log.LogProcessorFramework
Closes all log processors, their associated logs, and the backing graph instance
shutdown() - Method in interface org.janusgraph.core.log.TransactionRecovery
Shuts down the transaction recovery process
shutdown() - Method in class org.janusgraph.graphdb.log.StandardLogProcessorFramework
 
shutdown() - Method in class org.janusgraph.graphdb.log.StandardTransactionLogProcessor
 
shutdownConfigurationManagementGraph() - Static method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
 
shutdownJanusGraphManager() - Static method in class org.janusgraph.graphdb.management.JanusGraphManager
 
signature(PropertyKey...) - Method in interface org.janusgraph.core.schema.EdgeLabelMaker
 
signature(PropertyKey...) - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
 
signature(PropertyKey...) - Method in interface org.janusgraph.core.schema.RelationTypeMaker
Configures the signature of this relation type.
signature(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
signature(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
signature(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
SimpleAddedRelations - Class in org.janusgraph.graphdb.transaction.addedrelations
 
SimpleAddedRelations() - Constructor for class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
 
SimpleBulkPlacementStrategy - Class in org.janusgraph.graphdb.database.idassigner.placement
A id placement strategy that assigns all vertices created in a transaction to the same partition id.
SimpleBulkPlacementStrategy(int) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
SimpleBulkPlacementStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
SimpleIndexCache - Class in org.janusgraph.graphdb.transaction.indexcache
 
SimpleIndexCache() - Constructor for class org.janusgraph.graphdb.transaction.indexcache.SimpleIndexCache
 
SimpleJanusGraphProperty<V> - Class in org.janusgraph.graphdb.relations
 
SimpleJanusGraphProperty(InternalRelation, PropertyKey, V) - Constructor for class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
SimplePartitionAssignment - Class in org.janusgraph.graphdb.database.idassigner.placement
Simple implementation of PartitionAssignment.
SimplePartitionAssignment() - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
SimplePartitionAssignment(int) - Constructor for class org.janusgraph.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
SimpleQueryProfiler - Class in org.janusgraph.graphdb.query.profile
 
SimpleQueryProfiler() - Constructor for class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
SimpleQueryProfiler(String) - Constructor for class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
SimpleVertexQueryProcessor - Class in org.janusgraph.graphdb.query.vertex
This is an optimization of specifically for VertexCentricQuery that addresses the special but common case that the query is simple (i.e.
SimpleVertexQueryProcessor(VertexCentricQuery, StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.query.vertex.SimpleVertexQueryProcessor
 
simplifyAnd(And<E>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
 
singleton(long) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
 
size() - Method in interface org.janusgraph.core.VertexList
Returns the number of vertices in this list.
size() - Method in class org.janusgraph.diskstorage.EntryList.EmptyList
 
size() - Method in class org.janusgraph.diskstorage.StoreMetaData.Container
 
size() - Method in class org.janusgraph.diskstorage.util.StaticArrayEntryList
 
size() - Method in class org.janusgraph.graphdb.internal.OrderList
 
size() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
size() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
size() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
size() - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
size() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
Deprecated.
 
size() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Returns the number of elements currently stored in the PriorityQueue.
size(Iterable) - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
size() - Method in class org.janusgraph.util.datastructures.PowerSet
 
sizeLargerOrEqualThan(Iterable, int) - Static method in class org.janusgraph.util.datastructures.IterablesUtil
 
SKIPPED_GHOST_LIMIT_COUNT - Static variable in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
sleepAfterWrite(DistributedStoreManager.MaskedTimestamp) - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
sleepFor(Duration) - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Sleep for the given duration of time.
sleepFor(Duration) - Method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
 
sleepPast(Instant) - Method in interface org.janusgraph.diskstorage.util.time.TimestampProvider
Block until the current time as returned by TimestampProvider.getTime() is greater than the given timepoint.
sleepPast(Instant) - Method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
 
SliceQuery - Class in org.janusgraph.diskstorage.keycolumnvalue
Queries for a slice of data identified by a start point (inclusive) and end point (exclusive).
SliceQuery(StaticBuffer, StaticBuffer, String) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
SliceQuery(StaticBuffer, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
SliceQuery(SliceQuery) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
sort() - Method in interface org.janusgraph.core.VertexList
Sorts this list according to vertex ids in increasing order.
sort() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
sort() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
sortableDoubleBits(long) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts IEEE 754 representation of a double to sortable order (or back to the original)
sortableFloatBits(int) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts IEEE 754 representation of a float to sortable order (or back to the original)
sortableIntToFloat(int) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts a sortable int back to a float.
sortableLongToDouble(long) - Static method in class org.janusgraph.util.encoding.NumericUtils
Converts a sortable long back to a double.
sortKey(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
sortKey(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
sortKey(PropertyKey...) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
Configures the composite sort key for this label.
sortOrder(Order) - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
sortOrder(Order) - Method in class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
sortOrder(Order) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
Defines in which order to sort the relations for efficient retrieval, i.e.
splitAndP(List<HasContainer>, HasContainer) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
splitSeparatedName(String) - Static method in class org.janusgraph.graphdb.internal.Token
 
StandardBaseTransactionConfig - Class in org.janusgraph.diskstorage.util
 
StandardBaseTransactionConfig.Builder - Class in org.janusgraph.diskstorage.util
 
standardCleaner() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
StandardEdge - Class in org.janusgraph.graphdb.relations
 
StandardEdge(long, EdgeLabel, InternalVertex, InternalVertex, byte) - Constructor for class org.janusgraph.graphdb.relations.StandardEdge
 
StandardEdgeLabelMaker - Class in org.janusgraph.graphdb.types
 
StandardEdgeLabelMaker(StandardJanusGraphTx, String, IndexSerializer, AttributeHandler) - Constructor for class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
StandardIDPool - Class in org.janusgraph.graphdb.database.idassigner
 
StandardIDPool(IDAuthority, int, int, long, Duration, double) - Constructor for class org.janusgraph.graphdb.database.idassigner.StandardIDPool
 
StandardIndexProvider - Enum in org.janusgraph.diskstorage
This enum is only intended for use by JanusGraph internals.
StandardJanusGraph - Class in org.janusgraph.graphdb.database
 
StandardJanusGraph(GraphDatabaseConfiguration) - Constructor for class org.janusgraph.graphdb.database.StandardJanusGraph
 
StandardJanusGraphTx - Class in org.janusgraph.graphdb.transaction
 
StandardJanusGraphTx(StandardJanusGraph, TransactionConfiguration) - Constructor for class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
StandardKeyInformation - Class in org.janusgraph.diskstorage.indexing
 
StandardKeyInformation(Class<?>, Cardinality, Parameter...) - Constructor for class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
StandardKeyInformation(PropertyKey, Parameter...) - Constructor for class org.janusgraph.diskstorage.indexing.StandardKeyInformation
 
StandardLockCleanerRunnable - Class in org.janusgraph.diskstorage.locking.consistentkey
Attempt to delete locks before a configurable timestamp cutoff using the provided store, transaction, and serializer.
StandardLockCleanerRunnable(KeyColumnValueStore, KeyColumn, StoreTransaction, ConsistentKeyLockerSerializer, Instant, TimestampProvider) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
StandardLockCleanerService - Class in org.janusgraph.diskstorage.locking.consistentkey
Encapsulates an ExecutorService that creates and runs StandardLockCleanerRunnable instances.
StandardLockCleanerService(KeyColumnValueStore, ConsistentKeyLockerSerializer, ExecutorService, Duration, TimestampProvider) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerService
 
StandardLockCleanerService(KeyColumnValueStore, ConsistentKeyLockerSerializer, TimestampProvider) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.StandardLockCleanerService
 
StandardLogProcessorFramework - Class in org.janusgraph.graphdb.log
 
StandardLogProcessorFramework(StandardJanusGraph) - Constructor for class org.janusgraph.graphdb.log.StandardLogProcessorFramework
 
StandardPropertyKeyMaker - Class in org.janusgraph.graphdb.types
 
StandardPropertyKeyMaker(StandardJanusGraphTx, String, IndexSerializer, AttributeHandler) - Constructor for class org.janusgraph.graphdb.types.StandardPropertyKeyMaker
 
StandardRelation - Interface in org.janusgraph.graphdb.relations
 
StandardRelationTypeMaker - Class in org.janusgraph.graphdb.types
 
StandardRelationTypeMaker(StandardJanusGraphTx, String, IndexSerializer, AttributeHandler) - Constructor for class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
StandardScanMetrics - Class in org.janusgraph.diskstorage.keycolumnvalue.scan
 
StandardScanMetrics() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
StandardScanner - Class in org.janusgraph.diskstorage.keycolumnvalue.scan
 
StandardScanner(KeyColumnValueStoreManager) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner
 
StandardScanner.Builder - Class in org.janusgraph.diskstorage.keycolumnvalue.scan
 
StandardSchemaCache - Class in org.janusgraph.graphdb.database.cache
 
StandardSchemaCache(SchemaCache.StoreRetrieval) - Constructor for class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
StandardSchemaCache(int, SchemaCache.StoreRetrieval) - Constructor for class org.janusgraph.graphdb.database.cache.StandardSchemaCache
 
StandardSerializer - Class in org.janusgraph.graphdb.database.serialize
 
StandardSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
StandardStoreFeatures - Class in org.janusgraph.diskstorage.keycolumnvalue
Immutable, StandardStoreFeatures.Builder-customizable implementation of StoreFeatures.
StandardStoreFeatures.Builder - Class in org.janusgraph.diskstorage.keycolumnvalue
The only way to instantiate StandardStoreFeatures.
StandardStoreManager - Enum in org.janusgraph.diskstorage
This enum is only intended for use by JanusGraph internals.
StandardTransactionBuilder - Class in org.janusgraph.graphdb.transaction
Used to configure a JanusGraphTransaction.
StandardTransactionBuilder(GraphDatabaseConfiguration, StandardJanusGraph) - Constructor for class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
Constructs a new JanusGraphTransaction configuration with default configuration parameters.
StandardTransactionBuilder(GraphDatabaseConfiguration, StandardJanusGraph, Configuration) - Constructor for class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
StandardTransactionId - Class in org.janusgraph.graphdb.log
 
StandardTransactionId(String, long, Instant) - Constructor for class org.janusgraph.graphdb.log.StandardTransactionId
 
StandardTransactionIdSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
StandardTransactionIdSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
StandardTransactionLogProcessor - Class in org.janusgraph.graphdb.log
 
StandardTransactionLogProcessor(StandardJanusGraph, Instant) - Constructor for class org.janusgraph.graphdb.log.StandardTransactionLogProcessor
 
StandardVertex - Class in org.janusgraph.graphdb.vertices
 
StandardVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.vertices.StandardVertex
 
StandardVertexLabelMaker - Class in org.janusgraph.graphdb.types
 
StandardVertexLabelMaker(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.types.StandardVertexLabelMaker
 
StandardVertexProperty - Class in org.janusgraph.graphdb.relations
 
StandardVertexProperty(long, PropertyKey, InternalVertex, Object, byte) - Constructor for class org.janusgraph.graphdb.relations.StandardVertexProperty
 
start() - Method in interface org.janusgraph.core.TransactionBuilder
Starts and returns the transaction build by this builder
start() - Method in class org.janusgraph.diskstorage.util.time.Timer
 
start() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
startInclusive() - Method in interface org.janusgraph.util.datastructures.Interval
 
startInclusive() - Method in class org.janusgraph.util.datastructures.PointInterval
 
startInclusive() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
startProfile(QueryProfiler, JointIndexQuery.Subquery) - Static method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
startTimer() - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
startTimer() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
startTimer() - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
startTransaction(StandardJanusGraph) - Method in class org.janusgraph.graphdb.olap.AbstractScanJob
 
startTransaction(StandardJanusGraph) - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
startTransaction(StandardJanusGraph) - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
startTransactionRecovery(JanusGraph, Instant) - Static method in class org.janusgraph.core.JanusGraphFactory
Returns a TransactionRecovery process for recovering partially failed transactions.
state - Variable in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Modification
 
STATIC_FACTORY - Static variable in interface org.janusgraph.diskstorage.StaticBuffer
 
StaticArrayBuffer - Class in org.janusgraph.diskstorage.util
Implementation of StaticBuffer against byte array.
StaticArrayBuffer(byte[], int, int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(byte[]) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(byte[], int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(StaticBuffer) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(StaticArrayBuffer) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
STATICARRAYBUFFER_RAW_SIZE - Static variable in class org.janusgraph.util.datastructures.ByteSize
 
StaticArrayEntry - Class in org.janusgraph.diskstorage.util
 
StaticArrayEntry(byte[], int, int, int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(byte[], int, int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(byte[], int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(StaticBuffer, int) - Constructor for class org.janusgraph.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry.DataHandler<D> - Interface in org.janusgraph.diskstorage.util
 
StaticArrayEntry.GetColVal<E,D> - Interface in org.janusgraph.diskstorage.util
 
StaticArrayEntryList - Class in org.janusgraph.diskstorage.util
 
StaticArrayEntryList.MetaDataSerializer<V> - Interface in org.janusgraph.diskstorage.util
 
StaticBuffer - Interface in org.janusgraph.diskstorage
A Buffer that only allows static access.
StaticBuffer.Factory<T> - Interface in org.janusgraph.diskstorage
 
StaticIDBlockSizer - Class in org.janusgraph.graphdb.database.idassigner
 
StaticIDBlockSizer(long, long) - Constructor for class org.janusgraph.graphdb.database.idassigner.StaticIDBlockSizer
 
Stats() - Constructor for class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
Deprecated.
 
status(SchemaStatus...) - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
Set the target index statuses.
status(SchemaStatus) - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
Status(int, int) - Constructor for class org.janusgraph.util.system.ConfigurationLint.Status
 
statuses - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
stop() - Method in class org.janusgraph.diskstorage.util.time.Timer
 
stopTimer() - Method in interface org.janusgraph.graphdb.query.profile.QueryProfiler
 
stopTimer() - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
 
stopTimer() - Method in class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
STORAGE_BACKEND - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Define the storage backed to use for persistence
STORAGE_BATCH - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Enables batch loading which improves write performance but assumes that only one thread is interacting with the graph
STORAGE_CONF_FILE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Path to a configuration file for those storage backends that require/support a separate config file
STORAGE_DIRECTORY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Storage directory for those storage backends that require local storage
STORAGE_HOSTS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORAGE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORAGE_PORT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configuration key for the port on which to connect to remote storage backend servers.
STORAGE_READ_WAITTIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORAGE_READONLY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Specifies whether this database is read-only, i.e.
STORAGE_ROOT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Storage root directory for those storage backends that require local storage
STORAGE_TRANSACTIONAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Enables transactions on storage backends that support them
STORAGE_VERSION - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
Storage format version currently used by JanusGraph, version 1 is for JanusGraph 0.2.x and below
STORAGE_WRITE_WAITTIME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
StorageCallable<T> - Interface in org.janusgraph.diskstorage.util
Like Callable, except the exception type is narrowed from Exception to BackendException.
storageConfig - Variable in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
StorageRunnable - Interface in org.janusgraph.diskstorage.util
 
store - Variable in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
STORE_META_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_TIMESTAMPS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_TTL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_VISIBILITY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
StoreFeatures - Interface in org.janusgraph.diskstorage.keycolumnvalue
Describes features supported by a storage backend.
StoreManager - Interface in org.janusgraph.diskstorage.keycolumnvalue
Generic interface to a backend storage engine.
StoreMetaData<T> - Interface in org.janusgraph.diskstorage
Store-specific (Column-family-specific) options passed between JanusGraph core and its underlying KeyColumnValueStore implementation.
StoreMetaData.Container - Class in org.janusgraph.diskstorage
 
StoreMetaData.TTLImpl - Enum in org.janusgraph.diskstorage
Time-to-live for all data written to the store.
StoreTransaction - Interface in org.janusgraph.diskstorage.keycolumnvalue
A transaction handle uniquely identifies a transaction on the storage backend.
storeTTL(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
StreamIterable<E> - Class in org.janusgraph.graphdb.util
 
StreamIterable(Stream<E>) - Constructor for class org.janusgraph.graphdb.util.StreamIterable
 
StringArraySerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
StringArraySerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
StringEncoding - Class in org.janusgraph.util.encoding
 
StringEncoding() - Constructor for class org.janusgraph.util.encoding.StringEncoding
 
StringSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
Serializes Strings by trying to find the most efficient serialization format: 1) ASCII encoding (one byte per char) 2) Full UTF encoding (for non-ASCII strings) 3) Using compression algorithms for long strings
StringSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
stripEntireRelationTypePadding(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
stripRelationTypePadding(long) - Static method in class org.janusgraph.graphdb.idmanagement.IDManager
 
subList(int, int) - Method in interface org.janusgraph.core.VertexList
Returns a sub list of this list of vertices from the given position with the given number of vertices.
subList(int, int) - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
subList(int, int) - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
submit() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
submit(Runnable) - Method in class org.janusgraph.graphdb.util.WorkerPool
 
SubqueryCache - Interface in org.janusgraph.graphdb.transaction.subquerycache
Cache for JointIndexQuery.Subquery results.
SubqueryIterator - Class in org.janusgraph.graphdb.util
 
SubqueryIterator(JointIndexQuery.Subquery, IndexSerializer, BackendTransaction, SubqueryCache, int, Function<Object, ? extends JanusGraphElement>, List<Object>) - Constructor for class org.janusgraph.graphdb.util.SubqueryIterator
 
subrange(int, boolean) - Method in interface org.janusgraph.diskstorage.ReadBuffer
 
subrange(int, int) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
subrange(int, int, boolean) - Method in interface org.janusgraph.diskstorage.StaticBuffer
 
subrange(int, boolean) - Method in class org.janusgraph.diskstorage.util.ReadArrayBuffer
 
subrange(int, int) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
subrange(int, int, boolean) - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
SubsetSubqueryCache - Class in org.janusgraph.graphdb.transaction.subquerycache
Different from a simple exact mapping from keys to values, it leverages the fact that the results of a Subquery A with limit X are first X entries of the results of the a Subquery B with limit Y, where A and B only differ in limit, and X is less than or equal to Y.
SubsetSubqueryCache() - Constructor for class org.janusgraph.graphdb.transaction.subquerycache.SubsetSubqueryCache
 
subsumedBy(Class<? extends Element>) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
 
subsumes(KeyRangeQuery) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
subsumes(KeySliceQuery) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
subsumes(SliceQuery) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
success - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
SUCCESS_TX - Static variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
supportedStringMappings(Mapping...) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportNotQueryNormalForm() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportNotQueryNormalForm() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supports(KeyInformation, JanusGraphPredicate) - Method in interface org.janusgraph.diskstorage.indexing.IndexInformation
Whether the index supports executing queries with the given predicate against a key with the given information
supports(KeyInformation) - Method in interface org.janusgraph.diskstorage.indexing.IndexInformation
Whether the index supports indexing a key with the given information
supports(KeyInformation, JanusGraphPredicate) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
supports(KeyInformation) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
supports(MixedIndexType, ParameterIndexField) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
supports(MixedIndexType, ParameterIndexField, JanusGraphPredicate) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
supports(BiPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicateUtils
 
supports(String) - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.PropertyMixing
 
supportsAnyTTL(StoreFeatures) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
Returns true if the parameter supports at least one of the following: cell-level TTL StoreFeatures.hasCellTTL() store-level TTL StoreFeatures.hasStoreTTL()
supportsBulkPlacement() - Method in interface org.janusgraph.graphdb.database.idassigner.placement.IDPlacementStrategy
Whether this placement strategy supports bulk placement.
supportsBulkPlacement() - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
supportsCardinality(Cardinality) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsCardinality(Cardinality) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supportsCustomAnalyzer() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsCustomAnalyzer() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supportsDocumentTTL() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsDocumentTTL() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supportsExistsQuery(MixedIndexType, ParameterIndexField) - Method in class org.janusgraph.graphdb.database.IndexSerializer
 
supportsGeoContains() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsGeoContains() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supportsGeoExists() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsGeoExists() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
supportsInterruption() - Method in interface org.janusgraph.diskstorage.IDAuthority
Whether IDAuthority.getIDBlock(int, int, Duration) may be safely interrupted.
supportsInterruption() - Method in class org.janusgraph.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
supportsInterruption(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
supportsInterruption() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
supportsInterruption() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether calls to this manager and its stores may be safely interrupted without leaving the underlying system in an inconsistent state.
supportsNanoseconds() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
 
supportsNanoseconds() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
SupportsNullSerializer - Interface in org.janusgraph.graphdb.database.serialize
Marker interface to indicate that a given serializer supports serializing null values effectively.
supportsPersistence() - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures
 
supportsPersistence() - Method in interface org.janusgraph.diskstorage.keycolumnvalue.StoreFeatures
Whether the backend supports data persistence.
supportsStringMapping(Mapping) - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
 
system() - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Restricts the result set of this query to only system types.
SYSTEM_CONFIGURATION_IDENTIFIER - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_LOG_TRANSACTIONS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_MGMT_LOG_NAME - Static variable in class org.janusgraph.diskstorage.Backend
 
SYSTEM_PROPERTIES_STORE_NAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_TX_LOG_NAME - Static variable in class org.janusgraph.diskstorage.Backend
 
SystemConfiguration - Interface in org.janusgraph.diskstorage.configuration
 
systemETprefix - Static variable in class org.janusgraph.graphdb.internal.Token
 
SystemRelationType - Interface in org.janusgraph.graphdb.types.system
 
SystemTypeManager - Class in org.janusgraph.graphdb.types.system
 
SystemTypeManager() - Constructor for class org.janusgraph.graphdb.types.system.SystemTypeManager
 

T

take(StoreTransaction, KeyColumn, S) - Method in class org.janusgraph.diskstorage.locking.LockerState
 
targetStatuses - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
 
Temporals - Class in org.janusgraph.diskstorage.util.time
Created by bryn on 30/04/15.
Temporals() - Constructor for class org.janusgraph.diskstorage.util.time.Temporals
 
TemporaryBackendException - Exception in org.janusgraph.diskstorage
This exception signifies a (potentially) temporary exception in a JanusGraph storage backend, that is, an exception that is due to a temporary unavailability or other exception that is not permanent in nature.
TemporaryBackendException(String) - Constructor for exception org.janusgraph.diskstorage.TemporaryBackendException
 
TemporaryBackendException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.TemporaryBackendException
 
TemporaryBackendException(Throwable) - Constructor for exception org.janusgraph.diskstorage.TemporaryBackendException
Constructs an exception with a generic message
TemporaryLockingException - Exception in org.janusgraph.diskstorage.locking
This exception signifies a (potentially) temporary exception while attempting to acquire a lock in the JanusGraph storage backend.
TemporaryLockingException(String) - Constructor for exception org.janusgraph.diskstorage.locking.TemporaryLockingException
 
TemporaryLockingException(String, Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.TemporaryLockingException
 
TemporaryLockingException(Throwable) - Constructor for exception org.janusgraph.diskstorage.locking.TemporaryLockingException
Constructs an exception with a generic message
terminate(Thread[]) - Static method in class org.janusgraph.util.system.Threads
 
test(Object, Object) - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
 
TEXT_COMPRESSION_THRESHOLD - Static variable in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
THREAD_POOL_SIZE_SCALE_FACTOR - Static variable in class org.janusgraph.diskstorage.configuration.ExecutorServiceBuilder
 
threadBound() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
Threads - Class in org.janusgraph.util.system
Utility class for dealing with Thread
Threads() - Constructor for class org.janusgraph.util.system.Threads
 
ThresholdBasedIndexSelectionStrategy - Class in org.janusgraph.graphdb.query.index
 
ThresholdBasedIndexSelectionStrategy(Configuration) - Constructor for class org.janusgraph.graphdb.query.index.ThresholdBasedIndexSelectionStrategy
 
throwIfException(ExceptionWrapper) - Static method in class org.janusgraph.util.system.ExecuteUtil
 
throwIfSystemName(JanusGraphSchemaCategory, String) - Static method in class org.janusgraph.graphdb.types.system.SystemTypeManager
 
timeout - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
 
timeout(long, TemporalUnit) - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
Set the maximum amount of wall clock time that Callable.call() will wait for the index to reach the target status.
Timer - Class in org.janusgraph.diskstorage.util.time
A utility to measure time durations.
Timer(TimestampProvider) - Constructor for class org.janusgraph.diskstorage.util.time.Timer
 
times - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
times - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
times(TimestampProvider) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker.Builder
 
times - Variable in class org.janusgraph.diskstorage.locking.AbstractLocker
Sole source of time.
TIMESLICE_INTERVAL - Static variable in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
The time period that is stored under one key in the underlying KCVS.
TIMESTAMP - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
TIMESTAMP_PROVIDER - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
timestampProvider(TimestampProvider) - Method in class org.janusgraph.diskstorage.util.StandardBaseTransactionConfig.Builder
 
TimestampProvider - Interface in org.janusgraph.diskstorage.util.time
System time interface that abstracts time units, resolution, and measurements of time.
TimestampProviders - Enum in org.janusgraph.diskstorage.util.time
Implementations of TimestampProvider for different resolutions of time: NANO: nano-second time resolution based on System.nanoTime using a base-time established by System.currentTimeMillis().
TimestampRid - Class in org.janusgraph.diskstorage.locking.consistentkey
 
TimestampRid(Instant, StaticBuffer) - Constructor for class org.janusgraph.diskstorage.locking.consistentkey.TimestampRid
 
timestamps(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
timeUnit(ChronoUnit) - Static method in class org.janusgraph.diskstorage.util.time.Temporals
 
TITAN_COMPATIBLE_VERSIONS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
TITAN_COMPATIBLE_VERSIONS - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
Past versions of Titan Graph with which the runtime version shares a compatible storage format
TITAN_ID_STORE_NAME - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
Past name of the ids.store-name used by Titan Graph but which was not configurable
toArrayList(Collection<T>, Function<? super T, ? extends R>) - Static method in class org.janusgraph.graphdb.util.CollectionsUtil
 
Token - Class in org.janusgraph.graphdb.internal
 
Token() - Constructor for class org.janusgraph.graphdb.internal.Token
 
toLockCol(Instant, StaticBuffer, TimestampProvider) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
toLockKey(StaticBuffer, StaticBuffer) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
top() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Returns the least element of the PriorityQueue in constant time.
toPersist() - Method in enum org.janusgraph.core.JanusGraphComputer.ResultMode
 
toResultGraph() - Method in enum org.janusgraph.core.JanusGraphComputer.ResultMode
 
toString() - Method in exception org.janusgraph.core.InvalidElementException
 
toString() - Method in interface org.janusgraph.core.QueryDescription
Returns a string representation of the entire query
toString() - Method in class org.janusgraph.core.schema.Parameter
 
toString() - Method in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
toString() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
toString(ConfigElement) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
toString() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery.OrderEntry
 
toString() - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
toString() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRange
 
toString() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
toString() - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
toString() - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
toString() - Method in class org.janusgraph.diskstorage.locking.LocalLockMediator
 
toString() - Method in class org.janusgraph.diskstorage.log.util.AbstractMessage
 
toString() - Method in class org.janusgraph.diskstorage.log.util.FutureMessage
 
toString(ByteBuffer, String) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
 
toString() - Method in class org.janusgraph.diskstorage.util.KeyColumn
 
toString() - Method in class org.janusgraph.diskstorage.util.StaticArrayBuffer
 
toString() - Method in class org.janusgraph.diskstorage.util.time.Timer
 
toString() - Method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
 
toString() - Method in class org.janusgraph.graphdb.configuration.RegisteredAttributeClass
 
toString() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
 
toString() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusReport
 
toString() - Method in class org.janusgraph.graphdb.database.management.JanusGraphIndexWrapper
 
toString() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem.IndexJobStatus
 
toString() - Method in class org.janusgraph.graphdb.database.management.RelationIndexStatusReport
 
toString() - Method in class org.janusgraph.graphdb.database.management.RelationTypeIndexWrapper
 
toString() - Method in class org.janusgraph.graphdb.internal.OrderList.OrderEntry
 
toString() - Method in class org.janusgraph.graphdb.internal.OrderList
 
toString() - Method in class org.janusgraph.graphdb.log.StandardTransactionId
 
toString() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
toString() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
 
toString() - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusGraphP
 
toString() - Method in interface org.janusgraph.graphdb.query.condition.Condition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.DirectionCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.FixedCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.IncidenceCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
toString(String) - Method in class org.janusgraph.graphdb.query.condition.MultiCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.Not
 
toString() - Method in class org.janusgraph.graphdb.query.condition.PredicateCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.RelationTypeCondition
 
toString() - Method in class org.janusgraph.graphdb.query.condition.VisibilityFilterCondition
 
toString() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQuery
 
toString() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
toString() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
toString() - Method in class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
toString() - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQuery
 
toString() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
toString() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
toString() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
toString() - Method in class org.janusgraph.graphdb.relations.RelationCache
 
toString() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
toString() - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
Deprecated.
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphVariables
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder.OrderEntry
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphMixedIndexCountStep
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphPropertiesStep
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphStep
 
toString() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.step.JanusGraphVertexStep
 
toString() - Method in class org.janusgraph.graphdb.transaction.lock.IndexLockTuple
 
toString() - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
 
toString() - Method in class org.janusgraph.graphdb.types.IndexField
 
toString() - Method in class org.janusgraph.graphdb.types.indextype.IndexTypeWrapper
 
toString() - Method in enum org.janusgraph.graphdb.types.ParameterType
 
toString() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
 
toString() - Method in class org.janusgraph.graphdb.types.system.EmptyRelationType
 
toString() - Method in class org.janusgraph.graphdb.types.system.ImplicitKey
 
toString() - Method in class org.janusgraph.graphdb.types.vertices.JanusGraphSchemaVertex
 
toString() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
toString() - Method in class org.janusgraph.util.datastructures.PointInterval
 
toString() - Method in class org.janusgraph.util.datastructures.RangeInterval
 
toString() - Method in class org.janusgraph.util.system.ConfigurationLint.Status
 
toStringWithoutRoot() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
 
totals(String, RawQuery) - Method in class org.janusgraph.diskstorage.BackendTransaction
 
totals(RawQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface org.janusgraph.diskstorage.indexing.IndexProvider
Executes the given raw query against the index and returns the total hits.
totals(RawQuery) - Method in class org.janusgraph.diskstorage.indexing.IndexTransaction
 
totals(RawQuery, KeyInformation.IndexRetriever, BaseTransaction) - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIndexProvider
 
toTraversalSourceName(String) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Get traversal source name given a graph name.
toVertexArrayList() - Method in class org.janusgraph.graphdb.query.vertex.VertexLongList
 
toVertexId(long) - Static method in class org.janusgraph.core.util.JanusGraphId
Deprecated.
toVertexId(long) - Method in class org.janusgraph.graphdb.idmanagement.IDManager
Converts a user provided long id into a JanusGraph vertex id.
toVertexLongList() - Method in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
Tp3DefaultSchemaMaker - Class in org.janusgraph.core.schema
 
TP3ProfileWrapper - Class in org.janusgraph.graphdb.tinkerpop.profile
 
TP3ProfileWrapper(MutableMetrics) - Constructor for class org.janusgraph.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
Transaction - Interface in org.janusgraph.core
Transaction defines a transactional context for a JanusGraph.
TRANSACTION_LOG - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_LOG_DEFAULT_TTL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_RECOVERY_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
transactional - Variable in class org.janusgraph.diskstorage.common.AbstractStoreManager
 
transactional(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
TransactionalConfiguration - Class in org.janusgraph.diskstorage.configuration
 
TransactionalConfiguration(WriteConfiguration) - Constructor for class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
 
TransactionBuilder - Interface in org.janusgraph.core
Constructor returned by JanusGraph.buildTransaction() to build a new transaction.
TransactionConfiguration - Interface in org.janusgraph.graphdb.transaction
Provides configuration options for JanusGraphTransaction.
TransactionId - Interface in org.janusgraph.core.log
Identifies a transaction.
TransactionLock - Interface in org.janusgraph.graphdb.transaction.lock
 
TransactionLogHeader - Class in org.janusgraph.graphdb.database.log
 
TransactionLogHeader(long, Instant, TimestampProvider) - Constructor for class org.janusgraph.graphdb.database.log.TransactionLogHeader
 
TransactionLogHeader.Entry - Class in org.janusgraph.graphdb.database.log
 
TransactionLogHeader.Modification - Class in org.janusgraph.graphdb.database.log
 
TransactionLogHeader.SecondaryFailures - Class in org.janusgraph.graphdb.database.log
 
TransactionRecovery - Interface in org.janusgraph.core.log
TransactionRecovery is a process that runs in the background and read's from the transaction write-ahead log to determine which transactions have not been successfully persisted against all backends.
transformation(Condition<E>, Function<Condition<E>, Condition<E>>) - Static method in class org.janusgraph.graphdb.query.condition.ConditionUtil
 
traversal(Condition<E>, Predicate<Condition<E>>) - Static method in class org.janusgraph.graphdb.query.condition.ConditionUtil
 
TRUNCATED_ENTRY_LISTS - Static variable in class org.janusgraph.graphdb.olap.VertexJobConverter
Number of result sets that got (possibly) truncated due to an applied query limit
tryLock() - Method in class org.janusgraph.diskstorage.util.NoLock
 
tryLock(long, TimeUnit) - Method in class org.janusgraph.diskstorage.util.NoLock
 
TTL - Static variable in interface org.janusgraph.diskstorage.StoreMetaData
 
TTL - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
TTLKCVS - Class in org.janusgraph.diskstorage.keycolumnvalue.ttl
 
TTLKCVS(KeyColumnValueStore, int) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVS
 
TTLKCVSManager - Class in org.janusgraph.diskstorage.keycolumnvalue.ttl
Turns a store with fine-grained cell-level TTL support into a store with coarse-grained store-level (column-family-level) TTL support.
TTLKCVSManager(KeyColumnValueStoreManager) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
tx() - Method in interface org.janusgraph.graphdb.internal.InternalElement
Returns the transaction to which the element is currently bound or should be refreshed into
tx - Variable in class org.janusgraph.graphdb.olap.AbstractScanJob
 
tx - Variable in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Transaction in which this query is executed
tx() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
tx() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
tx() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
tx - Variable in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
 
tx() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
tx() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
TX_CACHE_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configures the maximum number of recently-used vertices cached by a transaction.
TX_DIRTY_SIZE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
Configures the initial size of the dirty (modified) vertex map used by a transaction.
TXUtils - Class in org.janusgraph.util.system
This class may become obsolete in the future, at which point it will be deprecated or removed.
TXUtils() - Constructor for class org.janusgraph.util.system.TXUtils
 
type(RelationType) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
type(RelationType) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
type - Variable in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
TYPE_LEN_RESERVE - Static variable in class org.janusgraph.graphdb.idmanagement.IDManager
Number of bits that need to be reserved from the type ids for storing additional information during serialization
TYPE_MODIFIER_DEFINITION_CATEGORIES - Static variable in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
TypeDefinitionCategory - Enum in org.janusgraph.graphdb.types
 
TypeDefinitionDescription - Class in org.janusgraph.graphdb.types
 
TypeDefinitionDescription(TypeDefinitionCategory, Object) - Constructor for class org.janusgraph.graphdb.types.TypeDefinitionDescription
 
TypeDefinitionDescriptionSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
TypeDefinitionDescriptionSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
TypeDefinitionMap - Class in org.janusgraph.graphdb.types
 
TypeDefinitionMap() - Constructor for class org.janusgraph.graphdb.types.TypeDefinitionMap
 
TypeDefinitionMap(TypeDefinitionMap) - Constructor for class org.janusgraph.graphdb.types.TypeDefinitionMap
 
TypedInterval(PropertyKey, Interval) - Constructor for class org.janusgraph.graphdb.database.EdgeSerializer.TypedInterval
 
typeId - Variable in class org.janusgraph.graphdb.database.idhandling.IDHandler.RelationTypeParse
 
typeId - Variable in class org.janusgraph.graphdb.relations.RelationCache
 
TypeInspector - Interface in org.janusgraph.graphdb.types
 
types(String...) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for only those relations matching one of the given relation types.
types(RelationType...) - Method in interface org.janusgraph.core.BaseVertexQuery
Query for only those relations matching one of the given relation types.
types(String...) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
types(RelationType...) - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
 
types(String...) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
types(RelationType...) - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
types(RelationType...) - Method in class org.janusgraph.graphdb.olap.QueryContainer.QueryBuilder
 
types - Variable in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The relation types (labels or keys) to query for.
types(RelationType...) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
types(String...) - Method in class org.janusgraph.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
TypeUtil - Class in org.janusgraph.graphdb.types
 
TypeUtil() - Constructor for class org.janusgraph.graphdb.types.TypeUtil
 

U

uid - Variable in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
uidBytes - Variable in class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
 
umbrellaElements - Variable in class org.janusgraph.diskstorage.configuration.ConfigElement.PathIdentifier
 
uncaughtException(Thread, Throwable) - Method in class org.janusgraph.diskstorage.util.UncaughtExceptionLogger
 
UncaughtExceptionLogger - Class in org.janusgraph.diskstorage.util
 
UncaughtExceptionLogger(UncaughtExceptionLogger.UELevel) - Constructor for class org.janusgraph.diskstorage.util.UncaughtExceptionLogger
 
UncaughtExceptionLogger.UELevel - Enum in org.janusgraph.diskstorage.util
 
UncheckedCallable<T> - Interface in org.janusgraph.diskstorage.util
 
unidirected() - Method in interface org.janusgraph.core.schema.EdgeLabelMaker
Configures the label to be unidirected.
unidirected() - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
unidirected(Direction) - Method in class org.janusgraph.graphdb.types.StandardEdgeLabelMaker
 
unique() - Method in interface org.janusgraph.core.schema.JanusGraphManagement.IndexBuilder
Makes this a unique index for the configured element type, i.e.
UNIQUE_INSTANCE_ID - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
UNIQUE_INSTANCE_ID_HOSTNAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
UNIQUE_INSTANCE_ID_SUFFIX - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
UniqueInstanceIdRetriever - Class in org.janusgraph.graphdb.idmanagement
Default implementation for unique instance identifier
UNKNOWN_FIELD_NAME - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
unlock(KeyColumn, T) - Method in class org.janusgraph.diskstorage.locking.LocalLockMediator
Release the lock specified by kc and which was previously locked by requester, if it is possible to release it.
unlock() - Method in class org.janusgraph.diskstorage.util.NoLock
 
unlock() - Method in class org.janusgraph.graphdb.transaction.lock.CombinerLock
 
unlock() - Method in class org.janusgraph.graphdb.transaction.lock.FakeLock
 
unlock() - Method in interface org.janusgraph.graphdb.transaction.lock.TransactionLock
 
unorderedScan(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
unregisterReader(MessageReader) - Method in class org.janusgraph.diskstorage.log.kcvs.KCVSLog
 
unregisterReader(MessageReader) - Method in interface org.janusgraph.diskstorage.log.Log
Removes the given reader from the list of registered readers and returns whether this reader was registered in the first place.
unsetBitb(byte, int) - Static method in class org.janusgraph.util.datastructures.BitMap
 
unsignedBitLength(long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
unsignedByte(byte) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
unsignedByte(int) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
unwrapTx(StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.cache.KCVSCache
 
unwrapTx(StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
 
unwrapTx(StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
 
update(byte, ElementLifeCycle.Event) - Static method in class org.janusgraph.graphdb.internal.ElementLifeCycle
 
updateConfiguration(String, Configuration) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Update configuration corresponding to supplied graphName; we update supplied existing properties and add new ones to the Configuration; The supplied Configuration must include a property "graph.graphname" and it must match supplied graphName; NOTE: The updated configuration is only guaranteed to take effect if the Graph corresponding to graphName has been closed and reopened on every JanusGraph Node.
updateConfiguration(String, Configuration) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Update configuration corresponding to supplied graphName; we update supplied existing properties and add new ones to the Configuration; The supplied Configuration must include a property "graph.graphname" and it must match supplied graphName; NOTE: The updated configuration is only guaranteed to take effect if the Graph corresponding to graphName has been closed and reopened on every JanusGraph Node.
updateIndex(Index, SchemaAction) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
Updates the provided index according to the given SchemaAction
updateIndex(Index, SchemaAction) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
 
updateLifeCycle(ElementLifeCycle.Event) - Method in class org.janusgraph.graphdb.vertices.StandardVertex
 
updateLimit(int) - Method in class org.janusgraph.diskstorage.indexing.IndexQuery
 
updateLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeyRangeQuery
 
updateLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KeySliceQuery
 
updateLimit(int) - Method in class org.janusgraph.diskstorage.keycolumnvalue.SliceQuery
 
updateLimit(int) - Method in interface org.janusgraph.graphdb.query.BackendQuery
Creates a new query identical to the current one but with the specified limit.
updateLimit(int) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
 
updateLimit(int) - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery
 
updateLimit(int) - Method in class org.janusgraph.graphdb.query.graph.MultiKeySliceQuery
 
updateSchemaVertex(JanusGraphSchemaVertex) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
updateState() - Method in interface org.janusgraph.diskstorage.log.MessageReader
Updates the state of the MessageReader.
updateState() - Method in class org.janusgraph.graphdb.database.management.ManagementLogger
 
updateTemplateConfiguration(Configuration) - Static method in class org.janusgraph.core.ConfiguredGraphFactory
Update template configuration by updating supplied existing properties and adding new ones to the Configuration; your updated Configuration may not contain the property "graph.graphname"; NOTE: Any graph using a configuration that was created using the template configuration must-- 1) be closed and reopened on every JanusGraph Node 2) have its corresponding Configuration removed and 3) recreate the graph-- before the update is guaranteed to take effect.
updateTemplateConfiguration(Configuration) - Method in class org.janusgraph.graphdb.management.ConfigurationManagementGraph
Update template configuration by updating supplied existing properties and adding new ones to the Configuration; your updated Configuration may not contain the property "graph.graphname"; NOTE: Any graph using a configuration that was created using the template configuration must-- 1) be closed and reopened on every JanusGraph Node 2) have its corresponding Configuration removed and 3) recreate the graph-- before the update is guaranteed to take effect.
updateTop() - Method in class org.janusgraph.graphdb.util.PriorityQueue
Deprecated.
Should be called when the Object at top changes values.
UPGRADEABLE_FIXED - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
List of FIXED fields that can be modified when graph.allow-upgrade is set to true
USE_MULTIQUERY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
useMultiQuery() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
useMultiQuery() - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
useMultiQuery() - Method in interface org.janusgraph.graphdb.transaction.TransactionConfiguration
Whether this transaction should batch backend queries.
USER_CONFIGURATION_IDENTIFIER - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
USER_LOG - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
USER_LOG_PREFIX - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
userLogFailure - Variable in class org.janusgraph.graphdb.database.log.TransactionLogHeader.SecondaryFailures
 
UserModifiableConfiguration - Class in org.janusgraph.diskstorage.configuration
Helper class for inspecting and modifying a configuration for JanusGraph.
UserModifiableConfiguration(ModifiableConfiguration) - Constructor for class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
 
UserModifiableConfiguration(ModifiableConfiguration, UserModifiableConfiguration.ConfigVerifier) - Constructor for class org.janusgraph.diskstorage.configuration.UserModifiableConfiguration
 
UserModifiableConfiguration.ConfigVerifier - Interface in org.janusgraph.diskstorage.configuration
 
username - Variable in class org.janusgraph.diskstorage.common.DistributedStoreManager
 
USERVERTEX_PADDING_BITWIDTH - Static variable in class org.janusgraph.graphdb.idmanagement.IDManager
The padding bit width for user vertices
useSimpleQueryProcessor(BaseVertexCentricQuery, InternalVertex...) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
UTF8_CHARSET - Static variable in class org.janusgraph.util.encoding.StringEncoding
 
UTF8_ENCODING - Static variable in class org.janusgraph.util.encoding.StringEncoding
 
UUIDSerializer - Class in org.janusgraph.graphdb.database.serialize.attribute
 
UUIDSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 

V

validate(String) - Static method in class org.janusgraph.util.system.ConfigurationLint
 
validateBackwardCompatibilityWithTitan(String, String) - Static method in class org.janusgraph.graphdb.configuration.validator.CompatibilityValidator
 
validateIndexStatus() - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
validateIndexStatus() - Method in class org.janusgraph.graphdb.olap.job.IndexRepairJob
Check that our target index is in either the ENABLED or REGISTERED state.
validateIndexStatus() - Method in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
validDataType(Class) - Method in interface org.janusgraph.graphdb.database.serialize.AttributeHandler
 
validDataType(Class) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
validDataType(Class) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
validFoldInHasContainer(Step<?, ?>, boolean) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
validJanusGraphHas(HasContainer) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
validJanusGraphHas(Iterable<HasContainer>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
validJanusGraphOrder(OrderGlobalStep, Traversal, boolean) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.step.HasStepFolder
 
value() - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
value(String) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
value(String) - Method in interface org.janusgraph.core.JanusGraphRelation
Retrieves the value associated with the given key on this vertex and casts it to the specified type.
value() - Method in class org.janusgraph.core.schema.Parameter
 
value - Variable in class org.janusgraph.diskstorage.indexing.IndexEntry
 
value() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
value(String) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
value(String) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
value() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
 
value() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
 
value(String) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
VALUE - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
valueOf(String) - Static method in enum org.janusgraph.core.Cardinality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.JanusGraphComputer.ResultMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.log.Change
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.Multiplicity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.schema.ConsistencyModifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.schema.JobStatus.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.schema.Mapping
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.schema.SchemaAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.schema.SchemaStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.common.DistributedStoreManager.Deployment
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.configuration.BasicConfiguration.Restriction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.configuration.ConfigOption.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.EntryMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.idmanagement.ConflictAvoidanceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.locking.LocalLockMediators
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.StandardIndexProvider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.StandardStoreManager
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.StoreMetaData.TTLImpl
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.util.CacheMetricsAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.util.HashingUtil.HashLength
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.util.HashUtility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.diskstorage.util.UncaughtExceptionLogger.UELevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.idhandling.IDHandler.DirectionID
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.log.LogTxMeta
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.log.LogTxStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.management.GraphCacheEvictionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.management.MgmtLogType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.database.management.ModifierType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.internal.ElementCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.internal.ElementLifeCycle.Event
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.internal.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.internal.RelationCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.query.condition.Condition.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.query.condition.VisibilityFilterCondition.Visibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy.OptimizablePosition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.types.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.janusgraph.util.stats.MetricManager
Returns the enum constant of this type with the specified name.
valueOrNull(PropertyKey) - Method in class org.janusgraph.core.EmptyJanusGraphVertexProperty
 
valueOrNull(PropertyKey) - Method in interface org.janusgraph.core.JanusGraphElement
Retrieves the value associated with the given key on this element and casts it to the specified type.
valueOrNull(PropertyKey) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
 
valueOrNull(PropertyKey) - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
 
valueOrNull(PropertyKey) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
valueOrNull(PropertyKey) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
values() - Static method in enum org.janusgraph.core.Cardinality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.JanusGraphComputer.ResultMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.log.Change
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.Multiplicity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.schema.ConsistencyModifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.schema.JobStatus.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.schema.Mapping
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.schema.SchemaAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.schema.SchemaStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.common.DistributedStoreManager.Deployment
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.configuration.BasicConfiguration.Restriction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.configuration.ConfigOption.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.EntryMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.idmanagement.ConflictAvoidanceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.keycolumnvalue.scan.ScanMetrics.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.locking.LocalLockMediators
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.StandardIndexProvider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.StandardStoreManager
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.StoreMetaData.TTLImpl
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.util.CacheMetricsAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.util.HashingUtil.HashLength
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.util.HashUtility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.util.time.TimestampProviders
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.diskstorage.util.UncaughtExceptionLogger.UELevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.idhandling.IDHandler.DirectionID
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.log.LogTxMeta
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.log.LogTxStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.management.GraphCacheEvictionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.management.MgmtLogType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.database.management.ModifierType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.idmanagement.IDManager.VertexIDType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.internal.ElementCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.internal.ElementLifeCycle.Event
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.internal.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.internal.RelationCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.query.condition.Condition.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.query.condition.VisibilityFilterCondition.Visibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.tinkerpop.optimize.strategy.AdjacentVertexOptimizerStrategy.OptimizablePosition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.types.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.janusgraph.util.stats.MetricManager
Returns an array containing the constants of this enum type, in the order they are declared.
variableKeyLength - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
variableKeyLengthSize - Static variable in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
VariableLong - Class in org.janusgraph.graphdb.database.idhandling
 
VariableLong() - Constructor for class org.janusgraph.graphdb.database.idhandling.VariableLong
 
variables() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
variables() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
VERBOSE_TX_RECOVERY - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
 
verify(Object) - Method in class org.janusgraph.diskstorage.configuration.ConfigOption
 
verifyAccess() - Method in class org.janusgraph.graphdb.relations.AbstractTypedRelation
Cannot currently throw exception when removed since internal logic relies on access to the edge beyond its removal.
verifyAccess(JanusGraphVertex...) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
verifyAccess() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
verifyArgsMustBeEitherIdOrElement(Object...) - Static method in class org.janusgraph.graphdb.tinkerpop.ElementUtils
 
verifyAttribute(V) - Method in interface org.janusgraph.core.attribute.AttributeSerializer
Verifies the given (not-null) attribute value is valid.
verifyAttribute(Geoshape) - Method in class org.janusgraph.core.attribute.GeoshapeSerializer
 
verifyAttribute(T) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
verifyAttribute(String) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
verifyAttribute(Class<V>, Object) - Method in interface org.janusgraph.graphdb.database.serialize.AttributeHandler
 
verifyAttribute(Class<V>, Object) - Method in class org.janusgraph.graphdb.database.serialize.StandardSerializer
 
verifyAttribute(PropertyKey, Object) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
 
verifyAttribute(Object) - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
verifyElement(ConfigElement) - Method in class org.janusgraph.diskstorage.configuration.AbstractConfiguration
 
verifyModification(ConfigOption) - Method in interface org.janusgraph.diskstorage.configuration.UserModifiableConfiguration.ConfigVerifier
Throws an exception if the given configuration option is not allowed to be changed.
verifyName(String) - Static method in class org.janusgraph.graphdb.internal.Token
 
verifyOpen(boolean, String, String...) - Static method in exception org.janusgraph.diskstorage.ResourceUnavailableException
 
verifyOption(ConfigOption) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
 
verifyValidDefinition(TypeDefinitionMap) - Method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
 
version() - Static method in interface org.janusgraph.core.JanusGraph
The version of this JanusGraph graph database
VERSION - Static variable in class org.janusgraph.graphdb.configuration.JanusGraphConstants
Runtime version of JanusGraph, as read from a properties file inside the core jar
vertex(Direction) - Method in interface org.janusgraph.core.JanusGraphEdge
Returns the vertex for the specified direction.
vertex(Direction) - Method in class org.janusgraph.graphdb.relations.AbstractEdge
 
vertex() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
 
VERTEX_EXISTS_QUERY - Static variable in class org.janusgraph.graphdb.olap.VertexJobConverter
 
VERTEX_ID_COMPARATOR - Static variable in class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
VertexArrayList - Class in org.janusgraph.graphdb.query.vertex
An implementation of VertexListInternal that stores the actual vertex references and simply wraps an ArrayList and keeps a boolean flag to remember whether this list is in sort order.
VertexArrayList(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexArrayList
 
VertexCache - Interface in org.janusgraph.graphdb.transaction.vertexcache
 
vertexCacheSize(int) - Method in interface org.janusgraph.core.TransactionBuilder
Configures the size of the internal caches used in the transaction.
vertexCacheSize(int) - Method in class org.janusgraph.graphdb.transaction.StandardTransactionBuilder
 
VertexCentricEdgeIterable<R extends JanusGraphRelation> - Class in org.janusgraph.graphdb.util
 
VertexCentricEdgeIterable(Iterable<InternalVertex>, RelationCategory) - Constructor for class org.janusgraph.graphdb.util.VertexCentricEdgeIterable
 
VertexCentricQuery - Class in org.janusgraph.graphdb.query.vertex
A vertex-centric query which implements ElementQuery so that it can be executed by QueryProcessor.
VertexCentricQuery(InternalVertex, Condition<JanusGraphRelation>, Direction, List<BackendQueryHolder<SliceQuery>>, OrderList, int) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
VertexCentricQuery(InternalVertex, BaseVertexCentricQuery) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
 
VertexCentricQuery(InternalVertex) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexCentricQuery
Constructs an empty query
VertexCentricQueryBuilder - Class in org.janusgraph.graphdb.query.vertex
Implementation of JanusGraphVertexQuery that extends BasicVertexCentricQueryBuilder for all the query building and optimization and adds only the execution logic in BasicVertexCentricQueryBuilder.constructQuery(org.janusgraph.graphdb.internal.RelationCategory).
VertexCentricQueryBuilder(InternalVertex) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
VertexConstructor() - Constructor for class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
vertexExistenceQuery - Variable in class org.janusgraph.graphdb.database.StandardJanusGraph
 
VertexExists - Static variable in class org.janusgraph.graphdb.types.system.BaseKey
 
VertexFactory - Interface in org.janusgraph.graphdb.transaction
 
VertexIDAssigner - Class in org.janusgraph.graphdb.database.idassigner
 
VertexIDAssigner(Configuration, IDAuthority, StoreFeatures) - Constructor for class org.janusgraph.graphdb.database.idassigner.VertexIDAssigner
 
VertexIdConstructor() - Constructor for class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
vertexIds() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Retrieves all vertices connected to each of the query's central vertices by edges matching the conditions defined in this query.
vertexIds() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
Retrieves all vertices connected to this query's base vertex by edges matching the conditions defined in this query.
vertexIds() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
vertexIds() - Method in class org.janusgraph.graphdb.query.vertex.SimpleVertexQueryProcessor
Returns the list of adjacent vertex ids for this query.
vertexIds() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
VertexIterable - Class in org.janusgraph.graphdb.transaction
 
VertexIterable(StandardJanusGraph, StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.transaction.VertexIterable
 
VertexJobConverter - Class in org.janusgraph.graphdb.olap
 
VertexJobConverter(JanusGraph, VertexScanJob) - Constructor for class org.janusgraph.graphdb.olap.VertexJobConverter
 
VertexJobConverter(VertexJobConverter) - Constructor for class org.janusgraph.graphdb.olap.VertexJobConverter
 
vertexLabel() - Method in interface org.janusgraph.core.JanusGraphVertex
Returns the vertex label of this vertex.
VertexLabel - Interface in org.janusgraph.core
A vertex label is a label attached to vertices in a JanusGraph graph.
vertexLabel() - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
vertexLabel() - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
VERTEXLABEL_DEFINITION_CATEGORIES - Static variable in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
 
VertexLabelDefinition - Class in org.janusgraph.graphdb.schema
Deprecated.
part of the management revamp in JG, see https://github.com/JanusGraph/janusgraph/projects/3.
VertexLabelDefinition(String, long, boolean, boolean) - Constructor for class org.janusgraph.graphdb.schema.VertexLabelDefinition
Deprecated.
 
VertexLabelDefinition(VertexLabel) - Constructor for class org.janusgraph.graphdb.schema.VertexLabelDefinition
Deprecated.
 
VertexLabelEdge - Static variable in class org.janusgraph.graphdb.types.system.BaseLabel
 
VertexLabelMaker - Interface in org.janusgraph.core.schema
A builder to create new VertexLabels.
VertexLabelVertex - Class in org.janusgraph.graphdb.types
 
VertexLabelVertex(StandardJanusGraphTx, long, byte) - Constructor for class org.janusgraph.graphdb.types.VertexLabelVertex
 
VertexList - Interface in org.janusgraph.core
VertexListInternal - Interface in org.janusgraph.graphdb.query.vertex
Extends on the VertexList interface by provided methods to add elements to the list which is needed during query execution when the result list is created.
VertexLongList - Class in org.janusgraph.graphdb.query.vertex
An implementation of VertexListInternal that stores only the vertex ids and simply wraps an LongArrayList and keeps a boolean flag to remember whether this list is in sort order.
VertexLongList(StandardJanusGraphTx) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexLongList
 
VertexLongList(StandardJanusGraphTx, LongArrayList, boolean) - Constructor for class org.janusgraph.graphdb.query.vertex.VertexLongList
 
VertexMapJob - Class in org.janusgraph.graphdb.olap.computer
 
VertexMapJob.Executor - Class in org.janusgraph.graphdb.olap.computer
 
VertexProgramScanJob<M> - Class in org.janusgraph.graphdb.olap.computer
 
VertexProgramScanJob.Executor - Class in org.janusgraph.graphdb.olap.computer
 
VertexScanJob - Interface in org.janusgraph.graphdb.olap
Expresses a computation over all vertices ina a graph database.
VertexState<M> - Class in org.janusgraph.graphdb.olap.computer
 
VertexState(Map<String, Integer>) - Constructor for class org.janusgraph.graphdb.olap.computer.VertexState
 
vertexStream() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns all vertices that match the query in the indexing backend.
vertexStream() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
vertexTotals() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Returns total vertices that match the query in the indexing backend ignoring limit and offset.
vertexTotals() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
 
vertices(Direction) - Method in interface org.janusgraph.core.JanusGraphEdge
 
vertices() - Method in interface org.janusgraph.core.JanusGraphIndexQuery
Deprecated.
vertices() - Method in interface org.janusgraph.core.JanusGraphMultiVertexQuery
Retrieves all vertices connected to each of the query's base vertices by edges matching the conditions defined in this query.
vertices() - Method in interface org.janusgraph.core.JanusGraphQuery
Returns all vertices that match the conditions.
vertices() - Method in interface org.janusgraph.core.JanusGraphVertexQuery
 
vertices(Traversal<Vertex, Vertex>) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
vertices() - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
 
vertices() - Method in class org.janusgraph.graphdb.query.graph.IndexQueryBuilder
Deprecated.
vertices() - Method in class org.janusgraph.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
vertices() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
 
vertices(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
 
vertices(Object...) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsTransaction
 
vertices(Direction, String...) - Method in class org.janusgraph.graphdb.types.system.EmptyVertex
 
vertices(Direction, String...) - Method in class org.janusgraph.graphdb.vertices.AbstractVertex
 
visibility(boolean) - Method in class org.janusgraph.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
VISIBILITY - Static variable in class org.janusgraph.graphdb.types.system.ImplicitKey
 
VisibilityFilterCondition<E extends JanusGraphElement> - Class in org.janusgraph.graphdb.query.condition
Evaluates elements based on their visibility
VisibilityFilterCondition(VisibilityFilterCondition.Visibility) - Constructor for class org.janusgraph.graphdb.query.condition.VisibilityFilterCondition
 
VisibilityFilterCondition.Visibility - Enum in org.janusgraph.graphdb.query.condition
 

W

waitCondition() - Method in class org.janusgraph.util.system.BackgroundThread
The wait condition for the background thread.
waitForCompletion(Thread[]) - Static method in class org.janusgraph.util.system.Threads
 
waitForCompletion(Thread[], int) - Static method in class org.janusgraph.util.system.Threads
 
waitForCompletion(Thread[], int, int) - Static method in class org.janusgraph.util.system.Threads
 
workerIterationEnd(ScanMetrics) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
Invoked after a block of computation (i.e.
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob.Executor
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexRepairJob
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
workerIterationEnd(ScanMetrics) - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
workerIterationEnd(ScanMetrics) - Method in interface org.janusgraph.graphdb.olap.VertexScanJob
 
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.scan.ScanJob
Invoked before a block of computation (i.e.
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob.Executor
 
workerIterationStart(JanusGraph, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexMapJob
 
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
 
workerIterationStart(JanusGraph, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob
 
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.GhostVertexRemover
 
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexRemoveJob
 
workerIterationStart(JanusGraph, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 
workerIterationStart(Configuration, Configuration, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
 
workerIterationStart(JanusGraph, Configuration, ScanMetrics) - Method in interface org.janusgraph.graphdb.olap.VertexScanJob
 
WorkerPool - Class in org.janusgraph.graphdb.util
Utility class for implementing a thread pool that closes gracefully and provides back-pressure when submitting jobs.
WorkerPool(int) - Constructor for class org.janusgraph.graphdb.util.WorkerPool
 
workers(int) - Method in interface org.janusgraph.core.JanusGraphComputer
 
workers(int) - Method in class org.janusgraph.graphdb.olap.computer.FulgoraGraphComputer
 
wrap(Iterable<R>, int) - Static method in class org.janusgraph.graphdb.query.ResultSetIterator
 
wrapCharArray(char[]) - Static method in class org.janusgraph.diskstorage.util.Hex
Create a String from a char array with zero-copy (if available), using reflection to access a package-protected constructor of String.
write(WriteBuffer, V) - Method in interface org.janusgraph.core.attribute.AttributeSerializer
Writes the attribute value to the given WriteBuffer.
write(WriteBuffer, Geoshape) - Method in class org.janusgraph.core.attribute.GeoshapeSerializer
 
write(byte[], int, V) - Method in interface org.janusgraph.diskstorage.util.StaticArrayEntryList.MetaDataSerializer
 
write(WriteBuffer, long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
write(WriteBuffer, boolean[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanArraySerializer
 
write(WriteBuffer, Boolean) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
write(WriteBuffer, byte[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteArraySerializer
 
write(WriteBuffer, Byte) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
write(WriteBuffer, Character) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
write(WriteBuffer, char[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharArraySerializer
 
write(WriteBuffer, Date) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
write(WriteBuffer, double[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleArraySerializer
 
write(WriteBuffer, Double) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
write(WriteBuffer, Duration) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DurationSerializer
 
write(WriteBuffer, E) - Method in class org.janusgraph.graphdb.database.serialize.attribute.EnumSerializer
 
write(WriteBuffer, float[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatArraySerializer
 
write(WriteBuffer, Float) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
write(WriteBuffer, Instant) - Method in class org.janusgraph.graphdb.database.serialize.attribute.InstantSerializer
 
write(WriteBuffer, int[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntArraySerializer
 
write(WriteBuffer, Integer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
write(WriteBuffer, T) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
write(WriteBuffer, long[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongArraySerializer
 
write(WriteBuffer, Long) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
write(WriteBuffer, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ObjectSerializer
 
write(WriteBuffer, Parameter[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterArraySerializer
 
write(WriteBuffer, Parameter) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ParameterSerializer
 
write(WriteBuffer, T) - Method in class org.janusgraph.graphdb.database.serialize.attribute.SerializableSerializer
 
write(WriteBuffer, short[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortArraySerializer
 
write(WriteBuffer, Short) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
write(WriteBuffer, StandardTransactionId) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
write(WriteBuffer, String[]) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringArraySerializer
 
write(WriteBuffer, String) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
write(WriteBuffer, TypeDefinitionDescription) - Method in class org.janusgraph.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
write(WriteBuffer, UUID) - Method in class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 
writeAsciiString(byte[], int, String) - Static method in class org.janusgraph.util.encoding.StringEncoding
 
writeBackward(WriteBuffer, long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
writeBuffer(DataOutput, StaticBuffer) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
WriteBuffer - Interface in org.janusgraph.diskstorage
A Buffer that allows simple writes and returns the result as a StaticBuffer.
WriteBufferUtil - Class in org.janusgraph.diskstorage.util
 
WriteBufferUtil() - Constructor for class org.janusgraph.diskstorage.util.WriteBufferUtil
 
WriteByteBuffer - Class in org.janusgraph.diskstorage.util
 
WriteByteBuffer() - Constructor for class org.janusgraph.diskstorage.util.WriteByteBuffer
 
WriteByteBuffer(int) - Constructor for class org.janusgraph.diskstorage.util.WriteByteBuffer
 
writeByteOrder(WriteBuffer, Boolean) - Method in class org.janusgraph.graphdb.database.serialize.attribute.BooleanSerializer
 
writeByteOrder(WriteBuffer, Byte) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ByteSerializer
 
writeByteOrder(WriteBuffer, Character) - Method in class org.janusgraph.graphdb.database.serialize.attribute.CharacterSerializer
 
writeByteOrder(WriteBuffer, Date) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DateSerializer
 
writeByteOrder(WriteBuffer, Double) - Method in class org.janusgraph.graphdb.database.serialize.attribute.DoubleSerializer
 
writeByteOrder(WriteBuffer, E) - Method in class org.janusgraph.graphdb.database.serialize.attribute.EnumSerializer
 
writeByteOrder(WriteBuffer, Float) - Method in class org.janusgraph.graphdb.database.serialize.attribute.FloatSerializer
 
writeByteOrder(WriteBuffer, Integer) - Method in class org.janusgraph.graphdb.database.serialize.attribute.IntegerSerializer
 
writeByteOrder(WriteBuffer, T) - Method in class org.janusgraph.graphdb.database.serialize.attribute.JsonSerializer
 
writeByteOrder(WriteBuffer, Long) - Method in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
 
writeByteOrder(WriteBuffer, Short) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ShortSerializer
 
writeByteOrder(WriteBuffer, String) - Method in class org.janusgraph.graphdb.database.serialize.attribute.StringSerializer
 
writeByteOrder(WriteBuffer, UUID) - Method in class org.janusgraph.graphdb.database.serialize.attribute.UUIDSerializer
 
writeByteOrder(WriteBuffer, V) - Method in interface org.janusgraph.graphdb.database.serialize.OrderPreservingSerializer
Writes the attribute value to the given WriteBuffer such that the byte order of the result is equal to the natural order of the attribute.
writeClassAndObject(Object) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
WriteConfiguration - Interface in org.janusgraph.diskstorage.configuration
 
writeEntry(DataOutput, Entry) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
writeInlineRelationType(WriteBuffer, long) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
 
writeLength(WriteBuffer, Object) - Method in class org.janusgraph.graphdb.database.serialize.attribute.ArraySerializer
 
writeLock(KeyColumn, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
 
writeLock(KeyColumn, StoreTransaction) - Method in interface org.janusgraph.diskstorage.locking.Locker
Attempt to acquire/take/claim/write the lock named by lockID.
writeObject(Object, Class<?>) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
writeObjectByteOrder(Object, Class<?>) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
writeObjectNotNull(Object) - Method in interface org.janusgraph.graphdb.database.serialize.DataOutput
 
writePositive(WriteBuffer, long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
writePositiveBackward(WriteBuffer, long) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
writePositiveWithPrefix(WriteBuffer, long, long, int) - Static method in class org.janusgraph.graphdb.database.idhandling.VariableLong
 
writeRelation(InternalRelation, int, TypeInspector) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
writeRelation(InternalRelation, InternalRelationType, int, TypeInspector) - Method in class org.janusgraph.graphdb.database.EdgeSerializer
 
writeRelationType(WriteBuffer, long, IDHandler.DirectionID, boolean) - Static method in class org.janusgraph.graphdb.database.idhandling.IDHandler
The edge type is written as follows: [ Invisible & System (2 bit) | Relation-Type-ID (1 bit) | Relation-Type-Count (variable) | Direction-ID (1 bit)] Would only need 1 bit to store relation-type-id, but using two so we can upper bound.
writeSingleLock(KeyColumn, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.AbstractLocker
Try to take/acquire/write/claim a lock uniquely identified within this Locker by the lockID argument on behalf of tx.
writeSingleLock(KeyColumn, StoreTransaction) - Method in class org.janusgraph.diskstorage.locking.consistentkey.ConsistentKeyLocker
Try to write a lock record remotely up to the configured number of times.
writeTx - Variable in class org.janusgraph.graphdb.olap.job.IndexUpdateJob
 

Z

zeroBuffer(int) - Static method in class org.janusgraph.diskstorage.util.BufferUtil
 
zeroByteBuffer(int) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

Copyright © 2012–2023. All rights reserved.