- 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
-
- AbstractIDAuthority(Configuration) - Constructor for class org.janusgraph.diskstorage.idmanagement.AbstractIDAuthority
-
- 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
-
- 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.inmemory.InMemoryKeyColumnValueStore
-
- 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.keycolumnvalue.ReadOnlyKeyColumnValueStore
-
- 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.ConcurrentBufferAddedRelations
-
- add(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
-
- add(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- add(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
-
- 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.GuavaVertexCache
-
- add(InternalVertex, long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.LRUVertexCache
-
- 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
-
- add(T) - Method in class org.janusgraph.graphdb.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- add(int) - Method in class org.janusgraph.util.datastructures.ImmutableIntSet
-
- add(int) - Method in class org.janusgraph.util.datastructures.IntHashSet
-
- add(int) - Method in interface org.janusgraph.util.datastructures.IntSet
-
- add(T) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- addAll(Iterable<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- addAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- addAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- addAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- addAll(int[]) - Method in class org.janusgraph.util.datastructures.ImmutableIntSet
-
- addAll(int[]) - Method in class org.janusgraph.util.datastructures.IntHashSet
-
- addAll(int[]) - Method in interface org.janusgraph.util.datastructures.IntSet
-
- addAll(Collection<? extends T>) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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(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
-
- addGangliaReporter(String, int, GMetric.UDPAddressingMode, int, Boolean, UUID, String, Duration) - Method in enum org.janusgraph.util.stats.MetricManager
-
Create a GangliaReporter
attached to the JanusGraph Metrics registry.
- 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 class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- 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
- addLocalAll(Iterable<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- addLocalAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- addLocalAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- addLocalAll(Iterable<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.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) - Method in class org.janusgraph.graphdb.query.profile.SimpleQueryProfiler
-
- addNested(String) - 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
-
- 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(VertexProperty.Cardinality, JanusGraphVertex, PropertyKey, Object) - 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.
- addToQueryCache(SliceQuery, EntryList) - Method in class org.janusgraph.graphdb.vertices.CacheVertex
-
- addToQueryCache(SliceQuery, EntryList) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
-
- addValue(int, double) - Method in class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- 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
-
- 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
-
- AllEdgesIterator - Class in org.janusgraph.graphdb.util
-
- AllEdgesIterator(Iterator<? extends Vertex>) - Constructor for class org.janusgraph.graphdb.util.AllEdgesIterator
-
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
-
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.AdjacentVertexFilterOptimizerStrategy
-
- apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphLocalQueryOptimizerStrategy
-
- apply(Traversal.Admin<?, ?>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStepStrategy
-
- applyPrior() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphLocalQueryOptimizerStrategy
-
- applyTTL(Collection<Entry>, int) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
-
- ARRAY_FACTORY - Static variable in interface org.janusgraph.diskstorage.StaticBuffer
-
- arrayDifference(long[], long[]) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- 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
-
- ArraysUtil - Class in org.janusgraph.util.datastructures
-
Utility class for sorting and retrieving from primitive arrays
- ArraysUtil() - Constructor for class org.janusgraph.util.datastructures.ArraysUtil
-
- 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
-
- 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
-
- 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.
- AttributeUtil - Class in org.janusgraph.graphdb.database.serialize
-
- AttributeUtil() - Constructor for class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- 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
-
- 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
-
- CachableStaticBuffer - Interface in org.janusgraph.diskstorage.keycolumnvalue.cache
-
- CACHE_NS - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- cardinality(Cardinality) - Method in interface org.janusgraph.core.schema.PropertyKeyMaker
-
- cardinality(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
-
- 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
-
- 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
-
- 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
-
- circle(double, double, double) - Static method in class org.janusgraph.core.attribute.Geoshape
-
Constructs a circle from a given center point and a radius in kilometer
- 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(JanusGraph) - Static method in class org.janusgraph.core.util.JanusGraphCleanup
-
- clear() - Method in class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
-
- 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 class org.janusgraph.graphdb.util.ConcurrentLRUCache
-
- clear() - Method in class org.janusgraph.graphdb.util.PriorityQueue
-
Removes all entries from the PriorityQueue.
- clear() - Method in class org.janusgraph.util.datastructures.CompactMap
-
- clear() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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.inmemory.InMemoryStoreManager
-
- 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.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.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.JanusGraphPropertiesStep
-
- clone() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- 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
-
- 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.inmemory.InMemoryKeyColumnValueStore
-
- close() - Method in class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
-
- 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.MetricInstrumentedIterator
-
- 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.computer.VertexMapJob.Executor
-
- close() - Method in class org.janusgraph.graphdb.olap.computer.VertexProgramScanJob.Executor
-
- close() - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
-
- close() - Method in class org.janusgraph.graphdb.olap.VertexJobConverter.GraphProvider
-
- 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.vertexcache.GuavaVertexCache
-
- close() - Method in class org.janusgraph.graphdb.transaction.vertexcache.LRUVertexCache
-
- 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.SubqueryIterator
-
- close() - Method in class org.janusgraph.graphdb.util.WorkerPool
-
- close(Duration) - Method in class org.janusgraph.util.system.BackgroundThread
-
- 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
-
- Cmp - Enum in org.janusgraph.core.attribute
-
Basic comparison relations for comparable (i.e.
- 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
-
- CommonsConfiguration() - Constructor for class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
-
- CommonsConfiguration(Configuration) - Constructor for class org.janusgraph.diskstorage.configuration.backend.CommonsConfiguration
-
- CompactMap - Class in org.janusgraph.util.datastructures
-
CompactMap is compact representation of the
Map
interface which is immutable.
- compare(ByteBuffer, ByteBuffer) - Static method in class org.janusgraph.diskstorage.util.ByteBufferUtil
-
Compares two
ByteBuffer
s 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(Object, Object) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- 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(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
-
- 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
-
- 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
-
- 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
-
- 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
-
- ConcurrentBufferAddedRelations - Class in org.janusgraph.graphdb.transaction.addedrelations
-
- ConcurrentBufferAddedRelations() - Constructor for class org.janusgraph.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
-
- 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
-
A LRU cache implementation based upon ConcurrentHashMap and other techniques to reduce
contention and synchronization overhead to utilize multiple CPU cores more effectively.
- ConcurrentLRUCache(int, int, int, int, boolean, boolean, ConcurrentLRUCache.EvictionListener<V>) - Constructor for class org.janusgraph.graphdb.util.ConcurrentLRUCache
-
- ConcurrentLRUCache(int, int) - Constructor for class org.janusgraph.graphdb.util.ConcurrentLRUCache
-
- ConcurrentLRUCache.EvictionListener<V> - Interface in org.janusgraph.graphdb.util
-
- ConcurrentLRUCache.Stats - Class in org.janusgraph.graphdb.util
-
- 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 in QNF
- 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
Condition
s.
- 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
-
- ConsistencyLevel - Enum in org.janusgraph.diskstorage.keycolumnvalue
-
Consistency Levels for transactions.
- 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
-
- 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
-
- 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.
- constructQuery(ElementCategory) - Method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
-
- constructQuery(InternalVertex, BaseVertexCentricQuery) - Method in class org.janusgraph.graphdb.query.vertex.BasicVertexCentricQueryBuilder
-
- 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
-
- Contain - Enum in org.janusgraph.core.attribute
-
Comparison relations for text objects.
- Container() - Constructor for class org.janusgraph.diskstorage.StoreMetaData.Container
-
- Container(boolean) - Constructor for class org.janusgraph.diskstorage.StoreMetaData.Container
-
- contains(Geoshape) - Method in class org.janusgraph.core.attribute.Geoshape
-
Whether this geometry contains the given geometry.
- 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.GuavaVertexCache
-
- contains(long) - Method in class org.janusgraph.graphdb.transaction.vertexcache.LRUVertexCache
-
- contains(long) - Method in interface org.janusgraph.graphdb.transaction.vertexcache.VertexCache
-
Checks whether the cache contains a vertex with the given id
- contains(int) - Method in class org.janusgraph.util.datastructures.ImmutableIntSet
-
- contains(int) - Method in class org.janusgraph.util.datastructures.IntHashSet
-
- contains(int) - Method in interface org.janusgraph.util.datastructures.IntSet
-
- contains(Object) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- containsAll(Collection<?>) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- containsKey(Object) - Method in class org.janusgraph.util.datastructures.CompactMap
-
- 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
-
- 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
-
- 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
-
- containsValue(Object) - Method in class org.janusgraph.util.datastructures.CompactMap
-
- 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
-
- containsVertexLabel(String) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphBlueprintsGraph
-
- containsVertexLabel(String) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
-
- context - Variable in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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.Geoshape.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(RecordIterator<KeyValueEntry>) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.KVUtil
-
- 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.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(Object) - Method in class org.janusgraph.graphdb.database.serialize.NoSerializer
-
- 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.JanusGraphPredicate.Converter
-
- convert(HasContainer) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicate.Converter
-
- convert(ConnectiveP<?>, ConnectiveJanusPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicate.Converter
-
- Converter() - Constructor for class org.janusgraph.graphdb.query.JanusGraphPredicate.Converter
-
- convertInternal(BiPredicate) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicate.Converter
-
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
-
- 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
-
- create(String) - Static method in class org.janusgraph.example.GraphOfTheGodsFactory
-
- create() - Method in interface org.janusgraph.util.datastructures.Factory
-
- 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
.
- createMapb(int) - Static method in class org.janusgraph.util.datastructures.BitMap
-
- createObject(Map<String, Object>) - Method in class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonDeserializerV2d0
-
- createObject(Map) - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierDeserializerV2d0
-
- createPredicateWithValue(String, Object) - Static method in class org.janusgraph.graphdb.tinkerpop.JanusGraphPSerializer
-
- 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.
- 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
-
- g - Variable in class org.janusgraph.graphdb.database.management.AbstractIndexStatusWatcher
-
- GANGLIA_ADDRESSING_MODE - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- GANGLIA_HOST_OR_GROUP - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
The unicast host or multicast group name to which Metrics will send
Ganglia data.
- GANGLIA_INTERVAL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- GANGLIA_PORT - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
The port to which Ganglia data are sent.
- GANGLIA_SPOOF - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
If non-null, it must be a valid Gmetric spoof string formatted as an
IP:hostname pair.
- GANGLIA_TTL - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
The multicast TTL to set on outgoing Ganglia datagrams.
- GANGLIA_USE_PROTOCOL_31 - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
Whether to send data to Ganglia in the 3.1 protocol format (true) or the
3.0 protocol format (false).
- GANGLIA_UUID - Static variable in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
The host UUID to set on outgoing Ganglia datagrams.
- Geo - Enum in org.janusgraph.core.attribute
-
Comparison relations for geographic shapes.
- geoContains(V) - Static method in enum org.janusgraph.core.attribute.Geo
-
- geoDisjoint(V) - Static method in enum org.janusgraph.core.attribute.Geo
-
- geoIntersect(V) - Static method in enum org.janusgraph.core.attribute.Geo
-
- geojsonReader - Variable in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- geojsonWriter - Variable in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- Geoshape - Class in org.janusgraph.core.attribute
-
A generic representation of a geographic shape, which can either be a single point,
circle, box, line or polygon.
- Geoshape(Shape) - Constructor for class org.janusgraph.core.attribute.Geoshape
-
- geoshape(Shape) - Static method in class org.janusgraph.core.attribute.Geoshape
-
Constructs a Geoshape from a spatial4j Shape
.
- geoshape(Geometry) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- Geoshape.GeoshapeBinarySerializer - Class in org.janusgraph.core.attribute
-
Geoshape binary serializer using spatial4j's BinaryCodec
.
- Geoshape.GeoShapeGryoSerializer - Class in org.janusgraph.core.attribute
-
Geoshape serializer for TinkerPop's Gryo.
- Geoshape.GeoshapeGsonDeserializerV1d0 - Class in org.janusgraph.core.attribute
-
Geoshape deserializer for GraphSON 1.0 supporting reading from GeoJSON (http://geojson.org/).
- Geoshape.GeoshapeGsonDeserializerV2d0 - Class in org.janusgraph.core.attribute
-
Geoshape deserializer for GraphSON 2.0 supporting reading from GeoJSON (http://geojson.org/).
- Geoshape.GeoshapeGsonSerializerV1d0 - Class in org.janusgraph.core.attribute
-
Geoshape serializer for GraphSON 1.0 supporting writing GeoJSON (http://geojson.org/).
- Geoshape.GeoshapeGsonSerializerV2d0 - Class in org.janusgraph.core.attribute
-
Geoshape serializer for GraphSON 2.0 supporting writing GeoJSON (http://geojson.org/).
- Geoshape.GeoshapeSerializer - Class in org.janusgraph.core.attribute
-
Geoshape attribute serializer for JanusGraph.
- Geoshape.Point - Class in org.janusgraph.core.attribute
-
A single point representation.
- Geoshape.Type - Enum in org.janusgraph.core.attribute
-
The Type of a shape: a point, box, circle, line or polygon.
- GeoshapeBinarySerializer() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeBinarySerializer
-
- GeoShapeGryoSerializer() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoShapeGryoSerializer
-
- GeoshapeGsonDeserializerV1d0() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonDeserializerV1d0
-
- GeoshapeGsonDeserializerV2d0() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonDeserializerV2d0
-
- GeoshapeGsonSerializerV1d0() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonSerializerV1d0
-
- GeoshapeGsonSerializerV2d0() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonSerializerV2d0
-
- GeoshapeSerializer() - Constructor for class org.janusgraph.core.attribute.Geoshape.GeoshapeSerializer
-
- geoWithin(V) - Static method in enum org.janusgraph.core.attribute.Geo
-
- 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>, 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>, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
-
- get(ConfigOption<O>, 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
-
- get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.IndexRetriever
-
- get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.Retriever
-
- get(String) - Method in interface org.janusgraph.diskstorage.indexing.KeyInformation.StoreRetriever
-
- 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
-
- 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.VertexJobConverter.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(long[]) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- get(int[]) - Static method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- 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 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(long, Retriever<Long, InternalVertex>) - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
-
- get(long, Retriever<Long, InternalVertex>) - Method in class org.janusgraph.graphdb.transaction.vertexcache.LRUVertexCache
-
- 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
-
- get(Object) - Method in class org.janusgraph.util.datastructures.CompactMap
-
- get() - Method in class org.janusgraph.util.datastructures.LongCounter
-
- 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.SimpleAddedRelations
-
- getAll() - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- getAll() - Method in class org.janusgraph.graphdb.transaction.lock.LockTuple
-
- getAll() - Method in class org.janusgraph.util.datastructures.ImmutableIntSet
-
- getAll() - Method in class org.janusgraph.util.datastructures.IntHashSet
-
- getAll() - Method in interface org.janusgraph.util.datastructures.IntSet
-
- getAllContainedIDs() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
-
- getAllManagerClasses() - Static method in enum org.janusgraph.diskstorage.StandardStoreManager
-
- getAllNew() - Method in class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
-
- getAllNew() - Method in class org.janusgraph.graphdb.transaction.vertexcache.LRUVertexCache
-
- 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
-
- getBinaryCodec() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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
-
- 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
-
- getCardinality() - Method in class org.janusgraph.diskstorage.indexing.StandardKeyInformation
-
- getCardinality() - Method in class org.janusgraph.graphdb.schema.RelationTypeDefinition
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- getContext() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- getConvergedKeys() - Method in class org.janusgraph.graphdb.database.management.GraphIndexStatusReport
-
- getConversionFunction(ElementCategory) - Method in class org.janusgraph.graphdb.transaction.StandardJanusGraphTx
-
- getCount(int) - Method in class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- getCount(K) - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- getCounter(String) - Method in enum org.janusgraph.util.stats.MetricManager
-
- getCounter(String, String...) - Method in enum org.janusgraph.util.stats.MetricManager
-
- getCountSave(K) - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- getCumulativeEvictions() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCumulativeHits() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCumulativeLookups() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCumulativeMisses() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCumulativeNonLivePuts() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCumulativePuts() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- getCurrentSize() - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache.Stats
-
- 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 class org.janusgraph.graphdb.schema.PropertyKeyDefinition
-
- 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
-
- 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
-
- 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
-
- getEdgeLabel(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
-
- 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
-
- 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 class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
-
- 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.inmemory.InMemoryStoreManager
-
- 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.MetricInstrumentedStoreManager
-
- getFeatures() - Method in class org.janusgraph.graphdb.database.indexing.StandardIndexInformation
-
- 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
-
- 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
-
- getGeojsonReader() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- getGeojsonWriter() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- getGeometryCollectionBuilder() - Static method in class org.janusgraph.core.attribute.Geoshape
-
- getGlobalRange(int) - Static method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
-
- getGlobalSystemConfig() - Method in class org.janusgraph.diskstorage.Backend
-
- getGlobalSystemConfig(Backend) - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- getGraphNames() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
-
- getGraphs() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
-
Deprecated.
- 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
-
- getHasContainers() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getHeader() - Method in class org.janusgraph.graphdb.database.log.TransactionLogHeader.Entry
-
- getHeapArray() - Method in class org.janusgraph.graphdb.util.PriorityQueue
-
This method returns the internal heap array as Object[].
- getHighLimit() - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- getHighLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
-
- 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
-
- 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
-
- getIdUpperBound() - Method in class org.janusgraph.graphdb.database.idassigner.placement.PartitionIDRange
-
- getIdUpperBound(int) - Method in class org.janusgraph.graphdb.database.idassigner.StaticIDBlockSizer
-
- 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.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
- 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
-
- 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
-
- getIndexJobStatus(Index) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- getIndexJobStatus(Index) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
-
- getIndexName() - Method in class org.janusgraph.graphdb.database.management.AbstractIndexStatusReport
-
- 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
-
- 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.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(boolean) - Static method in class org.janusgraph.graphdb.management.JanusGraphManager
-
- getInstance() - Static method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModuleV1d0
-
- getInstance() - Static method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModuleV2d0
-
- getInstance() - Static method in class org.janusgraph.graphdb.tinkerpop.JanusGraphIoRegistry
-
- getInstance() - Static method in class org.janusgraph.graphdb.tinkerpop.JanusGraphIoRegistryV1d0
-
- 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
-
- getInVertexId() - Method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- getIteration() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraMemory
-
- 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
-
- 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
-
- 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.inmemory.InMemoryKeyColumnValueStore
-
- getKeys(SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
-
- getKeys(KeyRangeQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.KCVSProxy
-
- getKeys(SliceQuery, 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(KeyRangeQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
-
- getKeys(SliceQuery, 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
-
- 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
-
- getLatitude() - Method in class org.janusgraph.core.attribute.Geoshape.Point
-
Latitude of this point
- 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(List<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- getLocalHighLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- getLocalHighLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getLocalHighLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.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.inmemory.InMemoryStoreManager
-
- 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 KeyRange
s locally hosted on this machine.
- getLocalKeyPartition() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedStoreManager
-
- getLocalLowLimit(List<HasContainer>) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- getLocalLowLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- getLocalLowLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getLocalLowLimit(List<HasContainer>) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- 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
-
- getLongitude() - Method in class org.janusgraph.core.attribute.Geoshape.Point
-
Longitude of this point
- getLongRepresentation() - Method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- 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 interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- getLowLimit() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
-
- 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
-
- 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
-
- getMaxCommitTime() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- getMaxObject() - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- 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
-
- getMessageCombiner(VertexProgram<M>) - Static method in class org.janusgraph.graphdb.olap.computer.FulgoraUtil
-
- 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
-
- getMetricsPrefix() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- getMultiplicity() - Method in class org.janusgraph.graphdb.types.StandardRelationTypeMaker
-
- getMutableVertexProperties() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexMemory
-
- getN() - Method in class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- 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.inmemory.InMemoryKeyColumnValueStore
-
- getName() - Method in class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
-
- 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
-
- 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
-
- getNumCompactions() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- getNumProcessed() - Method in class org.janusgraph.core.schema.JobStatus
-
- getObjects() - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- 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
-
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) - 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) - 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
-
- 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.graphdb.query.vertex.BaseVertexCentricQuery
-
- getOrders() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- getOrders() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
-
- getOrGenerateUniqueInstanceId(Configuration) - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- getOutVertexId() - Method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- 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, String...) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
-
- getPath(ConfigElement, boolean, String...) - Static method in class org.janusgraph.diskstorage.configuration.ConfigElement
-
- getPath(File) - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- getPoint(int) - Method in class org.janusgraph.core.attribute.Geoshape
-
Returns the point at the given position.
- getPoint() - Method in class org.janusgraph.core.attribute.Geoshape
-
Returns the singleton point of this shape.
- getPoint(Geoshape, int) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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
-
- getProfiler() - Method in class org.janusgraph.graphdb.query.BackendQueryHolder
-
- getProfiler() - Method in class org.janusgraph.graphdb.query.graph.JointIndexQuery.Subquery
-
- 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
-
- getPropertyKey(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
-
- 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
-
- 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(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
-
- getRadius() - Method in class org.janusgraph.core.attribute.Geoshape
-
Returns the radius in kilometers of this circle.
- getRandom() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- getRegisteredAttributeClasses(Configuration) - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- getRelationId() - Method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- getRelationIndex(RelationType, String) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- getRelationIndex(RelationType, String) - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
-
- getRelationIndexes(RelationType) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- 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
-
- getRelationType(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
-
- 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
-
- 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
-
- 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
-
This method can be overridden by extending classes to return a sentinel
object which will be used by the
PriorityQueue.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
-
- getShape() - Method in class org.janusgraph.core.attribute.Geoshape
-
Returns the underlying Shape
.
- getShapeFactory() - Static method in class org.janusgraph.core.attribute.Geoshape
-
- 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.inmemory.InMemoryKeyColumnValueStore
-
- getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
-
- 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
-
- 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
-
- 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
-
- getSpatialContext() - Static method in class org.janusgraph.core.attribute.Geoshape
-
- getStandaloneGlobalConfiguration(KeyColumnValueStoreManager, Configuration) - Static method in class org.janusgraph.diskstorage.Backend
-
- 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
-
- 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
-
- 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
-
- 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
-
- getSystemMetricsPrefix() - Static method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- 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
-
- getTotal() - Method in class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- getTotalMutations() - Method in class org.janusgraph.diskstorage.Mutation
-
- 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
-
- getTraversalSources() - Method in class org.janusgraph.graphdb.management.JanusGraphManager
-
Deprecated.
- getTTL(JanusGraphSchemaType) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- 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.attribute.Geoshape
-
- getType(Shape) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- getType() - Method in interface org.janusgraph.core.JanusGraphRelation
-
Returns the type of this relation.
- getType() - Method in interface org.janusgraph.core.schema.RelationTypeIndex
-
- 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
-
- getTypeDefinitions() - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule
-
- getTypeId() - Method in class org.janusgraph.graphdb.relations.RelationIdentifier
-
- getTypeNamespace() - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule
-
- 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
-
- 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
-
- getValues() - Method in class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- 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.VertexJobConverter
-
- 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
-
- getVertexLabel(String) - Method in interface org.janusgraph.graphdb.schema.SchemaProvider
-
- 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
-
- getVertexLabels() - Method in class org.janusgraph.graphdb.database.management.ManagementSystem
-
- getVertexLabels() - Method in class org.janusgraph.graphdb.schema.SchemaContainer
-
- 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
-
- 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.ConcurrentBufferAddedRelations
-
- getView(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
-
- getView(Predicate<InternalRelation>) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- getWildcardField() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
-
- getWktReader() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- getWktWriter() - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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
-
- 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.job.IndexUpdateJob
-
- graph - Variable in class org.janusgraph.graphdb.olap.VertexJobConverter
-
- graph() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
-
- graph() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphFeatures
-
- 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
-
- 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
-
- GraphCentricQueryBuilder(StandardJanusGraphTx, IndexSerializer) - 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) - Constructor for class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- 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
-
- 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() - Constructor for class org.janusgraph.graphdb.olap.VertexJobConverter.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
-
- gsonEquals(String) - Method in enum org.janusgraph.core.attribute.Geoshape.Type
-
- 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
-
- GuavaVertexCache - Class in org.janusgraph.graphdb.transaction.vertexcache
-
- GuavaVertexCache(long, int, int) - Constructor for class org.janusgraph.graphdb.transaction.vertexcache.GuavaVertexCache
-
- 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, String...) - Method in class org.janusgraph.diskstorage.configuration.BasicConfiguration
-
- has(ConfigOption, String...) - Method in interface org.janusgraph.diskstorage.configuration.Configuration
-
- has(ConfigOption, String...) - Method in class org.janusgraph.diskstorage.configuration.MergedConfiguration
-
- has(ConfigOption, 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
-
- HAS_CONTAINS - Static variable in enum org.janusgraph.core.attribute.Text
-
- 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
-
- 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
- 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
-
- 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.AttributeUtil
-
- hasGroupName() - Method in interface org.janusgraph.diskstorage.BaseTransactionConfig
-
- 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.attribute.Geoshape
-
- 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.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.IncidenceDirectionCondition
-
- 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.RelationIdentifier
-
- hashCode() - Method in class org.janusgraph.graphdb.relations.SimpleJanusGraphProperty
-
- hashCode() - Method in class org.janusgraph.graphdb.schema.SchemaElementDefinition
-
- hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder.OrderEntry
-
- hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- hashCode() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
-
- 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.ImmutableIntSet
-
- hashCode() - Method in class org.janusgraph.util.datastructures.IntHashSet
-
- 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 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
- 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
-
- hasMutations() - Method in class org.janusgraph.diskstorage.configuration.TransactionalConfiguration
-
- hasName() - Method in enum org.janusgraph.graphdb.internal.JanusGraphSchemaCategory
-
- hasNegation() - Method in enum org.janusgraph.core.attribute.Cmp
-
- hasNegation() - Method in enum org.janusgraph.core.attribute.Contain
-
- hasNegation() - Method in enum org.janusgraph.core.attribute.Text
-
- hasNegation() - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
-
- hasNegation() - Method in interface org.janusgraph.graphdb.query.JanusGraphPredicate
-
Whether this predicate has a predicate that is semantically its negation.
- hasNext() - Method in class org.janusgraph.diskstorage.util.MetricInstrumentedIterator
-
- 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
-
- hasNext() - Method in class org.janusgraph.graphdb.util.MultiDistinctOrderedIterator
-
- hasNext() - Method in class org.janusgraph.graphdb.util.SubqueryIterator
-
- hasNext() - Method in class org.janusgraph.graphdb.vertices.RemovableRelationIterator
-
- hasNext() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- 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
-
- hasObject(K) - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- 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
-
- 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
-
- HasStepFolder.OrderEntry - Class in org.janusgraph.graphdb.tinkerpop.optimize
-
- 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
-
- 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.
- HELPER - Static variable in class org.janusgraph.core.attribute.Geoshape
-
- 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
-
- 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
-
- ignoreUndefinedQueryTypes() - Method in interface org.janusgraph.core.schema.DefaultSchemaMaker
-
Whether to ignore undefined types occurring in a query.
- ignoreUndefinedQueryTypes() - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphDefaultSchemaMaker
-
- ignoreUndefinedQueryTypes() - Method in class org.janusgraph.graphdb.tinkerpop.Tp3DefaultSchemaMaker
-
- ignoreUndefinedQueryTypes() - Method in class org.janusgraph.graphdb.types.typemaker.DisableDefaultSchemaMaker
-
- ILLEGAL_CHARS - Static variable in class org.janusgraph.diskstorage.configuration.ConfigElement
-
- ImmutableIntSet - Class in org.janusgraph.util.datastructures
-
Immutable set of integers
- ImmutableIntSet(int[]) - Constructor for class org.janusgraph.util.datastructures.ImmutableIntSet
-
- ImmutableIntSet(int) - Constructor for class org.janusgraph.util.datastructures.ImmutableIntSet
-
- 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
-
- incBy(K, double) - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
Increases the count of object o by inc and returns the new count value
- IncidenceCondition<E extends JanusGraphRelation> - Class in org.janusgraph.graphdb.query.condition
-
- IncidenceCondition(JanusGraphVertex, JanusGraphVertex) - Constructor for class org.janusgraph.graphdb.query.condition.IncidenceCondition
-
- IncidenceDirectionCondition<E extends JanusGraphRelation> - Class in org.janusgraph.graphdb.query.condition
-
- IncidenceDirectionCondition(Direction, JanusGraphVertex) - Constructor for class org.janusgraph.graphdb.query.condition.IncidenceDirectionCondition
-
- 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
-
- increment(long) - Method in class org.janusgraph.util.datastructures.LongCounter
-
- 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
-
- 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
-
- IndexCache - Interface in org.janusgraph.graphdb.transaction.indexcache
-
- indexCover(CompositeIndexType, Condition<JanusGraphElement>, Set<Condition>) - Static method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
-
- indexCover(MixedIndexType, Condition<JanusGraphElement>, IndexSerializer, Set<Condition>) - Static method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
-
- indexCoversOrder(MixedIndexType, OrderList) - Static method in class org.janusgraph.graphdb.query.graph.GraphCentricQueryBuilder
-
- 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, ImmutableSet<Mapping>, String, ImmutableSet<Cardinality>, 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(List<IndexEntry>, List<IndexEntry>, boolean, boolean) - Constructor for class org.janusgraph.diskstorage.indexing.IndexMutation
-
- IndexMutation(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
-
- indexOf(int[], int) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- indexOfMin(double[]) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- 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
-
- 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
-
- 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
-
- 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.VertexJobConverter.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
-
- InMemoryKeyColumnValueStore - Class in org.janusgraph.diskstorage.keycolumnvalue.inmemory
-
- InMemoryKeyColumnValueStore(String) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
-
- InMemoryStoreManager - Class in org.janusgraph.diskstorage.keycolumnvalue.inmemory
-
In-memory backend storage engine.
- InMemoryStoreManager() - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
-
- InMemoryStoreManager(Configuration) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
-
- insert(StaticBuffer, StaticBuffer, StoreTransaction) - Method in interface org.janusgraph.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
-
Inserts the given key-value pair into the store.
- insertSortedInc(long[], long) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- insertWithOverflow(T) - Method in class org.janusgraph.graphdb.util.PriorityQueue
-
Adds an Object to a PriorityQueue in log(size) time.
- INSTANCE - Static variable in class org.janusgraph.diskstorage.util.NoLock
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.database.indexing.StandardIndexInformation
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.database.serialize.attribute.LongSerializer
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.tinkerpop.JanusGraphDefaultSchemaMaker
-
- instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.AdjacentVertexFilterOptimizerStrategy
-
- instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphLocalQueryOptimizerStrategy
-
- instance() - Static method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStepStrategy
-
- instance() - Static method in class org.janusgraph.graphdb.tinkerpop.plugin.JanusGraphGremlinPlugin
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.tinkerpop.Tp3DefaultSchemaMaker
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.transaction.lock.FakeLock
-
- INSTANCE - Static variable in class org.janusgraph.graphdb.types.typemaker.DisableDefaultSchemaMaker
-
- instanceConnectiveJanusPredicate(P<?>) - Static method in class org.janusgraph.graphdb.query.JanusGraphPredicate.Converter
-
- 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
-
- 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
-
- IntegerDoubleFrequency - Class in org.janusgraph.util.stats
-
Count relative integer frequencies
- IntegerDoubleFrequency() - Constructor for class org.janusgraph.util.stats.IntegerDoubleFrequency
-
- 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
-
- 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(Geoshape) - Method in class org.janusgraph.core.attribute.Geoshape
-
Whether this geometry has any points in common with the given geometry.
- 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
-
- IntHashSet - Class in org.janusgraph.util.datastructures
-
Implementation of
IntSet
against
IntIntHashMap
.
- IntHashSet() - Constructor for class org.janusgraph.util.datastructures.IntHashSet
-
- IntHashSet(int) - Constructor for class org.janusgraph.util.datastructures.IntHashSet
-
- IntSet - 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(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
-
- isBatchLoading() - Method in class org.janusgraph.graphdb.configuration.GraphDatabaseConfiguration
-
- isCachable() - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.JanusGraphPDeserializerV2d0
-
- 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
-
- 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
-
- isDecimal(Number) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- isDecimal(Class<?>) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- 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
-
- 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 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.ConcurrentBufferAddedRelations
-
- isEmpty() - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- isEmpty() - Method in class org.janusgraph.util.datastructures.CompactMap
-
- 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.RandomRemovalList
-
- isEmpty() - Method in class org.janusgraph.util.datastructures.RangeInterval
-
- isExhaustedPartition(int) - Method in class org.janusgraph.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
-
- 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
-
- isGeo(Class<?>) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- isGhostVertex(long, EntryList) - Method in class org.janusgraph.graphdb.olap.VertexJobConverter
-
- 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 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
-
- 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
-
- isJts(Shape) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- isKeyConsistent() - Method in enum org.janusgraph.diskstorage.keycolumnvalue.ConsistencyLevel
-
- 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.
- 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 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
-
- isMutationStarted() - Method in class org.janusgraph.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
-
- isNamespace() - Method in class org.janusgraph.diskstorage.configuration.ConfigElement
-
- 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
-
- 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.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 interface org.janusgraph.core.JanusGraphRelation
-
Gets the value of the property property.
- isProperty() - Method in class org.janusgraph.graphdb.olap.computer.FulgoraVertexProperty
-
Gets the value of the property property.
- isProperty() - Method in class org.janusgraph.graphdb.relations.AbstractEdge
-
Gets the value of the property property.
- isProperty() - Method in class org.janusgraph.graphdb.relations.AbstractVertexProperty
-
Gets the value of the property property.
- isProperty() - Method in enum org.janusgraph.graphdb.types.TypeDefinitionCategory
-
Gets the value of the property property.
- 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.VertexJobConverter.GraphProvider
-
- isQNF() - Method in enum org.janusgraph.core.attribute.Cmp
-
- isQNF() - Method in enum org.janusgraph.core.attribute.Contain
-
- isQNF() - Method in enum org.janusgraph.core.attribute.Geo
-
- isQNF() - Method in enum org.janusgraph.core.attribute.Text
-
- isQNF() - Method in class org.janusgraph.graphdb.predicate.AndJanusPredicate
-
- isQNF() - Method in class org.janusgraph.graphdb.predicate.OrJanusPredicate
-
- isQNF() - Method in interface org.janusgraph.graphdb.query.JanusGraphPredicate
-
Returns true if this predicate is in query normal form.
- 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 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
ByteBuffer
s 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
ByteBuffer
s 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.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
-
- isSortedInc(long[]) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- isSortedInc(int[]) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- 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
-
- isStatic() - Method in class org.janusgraph.graphdb.types.system.BaseVertexLabel
-
- isStatic() - Method in class org.janusgraph.graphdb.types.VertexLabelVertex
-
- isString(Object) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- isString(Class<?>) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- 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
-
- isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.EdgeLabelDefinition
-
- isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.PropertyKeyDefinition
-
- isUnidirected(Direction) - Method in class org.janusgraph.graphdb.schema.RelationTypeDefinition
-
- 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 enum org.janusgraph.core.attribute.Contain
-
- isValidCondition(Object) - Method in enum org.janusgraph.core.attribute.Geo
-
- isValidCondition(Object) - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
-
- isValidCondition(Object) - Method in interface org.janusgraph.graphdb.query.JanusGraphPredicate
-
Whether the given condition is a valid condition for this predicate.
- isValidConstraint(JanusGraphSchemaType) - Method in enum org.janusgraph.graphdb.internal.ElementCategory
-
- isValidCoordinate(double, double) - Static method in class org.janusgraph.core.attribute.Geoshape
-
Whether the given coordinates mark a point on earth.
- 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
-
- isValidTypeModifierDefinition(Set<TypeDefinitionCategory>) - Method in class org.janusgraph.graphdb.types.TypeDefinitionMap
-
- isValidValueType(Class<?>) - Method in enum org.janusgraph.core.attribute.Contain
-
- isValidValueType(Class<?>) - Method in enum org.janusgraph.core.attribute.Geo
-
- isValidValueType(Class<?>) - Method in enum org.janusgraph.core.attribute.Text
-
- isValidValueType(Class<?>) - Method in class org.janusgraph.graphdb.predicate.ConnectiveJanusPredicate
-
- isValidValueType(Class<?>) - Method in interface org.janusgraph.graphdb.query.JanusGraphPredicate
-
Whether the given class is a valid data type for a value to which this predicate may be applied.
- 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
-
- isWholeNumber(Number) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- isWholeNumber(Class<?>) - Static method in class org.janusgraph.graphdb.database.serialize.AttributeUtil
-
- 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
-
- iterator() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- random - Static variable in class org.janusgraph.util.datastructures.RandomRemovalList
-
- RandomRemovalList<T> - Class in org.janusgraph.util.datastructures
-
A list that allows efficient random removals.
- RandomRemovalList() - Constructor for class org.janusgraph.util.datastructures.RandomRemovalList
-
- RandomRemovalList(int) - Constructor for class org.janusgraph.util.datastructures.RandomRemovalList
-
- RandomRemovalList(Collection<T>) - Constructor for class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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.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(InputStream) - Static method in class org.janusgraph.core.attribute.Geoshape.GeoshapeBinarySerializer
-
Deserialize a geoshape.
- read(Kryo, Input, Class<Geoshape>) - Method in class org.janusgraph.core.attribute.Geoshape.GeoShapeGryoSerializer
-
- read(ScanBuffer) - Method in class org.janusgraph.core.attribute.Geoshape.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.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
-
- read(ScanBuffer) - Method in class org.janusgraph.graphdb.database.serialize.NoSerializer
-
- read(Kryo, Input, Class<P>) - Method in class org.janusgraph.graphdb.tinkerpop.JanusGraphPSerializer
-
- 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.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
-
- 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
-
- ReadOnlyKeyColumnValueStore - Class in org.janusgraph.diskstorage.keycolumnvalue
-
- ReadOnlyKeyColumnValueStore(KeyColumnValueStore) - Constructor for class org.janusgraph.diskstorage.keycolumnvalue.ReadOnlyKeyColumnValueStore
-
- 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
-
- readShape(DataInputStream) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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.
- 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(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
-
- 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
-
- RelationIdentifier - Class in org.janusgraph.graphdb.relations
-
- RelationIdentifierDeserializerV1d0() - Constructor for class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierDeserializerV1d0
-
- RelationIdentifierDeserializerV2d0() - Constructor for class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierDeserializerV2d0
-
- RelationIdentifierSerializerV1d0() - Constructor for class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV1d0
-
- RelationIdentifierSerializerV2d0() - Constructor for class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV2d0
-
- 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
-
- relations() - Method in class org.janusgraph.graphdb.query.vertex.VertexCentricQueryBuilder
-
- RelationType - Interface in org.janusgraph.core
-
- 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
-
- RelationTypeDefinition(String, long, Multiplicity) - Constructor for class org.janusgraph.graphdb.schema.RelationTypeDefinition
-
- 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
-
- 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
-
- RemovableRelationIterable(Iterable<InternalRelation>) - Constructor for class org.janusgraph.graphdb.vertices.RemovableRelationIterable
-
- RemovableRelationIterator<O extends JanusGraphRelation> - Class in org.janusgraph.graphdb.vertices
-
- RemovableRelationIterator(Iterator<InternalRelation>) - Constructor for class org.janusgraph.graphdb.vertices.RemovableRelationIterator
-
- 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.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.ConcurrentBufferAddedRelations
-
- remove(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleAddedRelations
-
- remove(InternalRelation) - Method in class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- remove(JanusGraphVertexProperty) - Method in class org.janusgraph.graphdb.transaction.indexcache.ConcurrentIndexCache
-
- 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
-
Removing edges is not supported!
- remove(Long) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
-
- 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
-
- remove() - Method in class org.janusgraph.graphdb.vertices.StandardVertex
-
- remove(Object) - Method in class org.janusgraph.util.datastructures.CompactMap
-
- remove() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- remove(Object) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- remove() - Method in interface org.janusgraph.util.datastructures.Removable
-
- remove(String) - Method in enum org.janusgraph.util.stats.MetricManager
-
- removeAll(Collection<?>) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- removeCsvReporter() - Method in enum org.janusgraph.util.stats.MetricManager
-
- 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
-
- removeGangliaReporter() - Method in enum org.janusgraph.util.stats.MetricManager
-
Stop a GangliaReporter
previously created by a call to
#addGangliaReporter(String, int, UDPAddressingMode, int, Boolean, UUID, String, Duration)
and release it for GC.
- removeGraph(String) - Method in class org.janusgraph.graphdb.management.JanusGraphManager
-
- removeGraphiteReporter() - Method in enum org.janusgraph.util.stats.MetricManager
-
- removeJmxReporter() - Method in enum org.janusgraph.util.stats.MetricManager
-
- 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
-
- removeObject(K) - Method in class org.janusgraph.util.stats.ObjectAccumulator
-
- 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
-
- 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
-
- 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.JanusGraphPropertiesStep
-
- reset() - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- 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
-
- 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
-
- 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
-
- retainAll(Collection<?>) - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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
-
- 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(int, ScanMetrics) - Method in class org.janusgraph.graphdb.olap.computer.PartitionedVertexProgramExecutor
-
- run() - Method in class org.janusgraph.util.system.BackgroundThread
-
- 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_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
-
- SchemaContainer(JanusGraph) - Constructor for class org.janusgraph.graphdb.schema.SchemaContainer
-
- 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
-
- SchemaElementDefinition(String, long) - Constructor for class org.janusgraph.graphdb.schema.SchemaElementDefinition
-
- 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
-
- 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
-
JanusGraph represents element identifiers as longs, but not all numbers
in the representable space of longs are valid.
- SchemaViolationException(String) - Constructor for exception org.janusgraph.core.SchemaViolationException
-
- SchemaViolationException(String, Object...) - Constructor for exception org.janusgraph.core.SchemaViolationException
-
- 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
-
- SerializableSerializer() - Constructor for class org.janusgraph.graphdb.database.serialize.attribute.SerializableSerializer
-
- serialize(Geoshape, JsonGenerator, SerializerProvider) - Method in class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonSerializerV1d0
-
- serialize(RelationIdentifier, JsonGenerator, SerializerProvider) - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV1d0
-
- serialize(RelationIdentifier, JsonGenerator, SerializerProvider) - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV2d0
-
- 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
-
- 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
-
- serializeWithType(Geoshape, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonSerializerV1d0
-
- serializeWithType(Geoshape, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.janusgraph.core.attribute.Geoshape.GeoshapeGsonSerializerV2d0
-
- serializeWithType(RelationIdentifier, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV1d0
-
- serializeWithType(RelationIdentifier, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class org.janusgraph.graphdb.tinkerpop.io.graphson.JanusGraphSONModule.RelationIdentifierSerializerV2d0
-
- 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
-
- set(long) - Method in class org.janusgraph.util.datastructures.LongCounter
-
- setAccessCheck(PreloadedVertex.AccessCheck) - Method in class org.janusgraph.graphdb.vertices.PreloadedVertex
-
- setAlive(boolean) - Method in class org.janusgraph.graphdb.util.ConcurrentLRUCache
-
- 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
-
- 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
-
- setConsistency(JanusGraphSchemaElement, ConsistencyModifier) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- 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)
- 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.VertexJobConverter.GraphProvider
-
- setGraphConfiguration(Configuration) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
-
- setHighLimit(Integer) - 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
-
- 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
-
- 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.HasStepFolder
-
- setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- setLimit(int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.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(List<HasContainer>, int, int) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- setLocalLimit(List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- setLocalLimit(List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- setLocalLimit(List<HasContainer>, int, int) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.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(Integer) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.QueryInfo
-
- setMaxOperationWaitTime(Duration) - Method in class org.janusgraph.diskstorage.configuration.backend.KCVSConfiguration
-
- 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.JanusGraphPropertiesStep
-
- setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphStep
-
- setMetrics(MutableMetrics) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.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
-
- 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
-
- setTimestampProvider(TimestampProvider) - Method in class org.janusgraph.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
-
- setTTL(JanusGraphSchemaType, Duration) - Method in interface org.janusgraph.core.schema.JanusGraphManagement
-
- 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
- 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.
- setUseCallerLoader(boolean) - Method in enum org.janusgraph.core.util.ReflectiveConfigOptionLoader
-
- setUseMultiQuery(boolean) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphPropertiesStep
-
- setUseMultiQuery(boolean) - Method in class org.janusgraph.graphdb.tinkerpop.optimize.JanusGraphVertexStep
-
- setUseMultiQuery(boolean) - Method in interface org.janusgraph.graphdb.tinkerpop.optimize.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
-
- 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
-
- SimpleBufferAddedRelations - Class in org.janusgraph.graphdb.transaction.addedrelations
-
- SimpleBufferAddedRelations() - Constructor for class org.janusgraph.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
-
- 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
-
- 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
-
- simplifyQNF(Condition<E>) - Static method in class org.janusgraph.graphdb.query.QueryUtil
-
- singleton(long) - Static method in class org.janusgraph.util.datastructures.AbstractLongListUtil
-
- size() - Method in class org.janusgraph.core.attribute.Geoshape
-
Returns the number of points comprising this geoshape.
- size(Shape) - Method in class org.janusgraph.core.attribute.JtsGeoshapeHelper
-
- 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
-
- size() - Method in class org.janusgraph.graphdb.util.PriorityQueue
-
Returns the number of elements currently stored in the PriorityQueue.
- size() - Method in class org.janusgraph.util.datastructures.CompactMap
-
- size() - Method in class org.janusgraph.util.datastructures.ImmutableIntSet
-
- size() - Method in interface org.janusgraph.util.datastructures.IntSet
-
- size(Iterable) - Static method in class org.janusgraph.util.datastructures.IterablesUtil
-
- size() - Method in class org.janusgraph.util.datastructures.RandomRemovalList
-
- 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(StoreTransaction, 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
-
- 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) - 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>, Iterable<HasContainer>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.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
-
- StandardIndexInformation - Class in org.janusgraph.graphdb.database.indexing
-
- 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
-
- 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
-
- StandardStoreFeatures.Builder - Class in org.janusgraph.diskstorage.keycolumnvalue
-
- StandardStoreManager - Enum in org.janusgraph.diskstorage
-
This enum is only intended for use by JanusGraph internals.
- StandardTransactionBuilder - Class in org.janusgraph.graphdb.transaction
-
- 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) - Static method in class org.janusgraph.graphdb.olap.VertexJobConverter
-
- startTransactionRecovery(JanusGraph, Instant) - Static method in class org.janusgraph.core.JanusGraphFactory
-
- 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
-
- 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
-
- 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
-
A unique identifier for the machine running the JanusGraph instance.
- 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
-
- storageConfig - Variable in class org.janusgraph.diskstorage.common.AbstractStoreManager
-
- 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
-
- 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
-
- SubqueryIterator - Class in org.janusgraph.graphdb.util
-
- SubqueryIterator(JointIndexQuery.Subquery, IndexSerializer, BackendTransaction, Cache<JointIndexQuery.Subquery, List<Object>>, 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
-
- 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
-
- sum(int[]) - Static method in class org.janusgraph.util.datastructures.ArraysUtil
-
- 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.graphdb.database.indexing.StandardIndexInformation
-
- supports(KeyInformation) - Method in class org.janusgraph.graphdb.database.indexing.StandardIndexInformation
-
- 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.JanusGraphPredicate.Converter
-
- supports(String) - Method in interface org.janusgraph.graphdb.vertices.PreloadedVertex.PropertyMixing
-
- supportsAnyTTL(StoreFeatures) - Static method in class org.janusgraph.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
-
- 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
-
- supportsGeoContains() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures.Builder
-
- supportsGeoContains() - Method in class org.janusgraph.diskstorage.indexing.IndexFeatures
-
- supportsInterruption() - Method in interface org.janusgraph.diskstorage.IDAuthority
-
- 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
-
- validate(String) - Static method in class org.janusgraph.util.system.ConfigurationLint
-
- 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.HasStepFolder
-
- validJanusGraphHas(HasContainer) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- validJanusGraphHas(Iterable<HasContainer>) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- validJanusGraphOrder(OrderGlobalStep, Traversal, boolean) - Static method in interface org.janusgraph.graphdb.tinkerpop.optimize.HasStepFolder
-
- 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.attribute.Cmp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.janusgraph.core.attribute.Contain
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.janusgraph.core.attribute.Geo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.janusgraph.core.attribute.Geoshape.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.janusgraph.core.attribute.Text
-
Returns the enum constant of this type with the specified name.
- 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.ConsistencyLevel
-
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.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.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 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.attribute.Cmp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.janusgraph.core.attribute.Contain
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.janusgraph.core.attribute.Geo
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.janusgraph.core.attribute.Geoshape.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.janusgraph.core.attribute.Text
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- 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.ConsistencyLevel
-
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.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.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() - Method in class org.janusgraph.util.datastructures.CompactMap
-
- 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.Geoshape.GeoshapeSerializer
-
- 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(V) - Method in class org.janusgraph.graphdb.database.serialize.NoSerializer
-
- 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
-
- 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
-
- 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
-
- VertexJobConverter.GraphProvider - Class in org.janusgraph.graphdb.olap
-
- 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
-
- VertexLabelDefinition(String, long, boolean, boolean) - Constructor for class org.janusgraph.graphdb.schema.VertexLabelDefinition
-
- VertexLabelDefinition(VertexLabel) - Constructor for class org.janusgraph.graphdb.schema.VertexLabelDefinition
-
- VertexLabelEdge - Static variable in class org.janusgraph.graphdb.types.system.BaseLabel
-
- VertexLabelMaker - Interface in org.janusgraph.core.schema
-
- 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
-
- 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
-