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

A

abbreviate(ChronoUnit) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Durations
 
AbstractConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
 
AbstractConfiguration(ConfigNamespace) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
AbstractEdge - Class in com.thinkaurelius.titan.graphdb.relations
 
AbstractEdge(long, EdgeLabel, InternalVertex, InternalVertex) - Constructor for class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
AbstractElement - Class in com.thinkaurelius.titan.graphdb.internal
AbstractElement is the base class for all elements in Titan.
AbstractElement(long) - Constructor for class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
AbstractIDAuthority - Class in com.thinkaurelius.titan.diskstorage.idmanagement
Base Class for IDAuthority implementations.
AbstractIDAuthority(Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
AbstractIndexStatusWatcher<R,S extends AbstractIndexStatusWatcher<R,S>> - Class in com.thinkaurelius.titan.graphdb.database.management
 
AbstractIndexStatusWatcher(TitanGraph) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
AbstractLocker<S extends LockStatus> - Class in com.thinkaurelius.titan.diskstorage.locking
Abstract base class for building lockers.
AbstractLocker(StaticBuffer, TimestampProvider, ConsistentKeyLockerSerializer, LocalLockMediator<StoreTransaction>, LockerState<S>, Duration, Logger) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker
 
AbstractLocker.Builder<S,B extends AbstractLocker.Builder<S,B>> - Class in com.thinkaurelius.titan.diskstorage.locking
Abstract builder for this Locker implementation.
AbstractLongListUtil - Class in com.thinkaurelius.titan.util.datastructures
Utility class for merging and sorting lists of longs
AbstractLongListUtil() - Constructor for class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
AbstractMessage - Class in com.thinkaurelius.titan.diskstorage.log.util
Abstract implementation of Message which exposes the timestamp, sender, and payload of a message.
AbstractMessage(StaticBuffer, Instant, String) - Constructor for class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
AbstractStoreManager - Class in com.thinkaurelius.titan.diskstorage.common
Abstract Store Manager used as the basis for concrete StoreManager implementations.
AbstractStoreManager(Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.common.AbstractStoreManager
 
AbstractStoreTransaction - Class in com.thinkaurelius.titan.diskstorage.common
Abstract implementation of StoreTransaction to be used as the basis for more specific implementations.
AbstractStoreTransaction(BaseTransactionConfig) - Constructor for class com.thinkaurelius.titan.diskstorage.common.AbstractStoreTransaction
 
AbstractTypedRelation - Class in com.thinkaurelius.titan.graphdb.relations
 
AbstractTypedRelation(long, RelationType) - Constructor for class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
AbstractVertex - Class in com.thinkaurelius.titan.graphdb.vertices
 
AbstractVertex(StandardTitanTx, long) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
AbstractVertexProperty<V> - Class in com.thinkaurelius.titan.graphdb.relations
 
AbstractVertexProperty(long, PropertyKey, InternalVertex, Object) - Constructor for class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
accessEdges() - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.AccessCheck
 
accessProperties() - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.AccessCheck
 
accessSetProperty() - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.AccessCheck
 
acquireEdgeLock(StaticBuffer, StaticBuffer) - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.BackendTransaction
 
acquireIndexLock(StaticBuffer, StaticBuffer) - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.BackendTransaction
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ReadOnlyKeyColumnValueStore
 
acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
acquireLock(InternalRelation, int, boolean) - Static method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
acquireLock(CompositeIndexType, boolean) - Static method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
action() - Method in class com.thinkaurelius.titan.util.system.BackgroundThread
The action taken by this background thread when the wait condition is met.
add(String, String, IndexEntry, boolean) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
add(String, String, String, Object, boolean) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
add(StaticBuffer, Entry) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.ExternalCachePersistor
 
add(StaticBuffer, Entry) - Method in interface com.thinkaurelius.titan.diskstorage.log.kcvs.ExternalPersistor
 
add(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
################################### Message Sending ###################################
add(StaticBuffer, StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
add(StaticBuffer, StaticBuffer, ExternalPersistor) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
add(StaticBuffer) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexRecords
 
add(PropertyKey, Order) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
add(Condition<E>) - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
add(MixedIndexType, IndexQuery) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
add(CompositeIndexType, MultiKeySliceQuery) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
add(TitanVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
add(TitanVertex) - Method in interface com.thinkaurelius.titan.graphdb.query.vertex.VertexListInternal
Adds the provided vertex to this list.
add(TitanVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
add(InternalRelation) - Method in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
 
add(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
add(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
 
add(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleAddedRelations
 
add(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
add(TitanVertexProperty) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.ConcurrentIndexCache
 
add(TitanVertexProperty) - Method in interface com.thinkaurelius.titan.graphdb.transaction.indexcache.IndexCache
 
add(TitanVertexProperty) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.SimpleIndexCache
 
add(InternalVertex, long) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 
add(InternalVertex, long) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.LRUVertexCache
 
add(InternalVertex, long) - Method in interface com.thinkaurelius.titan.graphdb.transaction.vertexcache.VertexCache
Adds the given vertex with the given id to the cache.
add(ConcurrentLRUCache.Stats) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
add(T) - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
add(int) - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
add(int) - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
add(int) - Method in interface com.thinkaurelius.titan.util.datastructures.IntSet
 
add(T) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
addAll(VertexList) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
addAll(VertexList) - Method in interface com.thinkaurelius.titan.graphdb.query.vertex.VertexListInternal
Copies all vertices in the given vertex list into this list.
addAll(VertexList) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
addAll(Iterable<HasContainer>) - Method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
addAll(Iterable<HasContainer>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
addAll(Iterable<HasContainer>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
addAll(Iterable<HasContainer>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
addAll(int[]) - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
addAll(int[]) - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
addAll(int[]) - Method in interface com.thinkaurelius.titan.util.datastructures.IntSet
 
addAll(Collection<? extends T>) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
addAllVertices(Collection<? extends Vertex>) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
Adds the given collection of vertices to the set of vertices against which to execute this query.
addAllVertices(Collection<? extends Vertex>) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
addConsoleReporter(Duration) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a ConsoleReporter attached to the Titan Metrics registry.
addCsvReporter(Duration, String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a CsvReporter attached to the Titan Metrics registry.
ADDED_RECORDS_COUNT - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.TitanVertex
Creates a new edge incident on this vertex.
addEdge(TitanVertex, TitanVertex, EdgeLabel) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
addEdge(String, Vertex, Object...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
addEdge(String, Vertex, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
addEdge(String, Vertex, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
AddedRelationsContainer - Interface in com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
addGangliaReporter(String, int, GMetric.UDPAddressingMode, int, Boolean, UUID, String, Duration) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a GangliaReporter attached to the Titan Metrics registry.
addGraphiteReporter(String, int, String, Duration) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a GraphiteReporter attached to the Titan Metrics registry.
addIndexKey(TitanGraphIndex, PropertyKey, Parameter...) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
 
addIndexKey(TitanGraphIndex, PropertyKey, Parameter...) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
addition(E) - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Adds a new entry as an addition to this mutation
addJmxReporter(String, String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a JmxReporter attached to the Titan Metrics registry.
addKey(PropertyKey) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement.IndexBuilder
Adds the given key to the composite key of this index
addKey(PropertyKey, Parameter...) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement.IndexBuilder
Adds the given key and associated parameters to the composite key of this index
addLogProcessor(String) - Method in interface com.thinkaurelius.titan.core.log.LogProcessorFramework
Returns a processor builder for the transaction log with the given log identifier.
addLogProcessor(String) - Method in class com.thinkaurelius.titan.graphdb.log.StandardLogProcessorFramework
 
addMessage(M, MessageScope, Map<MessageScope, Integer>, MessageCombiner<M>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
addNested(String) - Method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
addNested(String) - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
addNested(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
addPadding(long) - Method in enum com.thinkaurelius.titan.graphdb.idmanagement.IDManager.VertexIDType
 
addParameter(Parameter) - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Adds the given parameter to the list of parameters of this query.
addParameter(Parameter) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
addParameters(Iterable<Parameter>) - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Adds the given parameters to the list of parameters of this query.
addParameters(Parameter...) - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Adds the given parameters to the list of parameters of this query.
addParameters(Iterable<Parameter>) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
addParameters(Parameter...) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
addPoint(T) - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
addProcessor(ChangeProcessor) - Method in interface com.thinkaurelius.titan.core.log.LogProcessorBuilder
Adds a ChangeProcessor to this transaction log processor.
addProperty(RelationType, Object) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
addProperty(TitanVertex, PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
addProperty(VertexProperty.Cardinality, TitanVertex, PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
addQuery() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer
 
addRelation(InternalRelation) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertex
Add a new relation to the vertex
addRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
addRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
addRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
addRelationTypePadding(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
addSlf4jReporter(Duration, String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Create a Slf4jReporter attached to the Titan Metrics registry.
addToQueryCache(SliceQuery, EntryList) - Method in class com.thinkaurelius.titan.graphdb.vertices.CacheVertex
 
addToQueryCache(SliceQuery, EntryList) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
addValue(int, double) - Method in class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
addVertex(String) - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
Creates a new vertex in the graph with the vertex label named by the argument.
addVertex(Object...) - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
 
addVertex(Vertex) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
Adds the given vertex to the set of vertices against which to execute this query.
addVertex(Long, VertexLabel) - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Creates a new vertex in the graph with the given vertex id and the given vertex label.
addVertex(Vertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
addVertex(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
addVertex(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
addVertex(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
Creates a new vertex in the graph with the given vertex id.
addVertex(Long, VertexLabel) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
addVertex(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
addVertex(VertexLabel) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
adjacent(Vertex) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Restricts this query to only those edges that point to the given vertex.
adjacent(Vertex) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
adjacent(Vertex) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
adjacent(Vertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
ADJACENT_ID - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
adjacentVertex - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The vertex to be used for the adjacent vertex constraint.
AdjacentVertexFilterOptimizerStrategy - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
ADJUST_LIMIT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
adjustLimitForTxModifications(StandardTitanTx, int, int) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
adjustQueryLimit() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
aggregateMessage(long, M, MessageScope) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
AllEdgesIterable - Class in com.thinkaurelius.titan.graphdb.util
Constructs Iterables over all TitanEdges connecting a provided set of vertices.
AllEdgesIterator - Class in com.thinkaurelius.titan.graphdb.util
Defines an Iterator over all TitanEdges connecting a provided set of vertices.
AllEdgesIterator(Iterator<? extends Vertex>) - Constructor for class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.util.AllEdgesIterator
Returns an iterator over all edges contained in the subgraph spanned by the given vertices.
ALLOW_ALL - Static variable in class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
 
ALLOW_SETTING_VERTEX_ID - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
ALLOW_STALE_CONFIG - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
allowVertexIdSetting() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
allRequiredRepresentatives(InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
and(String, boolean) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
And<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
Combines multiple conditions under semantic AND, i.e.
And(Condition<E>...) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.And
 
And() - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.And
 
And(int) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.And
 
AND_QUERY - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
apply(Traversal.Admin<?, ?>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.AdjacentVertexFilterOptimizerStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStepStrategy
 
apply(Traversal.Admin<?, ?>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanLocalQueryOptimizerStrategy
 
applyPrior() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanLocalQueryOptimizerStrategy
 
applyTTL(Collection<Entry>, int) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
ARRAY_FACTORY - Static variable in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
arrayDifference(long[], long[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
ARRAYLIST_SIZE - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
ArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
ArraysUtil - Class in com.thinkaurelius.titan.util.datastructures
Utility class for sorting and retrieving from primitive arrays
ArraysUtil() - Constructor for class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
as(StaticBuffer.Factory<T>) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
as(StaticBuffer.Factory<T>) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
as(StaticBuffer.Factory<T>, int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
asByteBuffer() - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
asByteBuffer() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
asIndexType() - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
 
asIndexType() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
asParameter() - Method in enum com.thinkaurelius.titan.core.schema.Mapping
asReadBuffer() - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
asReadBuffer() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
asReadConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
asRelative(StaticBuffer.Factory<T>) - Method in interface com.thinkaurelius.titan.diskstorage.ReadBuffer
 
asRelative(StaticBuffer.Factory<T>) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
assignID(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
assignID(InternalVertex, VertexLabel) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
assignID(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
assignID(InternalVertex, VertexLabel) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
assignIDs(Iterable<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
attachProperties(TitanRelation, Object...) - Static method in class com.thinkaurelius.titan.graphdb.util.ElementHelper
 
attachProperties(TitanVertex, Object...) - Static method in class com.thinkaurelius.titan.graphdb.util.ElementHelper
This is essentially an adjusted copy&paste from TinkerPop's ElementHelper class.
ATTRIBUTE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
ATTRIBUTE_PREFIX - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
AttributeHandler - Interface in com.thinkaurelius.titan.graphdb.database.serialize
 
attributeHandler - Variable in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
AttributeSerializer<V> - Interface in com.thinkaurelius.titan.core.attribute
Allows custom serializer definitions for attribute values.
AttributeUtil - Class in com.thinkaurelius.titan.graphdb.database.serialize
 
AttributeUtil() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
AUTH_PASSWORD - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
AUTH_USERNAME - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
awaitGraphIndexStatus(TitanGraph, String) - Static method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
Returns a GraphIndexStatusWatcher configured to watch graphIndexName through graph g.
awaitGraphIndexUpdate(TitanGraph, String, long, TemporalUnit) - Static method in class com.thinkaurelius.titan.core.util.ManagementUtil
This method blocks and waits until the provided index has been updated across the entire Titan cluster and reached a stable state.
awaitRelationIndexStatus(TitanGraph, String, String) - Static method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
Returns a RelationIndexStatusWatcher configured to watch the index specified by relationIndexName and relationIndexType through graph g.
awaitVertexIndexUpdate(TitanGraph, String, String, long, TemporalUnit) - Static method in class com.thinkaurelius.titan.core.util.ManagementUtil
 

B

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

C

CachableStaticBuffer - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache
 
CACHE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
CacheEdge - Class in com.thinkaurelius.titan.graphdb.relations
 
CacheEdge(long, EdgeLabel, InternalVertex, InternalVertex, Entry) - Constructor for class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
CacheMetricsAction - Enum in com.thinkaurelius.titan.diskstorage.util
 
CacheTransaction - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache
 
CacheTransaction(StoreTransaction, KeyColumnValueStoreManager, int, Duration, boolean) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
CacheTransaction(StoreTransaction, KeyColumnValueStoreManager, int, Duration, boolean, int) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
CacheVertex - Class in com.thinkaurelius.titan.graphdb.vertices
 
CacheVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.CacheVertex
 
CacheVertexProperty - Class in com.thinkaurelius.titan.graphdb.relations
 
CacheVertexProperty(long, PropertyKey, InternalVertex, Object, Entry) - Constructor for class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
call(StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.util.BackendOperation.Transactional
 
call() - Method in interface com.thinkaurelius.titan.diskstorage.util.IOCallable
 
call() - Method in interface com.thinkaurelius.titan.diskstorage.util.StorageCallable
 
call() - Method in interface com.thinkaurelius.titan.diskstorage.util.UncheckedCallable
 
call() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusWatcher
 
call() - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.query.QueryUtil.IndexCall
 
Cardinality - Enum in com.thinkaurelius.titan.core
The cardinality of the values associated with given key for a particular element.
cardinality() - Method in interface com.thinkaurelius.titan.core.PropertyKey
The Cardinality of this property key.
cardinality(Cardinality) - Method in interface com.thinkaurelius.titan.core.schema.PropertyKeyMaker
Configures the Cardinality of this property key.
cardinality(Cardinality) - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
cardinality() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
cardinality() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
cardinality() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.PropertyKeyVertex
 
cellTTL(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
Change - Enum in com.thinkaurelius.titan.core.log
Identifies the type of change has undergone.
changeName(TitanSchemaElement, String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Changes the name of a TitanSchemaElement to the provided new name.
changeName(TitanSchemaElement, String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
ChangeProcessor - Interface in com.thinkaurelius.titan.core.log
Allows the user to define custom behavior to process those transactional changes that are recorded in a transaction log.
ChangeState - Interface in com.thinkaurelius.titan.core.log
Container interface for a set of changes against the graph caused by a particular transaction.
char2short(char) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
CHAR_LEN - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
CharacterSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
CharacterSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
CharArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
CharArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharArraySerializer
 
checkExternalVertexExistence(boolean) - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Enables/disables checking whether the vertex with a user provided id indeed exists.
checkExternalVertexExistence(boolean) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
checkInternalVertexExistence(boolean) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
checkLocks(StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker
 
checkLocks(StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.locking.Locker
Verify that all previous Locker.writeLock(KeyColumn, StoreTransaction) calls with tx actually succeeded.
checkSingleLock(KeyColumn, S, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker
Try to verify that the lock identified by lockID is already held by tx.
checkSingleLock(KeyColumn, ConsistentKeyLockStatus, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker
 
CheckSocket - Class in com.thinkaurelius.titan.util.system
 
CheckSocket() - Constructor for class com.thinkaurelius.titan.util.system.CheckSocket
 
checkTypeName(TitanSchemaCategory, String) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
chronoUnit(TimeUnit) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Temporals
 
circle(float, float, float) - Static method in class com.thinkaurelius.titan.core.attribute.Geoshape
Constructs a circle from a given center point and a radius in kilometer
circle(double, double, double) - Static method in class com.thinkaurelius.titan.core.attribute.Geoshape
Constructs a circle from a given center point and a radius in kilometer
clean(KeyColumn, Instant, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.locking.consistentkey.LockCleanerService
 
clean(KeyColumn, Instant, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService
 
cleanup() - Method in class com.thinkaurelius.titan.util.system.BackgroundThread
Any clean up that needs to be done before this thread is closed down.
clear(TitanGraph) - Static method in class com.thinkaurelius.titan.core.util.TitanCleanup
Clears out the entire graph.
clear() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
clear() - Method in enum com.thinkaurelius.titan.diskstorage.locking.LocalLockMediators
Only use this in testing.
clear(String) - Method in enum com.thinkaurelius.titan.diskstorage.locking.LocalLockMediators
Only use this in testing.
clear() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
clear() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
clear() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
clearCache() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
clearCache() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
clearCache() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
clearStorage() - Method in class com.thinkaurelius.titan.diskstorage.Backend
Clears the storage of all registered backend data providers.
clearStorage() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.IndexProvider
Clears the index and removes all entries in all stores.
clearStorage() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
clearStorage() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
clearStorage() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
clearStorage() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreManager
Deletes and clears all database in this storage manager.
clearStorage() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
clone() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanJob
Returns a clone of this ScanJob.
clone() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob.Executor
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob.Executor
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
clone() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
clone() - Method in interface com.thinkaurelius.titan.graphdb.olap.VertexScanJob
Returns a clone of this VertexScanJob.
clone() - Method in class com.thinkaurelius.titan.graphdb.query.condition.And
 
clone() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Or
 
clone() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
clone() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
close() - Method in interface com.thinkaurelius.titan.core.TitanGraph
Closes the graph database.
close() - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
 
close() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.configuration.ReadConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
close() - Method in class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
Closes this configuration handler
close() - Method in interface com.thinkaurelius.titan.diskstorage.IDAuthority
Closes the IDAuthority and any underlying storage backend.
close() - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.IndexProvider
Closes the index
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
Closes this store
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Closes this store and releases its resources.
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
close() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreManager
Closes the Storage Manager and all databases that have been opened.
close() - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
Closes the log by terminating all threads and waiting for their termination.
close() - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLogManager
 
close() - Method in interface com.thinkaurelius.titan.diskstorage.log.Log
Closes this log and stops the reading process.
close() - Method in interface com.thinkaurelius.titan.diskstorage.log.LogManager
Closes the log manager and all open logs (if they haven't already been explicitly closed)
close() - Method in interface com.thinkaurelius.titan.diskstorage.util.BackendOperation.TransactionalProvider
 
close() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
 
close() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
close() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
close() - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.IDPool
 
close() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.StandardIDPool
 
close() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
close() - Method in class com.thinkaurelius.titan.graphdb.database.RelationQueryCache
 
close() - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
close() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
close() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
close() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
close() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
close() - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 
close() - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.LRUVertexCache
 
close() - Method in interface com.thinkaurelius.titan.graphdb.transaction.vertexcache.VertexCache
Closes the cache which allows the cache to release allocated memory.
close() - Method in class com.thinkaurelius.titan.graphdb.util.WorkerPool
 
close(Duration) - Method in class com.thinkaurelius.titan.util.system.BackgroundThread
 
CLOSEDSTAR_CHECK - Static variable in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
closeQuietly(Closeable) - Static method in class com.thinkaurelius.titan.util.system.IOUtils
 
closeQuietly(AutoCloseable) - Static method in class com.thinkaurelius.titan.util.system.IOUtils
 
closeTransaction(StandardTitanTx) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
CLUSTER_MAX_PARTITIONS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Whether the id space should be partitioned for equal distribution of keys.
CLUSTER_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
CLUSTER_SIZE_DIVIDER - Static variable in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLogManager
If KCVSLogManager.LOG_MAX_PARTITIONS isn't set explicitly, the number of partitions is derived by taking the configured GraphDatabaseConfiguration.CLUSTER_MAX_PARTITIONS and dividing the number by this constant.
Cmp - Enum in com.thinkaurelius.titan.core.attribute
Basic comparison relations for comparable (i.e.
com.thinkaurelius.titan.core - package com.thinkaurelius.titan.core
 
com.thinkaurelius.titan.core.attribute - package com.thinkaurelius.titan.core.attribute
 
com.thinkaurelius.titan.core.log - package com.thinkaurelius.titan.core.log
 
com.thinkaurelius.titan.core.schema - package com.thinkaurelius.titan.core.schema
 
com.thinkaurelius.titan.core.util - package com.thinkaurelius.titan.core.util
 
com.thinkaurelius.titan.diskstorage - package com.thinkaurelius.titan.diskstorage
 
com.thinkaurelius.titan.diskstorage.common - package com.thinkaurelius.titan.diskstorage.common
 
com.thinkaurelius.titan.diskstorage.configuration - package com.thinkaurelius.titan.diskstorage.configuration
 
com.thinkaurelius.titan.diskstorage.configuration.backend - package com.thinkaurelius.titan.diskstorage.configuration.backend
 
com.thinkaurelius.titan.diskstorage.idmanagement - package com.thinkaurelius.titan.diskstorage.idmanagement
 
com.thinkaurelius.titan.diskstorage.indexing - package com.thinkaurelius.titan.diskstorage.indexing
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue - package com.thinkaurelius.titan.diskstorage.keycolumnvalue
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache - package com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory - package com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue - package com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan - package com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
 
com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl - package com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl
 
com.thinkaurelius.titan.diskstorage.locking - package com.thinkaurelius.titan.diskstorage.locking
 
com.thinkaurelius.titan.diskstorage.locking.consistentkey - package com.thinkaurelius.titan.diskstorage.locking.consistentkey
 
com.thinkaurelius.titan.diskstorage.log - package com.thinkaurelius.titan.diskstorage.log
 
com.thinkaurelius.titan.diskstorage.log.kcvs - package com.thinkaurelius.titan.diskstorage.log.kcvs
 
com.thinkaurelius.titan.diskstorage.log.util - package com.thinkaurelius.titan.diskstorage.log.util
 
com.thinkaurelius.titan.diskstorage.util - package com.thinkaurelius.titan.diskstorage.util
 
com.thinkaurelius.titan.diskstorage.util.time - package com.thinkaurelius.titan.diskstorage.util.time
 
com.thinkaurelius.titan.example - package com.thinkaurelius.titan.example
 
com.thinkaurelius.titan.graphdb.configuration - package com.thinkaurelius.titan.graphdb.configuration
 
com.thinkaurelius.titan.graphdb.database - package com.thinkaurelius.titan.graphdb.database
 
com.thinkaurelius.titan.graphdb.database.cache - package com.thinkaurelius.titan.graphdb.database.cache
 
com.thinkaurelius.titan.graphdb.database.idassigner - package com.thinkaurelius.titan.graphdb.database.idassigner
 
com.thinkaurelius.titan.graphdb.database.idassigner.placement - package com.thinkaurelius.titan.graphdb.database.idassigner.placement
 
com.thinkaurelius.titan.graphdb.database.idhandling - package com.thinkaurelius.titan.graphdb.database.idhandling
 
com.thinkaurelius.titan.graphdb.database.indexing - package com.thinkaurelius.titan.graphdb.database.indexing
 
com.thinkaurelius.titan.graphdb.database.log - package com.thinkaurelius.titan.graphdb.database.log
 
com.thinkaurelius.titan.graphdb.database.management - package com.thinkaurelius.titan.graphdb.database.management
 
com.thinkaurelius.titan.graphdb.database.serialize - package com.thinkaurelius.titan.graphdb.database.serialize
 
com.thinkaurelius.titan.graphdb.database.serialize.attribute - package com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
com.thinkaurelius.titan.graphdb.idmanagement - package com.thinkaurelius.titan.graphdb.idmanagement
 
com.thinkaurelius.titan.graphdb.internal - package com.thinkaurelius.titan.graphdb.internal
 
com.thinkaurelius.titan.graphdb.log - package com.thinkaurelius.titan.graphdb.log
 
com.thinkaurelius.titan.graphdb.olap - package com.thinkaurelius.titan.graphdb.olap
 
com.thinkaurelius.titan.graphdb.olap.computer - package com.thinkaurelius.titan.graphdb.olap.computer
 
com.thinkaurelius.titan.graphdb.olap.job - package com.thinkaurelius.titan.graphdb.olap.job
 
com.thinkaurelius.titan.graphdb.query - package com.thinkaurelius.titan.graphdb.query
 
com.thinkaurelius.titan.graphdb.query.condition - package com.thinkaurelius.titan.graphdb.query.condition
 
com.thinkaurelius.titan.graphdb.query.graph - package com.thinkaurelius.titan.graphdb.query.graph
 
com.thinkaurelius.titan.graphdb.query.profile - package com.thinkaurelius.titan.graphdb.query.profile
 
com.thinkaurelius.titan.graphdb.query.vertex - package com.thinkaurelius.titan.graphdb.query.vertex
 
com.thinkaurelius.titan.graphdb.relations - package com.thinkaurelius.titan.graphdb.relations
 
com.thinkaurelius.titan.graphdb.schema - package com.thinkaurelius.titan.graphdb.schema
 
com.thinkaurelius.titan.graphdb.tinkerpop - package com.thinkaurelius.titan.graphdb.tinkerpop
 
com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson - package com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson
 
com.thinkaurelius.titan.graphdb.tinkerpop.optimize - package com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
com.thinkaurelius.titan.graphdb.tinkerpop.profile - package com.thinkaurelius.titan.graphdb.tinkerpop.profile
 
com.thinkaurelius.titan.graphdb.transaction - package com.thinkaurelius.titan.graphdb.transaction
 
com.thinkaurelius.titan.graphdb.transaction.addedrelations - package com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
com.thinkaurelius.titan.graphdb.transaction.indexcache - package com.thinkaurelius.titan.graphdb.transaction.indexcache
 
com.thinkaurelius.titan.graphdb.transaction.lock - package com.thinkaurelius.titan.graphdb.transaction.lock
 
com.thinkaurelius.titan.graphdb.transaction.vertexcache - package com.thinkaurelius.titan.graphdb.transaction.vertexcache
 
com.thinkaurelius.titan.graphdb.types - package com.thinkaurelius.titan.graphdb.types
 
com.thinkaurelius.titan.graphdb.types.indextype - package com.thinkaurelius.titan.graphdb.types.indextype
 
com.thinkaurelius.titan.graphdb.types.system - package com.thinkaurelius.titan.graphdb.types.system
 
com.thinkaurelius.titan.graphdb.types.typemaker - package com.thinkaurelius.titan.graphdb.types.typemaker
 
com.thinkaurelius.titan.graphdb.types.vertices - package com.thinkaurelius.titan.graphdb.types.vertices
 
com.thinkaurelius.titan.graphdb.util - package com.thinkaurelius.titan.graphdb.util
 
com.thinkaurelius.titan.graphdb.vertices - package com.thinkaurelius.titan.graphdb.vertices
 
com.thinkaurelius.titan.util.datastructures - package com.thinkaurelius.titan.util.datastructures
 
com.thinkaurelius.titan.util.encoding - package com.thinkaurelius.titan.util.encoding
 
com.thinkaurelius.titan.util.stats - package com.thinkaurelius.titan.util.stats
 
com.thinkaurelius.titan.util.system - package com.thinkaurelius.titan.util.system
 
CombinerLock - Class in com.thinkaurelius.titan.graphdb.transaction.lock
 
CombinerLock(TransactionLock, TransactionLock, TimestampProvider) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.lock.CombinerLock
 
commit() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Commits this management transaction and persists all schema changes.
commit() - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Commits and closes the transaction.
commit() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
commit() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransaction
Commits the transaction and persists all modifications to the backend.
commit() - Method in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreTransaction
 
commit() - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
commit() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
commit() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
commit() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
commit() - Method in class com.thinkaurelius.titan.diskstorage.util.DefaultTransaction
 
commit() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
commit(Collection<InternalRelation>, Collection<InternalRelation>, StandardTitanTx) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
commit() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
commitIndexes() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
commitStorage() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
commitTime(Instant) - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Sets the timestamp for this transaction.
commitTime(Instant) - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder
 
commitTime(Instant) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
CommonsConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration.backend
ReadConfiguration wrapper for Apache Configuration
CommonsConfiguration() - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
CommonsConfiguration(Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
CompactMap - Class in com.thinkaurelius.titan.util.datastructures
CompactMap is compact representation of the Map interface which is immutable.
compare(ByteBuffer, ByteBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers according to their byte order (and not the byte value).
compare(long, TimeUnit, long, TimeUnit) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Durations
 
compare(Object, Object) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
Compares the two elements like Comparator.compare(Object, Object) but returns null in case the two elements are not comparable.
compare(TitanElement, TitanElement) - Static method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
compare(TitanElement, TitanElement) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
compare(TitanElement, TitanElement) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
compare(InternalRelation, InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.relations.RelationComparator
 
compareTo(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
compareTo(StaticArrayBuffer) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
compareTo(int, StaticBuffer, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
compareTo(int, StaticArrayBuffer, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
compareTo(TitanElement) - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
compareValues(Object, Object, Order) - Static method in class com.thinkaurelius.titan.graphdb.relations.RelationComparator
 
compareValues(Object, Object) - Static method in class com.thinkaurelius.titan.graphdb.relations.RelationComparator
 
COMPATIBLE_VERSIONS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.TitanConstants
Past versions of Titan with which the runtime version shares a compatible storage format
complete(MapReduce<K, V, ?, ?, ?>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMapEmitter
 
complete() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
complete(MapReduce<?, ?, OK, OV, ?>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraReduceEmitter
 
completeIteration() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
completeSubRound() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
CompositeIndexType - Interface in com.thinkaurelius.titan.graphdb.types
 
CompositeIndexTypeWrapper - Class in com.thinkaurelius.titan.graphdb.types.indextype
 
CompositeIndexTypeWrapper(SchemaSource) - Constructor for class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
compress(StaticBuffer) - Method in interface com.thinkaurelius.titan.diskstorage.util.BackendCompression
 
compute(Class<C>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
compute() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
compute(Class<C>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
compute() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
computeProperty(InternalElement) - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
COMPUTER_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
COMPUTER_RESULT_MODE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
CONCURRENT_PARTITIONS - Static variable in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
ConcurrentAddedRelations - Class in com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
ConcurrentAddedRelations() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
ConcurrentBufferAddedRelations - Class in com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
ConcurrentBufferAddedRelations() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
 
ConcurrentIndexCache - Class in com.thinkaurelius.titan.graphdb.transaction.indexcache
 
ConcurrentIndexCache() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.indexcache.ConcurrentIndexCache
 
ConcurrentLRUCache<V> - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
ConcurrentLRUCache(int, int) - Constructor for class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
ConcurrentLRUCache.EvictionListener<V> - Interface in com.thinkaurelius.titan.graphdb.util
 
ConcurrentLRUCache.Stats - Class in com.thinkaurelius.titan.graphdb.util
 
ConcurrentWriteConfiguration - Interface in com.thinkaurelius.titan.diskstorage.configuration
 
Condition<E extends TitanElement> - Interface in com.thinkaurelius.titan.graphdb.query.condition
A logical condition which evaluates against a provided element to true or false.
condition - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
The condition of this query in QNF
Condition.Type - Enum in com.thinkaurelius.titan.graphdb.query.condition
 
CONDITION_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
ConditionUtil - Class in com.thinkaurelius.titan.graphdb.query.condition
Utility methods for transforming and inspecting Conditions.
ConditionUtil() - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.ConditionUtil
 
ConfigElement - Class in com.thinkaurelius.titan.diskstorage.configuration
 
ConfigElement(ConfigNamespace, String, String) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
ConfigElement.PathIdentifier - Class in com.thinkaurelius.titan.diskstorage.configuration
 
ConfigNamespace - Class in com.thinkaurelius.titan.diskstorage.configuration
 
ConfigNamespace(ConfigNamespace, String, String, boolean) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
 
ConfigNamespace(ConfigNamespace, String, String) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
 
ConfigOption<O> - Class in com.thinkaurelius.titan.diskstorage.configuration
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, O) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, O, Predicate<O>) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, Predicate<O>) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O, Predicate<O>) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption(ConfigNamespace, String, String, ConfigOption.Type, Class<O>, O, Predicate<O>, ConfigOption<?>) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
ConfigOption.Type - Enum in com.thinkaurelius.titan.diskstorage.configuration
 
Configuration - Interface in com.thinkaurelius.titan.diskstorage.configuration
 
configuration() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
configuration() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
ConfigurationFileFilter - Class in com.thinkaurelius.titan.util.system
 
ConfigurationFileFilter() - Constructor for class com.thinkaurelius.titan.util.system.ConfigurationFileFilter
 
ConfigurationLint - Class in com.thinkaurelius.titan.util.system
 
ConfigurationLint() - Constructor for class com.thinkaurelius.titan.util.system.ConfigurationLint
 
ConfigurationLint.Status - Class in com.thinkaurelius.titan.util.system
 
ConfigurationPrinter - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.util.system
 
ConfigurationUtil() - Constructor for class com.thinkaurelius.titan.util.system.ConfigurationUtil
 
ConflictAvoidanceMode - Enum in com.thinkaurelius.titan.diskstorage.idmanagement
Represents ID allocation strategies for avoiding contention between concurrent Titan instances using a shared storage backend.
CONNECTION_TIMEOUT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Default timeout when connecting to a remote database instance

connectionTimeoutMS - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
consistencyChecks(boolean) - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Enables/disables consistency checking and locking for this transaction.
consistencyChecks(boolean) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
ConsistencyLevel - Enum in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Consistency Levels for transactions.
ConsistencyModifier - Enum in com.thinkaurelius.titan.core.schema
Used to control Titan's consistency behavior on eventually consistent or other non-transactional backend systems.
ConsistentKeyIDAuthority - Class in com.thinkaurelius.titan.diskstorage.idmanagement
IDAuthority implementation assuming that the backing store supports consistent key operations.
ConsistentKeyIDAuthority(KeyColumnValueStore, StoreManager, Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
ConsistentKeyLocker - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
A global Locker that resolves inter-thread lock contention via AbstractLocker and resolves inter-process contention by reading and writing lock data using KeyColumnValueStore.
ConsistentKeyLocker.Builder - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
 
ConsistentKeyLockerSerializer - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
ConsistentKeyLockStatus - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
consolidate() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
consolidate() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
consolidate() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVMutation
 
consolidate() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
consolidate(Function<E, V>, Function<K, V>) - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Consolidates this mutation by removing redundant deletions.
consolidate() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
 
constraints - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The constraints added to this query.
constraints2QNF(StandardTitanTx, List<PredicateCondition<String, E>>) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
Prepares the constraints from the query builder into a QNF compliant condition.
constructQuery(ElementCategory) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
constructQuery(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Constructs a VertexCentricQuery for this query builder.
constructQuery(RelationCategory) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
constructQueryWithoutProfile(ElementCategory) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
constructQueryWithoutProfile(RelationCategory) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
Contain - Enum in com.thinkaurelius.titan.core.attribute
Comparison relations for text objects.
Container() - Constructor for class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
Container(boolean) - Constructor for class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
contains(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
contains(K) - Method in class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
contains(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
Returns true of the given partitionId lies within this partition id range, else false.
contains(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 
contains(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.LRUVertexCache
 
contains(long) - Method in interface com.thinkaurelius.titan.graphdb.transaction.vertexcache.VertexCache
Checks whether the cache contains a vertex with the given id
contains(int) - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
contains(int) - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
contains(int) - Method in interface com.thinkaurelius.titan.util.datastructures.IntSet
 
contains(Object) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
containsAll(Collection<?>) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
containsEdgeLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Checks whether an edge label of the given name has been defined in the Titan schema.
containsEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
containsEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
containsGraphIndex(String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Whether the graph has a graph index defined with the given name.
containsGraphIndex(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsIndex(String) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
containsKey(KeyColumnValueStore, StaticBuffer, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
containsKey(KeyColumnValueStore, StaticBuffer, int, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
containsKey(StaticBuffer, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns true iff the store contains the given key, else false
containsKey(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
containsKey(Long) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
containsKey(Object) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
containsKeyColumn(KeyColumnValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
Returns true if the specified key-column pair exists in the store.
containsPoint(T) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
containsPropertyKey(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Checks whether a property key of the given name has been defined in the Titan schema.
containsPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
containsPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
containsRelationIndex(RelationType, String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Whether a RelationTypeIndex with the given name has been defined for the provided RelationType
containsRelationIndex(RelationType, String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsRelationType(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Checks whether a type with the specified name exists.
containsRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
containsRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
containsRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
containsRelationType(String) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
containsType(Condition<?>, Condition.Type) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.ConditionUtil
 
containsValue(Object) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
containsVertex(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
containsVertexLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Whether a vertex label with the given name exists in the graph.
containsVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
containsVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
containsVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
containsVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
ConversionHelper - Class in com.thinkaurelius.titan.util.encoding
 
ConversionHelper() - Constructor for class com.thinkaurelius.titan.util.encoding.ConversionHelper
 
convert(Object) - Method in interface com.thinkaurelius.titan.core.attribute.AttributeSerializer
Converts the given (not-null) value to the expected datatype V.
convert(Object) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeSerializer
 
convert() - Method in enum com.thinkaurelius.titan.core.Cardinality
 
convert(VertexProperty.Cardinality) - Static method in enum com.thinkaurelius.titan.core.Cardinality
 
convert(Cardinality) - Static method in enum com.thinkaurelius.titan.core.Multiplicity
 
convert(RecordIterator<KeyValueEntry>) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DateSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntegerSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringArraySerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.UUIDSerializer
 
convert(Class<V>, Object) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.AttributeHandler
Converts the given (not-null) value to the this datatype V.
convert(Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.NoSerializer
 
convert(Class<V>, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
convert(Order) - Static method in enum com.thinkaurelius.titan.graphdb.internal.Order
 
convert(TitanGraph, VertexScanJob) - Static method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
convert(VertexScanJob) - Static method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
convert(BiPredicate) - Static method in class com.thinkaurelius.titan.graphdb.query.TitanPredicate.Converter
 
convert2Spatial4j() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Converts this shape into its equivalent Spatial4j Shape.
Converter() - Constructor for class com.thinkaurelius.titan.graphdb.query.TitanPredicate.Converter
 
convertInternal(BiPredicate) - Static method in class com.thinkaurelius.titan.graphdb.query.TitanPredicate.Converter
Convert Tinkerpop's comparison operators to Titan's
convertLimit(long) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
copy() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
copy() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
copy() - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
copy() - Method in interface com.thinkaurelius.titan.diskstorage.configuration.WriteConfiguration
 
copy(D, byte[], int) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.DataHandler
 
count() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns the number of relations that match this query
create(String) - Static method in class com.thinkaurelius.titan.example.GraphOfTheGodsFactory
 
create() - Method in interface com.thinkaurelius.titan.util.datastructures.Factory
 
createMapb(int) - Static method in class com.thinkaurelius.titan.util.datastructures.BitMap
 
currentMap - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
CUSTOM_ATTRIBUTE_CLASS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
CUSTOM_ATTRIBUTE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
CUSTOM_SERIALIZER_CLASS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
customCleaner(LockCleanerService) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
customOption(String, Object) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
customOptions(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder
 

D

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

E

E_FAILED - Static variable in class com.thinkaurelius.titan.util.system.CheckSocket
 
E_USAGE - Static variable in class com.thinkaurelius.titan.util.system.CheckSocket
 
edge() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanFeatures
 
edgeCount() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns the number of edges that match this query
EdgeDirection - Class in com.thinkaurelius.titan.graphdb.relations
IMPORTANT: The byte values of the proper directions must be sequential, i.e.
EdgeDirection() - Constructor for class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
EdgeLabel - Interface in com.thinkaurelius.titan.core
EdgeLabel is an extension of RelationType for edges.
edgeLabel() - Method in interface com.thinkaurelius.titan.core.TitanEdge
Returns the edge label of this edge
EDGELABEL_DEFINITION_CATEGORIES - Static variable in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
EdgeLabelDefinition - Class in com.thinkaurelius.titan.graphdb.schema
 
EdgeLabelDefinition(String, long, Multiplicity, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.schema.EdgeLabelDefinition
 
EdgeLabelDefinition(EdgeLabel) - Constructor for class com.thinkaurelius.titan.graphdb.schema.EdgeLabelDefinition
 
EdgeLabelMaker - Interface in com.thinkaurelius.titan.core.schema
Used to define new EdgeLabels.
EdgeLabelVertex - Class in com.thinkaurelius.titan.graphdb.types.vertices
 
EdgeLabelVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
edgeMultiQuery(LongArrayList, SliceQuery, BackendTransaction) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
edgeProcessor - Variable in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
edgeProcessorImpl - Variable in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
edgeQuery(long, SliceQuery, BackendTransaction) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
edges() - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
Returns all edges that match the conditions.
edges() - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Returns all edges that match the query in the indexing backend.
edges() - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
Returns an iterable over all incident edges that match this query for each vertex
edges() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns an iterable over all incident edges that match this query
edges() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
edges() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
edges() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
edges() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
edges() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
edges(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
edges(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
edges(Direction, String...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
edges(Direction, String...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
edges(Direction, String...) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
edges2VertexIds(Iterable<TitanEdge>, TitanVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
edges2Vertices(Iterable<TitanEdge>, TitanVertex) - Static method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
EdgeSerializer - Class in com.thinkaurelius.titan.graphdb.database
 
EdgeSerializer(Serializer) - Constructor for class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
edgeSerializer - Variable in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
EdgeSerializer.TypedInterval - Class in com.thinkaurelius.titan.graphdb.database
 
EDGESTORE_CACHE_PERCENT - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
EDGESTORE_MAX_KEY - Static variable in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
EDGESTORE_MIN_KEY - Static variable in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
EDGESTORE_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
These are the names for the edge store and property index databases, respectively.
edgeStoreKeys(SliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
edgeStoreKeys(KeyRangeQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
edgeStoreMultiQuery(List<StaticBuffer>, SliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
edgeStoreQuery(KeySliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
elapsed() - Method in class com.thinkaurelius.titan.diskstorage.util.time.Timer
 
element() - Method in interface com.thinkaurelius.titan.core.TitanVertexProperty
Returns the vertex on which this property is incident.
element - Variable in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement.PathIdentifier
 
element() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
element() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
element() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
ElementCategory - Enum in com.thinkaurelius.titan.graphdb.internal
 
ElementHelper - Class in com.thinkaurelius.titan.graphdb.util
 
ElementHelper() - Constructor for class com.thinkaurelius.titan.graphdb.util.ElementHelper
 
ElementLifeCycle - Class in com.thinkaurelius.titan.graphdb.internal
ElementLifeCycle enumerates all possible states of the lifecycle of a entity.
ElementLifeCycle() - Constructor for class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
ElementLifeCycle.Event - Enum in com.thinkaurelius.titan.graphdb.internal
 
elementProcessor - Variable in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
elementProcessorImpl - Variable in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
ElementQuery<R extends TitanElement,B extends BackendQuery<B>> - Interface in com.thinkaurelius.titan.graphdb.query
A query that returns TitanElements.
ElementUtils - Class in com.thinkaurelius.titan.graphdb.tinkerpop
Created by bryn on 07/05/15.
ElementUtils() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.ElementUtils
 
emit(K, V) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMapEmitter
 
emit(OK, OV) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraReduceEmitter
 
EMPTY - Static variable in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
EMPTY - Static variable in interface com.thinkaurelius.titan.diskstorage.configuration.ReadConfiguration
 
EMPTY - Static variable in interface com.thinkaurelius.titan.diskstorage.StoreMetaData
 
EMPTY - Static variable in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionAssignment
Default assignment (when no id has been assigned yet)
EMPTY - Static variable in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
 
EMPTY_ITERATOR - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
EMPTY_LIST - Static variable in interface com.thinkaurelius.titan.diskstorage.EntryList
 
EMPTY_METADATA - Static variable in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
 
EMPTY_RETRIEVER - Static variable in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
EMPTY_SCHEMA - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
emptyBuffer() - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
emptyIterable() - Static method in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
EmptyList() - Constructor for class com.thinkaurelius.titan.diskstorage.EntryList.EmptyList
 
emptyQuery(ElementCategory) - Static method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
emptyQuery() - Static method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
emptyQuery(InternalVertex) - Static method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
EmptyRelationType - Class in com.thinkaurelius.titan.graphdb.types.system
 
EmptyRelationType() - Constructor for class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
emptyResult() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
emptyResult() - Method in interface com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.ResultConstructor
 
emptyResult() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
emptyResult() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
emptyResults(List<StaticBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
EmptyVertex - Class in com.thinkaurelius.titan.graphdb.types.system
 
EmptyVertex() - Constructor for class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
enableBatchLoading() - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Enabling batch loading disables a number of consistency checks inside Titan to speed up the ingestion of data under the assumptions that inconsistencies are resolved prior to loading.
enableBatchLoading() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
enableCache() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
encode(boolean) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanSerializer
 
encode(long) - Static method in class com.thinkaurelius.titan.util.encoding.LongEncoding
 
encode(long, String) - Static method in class com.thinkaurelius.titan.util.encoding.LongEncoding
 
endInclusive() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
endInclusive() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
endInclusive() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
Entry - Interface in com.thinkaurelius.titan.diskstorage
An entry is the primitive persistence unit used in the graph database storage backend.
Entry(TransactionLogHeader, StaticBuffer, LogTxStatus, EnumMap<LogTxMeta, Object>) - Constructor for class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
Entry(SchemaSource, Object) - Constructor for class com.thinkaurelius.titan.graphdb.types.SchemaSource.Entry
 
ENTRY2COLUMN_FCT - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
ENTRY2FIELD_FCT - Static variable in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
ENTRY_GETTER - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
ENTRY_SIZE_ESTIMATE - Static variable in class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
 
EntryArrayList - Class in com.thinkaurelius.titan.diskstorage.util
 
EntryArrayList() - Constructor for class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
 
EntryArrayList(Collection<? extends Entry>) - Constructor for class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
 
EntryList - Interface in com.thinkaurelius.titan.diskstorage
 
EntryList.EmptyList - Class in com.thinkaurelius.titan.diskstorage
 
EntryMetaData - Enum in com.thinkaurelius.titan.diskstorage
 
EntryMetaData.Map - Class in com.thinkaurelius.titan.diskstorage
 
entrySet() - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
EnumSerializer<E extends Enum> - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
EnumSerializer(Class<E>) - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.EnumSerializer
 
equals(Object) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
 
equals(Object) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.Point
 
equals(Object) - Method in class com.thinkaurelius.titan.core.schema.Parameter
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
equals(Object) - Method in interface com.thinkaurelius.titan.diskstorage.log.MessageReader
Need to override this method because the Log uses this comparison when unregistering readers
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
equals(StaticBuffer, ByteBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
Thread safe equals method for StaticBuffer - ByteBuffer equality comparison
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.util.KeyColumn
 
equals(Object) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.configuration.RegisteredAttributeClass
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
equals(Object) - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.DirectionCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.FixedCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceDirectionCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.RelationTypeCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.IndexLockTuple
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.types.IndexField
 
equals(Object) - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
equals(Object) - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
equals(Object) - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
equals(Object) - Method in class com.thinkaurelius.titan.util.datastructures.LongCounter
 
equals(Object) - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
equals(Object) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
evaluate(TitanRelation) - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.And
 
evaluate(E) - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.DirectionCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.FixedCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceDirectionCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.Or
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.RelationTypeCondition
 
evaluate(E) - Method in class com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition
 
EVENT_NAMES - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
evictedEntry(Long, V) - Method in interface com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.EvictionListener
 
ExceptionFactory - Class in com.thinkaurelius.titan.graphdb.util
 
ExceptionFactory() - Constructor for class com.thinkaurelius.titan.graphdb.util.ExceptionFactory
 
ExceptionUtil - Class in com.thinkaurelius.titan.util.datastructures
Utility class for analyzing exceptions
ExceptionUtil() - Constructor for class com.thinkaurelius.titan.util.datastructures.ExceptionUtil
 
execute() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
execute(Callable<V>, Duration) - Static method in class com.thinkaurelius.titan.diskstorage.util.BackendOperation
 
execute(BackendOperation.Transactional<R>, BackendOperation.TransactionalProvider, TimestampProvider) - Static method in class com.thinkaurelius.titan.diskstorage.util.BackendOperation
 
execute(BackendOperation.Transactional<R>, BackendOperation.TransactionalProvider, TimestampProvider, Duration) - Static method in class com.thinkaurelius.titan.diskstorage.util.BackendOperation
 
execute(BackendTransaction) - Method in class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
execute(Q, B, Object, QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.MetricsQueryExecutor
 
execute(Q, B, Object, QueryProfiler) - Method in interface com.thinkaurelius.titan.graphdb.query.QueryExecutor
Executes the given sub-query against a data store and returns an iterator over the results.
execute(RelationCategory, BasicVertexCentricQueryBuilder.ResultConstructor<Q>) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
execute(RelationCategory, BasicVertexCentricQueryBuilder.ResultConstructor<Q>) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
executeDirect(Callable<V>, Duration) - Static method in class com.thinkaurelius.titan.diskstorage.util.BackendOperation
 
executeImplicitKeyQuery(InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
If BaseVertexCentricQueryBuilder.isImplicitKeyQuery(com.thinkaurelius.titan.graphdb.internal.RelationCategory) is true, this method provides the result set for the query based on the evaluation of the ImplicitKey.
executeImplicitKeyQuery() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
executeMultiQuery(Collection<InternalVertex>, SliceQuery, QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
executeQuery(IndexQueryBuilder, ElementCategory, BackendTransaction, StandardTitanTx) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
executeQuery(TitanVertexQuery) - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
executeRelations(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
executeVertexIds(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
executeVertices(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
exhaustedPartition(int) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.IDPlacementStrategy
Called when there are no more idAuthorities left in the given partition.
exhaustedPartition(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
ExpectedValueCheckingStore - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
A KeyColumnValueStore wrapper intended for nontransactional stores that forwards all but these two methods to an encapsulated store instance:

ExpectedValueCheckingStore.acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) ExpectedValueCheckingStore.mutate(StaticBuffer, List, List, StoreTransaction)

This wrapper adds some logic to both of the overridden methods before calling the encapsulated store's version.

ExpectedValueCheckingStore(KeyColumnValueStore, Locker) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
 
ExpectedValueCheckingStoreManager - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
 
ExpectedValueCheckingStoreManager(KeyColumnValueStoreManager, String, LockerProvider, Duration) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
ExpectedValueCheckingTransaction - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
A StoreTransaction that supports locking via LocalLockMediator and writing and reading lock records in a ExpectedValueCheckingStore.
ExpectedValueCheckingTransaction(StoreTransaction, StoreTransaction, Duration) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
ExpirationKCVSCache - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache
 
ExpirationKCVSCache(KeyColumnValueStore, String, long, long, long) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
ExpiredLockException - Exception in com.thinkaurelius.titan.diskstorage.locking.consistentkey
 
ExpiredLockException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpiredLockException
 
ExpiredLockException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpiredLockException
 
ExpiredLockException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpiredLockException
 
expireSchemaElement(long) - Method in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
expireSchemaElement(long) - Method in interface com.thinkaurelius.titan.graphdb.database.cache.SchemaCache
 
expireSchemaElement(long) - Method in class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
ExternalCachePersistor - Class in com.thinkaurelius.titan.diskstorage.log.kcvs
 
ExternalCachePersistor(KCVSCache, CacheTransaction) - Constructor for class com.thinkaurelius.titan.diskstorage.log.kcvs.ExternalCachePersistor
 
ExternalPersistor - Interface in com.thinkaurelius.titan.diskstorage.log.kcvs
 
extractOrCondition(Or<TitanRelation>) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 

F

Factory<O> - Interface in com.thinkaurelius.titan.util.datastructures
Factory interface for the factory design pattern
failed(Throwable) - Method in class com.thinkaurelius.titan.diskstorage.log.util.FutureMessage
This method should be called by implementations when the message could not be added to the log with the respective exception object.
FAILED_TX - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
failedIndexes - Variable in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.SecondaryFailures
 
FakeLock - Class in com.thinkaurelius.titan.graphdb.transaction.lock
 
features() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
features() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
features() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
field - Variable in class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
fillBuffer(int, byte) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
filter(String, String) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationFileFilter
 
finalize() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
findEdge(TitanTransaction) - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
findParameter(Parameter[], V) - Method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
 
findProperty(TitanTransaction) - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
FITTED_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
FixedCondition<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
A fixed valued literal, which always returns either true or false irrespective of the element which is evaluated.
FixedCondition(boolean) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.FixedCondition
 
flatMap(Traverser.Admin<Element>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
flatMap(Traverser.Admin<Vertex>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
FLOAT_LEN - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
FloatArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
FloatArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatArraySerializer
 
FloatSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
FloatSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatSerializer
 
floatToSortableInt(float) - Static method in class com.thinkaurelius.titan.util.encoding.NumericUtils
Converts a float value to a sortable signed int.
foldInHasContainer(HasStepFolder, Traversal.Admin<?, ?>) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
foldInOrder(HasStepFolder, Traversal.Admin<?, ?>, Traversal<?, ?>, boolean) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
foldInRange(HasStepFolder, Traversal.Admin<?, ?>) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
FORCE_INDEX_USAGE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
forceCloseInstance(String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Forcefully removes a Titan instance from this graph cluster as identified by its name.
forceCloseInstance(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
freezeConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
fromConfig(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
fromIdentifierOrNow(String) - Static method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Like #fromIdentifierOrTime(String, long, java.util.concurrent.TimeUnit) but uses the current time point as the starting timestamp if the log has no record of the id.
fromIdentifierOrTime(String, Instant) - Static method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Starts reading the log from the last recorded point in the log for the given id.
fromLockColumn(StaticBuffer, TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
fromNow() - Static method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Starts reading the log such that it will start with the first entry written after now.
fromPosition(int) - Static method in class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
fromTime(Instant) - Static method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Starts reading the log from the given timestamp onward.
fromVertexId(long) - Static method in class com.thinkaurelius.titan.core.util.TitanId
Converts a Titan vertex id to the user provided id as the inverse mapping of TitanId.toVertexId(long).
fromVertexID(TitanVertex) - Static method in class com.thinkaurelius.titan.core.util.TitanId
Converts a Titan vertex id of a given vertex to the user provided id as the inverse mapping of TitanId.toVertexId(long).
FROZEN_KEY - Static variable in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
FulgoraElementTraversal<S,E> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraGraphComputer - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraGraphComputer(StandardTitanGraph, Configuration) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
FulgoraMapEmitter<K,V> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraMapEmitter(boolean) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMapEmitter
 
FulgoraMemory - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraMemory(VertexProgram<?>, Set<MapReduce>) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
FulgoraReduceEmitter<OK,OV> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraReduceEmitter() - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraReduceEmitter
 
FulgoraUtil - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraUtil() - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraUtil
 
FulgoraVertexMemory<M> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraVertexMemory(int, IDManager, VertexProgram<M>) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
FulgoraVertexProperty<V> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
FulgoraVertexProperty(VertexMemoryHandler, TitanVertex, String, V) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
FULLSCAN_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
FutureMessage<M extends Message> - Class in com.thinkaurelius.titan.diskstorage.log.util
Implementation of a Future for Messages that are being added to the Log via Log.add(com.thinkaurelius.titan.diskstorage.StaticBuffer).
FutureMessage(M) - Constructor for class com.thinkaurelius.titan.diskstorage.log.util.FutureMessage
 

G

g - Variable in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
GANGLIA_ADDRESSING_MODE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Whether to interpret GraphDatabaseConfiguration.GANGLIA_HOST_OR_GROUP as a unicast or multicast address.
GANGLIA_HOST_OR_GROUP - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The unicast host or multicast group name to which Metrics will send Ganglia data.
GANGLIA_INTERVAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds to wait between sending Metrics data to the host or group specified by GraphDatabaseConfiguration.GANGLIA_HOST_OR_GROUP.
GANGLIA_PORT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The port to which Ganglia data are sent.
GANGLIA_SPOOF - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The multicast TTL to set on outgoing Ganglia datagrams.
GANGLIA_USE_PROTOCOL_31 - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The host UUID to set on outgoing Ganglia datagrams.
Geo - Enum in com.thinkaurelius.titan.core.attribute
Comparison relations for geographic shapes.
geoDisjoint(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Geo
 
geoIntersect(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Geo
 
Geoshape - Class in com.thinkaurelius.titan.core.attribute
A generic representation of a geographic shape, which can either be a single point, circle, box, or polygon.
Geoshape.GeoshapeGsonSerializer - Class in com.thinkaurelius.titan.core.attribute
 
Geoshape.GeoshapeSerializer - Class in com.thinkaurelius.titan.core.attribute
 
Geoshape.Point - Class in com.thinkaurelius.titan.core.attribute
A single point representation.
Geoshape.Type - Enum in com.thinkaurelius.titan.core.attribute
The Type of a shape: a point, box, circle, or polygon
GeoshapeGsonSerializer() - Constructor for class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeGsonSerializer
 
GeoshapeSerializer() - Constructor for class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeSerializer
 
geoWithin(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Geo
 
get(String) - Method in interface com.thinkaurelius.titan.core.schema.TitanConfiguration
Returns a string representation of the provided configuration option or namespace for inspection.
get(int) - Method in interface com.thinkaurelius.titan.core.VertexList
Returns the vertex at a given position in the list.
get(String, Class<O>) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
get(String, Class<O>) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
Reads the configuration property for this StoreManager
get(ConfigOption<O>, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
get(Object) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
get(ConfigOption<O>, String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
get(ConfigOption<O>, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
get(ConfigOption<O>, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
get(String, Class<O>) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.ReadConfiguration
 
get(String, Class<O>) - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
get(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
 
get(int) - Method in class com.thinkaurelius.titan.diskstorage.EntryList.EmptyList
 
get(String, String) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation.IndexRetriever
Returns the KeyInformation for a particular key in a given store.
get(String) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation.IndexRetriever
Returns a KeyInformation.StoreRetriever for the given store on this IndexRetriever
get(String) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation.Retriever
Returns the KeyInformation.IndexRetriever for a given index.
get(String) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation.StoreRetriever
Returns the KeyInformation for a particular key for this store
get(KeyColumnValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns the value associated with the given key.
get(ScanMetrics.Metric) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics
Get the value of a standard counter.
get(ScanMetrics.Metric) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
get(String, TimestampProvider) - Method in interface com.thinkaurelius.titan.diskstorage.locking.LocalLockMediatorProvider
Returns a the single LocalLockMediator responsible for the specified namespace.
get(String, TimestampProvider) - Method in enum com.thinkaurelius.titan.diskstorage.locking.LocalLockMediators
 
get(byte[], int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer.Factory
 
get(K) - Method in class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
get() - Method in enum com.thinkaurelius.titan.diskstorage.util.HashUtility
 
get(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
get(String) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexInfoRetriever
 
get(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
get(String) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
get() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
get(int) - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
get(int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
get(int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
get(long) - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
get(long[]) - Static method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
get(int[]) - Static method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
get(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanGraphVariables
 
get(Object, PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.ConcurrentIndexCache
 
get(Object, PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.transaction.indexcache.IndexCache
 
get(Object, PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.SimpleIndexCache
 
get(int) - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
get(long, Retriever<Long, InternalVertex>) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 
get(long, Retriever<Long, InternalVertex>) - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.LRUVertexCache
 
get(long, Retriever<Long, InternalVertex>) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
get(Object) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
get() - Method in class com.thinkaurelius.titan.util.datastructures.LongCounter
 
get(I) - Method in interface com.thinkaurelius.titan.util.datastructures.Retriever
 
getActualStatus() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getAddedRelations(Predicate<InternalRelation>) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
getAddedRelations(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
getAddedRelations(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
getAdditions() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Returns the list of additions in this mutation
getAdditionTime(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getAdditionTimeInstant(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getAll() - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
getAll() - Method in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
This method returns all relations in this container.
getAll() - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleAddedRelations
 
getAll() - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
getAll() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
getAll() - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
getAll() - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
getAll() - Method in interface com.thinkaurelius.titan.util.datastructures.IntSet
 
getAllContainedIDs() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getAllManagerClasses() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
 
getAllNew() - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 
getAllNew() - Method in class com.thinkaurelius.titan.graphdb.transaction.vertexcache.LRUVertexCache
 
getAllNew() - Method in interface com.thinkaurelius.titan.graphdb.transaction.vertexcache.VertexCache
Returns an iterable over all new vertices in the cache
getAllProviderClasses() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
 
getAllRepresentatives(TitanVertex, boolean) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getAllShorthands() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
 
getAllShorthands() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
 
getAnnotation(String) - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
getAnnotations() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
getApplicableStatus() - Method in enum com.thinkaurelius.titan.core.schema.SchemaAction
 
getArity() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
Number of vertices on this relation.
getArity() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
getArity() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortArraySerializer
 
getArray(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringArraySerializer
 
getAsciiByteLength(String) - Static method in class com.thinkaurelius.titan.util.encoding.StringEncoding
 
getAt(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRange
 
getAutoSchemaMaker() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getAutoSchemaMaker() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
 
getBackend() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getBackend() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getBackendDescription() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getBackendQuery() - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
getBackingIndex() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns the name of the backing index.
getBackingIndex() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
getBackingIndexName() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getBackingIndexName() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getBaseTransactionConfig() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
getBaseType() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getBaseType() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getBaseType(InternalRelationType) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
getBaseType() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getBlockSize(int) - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
Returns the block size of the specified partition as determined by the configured IDBlockSizer.
getBlockSize(int) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.IDBlockSizer
The size of the id block to be returned by calls IDAuthority.getIDBlock(int,int, Duration) for the given id namespace.
getBlockSize(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.StaticIDBlockSizer
 
getBoolean() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getBoolean(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getBoolean() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getBoolean(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getBounds(RelationCategory, boolean) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
getByClazz(Class<? extends Element>) - Static method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
getByName(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
getByte() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getByte(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getByte() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getByte(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getByteLength(V) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList.MetaDataSerializer
 
getBytes(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getBytes(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getBytes(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getBytes(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getByteSize() - Method in class com.thinkaurelius.titan.diskstorage.EntryList.EmptyList
 
getByteSize() - Method in interface com.thinkaurelius.titan.diskstorage.EntryList
Returns the total amount of bytes this entry consumes on the heap - including all object headers.
getByteSize() - Method in class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
This implementation is an inexact estimate.
getByteSize() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
getCache() - Method in interface com.thinkaurelius.titan.diskstorage.Entry
Returns the cached parsed representation of this Entry if it exists, else NULL
getCache() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
getCacheMarker() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CachableStaticBuffer
 
getCanonicalId(long) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
getCanonicalVertex(InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getCanonicalVertexId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
getCanonicalVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getCardinality() - Method in enum com.thinkaurelius.titan.core.Multiplicity
 
getCardinality() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation
Returns the Cardinality for this key.
getCardinality() - Method in class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
getCardinality() - Method in class com.thinkaurelius.titan.graphdb.schema.RelationTypeDefinition
 
getCardinality() - Method in interface com.thinkaurelius.titan.graphdb.types.CompositeIndexType
 
getCardinality() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getCategory() - Method in enum com.thinkaurelius.titan.graphdb.database.management.ModifierType
 
getCategory() - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionDescription
 
getChar() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getChar(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getChar() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getChar(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getChars(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getChars(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getChars(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getChars(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getChild(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
 
getChild() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
getChildren() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
 
getChildren() - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
getChildren() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
getChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Literal
 
getChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
getChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
getColumn() - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
getColumn() - Method in class com.thinkaurelius.titan.diskstorage.util.KeyColumn
 
getColumn(E) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.GetColVal
 
getColumnAs(StaticBuffer.Factory<T>) - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
getCommitTime() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
getCommitTime() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getCommonConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
getCommonOrder() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
getCompareId() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
Long identifier used to compare elements.
getCompareId(Element) - Static method in class com.thinkaurelius.titan.graphdb.util.ElementHelper
 
getCompareId() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
getComponents(String) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getCompositeQuery() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
getCondition() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
getCondition() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
getCondition() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
getConfiguration() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfigurable
Get the configuration for this transaction
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreTransaction
 
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
Returns the backing configuration as a ReadConfiguration that can be used to create and configure a Titan graph.
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.util.DefaultTransaction
 
getConfiguration() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getConfiguration() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getConfiguration() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getConfigurationAtOpen() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getConsistency(TitanSchemaElement) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Retrieves the consistency modifier for the given TitanSchemaElement.
getConsistency(TitanSchemaElement) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
Retrieves the consistency level for a schema element (types and internal indexes)
getConsistencyModifier() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getConsistencyModifier() - Method in interface com.thinkaurelius.titan.graphdb.types.CompositeIndexType
 
getConsistencyModifier() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getConsistencyModifier() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseRelationType
 
getConsistencyModifier() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
getConsistencyModifier(SchemaSource) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
getConsistencyModifier() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getConsistentTx() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getContainedNamespaces(ReadConfiguration, ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
getContainedNamespaces(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
getContent() - Method in interface com.thinkaurelius.titan.diskstorage.log.Message
Returns the content of the message
getContent() - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
getContent() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getContentAsModifications(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getContentAsSecondaryFailures(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getConvergedKeys() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getConversionFunction(ElementCategory) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getCount(int) - Method in class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
getCount(K) - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
getCounter(String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getCounter(String, String...) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getCountSave(K) - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
getCumulativeEvictions() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCumulativeHits() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCumulativeLookups() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCumulativeMisses() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCumulativeNonLivePuts() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCumulativePuts() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCurrentSize() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
getCurrentThreadTx() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getCustom(String) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics
Get the value of a custom counter.
getCustom(String) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
getCustomOption(ConfigOption<V>) - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Get an arbitrary transaction-specific option.
getCustomOption(ConfigOption<V>) - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
getCustomOption(ConfigOption<V>) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getCustomOptions() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Return any transaction-specific options.
getCustomOptions() - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
getCustomOptions() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getDataOutput(int) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.Serializer
 
getDataOutput(int) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
getDataSerializer() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getDatatype() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getDataType() - Method in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
 
getDatatype() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
getDataType() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation
Returns the data type of the key's values.
getDataType() - Method in class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
getDataType() - Method in interface com.thinkaurelius.titan.diskstorage.StoreMetaData
 
getDataType() - Method in class com.thinkaurelius.titan.graphdb.schema.PropertyKeyDefinition
 
getDataType() - Method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
getDefaultFieldName(PropertyKey, Parameter[], String) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getDefaultMediator() - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
Get the default LocalLockMediator for Locker being built.
getDefaultMediator() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
getDefaultSchemaMaker() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getDefaultStringMapping() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
getDefaultValue() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getDefinition() - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
 
getDefinition() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getDeletions() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Returns the list of deletions in this mutation.
getDeletionTime(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
getDeployment() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
Returns the DistributedStoreManager.Deployment mode of this connection to the storage backend
getDeprecationReplacement() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getDescription() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getDirection() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeIndex
Returns the direction on which this index is installed.
getDirection() - Method in enum com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler.DirectionID
 
getDirection() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getDirection() - Method in class com.thinkaurelius.titan.graphdb.query.condition.DirectionCondition
 
getDirection() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
getDirtyVertexSize() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getDirtyVertexSize() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
The initial size of the dirty (modified) vertex map used by a transaction.
getDouble() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getDouble(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getDouble() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getDouble(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getDoubles(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getDoubles(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getDoubles(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getDoubles(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getEdgeId(Object) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.ElementUtils
 
getEdgeLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the edge label with the given name.
getEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getEdgeLabel(String) - Method in interface com.thinkaurelius.titan.graphdb.schema.SchemaProvider
 
getEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getEdgeLabels() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getEdges(Vertex, Change, Direction, String...) - Method in interface com.thinkaurelius.titan.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(RelationIdentifier...) - Method in interface com.thinkaurelius.titan.core.TitanTransaction
 
getEdges(StandardTitanTx, PropertyKey, Object) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
getEdges(StandardTitanTx, String, Object) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
getEdges(RelationIdentifier...) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getEdges(TypeDefinitionCategory, Direction) - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getEdges(TypeDefinitionCategory, Direction, TitanSchemaVertex) - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getEdgeSerializer() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getEdgeSerializer() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getElapsed() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getElapsed() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getElement() - Method in exception com.thinkaurelius.titan.core.InvalidElementException
Returns the element causing the exception
getElement() - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery.Result
Returns the element that matches the query
getElement() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
getElement() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getElement() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getElementType() - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
getEnd() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRange
 
getEnd() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getEnd() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
getEnd() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
getEnd() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
getEntries() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
 
getEntry() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
getEnumValue(String, Class<E>) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getErrorSettingCount() - Method in class com.thinkaurelius.titan.util.system.ConfigurationLint.Status
 
getExecutionInfo() - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
getExistingEdgeLabel(long) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
getExistingPropertyKey(long) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
getExistingRelationType(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getExistingRelationType(long) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
getExistingVertexLabel(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getExistingVertexLabel(long) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
getExpirationTimestamp() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
getExpirationTimestamp() - Method in interface com.thinkaurelius.titan.diskstorage.locking.LockStatus
Returns the moment at which this lock expires (inclusive).
getFailureStatus() - Method in enum com.thinkaurelius.titan.core.schema.SchemaAction
 
getFeatures() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.IndexInformation
The features of this index
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getFeatures() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreManager
Returns the features supported by this storage manager
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
getFeatures() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
getFeatures() - Method in class com.thinkaurelius.titan.graphdb.database.indexing.StandardIndexInformation
 
getFeatures(StandardTitanGraph, StoreFeatures) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanFeatures
 
getField(PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getField(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getField(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
getField(PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.types.MixedIndexType
 
getFieldKey() - Method in class com.thinkaurelius.titan.graphdb.types.IndexField
 
getFieldKeys() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns the indexed keys of this index.
getFieldKeys() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
getFieldKeys() - Method in interface com.thinkaurelius.titan.graphdb.types.CompositeIndexType
 
getFieldKeys() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getFieldKeys() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getFieldKeys() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
getFieldKeys() - Method in interface com.thinkaurelius.titan.graphdb.types.MixedIndexType
 
getFloat() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getFloat(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getFloat() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getFloat(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getFloats(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getFloats(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getFloats(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getFloats(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getFromCache(SliceQuery) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
getGlobalRange(int) - Static method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getGlobalSystemConfig() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getGlobalSystemConfig(Backend) - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getGraph() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraElementTraversal
 
getGraph() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
Returns the graph that this transaction is based on
getGraph() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getGraphIndex(String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns the graph index with the given name or null if it does not exist
getGraphIndex(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getGraphIndexDirect(String, StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getGraphIndexes(Class<? extends Element>) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns all graph indexes that index the given element type.
getGraphIndexes(Class<? extends Element>) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getGroupName() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Returns the (possibly null) group name for this transaction.
getGroupName() - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
getGroupName() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
getGroupName() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getHeader() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getHeapArray() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
This method returns the internal heap array as Object[].
getHistogram(String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getHistogram(String, String...) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getHomeDirectory() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Returns the home directory for the graph database initialized in this configuration
getHomePath() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Returns the home directory path for the graph database initialized in this configuration
getID(int) - Method in interface com.thinkaurelius.titan.core.VertexList
Returns the id of the vertex at the specified position
getId(long) - Method in interface com.thinkaurelius.titan.diskstorage.IDBlock
Returns the id at the given index.
getId() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
getID(int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
getID(int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
getID() - Method in interface com.thinkaurelius.titan.graphdb.types.CompositeIndexType
 
getID() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getIDAssigner(Backend) - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getIDAuthority() - Method in class com.thinkaurelius.titan.diskstorage.Backend
Returns the configured IDAuthority.
getIDBlock(int, int, Duration) - Method in interface com.thinkaurelius.titan.diskstorage.IDAuthority
Returns a block of new ids in the form of IDBlock.
getIDBlock(int, int, Duration) - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
getIdentifier() - Method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Returns the configured identifier of this marker or throws an exception if none exists.
getIdInspector() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getIDManager() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
getIDManager() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getIdMap(Iterable<K>) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
getIDRanges(int, List<KeyRange>) - Static method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getIDs() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
getIDs() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
getIdUpperBound(int) - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
getIdUpperBound(int) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.IDBlockSizer
Returns the upper bound for any id block returned by IDAuthority.getIDBlock(int,int, Duration) for the given id namespace.
getIdUpperBound() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getIdUpperBound(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.StaticIDBlockSizer
 
getImplementationClass(Configuration, String, Map<String, String>) - Static method in class com.thinkaurelius.titan.diskstorage.Backend
 
getInconsistentTx() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
getIndex() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
getIndex() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getIndex() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
getIndex() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.IndexLockTuple
 
getIndexCacheWeight() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getIndexCacheWeight() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
The maximum weight for the index cache store used in this particular transaction
getIndexedElement() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns which element type is being indexed by this index (vertex, edge, or property)
getIndexedElement() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
getIndexedKeys(IndexType) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
getIndexFeatures() - Method in class com.thinkaurelius.titan.diskstorage.Backend
Returns the IndexFeatures of all configured index backends
getIndexIdFromKey(StaticBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getIndexInfoRetriever(StandardTitanTx) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getIndexInformation() - Method in class com.thinkaurelius.titan.diskstorage.Backend
Get information about all registered IndexProviders.
getIndexJobStatus(TitanIndex) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
If an index update job was triggered through TitanManagement.updateIndex(TitanIndex, SchemaAction) with schema actions SchemaAction.REINDEX or SchemaAction.REMOVE_INDEX then this method can be used to track the status of this asynchronous process.
getIndexJobStatus(TitanIndex) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getIndexName() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getIndexName() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getIndexSerializer() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getIndexStatus() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeIndex
Returns the status of this index
getIndexStatus(PropertyKey) - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns the status of this index with respect to the provided PropertyKey.
getIndexStatus() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getIndexStatus(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
getIndexTransaction(String) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
getIndexUpdates(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getIndexUpdates(InternalVertex, Collection<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getInstance() - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson.TitanGraphSONModule
 
getInstanceId() - Method in interface com.thinkaurelius.titan.core.log.TransactionId
Returns the unique id of the Titan graph instance which executed the transaction.
getInstanceId() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
getInt() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getInt(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getInt() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getInt(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getInt(byte[], int) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getIntBuffer(int) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
getIntBuffer(int[]) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
getIntermediateResult() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement.IndexJobFuture
Returns a set of potentially incomplete and still-changing metrics for this job.
getInternalVertex(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getInternalVertex(long) - Method in interface com.thinkaurelius.titan.graphdb.transaction.VertexFactory
 
getInts(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getInts(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getInts(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getInts(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getInVertexId() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
getIteration() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
getJobConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
getJobId() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
getKCVSLogManager(String) - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getKey() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
getKey() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
getKey() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
getKey(HashingUtil.HashLength, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.HashingUtil
 
getKey() - Method in class com.thinkaurelius.titan.diskstorage.util.KeyColumn
 
getKey() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
getKey(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getKey(int) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
getKey() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
getKey() - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
getKeyConsistentTxConfig() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getKeyConsistentTxConfig() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration that enforces key consistency.
getKeyEnd() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
getKeyFilter() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanJob
A predicate that determines whether ScanJob.process(com.thinkaurelius.titan.diskstorage.StaticBuffer, java.util.Map, ScanMetrics) should be invoked for the given key.
getKeyFilter() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
getKeyFilter() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
getKeyID(StaticBuffer) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getKeyIndexes() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getKeyIndexes() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
getKeyIndexes() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getKeyIndexes() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getKeys(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
getKeys(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
getKeys(String) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.ReadConfiguration
 
getKeys(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
getKeys(SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
getKeys(SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
getKeys(KeyColumnValueStore, StoreFeatures, int, int, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
getKeys(KeyColumnValueStore, SliceQuery, StoreFeatures, int, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getKeys(SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getKeys(KeyRangeQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
getKeys(SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
getKeySelector() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getKeyStart() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
getLatestAccessedItems(int) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
getLatitude() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.Point
Latitude of this point
getLen() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
Number of vertices on this relation that are aware of its existence.
getLen() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
getLen() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
getLength(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
getLifeCycle() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalElement
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
getLifeCycle() - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
getLimit() - Method in class com.thinkaurelius.titan.graphdb.query.BaseQuery
 
getLimit() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
getLimit() - Method in interface com.thinkaurelius.titan.graphdb.query.Query
 
getLimit() - Method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
getLimit() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
getLimit() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
getLimit() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
getLoadedProperties() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionVertexAggregate
 
getLocalAddress() - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
getLocalConfiguration() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getLocalHost() - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
getLocalHostName() - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
getLocalIDPartition() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
getLocalKeyConsistentTxConfig() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getLocalKeyConsistentTxConfig() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration that enforces local key consistency.
getLocalKeyPartition() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
getLocalKeyPartition() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getLocalKeyPartition() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getLocalKeyPartition() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreManager
Returns KeyRanges locally hosted on this machine.
getLocalKeyPartition() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
getLock() - Static method in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
getLocker(String) - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getLocker(String) - Method in interface com.thinkaurelius.titan.diskstorage.locking.LockerProvider
 
getLocksForTx(StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.LockerState
 
getLogIdentifier() - Method in interface com.thinkaurelius.titan.core.log.LogProcessorBuilder
Returns the identifier of the transaction log to be processed by this processor.
getLogIdentifier() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getLogIdentifier() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
The name of the log to be used for logging the mutations in this transaction.
getLogKey() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
getLogManager(String) - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getLong() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getLong(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getLong() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getLong(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getLong(byte[], int) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getLongBuffer(long) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
getLongId() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
getLongitude() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.Point
Longitude of this point
getLongRepresentation() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
getLongs(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getLongs(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getLongs(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getLongs(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getLoopbackAddress() - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
getLowerID() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getManagedTypes() - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getManagerClass() - Method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
 
getMap() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
getMapping(KeyInformation) - Static method in enum com.thinkaurelius.titan.core.schema.Mapping
 
getMapping(String, String, KeyInformation.IndexRetriever) - Static method in enum com.thinkaurelius.titan.core.schema.Mapping
 
getMaxCommitTime() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getMaxObject() - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
getMaxWriteTime() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getMessage() - Method in class com.thinkaurelius.titan.diskstorage.log.util.FutureMessage
Returns the actual message that was added to the log
getMessage(MessageScope, Map<MessageScope, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
getMessageCombiner(VertexProgram<M>) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraUtil
 
getMetaData() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
getMetaData() - Method in interface com.thinkaurelius.titan.diskstorage.MetaAnnotated
Returns all meta data associated with this entry
getMetaData(E, EntryMetaData) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.GetColVal
 
getMetaData() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
getMetadata() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getMetaDataSchema(String) - Method in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreManager
 
getMetaSchema(E) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.GetColVal
 
getMetrics() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem.IndexJobStatus
 
getMetricsPrefix() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getMixedQuery() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
getModifier() - Method in class com.thinkaurelius.titan.graphdb.types.SchemaSource.Entry
 
getModifier() - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionDescription
 
getMultiplicity() - Method in class com.thinkaurelius.titan.graphdb.schema.RelationTypeDefinition
 
getMultiplicity() - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
getMutableVertexProperties() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
getN() - Method in class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
getName() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeMaker
Returns the name of this configured relation type.
getName() - Method in interface com.thinkaurelius.titan.core.schema.VertexLabelMaker
Returns the name of the to-be-build vertex label
getName() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
getName() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
Returns the name of this store.
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
getName() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueStore
Returns the name of this store
getName() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
getName() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreManager
Return an identifier for the StoreManager.
getName() - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
getName() - Method in interface com.thinkaurelius.titan.diskstorage.log.Log
Returns the name of this log
getName() - Method in enum com.thinkaurelius.titan.diskstorage.util.CacheMetricsAction
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
getName() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
getName() - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
getName(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
getName() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
getName() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getName() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getName() - Method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
 
getName() - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
getName() - Method in class com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
getNamespace() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getNew(Q) - Method in class com.thinkaurelius.titan.graphdb.query.MetricsQueryExecutor
 
getNew(Q) - Method in interface com.thinkaurelius.titan.graphdb.query.QueryExecutor
Returns all newly created elements in a transactional context that match the given query.
getNewIterator(int) - Method in class com.thinkaurelius.titan.graphdb.query.LimitAdjustingIterator
This returns the wrapped iterator with up to the specified number of elements.
getNextNonIdentityStep(Step) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
getNextTx() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getNoCombinedQueries() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.QueryDescription
Returns the number of sub-queries this query is comprised of.
getNotConvergedKeys() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getNumCompactions() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
getNumProcessed() - Method in class com.thinkaurelius.titan.core.schema.JobStatus
 
getObjects() - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
getOffset() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
getOffset() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getOldestAccessedItems(int) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
Returns 'n' number of oldest accessed entries present in this cache.
getOpenInstances() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns a set of unique instance ids for all Titan instances that are currently part of this graph cluster.
getOpenInstances() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getOpenInstancesInternal() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getOpenTransactions() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getOptionForShorthand(String) - Static method in class com.thinkaurelius.titan.diskstorage.Backend
 
getOrCreateDataDirectory(String) - Static method in class com.thinkaurelius.titan.diskstorage.util.DirectoryUtil
 
getOrCreateEdgeLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the edge label with the given name.
getOrCreateEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getOrCreateEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getOrCreateEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getOrCreatePropertyKey(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the property key with the given name.
getOrCreatePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getOrCreatePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getOrCreatePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getOrCreateVertexLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the vertex label with the given name.
getOrCreateVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getOrCreateVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getOrCreateVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getOrder() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
getOrder() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
getOrder(int) - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
getOrder() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
getOrder() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
getOrders() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
getOrGenerateUniqueInstanceId(Configuration) - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getOtherPartitionVertex(TitanVertex, long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getOtherVertexId() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
getOutVertexId() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
getPageSize() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
Returns the default configured page size for this storage backend.
getParameter(V) - Method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
 
getParameters() - Method in interface com.thinkaurelius.titan.diskstorage.indexing.KeyInformation
Returns the parameters of the key's configuration.
getParameters() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
getParameters() - Method in class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
getParameters() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getParameters() - Method in class com.thinkaurelius.titan.graphdb.types.ParameterIndexField
 
getParametersFor(PropertyKey) - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns the parameters associated with an indexed key of this index.
getParametersFor(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
getPartition(InternalElement) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.IDPlacementStrategy
Individually assigns an id to the given vertex or relation.
getPartition(InternalElement) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
getPartition(InternalElement) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
getPartitionBound() - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getPartitionedVertexId(long, long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getPartitionedVertexRepresentatives(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getPartitionHashForId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getPartitionID() - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionAssignment
Returns the assigned partition id
getPartitionID() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
getPartitionId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getPartitionKey(int) - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
Returns a byte buffer representation for the given partition id
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.IDPlacementStrategy
Bulk assignment of idAuthorities to vertices.
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
getPartitions(Map<InternalVertex, PartitionAssignment>) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
getPath(ConfigElement, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
getPath(ConfigElement, String...) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getPath(ConfigElement, boolean, String...) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getPath(File) - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getPoint(int) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Returns the point at the given position.
getPoint() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Returns the singleton point of this shape.
getPoints() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
getPoints() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
getPoints() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
getPosition() - Method in interface com.thinkaurelius.titan.diskstorage.ReadBuffer
 
getPosition() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getPosition() - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
getPosition() - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
getPowerOf2(long) - Static method in class com.thinkaurelius.titan.util.stats.NumberUtil
Returns an integer X such that 2^X=value.
getPredicate() - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
getPreferredTimestamps() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getPreferredTimestamps() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
If this storage backend supports one particular type of data timestamp/version better than others.
getPrefix() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getPreviousID() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
getPreviousID() - Method in interface com.thinkaurelius.titan.graphdb.relations.StandardRelation
 
getPreviousID() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
getPreviousScopes() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
getProfiler() - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
getProfiler() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
getProperties(Vertex, Change, String...) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
getProperty(String, Map<String, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionVertexAggregate
 
getProperty(String, Map<String, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
getPropertyKey(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the property key with the given name.
getPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getPropertyKey(String) - Method in interface com.thinkaurelius.titan.graphdb.schema.SchemaProvider
 
getPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getPropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getPropertyKeys() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getPropertyKeys(TitanVertex) - Static method in class com.thinkaurelius.titan.graphdb.util.ElementHelper
 
getPropertyKeysDirect() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
 
getPropertyKeysDirect() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
getPropertyKeysDirect() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
getPropertyKeysDirect() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
getPropertyKeysDirect() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
getProtectedConstructor(Class, Class...) - Static method in class com.thinkaurelius.titan.diskstorage.util.Hex
Used to get access to protected/private constructor of the specified class
getProviderName() - Method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
 
getQueries() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanJob
Returns one or more SliceQuery instances belonging to this ScanJob.
getQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob.Executor
 
getQueries(QueryContainer) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
getQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob.Executor
 
getQueries(QueryContainer) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob
 
getQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
getQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
getQueries(QueryContainer) - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
getQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
getQueries(QueryContainer) - Method in interface com.thinkaurelius.titan.graphdb.olap.VertexScanJob
Specify the queries for the data to be loaded into the vertices prior to processing.
getQueries() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
getQuery() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
getQuery(RelationCategory, boolean) - Method in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
getQuery(InternalRelationType, Direction, EdgeSerializer.TypedInterval[]) - Method in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
getQuery(CompositeIndexType, List<Object[]>) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getQuery(MixedIndexType, Condition, OrderList) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
getQuery(RelationCategory) - Method in class com.thinkaurelius.titan.graphdb.database.RelationQueryCache
 
getQuery(InternalRelationType, Direction) - Method in class com.thinkaurelius.titan.graphdb.database.RelationQueryCache
 
getQuery() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getQuery(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
getQuery(CompositeIndexType, Object[], StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.util.IndexHelper
 
getQueryCacheSize() - Method in class com.thinkaurelius.titan.graphdb.vertices.CacheVertex
 
getQueryResults(CompositeIndexType, Object[], StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.util.IndexHelper
 
getRadius() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Returns the radius in kilometers of this circle.
getRandom() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
getRandomID() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
Returns a random partition id that lies within this partition id range.
getRecordValues() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexRecords
 
getRegisteredAttributeClasses(Configuration) - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getRegistry() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Return the Titan Metrics registry.
getRelated(TypeDefinitionCategory, Direction) - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
 
getRelated(TypeDefinitionCategory, Direction) - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getRelationCategory() - Method in enum com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler.DirectionID
 
getRelationCountBound() - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getRelationID(long, long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getRelationId() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
getRelationIndex(RelationType, String) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns the RelationTypeIndex with the given name for the provided RelationType or null if it does not exist
getRelationIndex(RelationType, String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getRelationIndexes(RelationType) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns an Iterable over all RelationTypeIndexes defined for the provided RelationType
getRelationIndexes(RelationType) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getRelationIndexes() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getRelationIndexes() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getRelationIndexes() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getRelations(Change, RelationType...) - Method in interface com.thinkaurelius.titan.core.log.ChangeState
Returns all relations that match the change state and any of the provided relation types.
getRelationType(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the type with the given name.
getRelationType(long, IDHandler.DirectionID, boolean) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
getRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getRelationType(String) - Method in interface com.thinkaurelius.titan.graphdb.schema.SchemaProvider
 
getRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getRelationType(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getRelationType(String) - Method in interface com.thinkaurelius.titan.graphdb.types.TypeInspector
 
getRelationTypeName() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getRelationTypeName(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
getRelationTypes(Class<T>) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
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 com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getRestrictedPartitions() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getRestrictedPartitions() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Querying of partitioned vertices is restricted to the partitions returned by this method.
getResult() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery.Result
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in interface com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.ResultConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
getResult(InternalVertex, BaseVertexCentricQuery) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
getResultSize() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
getResultType() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
getReverseElementTraversal(MessageScope.Local<?>, Vertex, TitanTransaction) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraUtil
 
getReverseTitanVertexStep(MessageScope.Local<?>, TitanTransaction) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraUtil
 
getRid() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid
 
getRoot() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
getRootNamespace() - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
getRunningJob(Object) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner
 
getRuntime() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
getScanJobStatus(Object) - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getScanTxConfig() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
getScanTxConfig() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Get a transaction configuration suitable for reading data into a ScanJob.
getSchemaBase() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getSchemaCache() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getSchemaCountBound() - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getSchemaElement(long) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getSchemaId(String) - Method in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
getSchemaId(String) - Method in interface com.thinkaurelius.titan.graphdb.database.cache.SchemaCache
 
getSchemaId(String) - Method in class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
getSchemaId(IDManager.VertexIDType, long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getSchemaName(String) - Method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in interface com.thinkaurelius.titan.graphdb.database.cache.SchemaCache
 
getSchemaRelations(long, BaseRelationType, Direction) - Method in class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
getSchemaType() - Method in class com.thinkaurelius.titan.graphdb.types.SchemaSource.Entry
 
getSchemaTypeConstraint() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
getSchemaTypeConstraint() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
getSchemaVertex(TitanSchemaElement) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getSchemaVertex(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getScore() - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery.Result
Returns the score of the result with respect to the query (if available)
getScore() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery.Result
 
getSenderId() - Method in interface com.thinkaurelius.titan.diskstorage.log.Message
Returns the unique identifier for the sender of the message
getSenderId() - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
getSentinelObject() - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.internal.Token
 
getSerializer(EntryMetaData) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
getSerializer() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getSerializer(Configuration) - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getShort() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getShort(int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getShort() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getShort(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getShorthands() - Method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
 
getShorthands() - Method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
 
getShorts(int) - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
getShorts(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
getShorts(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
getShorts(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
getSignature() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getSignature() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
getSignature() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getSignature() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getSingleHostname() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
Returns a randomly chosen host name.
getSingleType() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getSize(D) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.DataHandler
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
getSlice(KeySliceQuery, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
Retrieves the list of entries (i.e.
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
Retrieves the list of entries (i.e.
getSlice(OrderedKeyValueStore, StaticBuffer, StaticBuffer, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
getSlice(OrderedKeyValueStore, StaticBuffer, StaticBuffer, int, StoreTransaction) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVUtil
 
getSlice(KVQuery, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Returns a list of all Key-value pairs (KeyValueEntry where the keys satisfy the given KVQuery.
getSlice(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
getSlice(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
getSlice(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
getSliceEnd() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
The end of the slice is considered to be exclusive
getSliceNoCache(KeySliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
getSliceNoCache(List<StaticBuffer>, SliceQuery, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
getSliceQueries() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer
 
getSlices(List<KVQuery>, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Like OrderedKeyValueStore.getSlice(KVQuery, com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreTransaction) but executes all of the given queries at once and returns a map of all the result sets of each query.
getSliceStart() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
The start of the slice is considered to be inclusive
getSortKey() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeIndex
Returns the (composite) sort key for this index.
getSortKey() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getSortKey() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getSortKey() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getSortKey() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getSortOrder() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeIndex
Returns the sort order of this index.
getSortOrder() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getSortOrder() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getSortOrder() - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Returns the expected sort order of this query if any was specified.
getSortOrder() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
getSortOrder() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
getSortOrder() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getSortOrder() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getStandaloneGlobalConfiguration(KeyColumnValueStoreManager, Configuration) - Static method in class com.thinkaurelius.titan.diskstorage.Backend
 
getStart() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRange
 
getStart() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVQuery
 
getStart() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
getStart() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
getStart() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
getStartTime(TimestampProvider) - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.time.Timer
 
getState() - Method in class com.thinkaurelius.titan.core.schema.JobStatus
 
getStaticBuffer() - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
getStaticBuffer() - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
getStaticBufferFlipBytes(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
getStaticBufferFlipBytes(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
getStatistics() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionLogProcessor
 
getStats() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
getStatus() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
getStatus() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getStatus() - Method in interface com.thinkaurelius.titan.graphdb.types.CompositeIndexType
 
getStatus() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
getStatus() - Method in class com.thinkaurelius.titan.graphdb.types.ParameterIndexField
 
getStatus() - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
 
getStatus() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getStatus() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getStorageConfig() - Method in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreManager
 
getStorageManager(Configuration) - Static method in class com.thinkaurelius.titan.diskstorage.Backend
 
getStore() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
getStore() - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
getStoreFeatures() - Method in class com.thinkaurelius.titan.diskstorage.Backend
Returns the StoreFeatures of the configured backend storage engine.
getStoreFeatures() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getStoreManager() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getStoreManagerClass() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getStoreName() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
getStoreName() - Method in interface com.thinkaurelius.titan.graphdb.types.MixedIndexType
 
getStoreTransaction() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
getSubQueries() - Method in interface com.thinkaurelius.titan.core.QueryDescription
Returns a list of all sub-queries that comprise this query
getSubQuery(int) - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Returns the backend query at the given position that comprises this ElementQuery
getSubQuery(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
getSubQuery(int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
getSubset(ReadConfiguration, ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
getSubset(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
getSubset(ConfigNamespace, String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
getSubset(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
getSubset(ConfigNamespace, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
getSubset(SliceQuery, EntryList) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
getSucceeded() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getSucceeded() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getSystemMetricsPrefix() - Static method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getSystemMgmtLog() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getSystemTxLog() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getSystemType(long) - Static method in class com.thinkaurelius.titan.graphdb.types.system.SystemTypeManager
 
getSystemType(String) - Static method in class com.thinkaurelius.titan.graphdb.types.system.SystemTypeManager
 
getTargetStatus() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
getTargetStatus() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
getTemporaryRelationID(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getTemporaryVertexID(IDManager.VertexIDType, long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getThis() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
getThis() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getThis() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
getThis() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
getTime() - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Returns the current time based on this timestamp provider as a Instant.
getTime(long) - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Returns the given time as a Instant based off of this timestamp providers units
getTime(Instant) - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Returns the scalar value for this instant given the configured time unit
getTimer() - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Returns a Timer based on this timestamp provider
getTimer() - Method in enum com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders
 
getTimer(String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getTimer(String, String...) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
getTimestamp() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid
 
getTimestamp() - Method in interface com.thinkaurelius.titan.diskstorage.log.Message
Returns the timestamp of this message in the specified time unit.
getTimestamp() - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
getTimestamp() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
getTimestampProvider() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Returns the timestamp provider of this transaction.
getTimestampProvider() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
getTimestampProvider() - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
getTimestampProvider() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getTimestampProvider() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getTitanVertex(Element) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
getTitanVertex(Traverser<? extends Element>) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
getTotal() - Method in class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
getTotalMutations() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
 
getTotalSettingCount() - Method in class com.thinkaurelius.titan.util.system.ConfigurationLint.Status
 
getTotalTime() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
getTP() - Method in enum com.thinkaurelius.titan.graphdb.internal.Order
 
getTransaction() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer
 
getTransactionId() - Method in interface com.thinkaurelius.titan.core.log.TransactionId
Returns the unique transaction id within a particular Titan instance.
getTransactionId() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
getTransactionTime() - Method in interface com.thinkaurelius.titan.core.log.TransactionId
Returns the time of the transaction
getTransactionTime() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
getTTL(TitanSchemaType) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Retrieves the time-to-live for the given TitanSchemaType as a Duration.
getTTL(TitanSchemaType) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getTTL(InternalRelation) - Static method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
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 com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getTTL() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
getTTL() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertexLabel
 
getTTL() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
getTTL() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
getTTL(SchemaSource) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
getTTL() - Method in class com.thinkaurelius.titan.graphdb.types.VertexLabelVertex
 
getTTL() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
getTTLSeconds(Duration) - Static method in class com.thinkaurelius.titan.util.encoding.ConversionHelper
 
getTTLSeconds(long, TemporalUnit) - Static method in class com.thinkaurelius.titan.util.encoding.ConversionHelper
 
getTx(Traversal.Admin<?, ?>) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
getTxDirtyVertexSize() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getTxHandle() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getTxLogPersistor() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
getTxVertexCacheSize() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getType() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Returns the Geoshape.Type of this geoshape.
getType() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeIndex
Returns the RelationType on which this index is installed.
getType() - Method in interface com.thinkaurelius.titan.core.TitanRelation
Returns the type of this relation.
getType() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
getType() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
getType() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getType() - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
getType() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
getType() - Method in class com.thinkaurelius.titan.graphdb.query.condition.And
 
getType() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
getType() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Literal
 
getType() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
getType() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Or
 
getType(StandardTitanTx, String) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
getType() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
getTypeCache(SchemaCache.StoreRetrieval) - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getTypeId() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
getUniqueGraphId() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getUniqueID() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
getUniqueIndexes(PropertyKey) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
getUnit() - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Return the units of TimestampProvider.getTime().
getUnknownIndexKeyName() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
getUnknownKeyName() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
getUnqiuePrefixes(Configuration) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationUtil
 
getUpperID() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
getUserConfiguration() - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getUserLog(String) - Method in class com.thinkaurelius.titan.diskstorage.Backend
 
getUserLogName(String) - Static method in class com.thinkaurelius.titan.diskstorage.Backend
 
getValue() - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
getValue() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueEntry
 
getValue(E) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry.GetColVal
 
getValue(TransactionConfiguration) - Method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxMeta
 
getValue() - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
getValue() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
getValue(TypeDefinitionCategory) - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
getValue(TypeDefinitionCategory, Class<O>) - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
getValueAs(StaticBuffer.Factory<T>) - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
getValueDirect(PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
 
getValueDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
getValueDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
getValueDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
getValueDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
getValuePosition() - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
getValues(TitanElement, PropertyKey) - Static method in class com.thinkaurelius.titan.graphdb.util.ElementHelper
 
getValues() - Method in class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
getVertex(long) - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Retrieves the vertex for the specified id.
getVertex(int) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
Returns the vertex at the given position (0=OUT, 1=IN) of this relation
getVertex(long) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
getVertex(long) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
getVertex() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
getVertex(int) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
getVertex(int) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
getVertex(long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getVertexCacheSize() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
getVertexCacheSize() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
The maximum number of recently-used vertices to cache in this transaction.
getVertexCentricDirection() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
getVertexCountBound() - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getVertexID() - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
getVertexID(long, long, IDManager.VertexIDType) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
getVertexId(StaticBuffer) - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
getVertexId(Object) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.ElementUtils
 
getVertexIDs(BackendTransaction) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
getVertexLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaInspector
Returns the vertex label with the given name.
getVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getVertexLabel(String) - Method in interface com.thinkaurelius.titan.graphdb.schema.SchemaProvider
 
getVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
getVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getVertexLabelInternal() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
getVertexLabelInternal() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
getVertexLabels() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Returns an Iterable over all defined VertexLabels.
getVertexLabels() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getVertexLabels() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
getVertexMapJob(StandardTitanGraph, FulgoraVertexMemory, Map<MapReduce, FulgoraMapEmitter>) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
getVertexProgramScanJob(StandardTitanGraph, FulgoraMemory, FulgoraVertexMemory, VertexProgram<M>) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob
 
getVertices(Change) - Method in interface com.thinkaurelius.titan.core.log.ChangeState
Returns all added, removed, or modified vertices when the change argument is Change.ADDED, Change.REMOVED, or Change.ANY respectively.
getVertices(long...) - Method in interface com.thinkaurelius.titan.core.TitanTransaction
 
getVertices(StandardTitanTx, PropertyKey, Object) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
getVertices(StandardTitanTx, String, Object) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
getVertices(long...) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
getView(Predicate<InternalRelation>) - Method in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
 
getView(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
getView(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
 
getView(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleAddedRelations
 
getView(Predicate<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
getWildcardField() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
getWrappedTransaction() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
getWrappedTx() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
getWrappedType() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
getWriteTimestamp() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
GHOST_VERTEX_COUNT - Static variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
GhostVertexRemover - Class in com.thinkaurelius.titan.graphdb.olap.job
 
GhostVertexRemover(TitanGraph) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
GhostVertexRemover() - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
GhostVertexRemover(GhostVertexRemover) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
GHOTST_PARTITION_VERTEX - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
GLOBAL_PREFIX - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
graph() - Method in interface com.thinkaurelius.titan.core.TitanElement
 
graph() - Method in interface com.thinkaurelius.titan.core.TitanVertexProperty
 
graph() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalElement
 
graph - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
graph - Variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
graph() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
graph() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanFeatures
 
GRAPH_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
GraphCentricQuery - Class in com.thinkaurelius.titan.graphdb.query.graph
An executable ElementQuery for TitanGraphQuery.
GraphCentricQuery(ElementCategory, Condition<TitanElement>, OrderList, BackendQueryHolder<JointIndexQuery>, int) - Constructor for class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
GraphCentricQueryBuilder - Class in com.thinkaurelius.titan.graphdb.query.graph
Builds a TitanGraphQuery, optimizes the query and compiles the result into a GraphCentricQuery which is then executed through a QueryProcessor.
GraphCentricQueryBuilder(StandardTitanTx, IndexSerializer) - Constructor for class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
GraphDatabaseConfiguration - Class in com.thinkaurelius.titan.graphdb.configuration
Provides functionality to configure a TitanGraph INSTANCE.
GraphDatabaseConfiguration(ReadConfiguration) - Constructor for class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
GraphIndexStatusReport - Class in com.thinkaurelius.titan.graphdb.database.management
 
GraphIndexStatusReport(boolean, String, SchemaStatus, Map<String, SchemaStatus>, Map<String, SchemaStatus>, Duration) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
GraphIndexStatusWatcher - Class in com.thinkaurelius.titan.graphdb.database.management
 
GraphIndexStatusWatcher(TitanGraph, String) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusWatcher
 
GRAPHITE_HOST - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The hostname to receive Graphite plaintext protocol metric data.
GRAPHITE_INTERVAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds to wait between sending Metrics data to the host specified GraphDatabaseConfiguration.GRAPHITE_HOST.
GRAPHITE_PORT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The port to which Graphite data are sent.
GRAPHITE_PREFIX - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
A Graphite-specific prefix for reported metrics.
GraphOfTheGodsFactory - Class in com.thinkaurelius.titan.example
Example Graph factory that creates a TitanGraph based on roman mythology.
GraphOfTheGodsFactory() - Constructor for class com.thinkaurelius.titan.example.GraphOfTheGodsFactory
 
GraphProvider() - Constructor for class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
graphShutdown() - Static method in class com.thinkaurelius.titan.graphdb.util.ExceptionFactory
 
GREMLIN_GRAPH - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
GREMLIN_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
groupName(String) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder
 
groupName(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
GUAVA_CACHE_ENTRY_SIZE - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
GUAVA_CACHE_SOFT_ENTRY_SIZE - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
GuavaVertexCache - Class in com.thinkaurelius.titan.graphdb.transaction.vertexcache
 
GuavaVertexCache(long, int, int) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.vertexcache.GuavaVertexCache
 

H

has(String, Object) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.BaseVertexQuery
Query for edges or properties that have defined property with the given key
has(String, TitanPredicate, Object) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
 
has(String, TitanPredicate, Object) - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
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 com.thinkaurelius.titan.core.TitanGraphQuery
 
has(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
 
has(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
has(String) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
has(String, TitanPredicate, Object) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
has(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
has(String) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
has(String, TitanPredicate, Object) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
has(ConfigOption, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
has(ConfigOption, String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
has(ConfigOption, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
has(ConfigOption, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
has(StoreTransaction, KeyColumn) - Method in class com.thinkaurelius.titan.diskstorage.locking.LockerState
 
has(String, Object) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
has(String) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
has(String, TitanPredicate, Object) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
has(String, TitanPredicate, Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
has(PropertyKey, TitanPredicate, Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String, Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
has(String, Object) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
has(String) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
has(String, TitanPredicate, Object) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasAcquiredLock() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
hasAcquireLocks() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasAcquireLocks() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether the persistence layer should acquire locks for this transaction during persistence.
hasAddedRelations(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
hasAddedRelations() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertex
Whether this vertex has added relations
hasAddedRelations() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
hasAddedRelations() - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
hasAddedRelations() - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
hasAdditions() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Whether this mutation has additions
hasAllCanonicalTypes() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasAnyIndex(PropertyKey) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
hasAssignIDsImmediately() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasAssignIDsImmediately() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
 
hasAuthentication() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
Whether authentication is enabled for this storage backend
hasBatchMutation() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasBatchMutation() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports batch mutations via KeyColumnValueStoreManager.mutateMany(java.util.Map, StoreTransaction).
hasCellTTL() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasCellTTL() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend support time-to-live (TTL) settings for column-value entries.
hasChildren() - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
hasChildren() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
hasChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Literal
 
hasChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
hasChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
hasCommitTime() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Returns true if a commit time has been set on this transaction.
hasCommitTime() - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
hasCommitTime() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasCommonOrder() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
Whether all individual orders are the same
hasContent() - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Entry
 
hasDataType() - Method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
hasDefaultConfiguration() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertexLabel
 
hasDefaultConfiguration() - Method in class com.thinkaurelius.titan.graphdb.schema.VertexLabelDefinition
 
hasDefaultConfiguration() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
hasDefaultConfiguration() - Method in class com.thinkaurelius.titan.graphdb.types.VertexLabelVertex
 
hasDeletions() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Whether this mutation has deletions
hasDeletions(Q) - Method in class com.thinkaurelius.titan.graphdb.query.MetricsQueryExecutor
 
hasDeletions(Q) - Method in interface com.thinkaurelius.titan.graphdb.query.QueryExecutor
Whether the transactional context contains any deletions that could potentially affect the result set of the given query.
hasDuplicateResults() - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Whether the combination of the individual sub-queries can result in duplicate results.
hasDuplicateResults() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
hasDuplicateResults() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
hasEnabledBatchLoading() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasEnabledBatchLoading() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether this transaction should be optimized for batch-loading, i.e.
hasFailed() - Method in class com.thinkaurelius.titan.core.schema.JobStatus
 
hasFlushIDs() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
hasForceIndexUsage() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
hasForceIndexUsage() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasForceIndexUsage() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
hasGroupName() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
True when BaseTransactionConfig.getGroupName() is non-null, false when null.
hasGroupName() - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
hasGroupName() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hashCode() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
 
hashCode() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.Point
 
hashCode() - Method in class com.thinkaurelius.titan.core.schema.Parameter
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.util.KeyColumn
 
hashCode() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
Thread-safe hashcode method for StaticBuffer written according to Effective Java 2e by Josh Bloch.
hashCode(int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.configuration.RegisteredAttributeClass
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
hashCode() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.DirectionCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.FixedCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceDirectionCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.RelationTypeCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.IndexLockTuple
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.types.IndexField
 
hashCode() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
hashCode() - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
hashCode() - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
hashCode() - Method in class com.thinkaurelius.titan.util.datastructures.LongCounter
 
hashCode() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
hashCode() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
HashingUtil - Class in com.thinkaurelius.titan.diskstorage.util
 
HashingUtil() - Constructor for class com.thinkaurelius.titan.diskstorage.util.HashingUtil
 
HashingUtil.HashLength - Enum in com.thinkaurelius.titan.diskstorage.util
 
hashPrefixKey(HashingUtil.HashLength, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.HashingUtil
 
HashUtility - Enum in com.thinkaurelius.titan.diskstorage.util
 
hasId() - Method in interface com.thinkaurelius.titan.core.TitanElement
Checks whether this entity has a unique identifier.
hasId() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
hasId() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
hasId() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseRelationType
 
hasId() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
hasId() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
hasIdentifier() - Method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
Whether this read marker has a configured identifier
hasLimit() - Method in class com.thinkaurelius.titan.graphdb.query.BaseQuery
 
hasLimit() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
hasLimit() - Method in interface com.thinkaurelius.titan.graphdb.query.Query
Whether this query has a defined limit
hasLoadedRelations(SliceQuery) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
hasLoadedRelations(SliceQuery) - Method in class com.thinkaurelius.titan.graphdb.vertices.CacheVertex
 
hasLoadedRelations(SliceQuery) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
hasLoadedRelations(SliceQuery) - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
hasLocalAddress(Collection<String>) - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
hasLocalKeyPartition() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasLocalKeyPartition() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasLocking() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
hasLogTransactions() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
hasMetaData() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
hasMetaData() - Method in interface com.thinkaurelius.titan.diskstorage.MetaAnnotated
Returns true if this entry has associated meta data
hasMetaData() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
hasModifications() - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Checks whether any changes to the graph database have been made in this transaction.
hasModifications() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
hasMultiQuery() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasMultiQuery() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports query operations on multiple keys via KeyColumnValueStore.getSlice(java.util.List, SliceQuery, StoreTransaction)
hasMutations() - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
hasName() - Method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
hasNegation() - Method in enum com.thinkaurelius.titan.core.attribute.Cmp
 
hasNegation() - Method in enum com.thinkaurelius.titan.core.attribute.Contain
 
hasNegation() - Method in enum com.thinkaurelius.titan.core.attribute.Text
 
hasNegation() - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
Whether this predicate has a predicate that is semantically its negation.
hasNext() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
 
hasNext() - Method in class com.thinkaurelius.titan.graphdb.query.LimitAdjustingIterator
 
hasNext() - Method in class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
hasNext() - Method in class com.thinkaurelius.titan.graphdb.query.ResultSetIterator
 
hasNext() - Method in class com.thinkaurelius.titan.graphdb.util.AllEdgesIterator
 
hasNext() - Method in class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterator
 
hasNext() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
hasNot(String) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Query for edges or properties that DO NOT have a defined property with the given key
hasNot(String, Object) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Identical to BaseVertexQuery.has(String, Object) but negates the condition, i.e.
hasNot(String) - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
 
hasNot(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
 
hasNot(String) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
hasNot(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
hasNot(String) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
hasNot(String, Object) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
hasNot(String, Object) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
hasNot(String) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
hasNot(String) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
hasNot(String, Object) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
hasNot(String, Object) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasNot(String) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasObject(K) - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
hasOrderedScan() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasOrderedScan() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports global key scans via KeyColumnValueStore.getKeys(KeyRangeQuery, StoreTransaction).
hasParameter(Parameter[]) - Method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
 
hasParameters() - Method in class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
hasPreloadedData() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasPreloadedData() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether the incident relation data on vertices is being externally pre-loaded.
hasProperties() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
hasPropertyPrefetching() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
hasPropertyPrefetching() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasPropertyPrefetching() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether this transaction loads all properties on a vertex when a single property is requested.
hasQueryOnlyGivenVertex() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasQueryOnlyLoaded() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
hasRemaining() - Method in interface com.thinkaurelius.titan.diskstorage.ScanBuffer
 
hasRemaining() - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
hasRemovedRelations(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
hasRemovedRelations() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertex
Whether this vertex has removed relations
hasRemovedRelations() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
hasRemovedRelations() - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
hasRemovedRelations() - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
hasRestrictedPartitions() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasRestrictedPartitions() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Returns true of the queryied partitions should be restricted in this transaction
hasScan() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasScan() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
hasSchemaTypeConstraint() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
hasSchemaTypeConstraint() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
hasSimpleInternalVertexKeyIndex(TitanRelation) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
hasSimpleInternalVertexKeyIndex(TitanVertexProperty) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
hasSimpleInternalVertexKeyIndex(PropertyKey) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeUtil
 
hasSingleType() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasSortKey() - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
hasStartTime() - Method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
 
HasStepFolder<S,E> - Interface in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
HasStepFolder.OrderEntry - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
hasStoreTTL() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasStoreTTL() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend supports time-to-live (TTL) settings on a per-store basis.
hasTimestamps() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasTimestamps() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Returns true if column-value entries in this storage backend are annotated with a timestamp, else false.
hasTxIsolation() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasTxIsolation() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend's transactions support isolation.
hasTypes() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
hasUmbrella() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
Whether this namespace or any parent namespace is an umbrella namespace.
hasUmbrellaElements() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement.PathIdentifier
 
hasUnorderedScan() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasUnorderedScan() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend supports global key scans via KeyColumnValueStore.getKeys(SliceQuery, StoreTransaction).
hasValidateKeysOnly() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
hasValue() - Method in interface com.thinkaurelius.titan.diskstorage.Entry
 
hasVerifyExternalVertexExistence() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyExternalVertexExistence() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyInternalVertexExistence() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
hasVerifyUniqueness() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
hasVisibility() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Returns true if this storage backend supports entry-level visibility by attaching a visibility or authentication token to each column-value entry in the data store and limited retrievals to "visible" entries.
Hex - Class in com.thinkaurelius.titan.diskstorage.util
Utility methods for hexadecimal representation of bytes
Hex() - Constructor for class com.thinkaurelius.titan.diskstorage.util.Hex
 
hexToBytes(String) - Static method in class com.thinkaurelius.titan.diskstorage.util.Hex
 
hide() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
hostnames - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 

I

id() - Method in interface com.thinkaurelius.titan.core.TitanElement
Returns a unique identifier for this entity.
id() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
id() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
ID - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
id() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
ID_STORE_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
idApplicationWaitMS - Variable in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
IDAuthority - Interface in com.thinkaurelius.titan.diskstorage
Handles the unique allocation of ids.
IDAUTHORITY_CAV_BITS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configures the number of bits of Titan 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 Titan instances attempt to allocate ids at the same time (e.g.
IDAUTHORITY_CAV_RETRIES - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
When Titan 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 com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Unique id marker to be used by this Titan instance when allocating ids.
IDAUTHORITY_CONFLICT_AVOIDANCE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Sets the strategy used by ConsistentKeyIDAuthority to avoid contention in ID block alloction between Titan instances concurrently sharing a single distributed storage backend.
IDAUTHORITY_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
IDAUTHORITY_WAIT - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage
Represents a block of ids.
IDBlockSizer - Interface in com.thinkaurelius.titan.graphdb.database.idassigner
 
IDENTIFYING_METADATA - Static variable in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
 
Idfiable - Interface in com.thinkaurelius.titan.core
Represents an entity that can be uniquely identified by a long id.
IDHandler - Class in com.thinkaurelius.titan.graphdb.database.idhandling
 
IDHandler() - Constructor for class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
IDHandler.DirectionID - Enum in com.thinkaurelius.titan.graphdb.database.idhandling
 
IDHandler.RelationTypeParse - Class in com.thinkaurelius.titan.graphdb.database.idhandling
 
IDInspector - Interface in com.thinkaurelius.titan.graphdb.idmanagement
Interface for determining the type of element a particular id refers to.
IDManager - Class in com.thinkaurelius.titan.graphdb.idmanagement
Handles the allocation of ids based on the type of element Responsible for the bit-wise pattern of Titan's internal id scheme.
IDManager(long) - Constructor for class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
IDManager() - Constructor for class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
IDManager.VertexIDType - Enum in com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.idassigner.placement
Determines how vertices are placed in individual graph partitions.
IDPool - Interface in com.thinkaurelius.titan.graphdb.database.idassigner
 
IDPoolExhaustedException - Exception in com.thinkaurelius.titan.graphdb.database.idassigner
 
IDPoolExhaustedException(String) - Constructor for exception com.thinkaurelius.titan.graphdb.database.idassigner.IDPoolExhaustedException
 
IDPoolExhaustedException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.graphdb.database.idassigner.IDPoolExhaustedException
 
IDPoolExhaustedException(Throwable) - Constructor for exception com.thinkaurelius.titan.graphdb.database.idassigner.IDPoolExhaustedException
 
IDS_BLOCK_SIZE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Size of the block to be acquired.
IDS_FLUSH - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
If flush ids is enabled, vertices and edges are assigned ids immediately upon creation.
IDS_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
IDS_RENEW_BUFFER_PERCENTAGE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configures when the id pool manager will attempt to allocate a new id block.
IDS_RENEW_TIMEOUT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The number of milliseconds that the Titan id pool manager will wait before giving up on allocating a new block of ids.
IGNORE_UNKNOWN_INDEX_FIELD - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
ignoreUndefinedQueryTypes() - Method in interface com.thinkaurelius.titan.core.schema.DefaultSchemaMaker
Whether to ignore undefined types occurring in a query.
ignoreUndefinedQueryTypes() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanDefaultSchemaMaker
 
ignoreUndefinedQueryTypes() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.Tp3DefaultSchemaMaker
 
ignoreUndefinedQueryTypes() - Method in class com.thinkaurelius.titan.graphdb.types.typemaker.DisableDefaultSchemaMaker
 
ILLEGAL_CHARS - Static variable in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
ImmutableIntSet - Class in com.thinkaurelius.titan.util.datastructures
Immutable set of integers
ImmutableIntSet(int[]) - Constructor for class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
ImmutableIntSet(int) - Constructor for class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
ImplicitKey - Class in com.thinkaurelius.titan.graphdb.types.system
 
impliedBy(Direction, Direction) - Static method in class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
incActionBy(int, CacheMetricsAction, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
incBy(K, double) - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
Increases the count of object o by inc and returns the new count value
IncidenceCondition<E extends TitanRelation> - Class in com.thinkaurelius.titan.graphdb.query.condition
 
IncidenceCondition(TitanVertex, TitanVertex) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.IncidenceCondition
 
IncidenceDirectionCondition<E extends TitanRelation> - Class in com.thinkaurelius.titan.graphdb.query.condition
 
IncidenceDirectionCondition(Direction, TitanVertex) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.IncidenceDirectionCondition
 
include(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
incr(String, long) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
increment(ScanMetrics.Metric) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics
Increment a standard counter by 1.
increment(ScanMetrics.Metric) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
increment(long) - Method in class com.thinkaurelius.titan.util.datastructures.LongCounter
 
incrementCustom(String, long) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics
Increment a custom counter by delta.
incrementCustom(String) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics
Like ScanMetrics.incrementCustom(String, long), except the delta is 1.
incrementCustom(String, long) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
incrementCustom(String) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
incrIteration() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
index - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
INDEX_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
INDEX_BACKEND - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Define the indexing backed to use for index support
INDEX_CONF_FILE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_DEFINITION_CATEGORIES - Static variable in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
INDEX_DIRECTORY - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_HOSTS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_JOB_NS - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
INDEX_MAX_RESULT_SET_SIZE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NAME - Static variable in class com.thinkaurelius.titan.example.GraphOfTheGodsFactory
 
INDEX_NAME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NAME - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
INDEX_NAME_MAPPING - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NAMESPACE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_PORT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
INDEX_RELATION_TYPE - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
IndexCache - Interface in com.thinkaurelius.titan.graphdb.transaction.indexcache
 
indexCover(CompositeIndexType, Condition<TitanElement>, Set<Condition>) - Static method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
indexCover(MixedIndexType, Condition<TitanElement>, IndexSerializer, Set<Condition>) - Static method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
indexCoversOrder(MixedIndexType, OrderList) - Static method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
IndexEntry - Class in com.thinkaurelius.titan.diskstorage.indexing
An index entry is a key-value pair (or field-value pair).
IndexEntry(String, Object) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
IndexEntry(String, Object, Map<EntryMetaData, Object>) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
indexesKey(PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
indexesKey(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
IndexFeatures - Class in com.thinkaurelius.titan.diskstorage.indexing
Characterizes the features that a particular IndexProvider implementation supports
IndexFeatures(boolean, Mapping, ImmutableSet<Mapping>, String, ImmutableSet<Cardinality>, boolean) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
IndexFeatures.Builder - Class in com.thinkaurelius.titan.diskstorage.indexing
 
IndexField - Class in com.thinkaurelius.titan.graphdb.types
 
IndexHelper - Class in com.thinkaurelius.titan.graphdb.util
 
IndexHelper() - Constructor for class com.thinkaurelius.titan.graphdb.util.IndexHelper
 
IndexInformation - Interface in com.thinkaurelius.titan.diskstorage.indexing
An IndexInformation gives basic information on what a particular IndexProvider supports.
IndexJobStatus(JobStatus.State, ScanMetrics) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem.IndexJobStatus
 
IndexLockTuple - Class in com.thinkaurelius.titan.graphdb.transaction.lock
 
IndexLockTuple(CompositeIndexType, Object...) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.lock.IndexLockTuple
 
indexMatch(TitanRelation, CompositeIndexType) - Static method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
indexMatches(TitanVertex, CompositeIndexType) - Static method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
indexMatches(TitanVertex, CompositeIndexType, PropertyKey, Object) - Static method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
IndexMutation - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
IndexMutation(boolean, boolean) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
indexName - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
indexOf(int[], int) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
indexOfMin(double[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
indexOnly(TitanSchemaType) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement.IndexBuilder
Restricts this index to only those elements that have the provided schemaType.
IndexProvider - Interface in com.thinkaurelius.titan.diskstorage.indexing
External index for querying.
indexQuery(String, String) - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
Returns a TitanIndexQuery to query for vertices or edges against the specified indexing backend using the given query string.
indexQuery(KeySliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
indexQuery(String, IndexQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
IndexQuery - Class in com.thinkaurelius.titan.diskstorage.indexing
An external index query executed on an IndexProvider.
IndexQuery(String, Condition, ImmutableList<IndexQuery.OrderEntry>, int) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition, ImmutableList<IndexQuery.OrderEntry>) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
IndexQuery(String, Condition, int) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
indexQuery(String, String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
indexQuery(String, String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
IndexQuery.OrderEntry - Class in com.thinkaurelius.titan.diskstorage.indexing
 
IndexQueryBuilder - Class in com.thinkaurelius.titan.graphdb.query.graph
Implementation of TitanIndexQuery for string based queries that are issued directly against the specified indexing backend.
IndexQueryBuilder(StandardTitanTx, IndexSerializer) - Constructor for class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
IndexRecords() - Constructor for class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexRecords
 
indexRelationType - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
indexRelationTypeName - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
IndexRemoveJob - Class in com.thinkaurelius.titan.graphdb.olap.job
 
IndexRemoveJob() - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
IndexRemoveJob(IndexRemoveJob) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
IndexRemoveJob(TitanGraph, String, String) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
IndexRepairJob - Class in com.thinkaurelius.titan.graphdb.olap.job
 
IndexRepairJob() - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
IndexRepairJob(IndexRepairJob) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
IndexRepairJob(String, String) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
IndexSerializer - Class in com.thinkaurelius.titan.graphdb.database
 
IndexSerializer(Configuration, Serializer, Map<String, ? extends IndexInformation>, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
indexSerializer - Variable in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
indexSerializer - Variable in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
IndexSerializer.IndexInfoRetriever - Class in com.thinkaurelius.titan.graphdb.database
 
IndexSerializer.IndexRecords - Class in com.thinkaurelius.titan.graphdb.database
 
IndexSerializer.IndexUpdate<K,E> - Class in com.thinkaurelius.titan.graphdb.database
 
INDEXSTORE_CACHE_PERCENT - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
INDEXSTORE_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
IndexTransaction - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
IndexType - Interface in com.thinkaurelius.titan.graphdb.types
 
IndexTypeWrapper - Class in com.thinkaurelius.titan.graphdb.types.indextype
 
IndexTypeWrapper(SchemaSource) - Constructor for class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
IndexUpdateJob - Class in com.thinkaurelius.titan.graphdb.olap.job
 
IndexUpdateJob() - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
IndexUpdateJob(IndexUpdateJob) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
IndexUpdateJob(String, String) - Constructor for class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
INITIAL_TITAN_VERSION - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
initialize(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.Backend
Initializes this backend with the given configuration.
initializeGraph(Configuration) - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
injectIDManager(IDManager) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
injectIDManager(IDManager) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
InMemoryKeyColumnValueStore - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory
An in-memory implementation of KeyColumnValueStore.
InMemoryKeyColumnValueStore(String) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
InMemoryStoreManager - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory
In-memory backend storage engine.
InMemoryStoreManager() - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
InMemoryStoreManager(Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
insert(StaticBuffer, StaticBuffer, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStore
Inserts the given key-value pair into the store.
insertSortedInc(long[], long) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
insertWithOverflow(T) - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Adds an Object to a PriorityQueue in log(size) time.
INSTANCE - Static variable in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.database.indexing.StandardIndexInformation
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongSerializer
 
instance() - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.AdjacentVertexFilterOptimizerStrategy
 
instance() - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStepStrategy
 
instance() - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanLocalQueryOptimizerStrategy
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanDefaultSchemaMaker
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanIoRegistry
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.tinkerpop.Tp3DefaultSchemaMaker
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.transaction.lock.FakeLock
 
INSTANCE - Static variable in class com.thinkaurelius.titan.graphdb.types.typemaker.DisableDefaultSchemaMaker
 
instantiate(String) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationUtil
 
instantiate(String, Object[], Class[]) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationUtil
 
InstantSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
InstantSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.InstantSerializer
 
INT_LEN - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
IntArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
IntArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntArraySerializer
 
IntegerDoubleFrequency - Class in com.thinkaurelius.titan.util.stats
Count relative integer frequencies
IntegerDoubleFrequency() - Constructor for class com.thinkaurelius.titan.util.stats.IntegerDoubleFrequency
 
IntegerSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
IntegerSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntegerSerializer
 
INTERNAL_INDEX_NAME - Static variable in class com.thinkaurelius.titan.graphdb.internal.Token
 
InternalElement - Interface in com.thinkaurelius.titan.graphdb.internal
Internal Element interface adding methods that should only be used by Titan
InternalRelation - Interface in com.thinkaurelius.titan.graphdb.internal
Internal Relation interface adding methods that should only be used by Titan.
InternalRelationType - Interface in com.thinkaurelius.titan.graphdb.internal
Internal Type interface adding methods that should only be used by Titan
internalState(LockerState<S>) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
This method is only intended for testing.
InternalVertex - Interface in com.thinkaurelius.titan.graphdb.internal
Internal Vertex interface adding methods that should only be used by Titan
InternalVertexLabel - Interface in com.thinkaurelius.titan.graphdb.internal
 
intersect(Geoshape) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
 
intersect(Interval<T>) - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
intersect(Interval<T>) - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
intersect(Interval<T>) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
interval(String, T, T) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.TitanGraphQuery
 
interval(String, T, T) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
interval(String, T, T) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
interval - Variable in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer.TypedInterval
 
interval(String, T, T) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
interval(String, T, T) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
interval(String, T, T) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
Interval<T> - Interface in com.thinkaurelius.titan.util.datastructures
 
IntHashSet - Class in com.thinkaurelius.titan.util.datastructures
Implementation of IntSet against IntIntHashMap.
IntHashSet() - Constructor for class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
IntHashSet(int) - Constructor for class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
IntSet - Interface in com.thinkaurelius.titan.util.datastructures
 
intSize - Static variable in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
inUse() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.CombinerLock
 
inUse() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.FakeLock
 
inUse() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.ReentrantTransactionLock
 
inUse() - Method in interface com.thinkaurelius.titan.graphdb.transaction.lock.TransactionLock
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.ExpirationKCVSCache
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
invalidate(StaticBuffer, List<CachableStaticBuffer>) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
InvalidElementException - Exception in com.thinkaurelius.titan.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, TitanElement) - Constructor for exception com.thinkaurelius.titan.core.InvalidElementException
 
InvalidIDException - Exception in com.thinkaurelius.titan.core
Titan represents element identifiers as longs, but not all numbers in the representable space of longs are valid.
InvalidIDException(String) - Constructor for exception com.thinkaurelius.titan.core.InvalidIDException
 
InvalidIDException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.core.InvalidIDException
 
InvalidIDException(Throwable) - Constructor for exception com.thinkaurelius.titan.core.InvalidIDException
 
inVertex() - Method in interface com.thinkaurelius.titan.core.TitanEdge
 
invisible() - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
invisible() - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
invisible() - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
io(Io.Builder<I>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
io(Io.Builder<I>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
IOCallable<T> - Interface in com.thinkaurelius.titan.diskstorage.util
 
IOUtils - Class in com.thinkaurelius.titan.util.system
IO Utility class
IOUtils() - Constructor for class com.thinkaurelius.titan.util.system.IOUtils
 
is(long) - Method in enum com.thinkaurelius.titan.graphdb.idmanagement.IDManager.VertexIDType
 
isAddition() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
isApplicableStatus(SchemaStatus) - Method in enum com.thinkaurelius.titan.core.schema.SchemaAction
 
isArrayOf(Object, Class) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
isAsciiString(String) - Static method in class com.thinkaurelius.titan.util.encoding.StringEncoding
 
isBatchLoading() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
isCanonicalVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isCausedBy(Class<?>) - Method in exception com.thinkaurelius.titan.core.TitanException
Checks whether this exception is cause by an exception of the given type.
isCausedBy(Throwable, Class<?>) - Static method in class com.thinkaurelius.titan.util.datastructures.ExceptionUtil
 
isChecked() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
isClosed() - Method in interface com.thinkaurelius.titan.core.TitanGraph
Checks whether the graph is closed.
isClosed() - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Checks whether the transaction has been closed.
isClosed() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.BaseKeyColumnValueAdapter
 
isClosed() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
isClosed() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
isCompatible(ReadMarker) - Method in class com.thinkaurelius.titan.diskstorage.log.ReadMarker
 
isCompositeIndex() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Whether this is a composite index
isCompositeIndex() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
isCompositeIndex() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
isCompositeIndex() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
isCompositeIndex() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
isCompositeIndex() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
isConsolidated() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
isConsolidated() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVEntryMutation
 
isConsolidated() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVMutation
 
isConsolidated() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KVMutation
 
isConsolidated(Function<E, V>, Function<K, V>) - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Checks whether this mutation is consolidated in the sense of Mutation.consolidate(com.google.common.base.Function, com.google.common.base.Function).
isConsolidated() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
 
isConstrained() - Method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.Multiplicity
 
isDecimal(Number) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
isDecimal(Class<?>) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
isDeleted() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
isDeleted(Q, R) - Method in class com.thinkaurelius.titan.graphdb.query.MetricsQueryExecutor
 
isDeleted(Q, R) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
isDeprecated() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isDirected() - Method in interface com.thinkaurelius.titan.core.EdgeLabel
Checks whether this labels is defined as directed.
isDirected() - Method in class com.thinkaurelius.titan.graphdb.schema.EdgeLabelDefinition
 
isDirected() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
isDirected() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
isDistributed() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isDistributed() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend writes and reads data from more than one machine.
isDone() - Method in class com.thinkaurelius.titan.core.schema.JobStatus
 
isEdge() - Method in interface com.thinkaurelius.titan.core.TitanRelation
Checks whether this relation is an edge.
isEdge() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isEdge() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
isEdge() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
isEdge() - Method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
isEdgeLabel() - Method in interface com.thinkaurelius.titan.core.RelationType
Checks if this relation type is an edge label
isEdgeLabel() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
isEdgeLabel() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
isEdgeLabel() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
isEdgeLabel() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
isEdgeLabel() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.PropertyKeyVertex
 
isEdgeLabelId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isEdgeLabelId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isEdgeReturnStep(TitanVertexStep) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
isEmpty() - Method in class com.thinkaurelius.titan.diskstorage.Mutation
 
isEmpty() - Method in class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
isEmpty() - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Whether the result set of this query is empty
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
isEmpty(Condition<?>) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
isEmpty() - Method in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
 
isEmpty() - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
isEmpty() - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
isEmpty() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
isEmpty() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
isEmpty() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
isEmpty() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
isExhaustedPartition(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
isFitted() - Method in interface com.thinkaurelius.titan.core.QueryDescription.SubQuery
Whether this query is fitted, i.e.
isFitted() - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
isFixed() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isFrozen() - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
isGenericSchemaVertexId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isGenericSchemaVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isGhostVertex(long, EntryList) - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
isGlobal() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isGlobalGraphIndex() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
isHidden() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isIdentifying() - Method in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
 
isImmutable() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
isImplicitKeyQuery(RelationCategory) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
Whether this query is asking for the value of an ImplicitKey.
isIncidentOn(Vertex) - Method in interface com.thinkaurelius.titan.core.TitanRelation
Checks whether this relation is incident on the specified vertex.
isIncidentOn(Vertex) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isIncidentOn(Vertex) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
isInitialIteration() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
isInstance(TitanElement) - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
isInvisible() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
isInvisible() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
isInvisible() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
isInvisible() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
isInvisibleType() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
isInvisibleType() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseRelationType
 
isInvisibleType() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
isInvisibleType() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
isIterableOf(Object, Class) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
isKeyConsistent() - Method in enum com.thinkaurelius.titan.diskstorage.keycolumnvalue.ConsistencyLevel
 
isKeyConsistent() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isKeyConsistent() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend provides strong consistency within each key/row.
isKeyOrdered() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
isKeyOrdered() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether this storage backend preserves key locality.
isLoaded() - Method in interface com.thinkaurelius.titan.core.TitanElement
Checks whether this entity has been loaded into the current transaction and not yet modified.
isLoaded() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
isLoaded(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
isLoaded() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isLoaded() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
isLocal() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isLocalConnection(String) - Static method in class com.thinkaurelius.titan.util.system.NetworkUtil
 
isLoop() - Method in interface com.thinkaurelius.titan.core.TitanRelation
Checks whether this relation is a loop.
isLoop() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isLoop() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
isManaged() - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.schema.TitanGraphIndex
Whether this is a mixed index
isMixedIndex() - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
isMixedIndex() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
isMixedIndex() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
isMixedIndex() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
 
isMixedIndex() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
isModified() - Method in interface com.thinkaurelius.titan.core.TitanVertex
Checks whether this entity has been loaded into the current transaction and modified.
isModified(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
isModified() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
isModified() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
isMutationStarted() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
Tells whether this transaction has been used in a ExpectedValueCheckingStore.mutate(StaticBuffer, List, List, StoreTransaction) call.
isNamespace() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
isNew() - Method in interface com.thinkaurelius.titan.core.TitanElement
Checks whether this entity has been newly created in the current transaction.
isNew() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
isNew() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
isNew(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
isNew() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isNew() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
isNotSystemName(TitanSchemaCategory, String) - Static method in class com.thinkaurelius.titan.graphdb.types.system.SystemTypeManager
 
isOpen() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Whether this management transaction is open or has been closed (i.e.
isOpen() - Method in interface com.thinkaurelius.titan.core.TitanGraph
Checks whether the graph is open.
isOpen() - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Checks whether the transaction is still open.
isOpen() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
isOpen() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
isOpen() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
isOption() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
isOption() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
 
isOption() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
isOrderPreservingDatatype(Class<?>) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.AttributeHandler
 
isOrderPreservingDatatype(Class<?>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
isPartitioned() - Method in interface com.thinkaurelius.titan.core.VertexLabel
Whether vertices with this label are partitioned.
isPartitioned() - Method in class com.thinkaurelius.titan.graphdb.schema.VertexLabelDefinition
 
isPartitioned() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
isPartitioned() - Method in class com.thinkaurelius.titan.graphdb.types.VertexLabelVertex
 
isPartitionedVertex(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isPartitionedVertex(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isPartitionedVertex(InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
isPartitionedVertex(TitanVertex) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
isPoints() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
isPoints() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
isPoints() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
isPowerOf2(long) - Static method in class com.thinkaurelius.titan.util.stats.NumberUtil
 
isPresent() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isPresent() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
isPresent() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
isPrimarySuccess() - Method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxStatus
 
isProper() - Method in enum com.thinkaurelius.titan.core.log.Change
 
isProper() - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
isProperDirection(Direction) - Static method in class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
isProperty() - Method in interface com.thinkaurelius.titan.core.TitanRelation
Gets the value of the property property.
isProperty() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
Gets the value of the property property.
isProperty() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
Gets the value of the property property.
isProperty() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
Gets the value of the property property.
isProperty() - Method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
Gets the value of the property property.
isPropertyKey() - Method in interface com.thinkaurelius.titan.core.RelationType
Checks if this relation type is a property key
isPropertyKey() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
isPropertyKey() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
isPropertyKey() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
isPropertyKey() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
isPropertyKey() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.PropertyKeyVertex
 
isPropertyKeyId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isPropertyKeyId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isProvided() - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
isQNF() - Method in enum com.thinkaurelius.titan.core.attribute.Cmp
 
isQNF() - Method in enum com.thinkaurelius.titan.core.attribute.Contain
 
isQNF() - Method in enum com.thinkaurelius.titan.core.attribute.Geo
 
isQNF() - Method in enum com.thinkaurelius.titan.core.attribute.Text
 
isQNF() - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
Returns true if this predicate is in query normal form.
isQueryNormalForm(Condition<?>) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
Query-normal-form (QNF) for Titan is a variant of CNF (conjunctive normal form) with negation inlined where possible
isReadOnly() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
isReadOnly() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
isReadOnly() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Checks whether the graph transaction is configured as read-only.
isRelation() - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
isRelationType() - Method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
isRelationTypeId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isRelationTypeId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isRelationTypeIndex() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
isRemoved() - Method in interface com.thinkaurelius.titan.core.TitanElement
Checks whether this entity has been deleted into the current transaction.
isRemoved() - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
isRemoved(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
isRemoved() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
isRemoved() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
isRemovedRelation(Long) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
isRoot() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
isRunning() - Method in class com.thinkaurelius.titan.core.schema.JobStatus
 
isSchemaVertexId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isSchemaVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isSimple() - Method in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
isSingleThreaded() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether this transaction is only accessed by a single thread.
isSmallerOrEqualThan(ByteBuffer, ByteBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers and checks whether the first ByteBuffer is smaller than or equal to the second.
isSmallerThan(ByteBuffer, ByteBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.ByteBufferUtil
Compares two ByteBuffers and checks whether the first ByteBuffer is smaller than the second.
isSorted() - Method in interface com.thinkaurelius.titan.core.QueryDescription.SubQuery
Whether this query respects the sort order of parent query or requires sorting in-memory.
isSorted() - Method in interface com.thinkaurelius.titan.core.VertexList
Whether this list of vertices is sorted by id in increasing order.
isSorted() - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
isSorted() - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Whether this query expects the results to be in a particular sort order.
isSorted() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
isSorted() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
isSorted() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
isSorted() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
isSorted(LongArrayList, boolean) - Static method in class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
isSorted(LongArrayList) - Static method in class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
isSortedInc(long[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
isSortedInc(int[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
isStable() - Method in enum com.thinkaurelius.titan.core.schema.SchemaStatus
 
isStatic() - Method in interface com.thinkaurelius.titan.core.VertexLabel
Whether vertices with this label are static, that is, immutable beyond the transaction in which they were created.
isStatic() - Method in class com.thinkaurelius.titan.graphdb.schema.VertexLabelDefinition
 
isStatic() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
isStatic() - Method in class com.thinkaurelius.titan.graphdb.types.VertexLabelVertex
 
isString(Object) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
isString(Class<?>) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
isSubType(IDManager.VertexIDType) - Method in enum com.thinkaurelius.titan.graphdb.idmanagement.IDManager.VertexIDType
 
isSuccess() - Method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxStatus
 
isSystemName(String) - Static method in class com.thinkaurelius.titan.graphdb.internal.Token
 
isSystemRelationTypeId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isSystemRelationTypeId(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isSystemType(String) - Static method in class com.thinkaurelius.titan.graphdb.types.system.SystemTypeManager
 
isTemporary(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isTemporaryId(long) - Static method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
isThreadBound() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
isThreadBound() - Method in interface com.thinkaurelius.titan.graphdb.transaction.TransactionConfiguration
Whether this transaction is bound to a running thread.
isUmbrella() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigNamespace
Wether this namespace is an umbrella namespace, that is, is expects immediate sub-namespaces which are user defined.
isUnidirected() - Method in interface com.thinkaurelius.titan.core.EdgeLabel
Checks whether this labels is defined as unidirected.
isUnidirected(Direction) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
isUnidirected() - Method in class com.thinkaurelius.titan.graphdb.schema.EdgeLabelDefinition
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.schema.EdgeLabelDefinition
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.schema.PropertyKeyDefinition
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.schema.RelationTypeDefinition
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
isUnidirected() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
isUnidirected() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.vertices.EdgeLabelVertex
 
isUnidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.vertices.PropertyKeyVertex
 
isUnique(Direction) - Method in enum com.thinkaurelius.titan.core.Multiplicity
If this multiplicity implies edge uniqueness in the given direction for any given vertex.
isUnique() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Whether this is a unique index, i.e.
isUnique() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
isUnmodifiableVertex(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isUnmodifiableVertex(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isUserVertexId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isUserVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isValid(byte) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
isValidCondition(Object) - Method in enum com.thinkaurelius.titan.core.attribute.Contain
 
isValidCondition(Object) - Method in enum com.thinkaurelius.titan.core.attribute.Geo
 
isValidCondition(Object) - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
Whether the given condition is a valid condition for this predicate.
isValidConstraint(TitanSchemaType) - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
isValidCoordinate(float, float) - Static method in class com.thinkaurelius.titan.core.attribute.Geoshape
Whether the given coordinates mark a point on earth.
isValidData(Object) - Method in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
 
isValidDefinition(Set<TypeDefinitionCategory>) - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
isValidIdMap(Map<?, Integer>) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
isValidTypeModifierDefinition(Set<TypeDefinitionCategory>) - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
isValidValueType(Class<?>) - Method in enum com.thinkaurelius.titan.core.attribute.Contain
 
isValidValueType(Class<?>) - Method in enum com.thinkaurelius.titan.core.attribute.Geo
 
isValidValueType(Class<?>) - Method in enum com.thinkaurelius.titan.core.attribute.Text
 
isValidValueType(Class<?>) - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
Whether the given class is a valid data type for a value to which this predicate may be applied.
isVertexLabelVertexId(long) - Method in interface com.thinkaurelius.titan.graphdb.idmanagement.IDInspector
 
isVertexLabelVertexId(long) - Method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
isVertexReturnStep(TitanVertexStep) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
isWholeNumber(Number) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
isWholeNumber(Class<?>) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.AttributeUtil
 
it() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalElement
Returns this element in the context of the current transaction.
it() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
Returns this relation in the current transactional context
it() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalVertex
 
it() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
it() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
it() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
it() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
it() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
IterablesUtil - Class in com.thinkaurelius.titan.util.datastructures
Utility class for interacting with Iterable.
IterablesUtil() - Constructor for class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.query.QueryProcessor
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.SimpleVertexQueryProcessor
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.transaction.VertexIterable
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.util.VertexCentricEdgeIterable
 
iterator() - Method in class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterable
 
iterator() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 

J

job - Variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
JOB_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
JOB_START_TIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
jobStartTime - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
JobStatus - Class in com.thinkaurelius.titan.core.schema
 
JobStatus(JobStatus.State, long) - Constructor for class com.thinkaurelius.titan.core.schema.JobStatus
 
JobStatus.State - Enum in com.thinkaurelius.titan.core.schema
 
JointIndexQuery - Class in com.thinkaurelius.titan.graphdb.query.graph
A component/sub-query of a GraphCentricQuery that gets executed against an indexing backend or the index store by the query processor of the enclosing transaction.
JointIndexQuery() - Constructor for class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
JointIndexQuery.Subquery - Class in com.thinkaurelius.titan.graphdb.query.graph
 

K

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

L

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

M

M_ACQUIRE_LOCK - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_CALLS - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_CLOSE - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_CLOSE_MANAGER - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
M_CONTAINS_KEY - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_ENTRIES_COUNT - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_ENTRIES_HISTO - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_EXCEPTIONS - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_GET_KEYS - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_GET_PART - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_GET_SLICE - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_ITERATOR - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_MUTATE - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
M_OPEN_DATABASE - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
M_START_TX - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
M_TIME - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
main(String[]) - Static method in class com.thinkaurelius.titan.example.GraphOfTheGodsFactory
Calls TitanFactory.open(String), passing the Titan configuration file path which must be the sole element in the args array, then calls GraphOfTheGodsFactory.load(com.thinkaurelius.titan.core.TitanGraph) on the opened graph, then calls TitanGraph.close() and returns.
main(String[]) - Static method in class com.thinkaurelius.titan.util.system.CheckSocket
 
main(String[]) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationFileFilter
 
main(String[]) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationLint
 
main(String[]) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationPrinter
 
make() - Method in interface com.thinkaurelius.titan.core.schema.EdgeLabelMaker
Defines the EdgeLabel specified by this EdgeLabelMaker and returns the resulting label
make() - Method in interface com.thinkaurelius.titan.core.schema.PropertyKeyMaker
Defines the PropertyKey specified by this PropertyKeyMaker and returns the resulting key.
make() - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeMaker
Builds the configured relation type
make() - Method in interface com.thinkaurelius.titan.core.schema.VertexLabelMaker
Creates a VertexLabel according to the specifications of this builder.
make() - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
make() - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
make() - Method in class com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
makeDefinition() - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
makeEdgeLabel(EdgeLabelMaker) - Method in interface com.thinkaurelius.titan.core.schema.DefaultSchemaMaker
Creates a new edge label with default settings against the provided EdgeLabelMaker.
makeEdgeLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaManager
Returns a EdgeLabelMaker instance to define a new EdgeLabel with the given name.
makeEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
makeEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
makeEdgeLabel(String, TypeDefinitionMap) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makeEdgeLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makeEdgeLabel(EdgeLabelMaker) - Method in class com.thinkaurelius.titan.graphdb.types.typemaker.DisableDefaultSchemaMaker
 
makeImmutable() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
makePropertyKey(PropertyKeyMaker) - Method in interface com.thinkaurelius.titan.core.schema.DefaultSchemaMaker
Creates a new property key with default settings against the provided PropertyKeyMaker.
makePropertyKey(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaManager
Returns a PropertyKeyMaker instance to define a new PropertyKey with the given name.
makePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
makePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
makePropertyKey(String, TypeDefinitionMap) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makePropertyKey(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makePropertyKey(PropertyKeyMaker) - Method in class com.thinkaurelius.titan.graphdb.types.typemaker.DisableDefaultSchemaMaker
 
makeQuery(Q) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
makeSchemaVertex(TitanSchemaCategory, String, TypeDefinitionMap) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makeSystemName(String) - Static method in class com.thinkaurelius.titan.graphdb.internal.Token
 
makeVertexLabel(VertexLabelMaker) - Method in interface com.thinkaurelius.titan.core.schema.DefaultSchemaMaker
Creates a new vertex label with the default settings against the provided VertexLabelMaker.
makeVertexLabel(String) - Method in interface com.thinkaurelius.titan.core.schema.SchemaManager
Returns a VertexLabelMaker to define a new vertex label with the given name.
makeVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
makeVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
makeVertexLabel(String) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
makeVertexLabel(VertexLabelMaker) - Method in class com.thinkaurelius.titan.graphdb.types.typemaker.DisableDefaultSchemaMaker
 
MANAGEMENT_LOG - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
ManagementLogger - Class in com.thinkaurelius.titan.graphdb.database.management
 
ManagementLogger(StandardTitanGraph, Log, SchemaCache, TimestampProvider) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.ManagementLogger
 
ManagementSystem - Class in com.thinkaurelius.titan.graphdb.database.management
 
ManagementSystem(StandardTitanGraph, KCVSConfiguration, Log, ManagementLogger, SchemaCache) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
ManagementSystem.IndexJobStatus - Class in com.thinkaurelius.titan.graphdb.database.management
 
ManagementUtil - Class in com.thinkaurelius.titan.core.util
 
ManagementUtil() - Constructor for class com.thinkaurelius.titan.core.util.ManagementUtil
 
manager - Variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
Map() - Constructor for class com.thinkaurelius.titan.diskstorage.EntryMetaData.Map
 
MAP_JOB_FAILURE - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
MAP_JOB_SUCCESS - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
mapKey2Field(String, KeyInformation) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.IndexInformation
Adjusts the name of the key so that it is a valid field name that can be used in the index.
mapKey2Field(String, KeyInformation) - Method in class com.thinkaurelius.titan.graphdb.database.indexing.StandardIndexInformation
 
Mapping - Enum in com.thinkaurelius.titan.core.schema
Used to change the default mapping of an indexed key by providing the mapping explicitly as a parameter to TitanManagement.addIndexKey(TitanGraphIndex, com.thinkaurelius.titan.core.PropertyKey, Parameter[]).
mapQueue - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMapEmitter
 
mapReduce(MapReduce) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
MAPREDUCE_CHECK - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
Maps - Class in com.thinkaurelius.titan.util.datastructures
Utility class for Maps
Maps() - Constructor for class com.thinkaurelius.titan.util.datastructures.Maps
 
MaskedTimestamp(Instant) - Constructor for class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
MaskedTimestamp(StoreTransaction) - Constructor for class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp
 
matches(SliceQuery, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
matches(KeyRangeQuery, StaticBuffer, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSUtil
 
matches(R) - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Whether the given element matches the conditions of this query.
matches(TitanElement) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
matches(TitanRelation) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
matchesConstraint(TitanSchemaType, TitanElement) - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
MAX_BUFFER_CAPACITY - Static variable in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
MAX_CACHED_TYPES_DEFAULT - Static variable in class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
MAX_COMMIT_TIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
MAX_KEY - Static variable in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
MAX_LENGTH - Static variable in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
MAX_PADDING_BITWIDTH - Static variable in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
The maximum number of padding bits of any type
maxVariableKeyLength - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
mediator(LocalLockMediator<StoreTransaction>) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
mediatorName(String) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
Retrieve the mediator associated with name via LocalLockMediators#get(String).
memoryKeys - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
merge(IndexMutation) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
merge(Mutation<E, K>) - Method in class com.thinkaurelius.titan.diskstorage.Mutation
Merges another mutation into this mutation.
MergedConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
 
MergedConfiguration(Configuration, Configuration) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
mergeJoin(LongArrayList, LongArrayList, boolean) - Static method in class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
mergeLimits(int, int) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
mergeSort(Iterable<R>, Iterable<R>, Comparator<R>, boolean) - Static method in class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
mergeSort(LongArrayList, LongArrayList) - Static method in class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
mergeSort(Collection<E>, Collection<E>, Comparator<E>) - Static method in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
mergeSortedInc(long[], long[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
Message - Interface in com.thinkaurelius.titan.diskstorage.log
Messages which are added to and received from the Log.
MessageReader - Interface in com.thinkaurelius.titan.diskstorage.log
Implementations of this interface are used to process messages read from the log.
MetaAnnotatable - Interface in com.thinkaurelius.titan.diskstorage
 
MetaAnnotated - Interface in com.thinkaurelius.titan.diskstorage
 
MetaData2ImplicitKey - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
MetricInstrumentedIterator - Class in com.thinkaurelius.titan.diskstorage.util
This class is used by MetricInstrumentedStore to measure wallclock time, method invocation counts, and exceptions thrown by the methods on RecordIterator instances returned from MetricInstrumentedStore.getSlice(com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery, com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreTransaction).
MetricInstrumentedSchemaCache - Class in com.thinkaurelius.titan.graphdb.database.cache
 
MetricInstrumentedSchemaCache(SchemaCache.StoreRetrieval) - Constructor for class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
MetricInstrumentedStore - Class in com.thinkaurelius.titan.diskstorage.util
This class instruments an arbitrary KeyColumnValueStore backend with Metrics.
MetricInstrumentedStore(KeyColumnValueStore, String) - Constructor for class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
MetricInstrumentedStoreManager - Class in com.thinkaurelius.titan.diskstorage.util
 
MetricInstrumentedStoreManager(KeyColumnValueStoreManager, String, boolean, String) - Constructor for class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
MetricManager - Enum in com.thinkaurelius.titan.util.stats
Singleton that contains and configures Titan's MetricRegistry.
METRICS_CACHE_SUFFIX - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
METRICS_CONSOLE_INTERVAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Metrics console reporter interval in milliseconds.
METRICS_CONSOLE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_CSV_DIR - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Metrics CSV output directory.
METRICS_CSV_INTERVAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Metrics CSV reporter interval in milliseconds.
METRICS_CSV_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_GANGLIA_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The configuration namespace within GraphDatabaseConfiguration.METRICS_NS for Ganglia.
METRICS_GRAPHITE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The configuration namespace within GraphDatabaseConfiguration.METRICS_NS for Graphite.
METRICS_JMX_AGENTID - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The JMX agentId through which to report Metrics.
METRICS_JMX_DOMAIN - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The JMX domain in which to report Metrics.
METRICS_JMX_ENABLED - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Whether to report Metrics through a JMX MBean.
METRICS_JMX_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_MERGE_STORES - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Whether to aggregate measurements for the edge store, vertex index, edge index, and ID store.
METRICS_MERGED_CACHE - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
METRICS_MERGED_STORE - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
METRICS_NAME - Static variable in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
METRICS_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configuration key prefix for Metrics.
METRICS_PREFIX - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The default name prefix for Metrics reported by Titan.
METRICS_PREFIX_DEFAULT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
This is the prefix used outside of a graph database configuration, or for operations where a system-internal transaction is necessary as an implementation detail.
METRICS_RELATIONS - Static variable in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
METRICS_SCHEMA_PREFIX_DEFAULT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_SLF4J_INTERVAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Metrics Slf4j reporter interval in milliseconds.
METRICS_SLF4J_LOGGER - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
The complete name of the Logger through which Metrics will report via Slf4j.
METRICS_SLF4J_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_STOREMANAGER_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
METRICS_SYSTEM_PREFIX_DEFAULT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
METRICS_TYPENAME - Static variable in class com.thinkaurelius.titan.graphdb.database.cache.MetricInstrumentedSchemaCache
 
metricsPrefix - Variable in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
MetricsQueryExecutor<Q extends ElementQuery,R extends TitanElement,B extends BackendQuery> - Class in com.thinkaurelius.titan.graphdb.query
Wraps a QueryExecutor to gather metrics on the query execution and forward them to METRICS.
MetricsQueryExecutor(String, String, QueryExecutor<Q, R, B>) - Constructor for class com.thinkaurelius.titan.graphdb.query.MetricsQueryExecutor
 
mgmt - Variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
MgmtLogType - Enum in com.thinkaurelius.titan.graphdb.database.management
 
min(Duration, Duration) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Durations
 
MIN_KEY - Static variable in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
MIN_TASKS_TO_PARALLELIZE - Static variable in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
MixedConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
 
MixedConfiguration(ConfigNamespace, ReadConfiguration, ReadConfiguration) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
MixedIndexType - Interface in com.thinkaurelius.titan.graphdb.types
 
MixedIndexTypeWrapper - Class in com.thinkaurelius.titan.graphdb.types.indextype
 
MixedIndexTypeWrapper(SchemaSource) - Constructor for class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
ModifiableConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
 
ModifiableConfiguration(ConfigNamespace, WriteConfiguration, BasicConfiguration.Restriction) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
ModificationDeserializer - Class in com.thinkaurelius.titan.graphdb.log
 
ModificationDeserializer() - Constructor for class com.thinkaurelius.titan.graphdb.log.ModificationDeserializer
 
ModifierType - Enum in com.thinkaurelius.titan.graphdb.database.management
 
modulateNaturalOrder(int) - Method in enum com.thinkaurelius.titan.graphdb.internal.Order
Modulates the result of a Comparable.compareTo(Object) execution for this specific order, i.e.
movePositionTo(int) - Method in interface com.thinkaurelius.titan.diskstorage.ReadBuffer
 
movePositionTo(int) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
MSG_USAGE - Static variable in class com.thinkaurelius.titan.util.system.CheckSocket
 
MultiCondition<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
Abstract condition element that combines multiple conditions (for instance, AND, OR).
MultiKeySliceQuery - Class in com.thinkaurelius.titan.graphdb.query.graph
 
MultiKeySliceQuery(List<KeySliceQuery>) - Constructor for class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
multiplicity() - Method in interface com.thinkaurelius.titan.core.EdgeLabel
The Multiplicity for this edge label.
Multiplicity - Enum in com.thinkaurelius.titan.core
The multiplicity of edges between vertices for a given label.
multiplicity(Multiplicity) - Method in interface com.thinkaurelius.titan.core.schema.EdgeLabelMaker
Sets the multiplicity of this label.
multiplicity() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelationType
 
multiplicity(Multiplicity) - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
multiplicity(Multiplicity) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
multiplicity() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
multiplicity() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
multiplicity() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
multiplicity() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
MultiQueriable<S,E> - Interface in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
multiQuery(TitanVertex...) - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
Deprecated.
multiQuery(Collection<TitanVertex>) - Method in interface com.thinkaurelius.titan.core.TitanGraphTransaction
Deprecated.
multiQuery(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
multiQuery(TitanVertex...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
Deprecated.
multiQuery(Collection<TitanVertex>) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
Deprecated.
multiQuery(TitanVertex...) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
Deprecated.
multiQuery(Collection<TitanVertex>) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
Deprecated.
MULTIQUERY_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
MultiVertexCentricQueryBuilder - Class in com.thinkaurelius.titan.graphdb.query.vertex
MultiVertexCentricQueryBuilder(StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
mutate(Map<String, Map<String, IndexMutation>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.indexing.IndexProvider
Mutates the index (adds and removes fields or entire documents)
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryKeyColumnValueStore
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
Verifies acquisition of locks txh from previous calls to KeyColumnValueStore.acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) , then writes supplied additions and/or deletions to key in the underlying data store.
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ReadOnlyKeyColumnValueStore
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVS
 
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
Verifies acquisition of locks txh from previous calls to KeyColumnValueStore.acquireLock(StaticBuffer, StaticBuffer, StaticBuffer, StoreTransaction) , then writes supplied additions and/or deletions to key in the underlying data store.
mutate(StaticBuffer, List<Entry>, List<StaticBuffer>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
mutateEdges(StaticBuffer, List<Entry>, List<Entry>) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
Applies the specified insertion and deletion mutations on the edge store to the provided key.
mutateEntries(StaticBuffer, List<Entry>, List<Entry>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
mutateIndex(StaticBuffer, List<Entry>, List<Entry>) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
Applies the specified insertion and deletion mutations on the property index to the provided key.
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Executes multiple mutations at once.
mutateMany(Map<String, KVMutation>, StoreTransaction) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManager
Executes multiple mutations at once.
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
mutateMany(Map<String, Map<StaticBuffer, KCVMutation>>, StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
Mutation<E,K> - Class in com.thinkaurelius.titan.diskstorage
Container for collection mutations against a data store.
Mutation(List<E>, List<K>) - Constructor for class com.thinkaurelius.titan.diskstorage.Mutation
 
Mutation() - Constructor for class com.thinkaurelius.titan.diskstorage.Mutation
 

N

name() - Method in interface com.thinkaurelius.titan.core.Namifiable
Returns the unique name of this entity.
name() - Method in interface com.thinkaurelius.titan.core.schema.TitanGraphIndex
Returns the name of the index
name() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
name() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
name() - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
 
name(String) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
name(String) - Method in class com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
name() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseRelationType
 
name() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
name() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
name() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
NAME_PREFIX - Static variable in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
Namifiable - Interface in com.thinkaurelius.titan.core
Represents an entity that can be uniquely identified by a String name.
negate() - Method in enum com.thinkaurelius.titan.core.attribute.Text
 
negate() - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
Returns the negation of this predicate if it exists, otherwise an exception is thrown.
NetworkUtil - Class in com.thinkaurelius.titan.util.system
 
NetworkUtil() - Constructor for class com.thinkaurelius.titan.util.system.NetworkUtil
 
New - Static variable in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
The entity has been newly created and not yet persisted.
newCondition() - Method in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
newThreadBoundTransaction() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
newThreadBoundTransaction() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
newTransaction() - Method in interface com.thinkaurelius.titan.core.TitanGraph
Opens a new thread-independent TitanTransaction.
newTransaction() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
newTransaction(TransactionConfiguration) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
next() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
 
next() - Method in class com.thinkaurelius.titan.graphdb.query.LimitAdjustingIterator
 
next() - Method in class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
next() - Method in class com.thinkaurelius.titan.graphdb.query.ResultSetIterator
 
next() - Method in class com.thinkaurelius.titan.graphdb.util.AllEdgesIterator
 
next() - Method in class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterator
 
next() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
nextBiggerBuffer(StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
nextBiggerBufferAllowOverflow(StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
nextID() - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.IDPool
 
nextID() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.StandardIDPool
 
nextInternal() - Method in class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
NO_ADDITIONS - Static variable in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
 
NO_COMPRESSION - Static variable in interface com.thinkaurelius.titan.diskstorage.util.BackendCompression
 
NO_DELETIONS - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
NO_DELETIONS - Static variable in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStore
 
NO_FILTER - Static variable in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
NO_LIMIT - Static variable in interface com.thinkaurelius.titan.graphdb.query.Query
 
NO_OP - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
NO_ORDER - Static variable in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
NO_ORDER - Static variable in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
noFilter() - Static method in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
NoKCVSCache - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache
 
NoKCVSCache(KeyColumnValueStore) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.NoKCVSCache
 
NoLock - Class in com.thinkaurelius.titan.diskstorage.util
Implementation of a lock that has no effect, i.e.
NON_EXISTANT_TYPE - Static variable in class com.thinkaurelius.titan.graphdb.internal.Token
 
NON_PERSISTING_KEYS - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
nonnegativeInt() - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
NoOpStoreTransaction - Class in com.thinkaurelius.titan.diskstorage.common
Dummy transaction object that does nothing
NoOpStoreTransaction(BaseTransactionConfig) - Constructor for class com.thinkaurelius.titan.diskstorage.common.NoOpStoreTransaction
 
noPartitionRestriction() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Removes any query partition restriction for this query
NoSerializer<V> - Class in com.thinkaurelius.titan.graphdb.database.serialize
 
NoSerializer(Class<V>) - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.NoSerializer
 
Not<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
Negates the wrapped condition, i.e.
Not(Condition<E>) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.Not
 
notKeyConsistent() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
NumberUtil - Class in com.thinkaurelius.titan.util.stats
 
NumberUtil() - Constructor for class com.thinkaurelius.titan.util.stats.NumberUtil
 
numChildren() - Method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
 
numChildren() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
numChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Literal
 
numChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
numChildren() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
NumericUtils - Class in com.thinkaurelius.titan.util.encoding
This file is copied verbatim from Apache Lucene NumericUtils.java Only the double/float to sortable long/int conversions are retained.
numIds() - Method in interface com.thinkaurelius.titan.diskstorage.IDBlock
Number of ids in this block.
numObjects() - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
numProperties() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
numSubQueries() - Method in interface com.thinkaurelius.titan.graphdb.query.ElementQuery
Returns the number of sub-queries this query is comprised of.
numSubQueries() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
numSubQueries() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
NUMVERTICES_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 

O

OBJECT_HEADER - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
OBJECT_REFERENCE - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
ObjectAccumulator<K> - Class in com.thinkaurelius.titan.util.stats
This class counts arbitrary objects of type and tries to do so efficiently in time and space.
ObjectAccumulator() - Constructor for class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
ObjectAccumulator(int) - Constructor for class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
ObjectSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ObjectSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ObjectSerializer
 
observeWith(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.BackendQueryHolder
 
observeWith(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
observeWith(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
observeWith(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
observeWith(QueryProfiler) - Method in interface com.thinkaurelius.titan.graphdb.query.profile.ProfileObservable
 
observeWith(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
of(String, V) - Static method in class com.thinkaurelius.titan.core.schema.Parameter
 
of(int) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
of(Iterable<? extends Entry>) - Static method in class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
 
of(KeyIterator, String...) - Static method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
If the iterator argument is non-null, then return a new MetricInstrumentedIterator wrapping it.
of(TimestampProvider) - Static method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
of(TimestampProvider, Configuration) - Static method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
of(byte[]) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
of(ByteBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
of(StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
of(StaticBuffer, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
of(Entry...) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
of(Iterable<Entry>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
of(TitanTransaction) - Static method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraElementTraversal
 
of(Condition<E>...) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.And
 
of(Condition<E>) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
of(Condition<E>...) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.Or
 
of(K, TitanPredicate, Object) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
of(PropertyKey) - Static method in class com.thinkaurelius.titan.graphdb.types.IndexField
 
of(PropertyKey, Parameter...) - Static method in class com.thinkaurelius.titan.graphdb.types.ParameterIndexField
 
of(TypeDefinitionCategory) - Static method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionDescription
 
of(Iterable<? extends Vertex>) - Static method in class com.thinkaurelius.titan.graphdb.util.AllEdgesIterable
Returns an iterable over all edges incident on the vertices returned by the given Iterable over vertices.
of(Set<? extends Vertex>) - Static method in class com.thinkaurelius.titan.graphdb.util.AllEdgesIterable
Returns an iterable over all edges contained in the subgraph spanned by the given vertices.
of(String[], Object[]) - Static method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
ofByteBuffer(E, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
ofByteBuffer(Iterable<E>, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
ofByteBuffer(Iterator<E>, StaticArrayEntry.GetColVal<E, ByteBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
ofBytes(E, StaticArrayEntry.GetColVal<E, byte[]>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
ofBytes(Iterable<E>, StaticArrayEntry.GetColVal<E, byte[]>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
offset(int) - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Specifies the offset of the query.
offset(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
ofStaticBuffer(E, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
ofStaticBuffer(Iterable<E>, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
ofStaticBuffer(Iterator<E>, StaticArrayEntry.GetColVal<E, StaticBuffer>) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
oneAlife(Thread[]) - Static method in class com.thinkaurelius.titan.util.system.Threads
 
oneBuffer(int) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
oneByteBuffer(int) - Static method in class com.thinkaurelius.titan.diskstorage.util.ByteBufferUtil
 
open() - Method in class com.thinkaurelius.titan.core.TitanFactory.Builder
Opens a Titan graph with the previously configured options.
open(String) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Opens a TitanGraph database.
open(Configuration) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Opens a TitanGraph database configured according to the provided configuration.
open(BasicConfiguration) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Opens a TitanGraph database configured according to the provided configuration.
open(ReadConfiguration) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Opens a TitanGraph database configured according to the provided configuration.
openDatabase(String, StoreMetaData.Container) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.inmemory.InMemoryStoreManager
 
openDatabase(String, StoreMetaData.Container) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSManagerProxy
 
openDatabase(String) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Opens an ordered database by the given name.
openDatabase(String, StoreMetaData.Container) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyColumnValueStoreManager
Opens an ordered database by the given name.
openDatabase(String) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeyValueStoreManager
Opens a key-value database by the given name.
openDatabase(String) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManager
Opens an ordered database by the given name.
openDatabase(String) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
openDatabase(String, StoreMetaData.Container) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
openDatabase(String) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
openDatabase(String, StoreMetaData.Container) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
openDatabase(String) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStoreManager
 
openDatabase(String, StoreMetaData.Container) - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStoreManager
 
openLog(String) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLogManager
 
openLog(String) - Method in interface com.thinkaurelius.titan.diskstorage.log.LogManager
Opens a log for the given name.
openManagement() - Method in interface com.thinkaurelius.titan.core.TitanGraph
Returns the management system for this graph instance.
openManagement() - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
OPENSTAR_CHECK - Static variable in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
openTransactionLog(TitanGraph) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Returns a LogProcessorFramework for processing transaction log entries against the provided graph instance.
openTx() - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
openTx() - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
openTx() - Method in interface com.thinkaurelius.titan.diskstorage.util.BackendOperation.TransactionalProvider
 
OPERATION_NAMES - Static variable in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedStore
 
OPTIMIZATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
or(String, boolean) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
Or<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
Combines multiple conditions under semantic OR, i.e.
Or(Condition<E>...) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.Or
 
Or(int) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.Or
 
Or() - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.Or
 
OR_QUERY - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
Order - Enum in com.thinkaurelius.titan.graphdb.internal
Constants to specify the ordering of a result set in queries.
order - Variable in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder.OrderEntry
 
orderBy(String, Order) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Orders the relation results of this query according to their property for the given key in the given order (increasing/decreasing).
orderBy(String, Order) - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
Orders the element results of this query according to their property for the given key in the given order (increasing/decreasing).
orderBy(String, Order) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
orderBy(String, Order) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
orderBy(String, Order) - Method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
orderBy(String, Order) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
ORDERED_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
OrderedKeyValueStore - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue
A KeyValueStore where the keys are ordered such that keys can be retrieved in order.
OrderedKeyValueStoreAdapter - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue
Wraps a OrderedKeyValueStore and exposes it as a KeyColumnValueStore.
OrderedKeyValueStoreAdapter(OrderedKeyValueStore) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
OrderedKeyValueStoreAdapter(OrderedKeyValueStore, int) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
OrderedKeyValueStoreManager - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue
A KeyValueStoreManager where the stores maintain keys in their natural order.
OrderedKeyValueStoreManagerAdapter - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue
OrderedKeyValueStoreManagerAdapter(OrderedKeyValueStoreManager) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
OrderedKeyValueStoreManagerAdapter(OrderedKeyValueStoreManager, Map<String, Integer>) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreManagerAdapter
 
orderedScan(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
OrderEntry(String, Order, Class<?>) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
OrderEntry(PropertyKey, Order) - Constructor for class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
OrderEntry(String, Order) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder.OrderEntry
 
OrderList - Class in com.thinkaurelius.titan.graphdb.internal
 
OrderList() - Constructor for class com.thinkaurelius.titan.graphdb.internal.OrderList
 
OrderList.OrderEntry - Class in com.thinkaurelius.titan.graphdb.internal
 
OrderPreservingSerializer<V> - Interface in com.thinkaurelius.titan.graphdb.database.serialize
Interface that extends AttributeSerializer to provide a serialization that is byte order preserving, i.e.
orders - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The order in which the relations should be returned.
ORDERS_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
otherVertex(Vertex) - Method in interface com.thinkaurelius.titan.core.TitanEdge
Returns the vertex at the opposite end of the edge.
otherVertex(Vertex) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
outVertex() - Method in interface com.thinkaurelius.titan.core.TitanEdge
 
outVertexId - Variable in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Modification
 

P

padBuffer(StaticBuffer, int) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
PAGE_SIZE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Default number of results to pull over the wire when iterating over a distributed storage backend.
pageSize - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
PARALLEL_BACKEND_OPS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
If enabled, Titan attempts to parallelize storage operations against the storage backend using a fixed thread pool shared across the entire Titan graph database instance.
Parameter<V> - Class in com.thinkaurelius.titan.core.schema
Simple class to represent arbitrary parameters as key-value pairs.
Parameter(String, V) - Constructor for class com.thinkaurelius.titan.core.schema.Parameter
 
ParameterArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ParameterArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
ParameterIndexField - Class in com.thinkaurelius.titan.graphdb.types
 
ParameterSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ParameterSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterSerializer
 
ParameterType - Enum in com.thinkaurelius.titan.graphdb.types
 
parse(ConfigNamespace, String) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
parse(String) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Durations
 
parse(StaticBuffer, Serializer, TimestampProvider) - Static method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
parse(String) - Static method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
parseDirection(Entry) - Method in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
parseRelation(Entry, boolean, TypeInspector) - Method in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
parseRelation(Entry, boolean, TypeInspector) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationReader
 
parseRelation(TransactionLogHeader.Modification, StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.log.ModificationDeserializer
 
partition() - Method in interface com.thinkaurelius.titan.core.schema.VertexLabelMaker
Enables partitioning for this vertex label.
partition() - Method in class com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
PARTITION_FINDING_ATTEMPTS - Static variable in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
PARTITION_KEY - Static variable in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
PARTITION_VERTEX_POSTFAIL - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PARTITION_VERTEX_POSTSUCCESS - Static variable in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PartitionAssignment - Interface in com.thinkaurelius.titan.graphdb.database.idassigner.placement
Utility interface used in IDPlacementStrategy to hold the partition assignment of a vertex (if it is already assigned a partition) or to be assigned a partition id.
PARTITIONED_VERTEX_ANNOTATION - Static variable in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
PARTITIONED_VERTEX_PARTITION - Static variable in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
PartitionedVertexProgramExecutor<M> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
PartitionedVertexProgramExecutor(StandardTitanGraph, FulgoraMemory, FulgoraVertexMemory, VertexProgram<M>) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
PartitionIDRange - Class in com.thinkaurelius.titan.graphdb.database.idassigner.placement
An instance of this class describes a range of partition ids.
PartitionIDRange(int, int, int) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
PartitionVertexAggregate<M> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
PartitionVertexAggregate(Map<MessageScope, Integer>) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.PartitionVertexAggregate
 
password - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
PermanentBackendException - Exception in com.thinkaurelius.titan.diskstorage
This exception signifies a permanent exception in a Titan storage backend, that is, an exception that is due to a permanent failure while persisting data.
PermanentBackendException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.PermanentBackendException
 
PermanentBackendException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.PermanentBackendException
 
PermanentBackendException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.PermanentBackendException
Constructs an exception with a generic message
PermanentLockingException - Exception in com.thinkaurelius.titan.diskstorage.locking
This exception signifies a failure to lock based on durable state.
PermanentLockingException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.PermanentLockingException
 
PermanentLockingException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.PermanentLockingException
 
PermanentLockingException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.PermanentLockingException
Constructs an exception with a generic message
persist(GraphComputer.Persist) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
persists(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
PLACEMENT_STRATEGY - Static variable in class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
point(float, float) - Static method in class com.thinkaurelius.titan.core.attribute.Geoshape
Constructs a point from its latitude and longitude information
point(double, double) - Static method in class com.thinkaurelius.titan.core.attribute.Geoshape
Constructs a point from its latitude and longitude information
PointInterval<T> - Class in com.thinkaurelius.titan.util.datastructures
 
PointInterval(T) - Constructor for class com.thinkaurelius.titan.util.datastructures.PointInterval
 
PointInterval(T...) - Constructor for class com.thinkaurelius.titan.util.datastructures.PointInterval
 
PointInterval(Iterable<T>) - Constructor for class com.thinkaurelius.titan.util.datastructures.PointInterval
 
pointRange(StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
poll - Variable in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
pollInterval(long, TemporalUnit) - Method in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
Set the index information polling interval.
pop() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
port - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
position(Direction) - Static method in class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
positiveBackwardLength(long) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
positiveBuffer(long) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
positiveBuffer(long[]) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
positiveInt() - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
positiveLength(long) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
positiveLong() - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
positiveWithPrefixLength(long, int) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
preBuild() - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
Inspect and modify this builder's state after the client has called build(), but before a return object has been instantiated.
PredicateCondition<K,E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
 
PredicateCondition(K, TitanPredicate, Object) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
preevaluate(Object, Object) - Method in enum com.thinkaurelius.titan.core.attribute.Text
 
preferredTimestamps(TimestampProviders) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
PreInitializeConfigOptions - Annotation Type in com.thinkaurelius.titan.graphdb.configuration
 
PreloadedVertex - Class in com.thinkaurelius.titan.graphdb.vertices
 
PreloadedVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
PreloadedVertex.AccessCheck - Interface in com.thinkaurelius.titan.graphdb.vertices
 
PreloadedVertex.PropertyMixing - Interface in com.thinkaurelius.titan.graphdb.vertices
 
prepareCommit(Collection<InternalRelation>, Collection<InternalRelation>, Predicate<InternalRelation>, BackendTransaction, StandardTitanTx, boolean) - Method in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
previousMap - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
PriorityQueue<T> - Class in com.thinkaurelius.titan.graphdb.util
A PriorityQueue maintains a partial ordering of its elements such that the least element can always be found in constant time.
PriorityQueue(int) - Constructor for class com.thinkaurelius.titan.graphdb.util.PriorityQueue
 
PriorityQueue(int, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.util.PriorityQueue
 
process(TitanTransaction, TransactionId, ChangeState) - Method in interface com.thinkaurelius.titan.core.log.ChangeProcessor
Process the changes caused by the transaction identified by txId within a newly opened transaction tx.
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanJob
Run this ScanJob's computation on the supplied row-key and entries.
process(TitanVertex, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexMapJob
 
process(TitanVertex, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexProgramScanJob
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
process(TitanVertex, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
 
process(StaticBuffer, Map<SliceQuery, EntryList>, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
process(TitanVertex, ScanMetrics) - Method in interface com.thinkaurelius.titan.graphdb.olap.VertexScanJob
Process the given vertex with its adjacency list and properties pre-loaded.
processIntersectingRetrievals(List<QueryUtil.IndexCall<R>>, int) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
ProcessMessageJob - Class in com.thinkaurelius.titan.diskstorage.log.util
Helper class for processing read messages with the registered message readers.
ProcessMessageJob(Message, MessageReader) - Constructor for class com.thinkaurelius.titan.diskstorage.log.util.ProcessMessageJob
 
processNextStart() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
processNextStart() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
profile(QueryProfiler, Q, Function<Q, R>) - Static method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
profile(String, QueryProfiler, Q, Function<Q, R>) - Static method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
profile(QueryProfiler, Q, boolean, Function<Q, R>) - Static method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
profile(String, QueryProfiler, Q, boolean, Function<Q, R>) - Static method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
ProfileObservable - Interface in com.thinkaurelius.titan.graphdb.query.profile
 
profiler(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
profiler - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
The query profiler used to observe this query
profiler(QueryProfiler) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Sets the query profiler to observe this query.
program(VertexProgram) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
PROPER_DIRS - Static variable in class com.thinkaurelius.titan.graphdb.relations.EdgeDirection
 
properties() - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
Returns all properties that match the conditions
properties() - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Returns all properties that match the query in the indexing backend.
properties() - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
Returns an iterable over all incident properties that match this query for each vertex
properties() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns an iterable over all incident properties that match this query
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
properties - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
properties() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
properties() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
properties() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
properties() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
properties() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
properties(String...) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
properties(String...) - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.PropertyMixing
 
property(String, V) - Method in interface com.thinkaurelius.titan.core.TitanElement
Sets the value for the given key on this element.
property(String, V) - Method in interface com.thinkaurelius.titan.core.TitanVertex
Creates a new property for this vertex and given key with the specified value.
property(String, V, Object...) - Method in interface com.thinkaurelius.titan.core.TitanVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in interface com.thinkaurelius.titan.core.TitanVertex
 
property(String, V) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
property(String, V) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
property(String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
property(String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
property(VertexProperty.Cardinality, String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
property(String, V, Object...) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
property(VertexProperty.Cardinality, String, V) - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.PropertyMixing
 
PROPERTY_PREFETCHING - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
propertyCount() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns the number of properties that match this query
propertyIterator() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
PropertyKey - Interface in com.thinkaurelius.titan.core
PropertyKey is an extension of RelationType for properties.
propertyKey() - Method in interface com.thinkaurelius.titan.core.TitanProperty
 
propertyKey() - Method in interface com.thinkaurelius.titan.core.TitanVertexProperty
 
propertyKey() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
PROPERTYKEY_DEFINITION_CATEGORIES - Static variable in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
PropertyKeyDefinition - Class in com.thinkaurelius.titan.graphdb.schema
 
PropertyKeyDefinition(String, long, Cardinality, Class) - Constructor for class com.thinkaurelius.titan.graphdb.schema.PropertyKeyDefinition
 
PropertyKeyDefinition(String, long, Multiplicity, Class) - Constructor for class com.thinkaurelius.titan.graphdb.schema.PropertyKeyDefinition
 
PropertyKeyDefinition(PropertyKey) - Constructor for class com.thinkaurelius.titan.graphdb.schema.PropertyKeyDefinition
 
PropertyKeyMaker - Interface in com.thinkaurelius.titan.core.schema
Used to define new PropertyKeys.
PropertyKeyVertex - Class in com.thinkaurelius.titan.graphdb.types.vertices
 
PropertyKeyVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.types.vertices.PropertyKeyVertex
 
PropertyPlacementStrategy - Class in com.thinkaurelius.titan.graphdb.database.idassigner.placement
 
PropertyPlacementStrategy(Configuration) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
PropertyPlacementStrategy(String, int) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
put(EntryMetaData, Object) - Method in class com.thinkaurelius.titan.diskstorage.EntryMetaData.Map
 
put(K, V) - Method in class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
put(WriteBuffer, byte[]) - Static method in class com.thinkaurelius.titan.diskstorage.util.WriteBufferUtil
 
put(WriteBuffer, StaticBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.WriteBufferUtil
 
put(Long, V) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
put(String, Object) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
putAll(Map<? extends String, ? extends Object>) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
putBoolean(boolean) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putBoolean(boolean) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putByte(byte) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putByte(byte) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putByte(byte) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putBytes(byte[]) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putBytes(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putBytes(byte[]) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putBytes(StaticBuffer) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putBytes(byte[]) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putBytes(StaticBuffer) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putChar(char) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putChar(char) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putChar(char) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putDouble(double) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putDouble(double) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putDouble(double) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putFloat(float) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putFloat(float) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putFloat(float) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putIfAbsent(Long, V) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
putIfAbsent(ConcurrentMap<K, V>, K, Factory<V>) - Static method in class com.thinkaurelius.titan.util.datastructures.Maps
 
putInt(byte[], int, int) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
putInt(int) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putInt(int) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putInt(int) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putLong(byte[], int, long) - Static method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
putLong(long) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putLong(long) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putLong(long) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 
putShort(short) - Method in class com.thinkaurelius.titan.diskstorage.util.WriteByteBuffer
 
putShort(short) - Method in interface com.thinkaurelius.titan.diskstorage.WriteBuffer
 
putShort(short) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.DataOutput
 

Q

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

R

random - Static variable in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
RandomRemovalList<T> - Class in com.thinkaurelius.titan.util.datastructures
A list that allows efficient random removals.
RandomRemovalList() - Constructor for class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
RandomRemovalList(int) - Constructor for class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
RandomRemovalList(Collection<T>) - Constructor for class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
randomUniqueIDLimit - Variable in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
RangeInterval<T> - Class in com.thinkaurelius.titan.util.datastructures
 
RangeInterval() - Constructor for class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
RangeInterval(T, T) - Constructor for class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
rawQuery(String, RawQuery) - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
 
RawQuery - Class in com.thinkaurelius.titan.diskstorage.indexing
 
RawQuery(String, String, Parameter[]) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
RawQuery.Result<O> - Class in com.thinkaurelius.titan.diskstorage.indexing
 
reachedLimit() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.KeySelector
 
read(ScanBuffer) - Method in interface com.thinkaurelius.titan.core.attribute.AttributeSerializer
Reads an attribute from the given ReadBuffer.
read(ScanBuffer) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeSerializer
 
read(Message) - Method in interface com.thinkaurelius.titan.diskstorage.log.MessageReader
Processes the given message.
read(byte[], int) - Method in interface com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList.MetaDataSerializer
 
read(ScanBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
read(Message) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementLogger
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DateSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DurationSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.EnumSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.InstantSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntegerSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ObjectSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringArraySerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.UUIDSerializer
 
read(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.NoSerializer
 
ReadArrayBuffer - Class in com.thinkaurelius.titan.diskstorage.util
Implementation of ReadBuffer against a byte array.
ReadArrayBuffer(byte[]) - Constructor for class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
ReadArrayBuffer(byte[], int, int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
readAsciiString(byte[], int) - Static method in class com.thinkaurelius.titan.util.encoding.StringEncoding
 
readBackward(ReadBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
readBitb(byte, int) - Static method in class com.thinkaurelius.titan.util.datastructures.BitMap
 
ReadBuffer - Interface in com.thinkaurelius.titan.diskstorage
A Buffer that allows sequential reads and static reads.
readBuffer(ScanBuffer) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DateSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.EnumSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntegerSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortSerializer
 
readByteOrder(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
readByteOrder(ScanBuffer) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.OrderPreservingSerializer
Reads an attribute from the given ReadBuffer assuming it was written in byte order.
readClassAndObject(ScanBuffer) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.Serializer
 
readClassAndObject(ScanBuffer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
ReadConfiguration - Interface in com.thinkaurelius.titan.diskstorage.configuration
 
readEntry(ReadBuffer, Serializer) - Static method in class com.thinkaurelius.titan.diskstorage.util.BufferUtil
 
readInlineRelationType(ReadBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
ReadMarker - Class in com.thinkaurelius.titan.diskstorage.log
 
readObject(ScanBuffer, Class<T>) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.Serializer
 
readObject(ScanBuffer, Class<T>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
readObjectByteOrder(ScanBuffer, Class<T>) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.Serializer
 
readObjectByteOrder(ScanBuffer, Class<T>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
readObjectNotNull(ScanBuffer, Class<T>) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.Serializer
 
readObjectNotNull(ScanBuffer, Class<T>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
readOnly() - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Makes the transaction read only.
readOnly() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
ReadOnlyKeyColumnValueStore - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Wraps a KeyColumnValueStore and throws exceptions when a mutation is attempted.
ReadOnlyKeyColumnValueStore(KeyColumnValueStore) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ReadOnlyKeyColumnValueStore
 
readPositive(ScanBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
readPositiveBackward(ReadBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
readPositiveWithPrefix(ReadBuffer, int) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
readRelation(Entry, boolean, TypeInspector) - Method in class com.thinkaurelius.titan.graphdb.database.EdgeSerializer
 
readRelation(InternalVertex, Iterable<Entry>, StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.transaction.RelationConstructor
 
readRelation(InternalVertex, Entry, StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.transaction.RelationConstructor
 
readRelation(InternalVertex, Entry, EdgeSerializer, TypeInspector, VertexFactory) - Static method in class com.thinkaurelius.titan.graphdb.transaction.RelationConstructor
 
readRelationCache(Entry, StandardTitanTx) - Static method in class com.thinkaurelius.titan.graphdb.transaction.RelationConstructor
 
readRelationType(ReadBuffer) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
ReassignableRelation - Interface in com.thinkaurelius.titan.graphdb.relations
 
RecordIterator<T> - Interface in com.thinkaurelius.titan.diskstorage.util
Iterator over records in the storage backend.
reduceMap - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMapEmitter
 
reduceQueue - Variable in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraReduceEmitter
 
ReentrantTransactionLock - Class in com.thinkaurelius.titan.graphdb.transaction.lock
 
ReentrantTransactionLock() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.lock.ReentrantTransactionLock
 
ReflectiveConfigOptionLoader - Enum in com.thinkaurelius.titan.core.util
This class supports iteration over Titan's ConfigNamespaces at runtime.
register(String, String, KeyInformation, BaseTransaction) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
register(MixedIndexType, PropertyKey, BackendTransaction) - Static method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
registerClass(int, Class<T>, AttributeSerializer<T>) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.AttributeHandler
 
registerClass(int, Class<V>, AttributeSerializer<V>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
registerClassInternal(int, Class<? extends V>, AttributeSerializer<V>) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
REGISTERED_LOG_MANAGERS - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
RegisteredAttributeClass<T> - Class in com.thinkaurelius.titan.graphdb.configuration
Helper class for registering data types with Titan
RegisteredAttributeClass(int, Class<T>, AttributeSerializer<T>) - Constructor for class com.thinkaurelius.titan.graphdb.configuration.RegisteredAttributeClass
 
registerReader(ReadMarker, MessageReader...) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
################################### Message Reading ###################################
registerReader(ReadMarker, MessageReader...) - Method in interface com.thinkaurelius.titan.diskstorage.log.Log
 
registerReaders(ReadMarker, Iterable<MessageReader>) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
registerReaders(ReadMarker, Iterable<MessageReader>) - Method in interface com.thinkaurelius.titan.diskstorage.log.Log
Registers the given readers with this log.
REGISTRATION_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
REGISTRATION_TIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
reindexElement(TitanElement, MixedIndexType, Map<String, Map<String, List<IndexEntry>>>) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
reindexElement(TitanElement, CompositeIndexType) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
RELATION_INDEX_SEPARATOR - Static variable in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
RelationCache - Class in com.thinkaurelius.titan.graphdb.relations
Immutable map from long key ids to objects.
RelationCache(Direction, long, long, Object, LongObjectHashMap<Object>) - Constructor for class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
RelationCache(Direction, long, long, Object) - Constructor for class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
RelationCategory - Enum in com.thinkaurelius.titan.graphdb.internal
 
RelationComparator - Class in com.thinkaurelius.titan.graphdb.relations
A Comparator for TitanRelation that uses a defined order to compare the relations with or otherwise uses the natural order of relations.
RelationComparator(InternalVertex) - Constructor for class com.thinkaurelius.titan.graphdb.relations.RelationComparator
 
RelationComparator(InternalVertex, OrderList) - Constructor for class com.thinkaurelius.titan.graphdb.relations.RelationComparator
 
RelationConstructor() - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.RelationConstructor
 
RelationConstructor - Class in com.thinkaurelius.titan.graphdb.transaction
 
RelationConstructor() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.RelationConstructor
 
relationEntry - Variable in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Modification
 
RelationFactory - Interface in com.thinkaurelius.titan.graphdb.database
 
relationId - Variable in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
RelationIdentifier - Class in com.thinkaurelius.titan.graphdb.relations
 
RelationIdentifierDeserializer() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson.TitanGraphSONModule.RelationIdentifierDeserializer
 
RelationIdentifierSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson.TitanGraphSONModule.RelationIdentifierSerializer
 
RelationIndexStatusReport - Class in com.thinkaurelius.titan.graphdb.database.management
 
RelationIndexStatusReport(boolean, String, String, SchemaStatus, SchemaStatus, Duration) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
RelationIndexStatusWatcher - Class in com.thinkaurelius.titan.graphdb.database.management
 
RelationIndexStatusWatcher(TitanGraph, String, String) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusWatcher
 
RelationQueryCache - Class in com.thinkaurelius.titan.graphdb.database
 
RelationQueryCache(EdgeSerializer) - Constructor for class com.thinkaurelius.titan.graphdb.database.RelationQueryCache
 
RelationQueryCache(EdgeSerializer, int) - Constructor for class com.thinkaurelius.titan.graphdb.database.RelationQueryCache
 
RelationReader - Interface in com.thinkaurelius.titan.graphdb.database
 
relations() - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
Returns an iterable over all incident relations that match this query for each vertex
relations() - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
Returns an iterable over all incident relations that match this query
relations() - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
relations() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
relations() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.SimpleVertexQueryProcessor
Converts the entries from this query result into actual TitanRelation.
relations() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
RelationType - Interface in com.thinkaurelius.titan.core
RelationType defines the schema for TitanRelation.
RelationTypeCondition<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
 
RelationTypeCondition(RelationType) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.RelationTypeCondition
 
RelationTypeDefinition - Class in com.thinkaurelius.titan.graphdb.schema
 
RelationTypeDefinition(String, long, Multiplicity) - Constructor for class com.thinkaurelius.titan.graphdb.schema.RelationTypeDefinition
 
RelationTypeIndex - Interface in com.thinkaurelius.titan.core.schema
A RelationTypeIndex is an index installed on a RelationType to speed up vertex-centric indexes for that type.
RelationTypeIndexWrapper - Class in com.thinkaurelius.titan.graphdb.database.management
 
RelationTypeIndexWrapper(InternalRelationType) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
relationTypeLength(long) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler
 
RelationTypeMaker - Interface in com.thinkaurelius.titan.core.schema
RelationTypeMaker is a factory for RelationTypes.
RelationTypeParse(long, IDHandler.DirectionID) - Constructor for class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler.RelationTypeParse
 
RelationTypeVertex - Class in com.thinkaurelius.titan.graphdb.types.vertices
 
RelationTypeVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
release(StoreTransaction, KeyColumn) - Method in class com.thinkaurelius.titan.diskstorage.locking.LockerState
 
Removable - Interface in com.thinkaurelius.titan.util.datastructures
Interface to decorate elements that can be removed
RemovableRelationIterable<O extends TitanRelation> - Class in com.thinkaurelius.titan.graphdb.vertices
 
RemovableRelationIterable(Iterable<InternalRelation>) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterable
 
RemovableRelationIterator<O extends TitanRelation> - Class in com.thinkaurelius.titan.graphdb.vertices
 
RemovableRelationIterator(Iterator<InternalRelation>) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterator
 
remove() - Method in interface com.thinkaurelius.titan.core.TitanElement
Deletes this entity and any incident edges or properties from the graph.
remove(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
remove(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
remove(ConfigOption<O>, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
remove(String) - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
remove(String) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.WriteConfiguration
 
remove() - Method in class com.thinkaurelius.titan.diskstorage.util.MetricInstrumentedIterator
 
remove() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
remove() - Method in class com.thinkaurelius.titan.graphdb.query.LimitAdjustingIterator
 
remove() - Method in class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
remove() - Method in class com.thinkaurelius.titan.graphdb.query.ResultSetIterator
 
remove() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
remove() - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
remove() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
remove() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
remove() - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
remove(String) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanGraphVariables
 
remove(InternalRelation) - Method in interface com.thinkaurelius.titan.graphdb.transaction.addedrelations.AddedRelationsContainer
 
remove(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentAddedRelations
 
remove(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.ConcurrentBufferAddedRelations
 
remove(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleAddedRelations
 
remove(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
remove(TitanVertexProperty) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.ConcurrentIndexCache
 
remove(TitanVertexProperty) - Method in interface com.thinkaurelius.titan.graphdb.transaction.indexcache.IndexCache
 
remove(TitanVertexProperty) - Method in class com.thinkaurelius.titan.graphdb.transaction.indexcache.SimpleIndexCache
 
remove() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
remove() - Method in class com.thinkaurelius.titan.graphdb.util.AllEdgesIterator
Removing edges is not supported!
remove(Long) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
remove() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
remove() - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
remove() - Method in class com.thinkaurelius.titan.graphdb.vertices.RemovableRelationIterator
 
remove() - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
remove(Object) - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
remove() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
remove(Object) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
remove() - Method in interface com.thinkaurelius.titan.util.datastructures.Removable
 
remove(String) - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
 
removeAll(Collection<?>) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
removeAllReporters() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Remove all Titan Metrics reporters previously configured through the add* methods on this class.
removeConsoleReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a ConsoleReporter previously created by a call to #addConsoleReporter(long) and release it for GC.
removeCsvReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a CsvReporter previously created by a call to #addCsvReporter(long, String) and release it for GC.
Removed - Static variable in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
The entity has been deleted but not yet erased from the database.
REMOVED_RELATION_COUNT - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
REMOVED_VERTEX_COUNT - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
removedException(TitanElement) - Static method in exception com.thinkaurelius.titan.core.InvalidElementException
 
removeElement(Object, MixedIndexType, Map<String, Map<String, List<IndexEntry>>>) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
removeGangliaReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a GangliaReporter previously created by a call to #addGangliaReporter(String, int, UDPAddressingMode, int, Boolean, UUID, long) and release it for GC.
removeGraphiteReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a GraphiteReporter previously created by a call to #addGraphiteReporter(String, int, String, long) and release it for GC.
removeJmxReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a JmxReporter previously created by a call to MetricManager.addJmxReporter(String, String) and release it for GC.
removeLogProcessor(String) - Method in interface com.thinkaurelius.titan.core.log.LogProcessorFramework
Removes the log processor for the given identifier and closes the associated log.
removeLogProcessor(String) - Method in class com.thinkaurelius.titan.graphdb.log.StandardLogProcessorFramework
 
removeObject(K) - Method in class com.thinkaurelius.titan.util.stats.ObjectAccumulator
 
removePadding(long) - Method in enum com.thinkaurelius.titan.graphdb.idmanagement.IDManager.VertexIDType
 
removePropertyDirect(PropertyKey) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
 
removePropertyDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
removePropertyDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
removePropertyDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
removePropertyDirect(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
removeRelation(InternalRelation) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
removeRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
removeRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
removeRelation(InternalRelation) - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
removeSlf4jReporter() - Method in enum com.thinkaurelius.titan.util.stats.MetricManager
Stop a Slf4jReporter previously created by a call to #addSlf4jReporter(long, String) and release it for GC.
reset() - Method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
 
reset() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
reset() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
resetCache() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.CompositeIndexTypeWrapper
 
resetCache() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
resetCache() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.MixedIndexTypeWrapper
 
resetCache() - Method in interface com.thinkaurelius.titan.graphdb.types.IndexType
Resets the internal caches used to speed up lookups on this index.
resetCache() - Method in interface com.thinkaurelius.titan.graphdb.types.SchemaSource
Resets the internal caches used to speed up lookups on this schema source.
resetCache() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.RelationTypeVertex
 
resetCache() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
Resets the internal caches used to speed up lookups on this index type.
resetDelete() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexMutation
 
ResourceUnavailableException - Exception in com.thinkaurelius.titan.diskstorage
This exception is thrown if a resource is being accessed that is unavailable.
ResourceUnavailableException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.ResourceUnavailableException
 
ResourceUnavailableException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.ResourceUnavailableException
 
ResourceUnavailableException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.ResourceUnavailableException
Constructs an exception with a generic message
restore(Map<String, Map<String, List<IndexEntry>>>, KeyInformation.IndexRetriever, BaseTransaction) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
restrictedPartitions(int[]) - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Configures this transaction such that queries against partitioned vertices are restricted to the given partitions.
restrictedPartitions(int[]) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
restrictTo(Configuration, String...) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
restrictTo(String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
restrictTo(String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.Configuration
 
restrictTo(String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MergedConfiguration
 
restrictTo(String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.MixedConfiguration
 
restrictTo(String...) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.SystemConfiguration
 
Result(O, double) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.RawQuery.Result
 
result(GraphComputer.ResultGraph) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
ResultMergeSortIterator<R> - Class in com.thinkaurelius.titan.graphdb.query
 
ResultMergeSortIterator(Iterator<R>, Iterator<R>, Comparator<R>, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.query.ResultMergeSortIterator
 
resultMode(TitanGraphComputer.ResultMode) - Method in interface com.thinkaurelius.titan.core.TitanGraphComputer
 
ResultSetIterator<R extends TitanElement> - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.query.ResultSetIterator
 
retainAll(Collection<?>) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
retrieve(Object, TitanTransaction) - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
retrievePartitionAggregates() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
Retriever<I,O> - Interface in com.thinkaurelius.titan.util.datastructures
Interface for the Retriever design pattern.
retrieveSchemaByName(String) - Method in interface com.thinkaurelius.titan.graphdb.database.cache.SchemaCache.StoreRetrieval
 
retrieveSchemaRelations(long, BaseRelationType, Direction) - Method in interface com.thinkaurelius.titan.graphdb.database.cache.SchemaCache.StoreRetrieval
 
retrieveSliceQuery() - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.AccessCheck
 
reuseIterator() - Method in class com.thinkaurelius.titan.diskstorage.EntryList.EmptyList
 
reuseIterator() - Method in interface com.thinkaurelius.titan.diskstorage.EntryList
Returns the same iterator as List.iterator() with the only difference that it reuses Entry objects when calling Iterator.next().
reuseIterator() - Method in class com.thinkaurelius.titan.diskstorage.util.EntryArrayList
 
reuseIterator() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
rid - Variable in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
rid(StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
rid - Variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.schema.TitanManagement
Closes this management transaction and discards all changes.
rollback() - Method in interface com.thinkaurelius.titan.core.TitanTransaction
Aborts and closes the transaction.
rollback() - Method in class com.thinkaurelius.titan.diskstorage.BackendTransaction
Rolls back all transactions and makes sure that this does not get cut short by exceptions.
rollback() - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransaction
Aborts (or rolls back) the transaction.
rollback() - Method in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreTransaction
 
rollback() - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
rollback() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexTransaction
 
rollback() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.CacheTransaction
 
rollback() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingTransaction
 
rollback() - Method in class com.thinkaurelius.titan.diskstorage.util.DefaultTransaction
 
rollback() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
rollback() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
rollbackQuietly(TitanTransaction) - Static method in class com.thinkaurelius.titan.util.system.TXUtils
 
ROOT_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
run() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
run() - Method in class com.thinkaurelius.titan.diskstorage.log.util.ProcessMessageJob
 
run(int, ScanMetrics) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionedVertexProgramExecutor
 
run() - Method in class com.thinkaurelius.titan.util.system.BackgroundThread
 

S

ScanBuffer - Interface in com.thinkaurelius.titan.diskstorage
A Buffer that allows sequential reads.
ScanJob - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
A global computation over
ScanMetrics - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
Counters associated with a ScanJob.
ScanMetrics.Metric - Enum in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
An enum of standard counters.
scanTxConfig(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
SCHEMA_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
SCHEMA_PARTITION - Static variable in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
Id of the partition that schema elements are assigned to
SchemaAction - Enum in com.thinkaurelius.titan.core.schema
SchemaCache - Interface in com.thinkaurelius.titan.graphdb.database.cache
This interface defines the methods that a SchemaCache must implement.
SchemaCache.StoreRetrieval - Interface in com.thinkaurelius.titan.graphdb.database.cache
 
SchemaCategory - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
SchemaContainer - Class in com.thinkaurelius.titan.graphdb.schema
 
SchemaContainer(TitanGraph) - Constructor for class com.thinkaurelius.titan.graphdb.schema.SchemaContainer
 
SchemaDefinitionDesc - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
SchemaDefinitionEdge - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
SchemaDefinitionProperty - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
SchemaElementDefinition - Class in com.thinkaurelius.titan.graphdb.schema
 
SchemaElementDefinition(String, long) - Constructor for class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
SchemaInspector - Interface in com.thinkaurelius.titan.core.schema
 
SchemaManager - Interface in com.thinkaurelius.titan.core.schema
 
SchemaName - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
SchemaProvider - Interface in com.thinkaurelius.titan.graphdb.schema
 
SchemaSource - Interface in com.thinkaurelius.titan.graphdb.types
 
SchemaSource.Entry - Class in com.thinkaurelius.titan.graphdb.types
 
SchemaStatus - Enum in com.thinkaurelius.titan.core.schema
Designates the status of a TitanIndex in a graph.
SchemaUpdateTime - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
SchemaViolationException - Exception in com.thinkaurelius.titan.core
Titan represents element identifiers as longs, but not all numbers in the representable space of longs are valid.
SchemaViolationException(String) - Constructor for exception com.thinkaurelius.titan.core.SchemaViolationException
 
SchemaViolationException(String, Object...) - Constructor for exception com.thinkaurelius.titan.core.SchemaViolationException
 
self() - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
Concrete subclasses should just "return this;".
self() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
self() - Method in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
self() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusWatcher
 
self() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusWatcher
 
sendCacheEviction(Set<TitanSchemaVertex>, Set<Callable<Boolean>>, Set<String>) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementLogger
 
SEPARATOR - Static variable in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
SEPARATOR_CHAR - Static variable in class com.thinkaurelius.titan.graphdb.internal.Token
 
serialize(Geoshape, JsonGenerator, SerializerProvider) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeGsonSerializer
 
serialize(RelationIdentifier, JsonGenerator, SerializerProvider) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson.TitanGraphSONModule.RelationIdentifierSerializer
 
serializeModifications(Serializer, LogTxStatus, StandardTitanTx, Collection<InternalRelation>, Collection<InternalRelation>) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
serializePrimary(Serializer, LogTxStatus) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
serializer - Variable in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
serializer(ConsistentKeyLockerSerializer) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
serializer - Variable in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker
This is sort-of Cassandra/HBase specific.
Serializer - Interface in com.thinkaurelius.titan.graphdb.database.serialize
 
serializer - Variable in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
SerializerInjected - Interface in com.thinkaurelius.titan.graphdb.database.serialize
Marks a AttributeSerializer that requires a Serializer to serialize the internal state.
serializeSecondary(Serializer, LogTxStatus, Map<String, Throwable>, boolean) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
serializeUserLog(Serializer, TransactionLogHeader.Entry, StandardTransactionId) - Method in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
serializeWithType(RelationIdentifier, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson.TitanGraphSONModule.RelationIdentifierSerializer
 
set(String, Object) - Method in interface com.thinkaurelius.titan.core.schema.TitanConfiguration
Sets the configuration option identified by the provided path to the given value.
set(String, Object) - Method in class com.thinkaurelius.titan.core.TitanFactory.Builder
Configures the provided configuration path to the given value.
set(String, O) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration
 
set(String, O, O) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
set(String, O) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
Sets a configuration property for this StoreManager.
set(String, O, O, boolean) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
set(String, O, O) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.ConcurrentWriteConfiguration
 
set(ConfigOption<O>, O, String...) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
set(String, O) - Method in class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
set(String, Object) - Method in class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
 
set(String, O) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.WriteConfiguration
 
set(String, Object) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
set(String, Object) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
set(String, Object) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanGraphVariables
 
set(long) - Method in class com.thinkaurelius.titan.util.datastructures.LongCounter
 
setAccessCheck(PreloadedVertex.AccessCheck) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
setAlive(boolean) - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
setAll(Map<ConfigElement.PathIdentifier, Object>) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ModifiableConfiguration
 
setAnnotation(String, Object) - Method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
setAnnotation(String, Object) - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
setAnnotation(String, Object) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.BooleanArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ByteArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DoubleArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.FloatArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.IntArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.LongArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortArraySerializer
 
setArray(Object, int, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringArraySerializer
 
setBackendTransaction(BackendTransaction) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
setBitb(byte, int) - Static method in class com.thinkaurelius.titan.util.datastructures.BitMap
 
setCache(RelationCache) - Method in interface com.thinkaurelius.titan.diskstorage.Entry
Sets the cached parsed representation of this Entry.
setCache(RelationCache) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
setChecked() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus
 
setCommitTime(Instant) - Method in interface com.thinkaurelius.titan.diskstorage.BaseTransactionConfig
Sets the commit time of this transaction.
setCommitTime(Instant) - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig
 
setCommitTime(Instant) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
setConsistency(TitanSchemaElement, ConsistencyModifier) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Sets the consistency modifier for the given TitanSchemaElement.
setConsistency(TitanSchemaElement, ConsistencyModifier) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
Sets the consistency level for those schema elements that support it (types and internal indexes)
setDefaultStringMapping(Mapping) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
setDirection(Direction) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
setElementIdentifier(String) - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
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 com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
setEnabled(boolean) - Method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
 
setEnd(T, boolean) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
setEndInclusive(boolean) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
setFinishJob(Consumer<ScanMetrics>) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setFrozen() - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
setGraph(TitanGraph) - Method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter.GraphProvider
 
setGraphConfiguration(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setId(long) - Method in class com.thinkaurelius.titan.graphdb.internal.AbstractElement
 
setId(long) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalElement
 
setId(long) - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseRelationType
 
setId(long) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
setId(long) - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
setIDBlockSizer(IDBlockSizer) - Method in interface com.thinkaurelius.titan.diskstorage.IDAuthority
Sets the IDBlockSizer to be used by this IDAuthority.
setIDBlockSizer(IDBlockSizer) - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
setIndex(String) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
setIteration(int) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
setJob(ScanJob) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setJobConfiguration(Configuration) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setJobId(Object) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
setLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
setLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
setLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
setLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
setLimit(int) - Method in class com.thinkaurelius.titan.graphdb.query.BaseQuery
Sets the limit of the query if it wasn't specified in the constructor
setLimit(int) - Method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
setLimit(int) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
setLimit(int) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
setLimit(int) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
setLoadedProperties(long, EntryList) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
setLoadedProperties(EntryList) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionVertexAggregate
 
setLocalPartitionBounds(List<PartitionIDRange>) - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.IDPlacementStrategy
If Titan 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 com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
setMaxOperationWaitTime(Duration) - Method in class com.thinkaurelius.titan.diskstorage.configuration.backend.KCVSConfiguration
 
setMessage(M, MessageScope, Map<MessageScope, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
setMetaData(EntryMetaData, Object) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
setMetaData(EntryMetaData, Object) - Method in interface com.thinkaurelius.titan.diskstorage.MetaAnnotatable
 
setMetaData(EntryMetaData, Object) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
setMetrics(MutableMetrics) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
setMetrics(MutableMetrics) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
setMetrics(MutableMetrics) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
setNumProcessingThreads(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setOffset(int) - Method in class com.thinkaurelius.titan.diskstorage.indexing.RawQuery
 
setOtherVertexID(long) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
setPartitionID(int) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
setPartitionKey(String) - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PropertyPlacementStrategy
 
setPoint(T) - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
setPreferredClassLoaders(List<ClassLoader>) - Method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
 
setPreloadedData(boolean) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
setPreviousID(long) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
setPreviousID(long) - Method in interface com.thinkaurelius.titan.graphdb.relations.StandardRelation
 
setPreviousID(long) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
setProcessorIdentifier(String) - Method in interface com.thinkaurelius.titan.core.log.LogProcessorBuilder
Sets the identifier of this processor.
setProperty(long, String, V) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexMemory
 
setProperty(String, V, Map<String, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.PartitionVertexAggregate
 
setProperty(String, V, Map<String, Integer>) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
setPropertyDirect(PropertyKey, Object) - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalRelation
 
setPropertyDirect(PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheEdge
 
setPropertyDirect(PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.relations.CacheVertexProperty
 
setPropertyDirect(PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
setPropertyDirect(PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
setPropertyMixing(PreloadedVertex.PropertyMixing) - Method in class com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex
 
setQuery(String) - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
setRelationID(long) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
setResultSize(long) - Method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
setResultSize(long) - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
setResultSize(long) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
setRetryAttempts(int) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
setSerializer(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterArraySerializer
 
setSerializer(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ParameterSerializer
 
setSerializer(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
setSerializer(Serializer) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
setSerializer(Serializer) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.SerializerInjected
 
setStart(T, boolean) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
setStartInclusive(boolean) - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
setStartTime(Instant) - Method in interface com.thinkaurelius.titan.core.log.LogProcessorBuilder
Sets the time at which this log processor should start processing transaction log entries
setStartTimeNow() - Method in interface com.thinkaurelius.titan.core.log.LogProcessorBuilder
Indicates that the transaction log processor should process newly added events.
setStatic() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
setStoreName(String) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setTimestampProvider(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
setTTL(TitanSchemaType, Duration) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Sets the time-to-live for the given TitanSchemaType.
setTTL(int) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer.IndexUpdate
 
setTTL(TitanSchemaType, Duration) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
Sets time-to-live for those schema types that support it
setType(RelationType) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
SETUP_WAITTIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Time in milliseconds for backend manager to wait for the storage backends to become available when Titan is run in server mode.
setUseCallerLoader(boolean) - Method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
 
setUseMultiQuery(boolean) - Method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.MultiQueriable
 
setUseMultiQuery(boolean) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
setUseMultiQuery(boolean) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
setUseThreadContextLoader(boolean) - Method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
 
setValue(TransactionBuilder, Object) - Method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxMeta
 
setValue(Object) - Method in interface com.thinkaurelius.titan.graphdb.database.RelationFactory
 
setValue(TypeDefinitionCategory, Object) - Method in class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
setVertexAt(int, InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
setVertexAt(int, InternalVertex) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
setVertexAt(int, InternalVertex) - Method in interface com.thinkaurelius.titan.graphdb.relations.ReassignableRelation
 
setWildcardField(String) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
setWorkBlockSize(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner.Builder
 
short2char(short) - Static method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.CharacterSerializer
 
SHORT_LEN - Static variable in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
ShortArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ShortArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortArraySerializer
 
ShortSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
ShortSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.ShortSerializer
 
shutdown() - Method in interface com.thinkaurelius.titan.core.log.LogProcessorFramework
Closes all log processors, their associated logs, and the backing graph instance
shutdown() - Method in interface com.thinkaurelius.titan.core.log.TransactionRecovery
Shuts down the transaction recovery process
shutdown() - Method in class com.thinkaurelius.titan.graphdb.log.StandardLogProcessorFramework
 
shutdown() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionLogProcessor
 
signature(PropertyKey...) - Method in interface com.thinkaurelius.titan.core.schema.EdgeLabelMaker
 
signature(PropertyKey...) - Method in interface com.thinkaurelius.titan.core.schema.PropertyKeyMaker
 
signature(PropertyKey...) - Method in interface com.thinkaurelius.titan.core.schema.RelationTypeMaker
Configures the signature of this relation type.
signature(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
signature(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
signature(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
SimpleAddedRelations - Class in com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
SimpleAddedRelations() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleAddedRelations
 
SimpleBufferAddedRelations - Class in com.thinkaurelius.titan.graphdb.transaction.addedrelations
 
SimpleBufferAddedRelations() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.addedrelations.SimpleBufferAddedRelations
 
SimpleBulkPlacementStrategy - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
SimpleBulkPlacementStrategy(Configuration) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
SimpleIndexCache - Class in com.thinkaurelius.titan.graphdb.transaction.indexcache
 
SimpleIndexCache() - Constructor for class com.thinkaurelius.titan.graphdb.transaction.indexcache.SimpleIndexCache
 
SimplePartitionAssignment - Class in com.thinkaurelius.titan.graphdb.database.idassigner.placement
Simple implementation of PartitionAssignment.
SimplePartitionAssignment() - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
SimplePartitionAssignment(int) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimplePartitionAssignment
 
SimpleQueryProfiler - Class in com.thinkaurelius.titan.graphdb.query.profile
 
SimpleQueryProfiler() - Constructor for class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
SimpleQueryProfiler(String) - Constructor for class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
SimpleTitanProperty<V> - Class in com.thinkaurelius.titan.graphdb.relations
 
SimpleTitanProperty(InternalRelation, PropertyKey, V) - Constructor for class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
SimpleVertexQueryProcessor - Class in com.thinkaurelius.titan.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, StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.SimpleVertexQueryProcessor
 
simplifyQNF(Condition<E>) - Static method in class com.thinkaurelius.titan.graphdb.query.QueryUtil
 
singleton(long) - Static method in class com.thinkaurelius.titan.util.datastructures.AbstractLongListUtil
 
size() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
Returns the number of points comprising this geoshape.
size() - Method in interface com.thinkaurelius.titan.core.VertexList
Returns the number of vertices in this list.
size() - Method in class com.thinkaurelius.titan.diskstorage.EntryList.EmptyList
 
size() - Method in class com.thinkaurelius.titan.diskstorage.StoreMetaData.Container
 
size() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntryList
 
size() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
size() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
size() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
size() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
size() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
size() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
size() - Method in class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache
 
size() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Returns the number of elements currently stored in the PriorityQueue.
size() - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
size() - Method in class com.thinkaurelius.titan.util.datastructures.ImmutableIntSet
 
size() - Method in class com.thinkaurelius.titan.util.datastructures.IntHashSet
 
size() - Method in interface com.thinkaurelius.titan.util.datastructures.IntSet
 
size(Iterable) - Static method in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
size() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
sizeLargerOrEqualThan(Iterable, int) - Static method in class com.thinkaurelius.titan.util.datastructures.IterablesUtil
 
SKIPPED_GHOST_LIMIT_COUNT - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover
 
sleepAfterWrite(StoreTransaction, DistributedStoreManager.MaskedTimestamp) - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
This method attempts to generate Rid in the following three ways, in order, returning the value produced by the first successful attempt in the sequence.
sleepFor(Duration) - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Sleep for the given duration of time.
sleepFor(Duration) - Method in enum com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders
 
sleepPast(Instant) - Method in interface com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider
Block until the current time as returned by TimestampProvider.getTime() is greater than the given timepoint.
sleepPast(Instant) - Method in enum com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders
 
SliceQuery - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Queries for a slice of data identified by a start point (inclusive) and end point (exclusive).
SliceQuery(StaticBuffer, StaticBuffer) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
SliceQuery(SliceQuery) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
sort() - Method in interface com.thinkaurelius.titan.core.VertexList
Sorts this list according to vertex ids in increasing order.
sort() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
sort() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
sortableDoubleBits(long) - Static method in class com.thinkaurelius.titan.util.encoding.NumericUtils
Converts IEEE 754 representation of a double to sortable order (or back to the original)
sortableFloatBits(int) - Static method in class com.thinkaurelius.titan.util.encoding.NumericUtils
Converts IEEE 754 representation of a float to sortable order (or back to the original)
sortableIntToFloat(int) - Static method in class com.thinkaurelius.titan.util.encoding.NumericUtils
Converts a sortable int back to a float.
sortableLongToDouble(long) - Static method in class com.thinkaurelius.titan.util.encoding.NumericUtils
Converts a sortable long back to a double.
sortKey(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
sortKey(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
sortKey(PropertyKey...) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
Configures the composite sort key for this label.
sortOrder(Order) - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
sortOrder(Order) - Method in class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
sortOrder(Order) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
Defines in which order to sort the relations for efficient retrieval, i.e.
splitSeparatedName(String) - Static method in class com.thinkaurelius.titan.graphdb.internal.Token
 
StandardBaseTransactionConfig - Class in com.thinkaurelius.titan.diskstorage.util
 
StandardBaseTransactionConfig.Builder - Class in com.thinkaurelius.titan.diskstorage.util
 
standardCleaner() - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.Builder
 
StandardEdge - Class in com.thinkaurelius.titan.graphdb.relations
 
StandardEdge(long, EdgeLabel, InternalVertex, InternalVertex, byte) - Constructor for class com.thinkaurelius.titan.graphdb.relations.StandardEdge
 
StandardEdgeLabelMaker - Class in com.thinkaurelius.titan.graphdb.types
 
StandardEdgeLabelMaker(StandardTitanTx, String, IndexSerializer, AttributeHandler) - Constructor for class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
StandardIDPool - Class in com.thinkaurelius.titan.graphdb.database.idassigner
 
StandardIDPool(IDAuthority, int, int, long, Duration, double) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.StandardIDPool
 
StandardIndexInformation - Class in com.thinkaurelius.titan.graphdb.database.indexing
 
StandardIndexProvider - Enum in com.thinkaurelius.titan.diskstorage
This enum is only intended for use by Titan internals.
StandardKeyInformation - Class in com.thinkaurelius.titan.diskstorage.indexing
 
StandardKeyInformation(Class<?>, Cardinality, Parameter...) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
StandardKeyInformation(PropertyKey, Parameter...) - Constructor for class com.thinkaurelius.titan.diskstorage.indexing.StandardKeyInformation
 
StandardLockCleanerRunnable - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable
 
StandardLockCleanerService - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
Encapsulates an ExecutorService that creates and runs StandardLockCleanerRunnable instances.
StandardLockCleanerService(KeyColumnValueStore, ConsistentKeyLockerSerializer, ExecutorService, Duration, TimestampProvider) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService
 
StandardLockCleanerService(KeyColumnValueStore, ConsistentKeyLockerSerializer, TimestampProvider) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService
 
StandardLogProcessorFramework - Class in com.thinkaurelius.titan.graphdb.log
 
StandardLogProcessorFramework(StandardTitanGraph) - Constructor for class com.thinkaurelius.titan.graphdb.log.StandardLogProcessorFramework
 
StandardPropertyKeyMaker - Class in com.thinkaurelius.titan.graphdb.types
 
StandardPropertyKeyMaker(StandardTitanTx, String, IndexSerializer, AttributeHandler) - Constructor for class com.thinkaurelius.titan.graphdb.types.StandardPropertyKeyMaker
 
StandardRelation - Interface in com.thinkaurelius.titan.graphdb.relations
 
StandardRelationTypeMaker - Class in com.thinkaurelius.titan.graphdb.types
 
StandardRelationTypeMaker(StandardTitanTx, String, IndexSerializer, AttributeHandler) - Constructor for class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
StandardScanMetrics - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
 
StandardScanMetrics() - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanMetrics
 
StandardScanner - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
 
StandardScanner(KeyColumnValueStoreManager) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.StandardScanner
 
StandardScanner.Builder - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan
 
StandardSchemaCache - Class in com.thinkaurelius.titan.graphdb.database.cache
 
StandardSchemaCache(SchemaCache.StoreRetrieval) - Constructor for class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
StandardSchemaCache(int, SchemaCache.StoreRetrieval) - Constructor for class com.thinkaurelius.titan.graphdb.database.cache.StandardSchemaCache
 
StandardSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize
 
StandardSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
StandardStoreFeatures - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Immutable, StandardStoreFeatures.Builder-customizable implementation of StoreFeatures.
StandardStoreFeatures.Builder - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue
The only way to instantiate StandardStoreFeatures.
StandardStoreManager - Enum in com.thinkaurelius.titan.diskstorage
This enum is only intended for use by Titan internals.
StandardTitanGraph - Class in com.thinkaurelius.titan.graphdb.database
 
StandardTitanGraph(GraphDatabaseConfiguration) - Constructor for class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
StandardTitanTx - Class in com.thinkaurelius.titan.graphdb.transaction
 
StandardTitanTx(StandardTitanGraph, TransactionConfiguration) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
StandardTransactionBuilder - Class in com.thinkaurelius.titan.graphdb.transaction
Used to configure a TitanTransaction.
StandardTransactionBuilder(GraphDatabaseConfiguration, StandardTitanGraph) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
Constructs a new TitanTransaction configuration with default configuration parameters.
StandardTransactionBuilder(GraphDatabaseConfiguration, StandardTitanGraph, Configuration) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
StandardTransactionId - Class in com.thinkaurelius.titan.graphdb.log
 
StandardTransactionId(String, long, Instant) - Constructor for class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
StandardTransactionIdSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
StandardTransactionIdSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StandardTransactionIdSerializer
 
StandardTransactionLogProcessor - Class in com.thinkaurelius.titan.graphdb.log
 
StandardTransactionLogProcessor(StandardTitanGraph, Instant) - Constructor for class com.thinkaurelius.titan.graphdb.log.StandardTransactionLogProcessor
 
StandardVertex - Class in com.thinkaurelius.titan.graphdb.vertices
 
StandardVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
StandardVertexLabelMaker - Class in com.thinkaurelius.titan.graphdb.types
 
StandardVertexLabelMaker(StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.types.StandardVertexLabelMaker
 
StandardVertexProperty - Class in com.thinkaurelius.titan.graphdb.relations
 
StandardVertexProperty(long, PropertyKey, InternalVertex, Object, byte) - Constructor for class com.thinkaurelius.titan.graphdb.relations.StandardVertexProperty
 
start() - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Starts and returns the transaction build by this builder
start() - Method in class com.thinkaurelius.titan.diskstorage.util.time.Timer
 
start() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
startInclusive() - Method in interface com.thinkaurelius.titan.util.datastructures.Interval
 
startInclusive() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
startInclusive() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
startTimer() - Method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
startTimer() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
startTimer() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
startTransaction(StandardTitanGraph) - Static method in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
startTransactionRecovery(TitanGraph, Instant) - Static method in class com.thinkaurelius.titan.core.TitanFactory
Returns a TransactionRecovery process for recovering partially failed transactions.
state - Variable in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.Modification
 
STATIC_FACTORY - Static variable in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
STATIC_KEY_LENGTHS - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
StaticArrayBuffer - Class in com.thinkaurelius.titan.diskstorage.util
Implementation of StaticBuffer against byte array.
StaticArrayBuffer(byte[], int, int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(byte[]) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(byte[], int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(StaticBuffer) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
StaticArrayBuffer(StaticArrayBuffer) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
STATICARRAYBUFFER_RAW_SIZE - Static variable in class com.thinkaurelius.titan.util.datastructures.ByteSize
 
StaticArrayEntry - Class in com.thinkaurelius.titan.diskstorage.util
 
StaticArrayEntry(byte[], int, int, int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(byte[], int, int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(byte[], int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry(StaticBuffer, int) - Constructor for class com.thinkaurelius.titan.diskstorage.util.StaticArrayEntry
 
StaticArrayEntry.DataHandler<D> - Interface in com.thinkaurelius.titan.diskstorage.util
 
StaticArrayEntry.GetColVal<E,D> - Interface in com.thinkaurelius.titan.diskstorage.util
 
StaticArrayEntryList - Class in com.thinkaurelius.titan.diskstorage.util
 
StaticArrayEntryList.MetaDataSerializer<V> - Interface in com.thinkaurelius.titan.diskstorage.util
 
StaticBuffer - Interface in com.thinkaurelius.titan.diskstorage
A Buffer that only allows static access.
StaticBuffer.Factory<T> - Interface in com.thinkaurelius.titan.diskstorage
 
StaticIDBlockSizer - Class in com.thinkaurelius.titan.graphdb.database.idassigner
 
StaticIDBlockSizer(long, long) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.StaticIDBlockSizer
 
Stats() - Constructor for class com.thinkaurelius.titan.graphdb.util.ConcurrentLRUCache.Stats
 
status - Variable in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
status(SchemaStatus) - Method in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
Set the target index status.
status(SchemaStatus) - Method in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
Status(int, int) - Constructor for class com.thinkaurelius.titan.util.system.ConfigurationLint.Status
 
stop() - Method in class com.thinkaurelius.titan.diskstorage.util.time.Timer
 
stopTimer() - Method in interface com.thinkaurelius.titan.graphdb.query.profile.QueryProfiler
 
stopTimer() - Method in class com.thinkaurelius.titan.graphdb.query.profile.SimpleQueryProfiler
 
stopTimer() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
STORAGE_BACKEND - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Define the storage backed to use for persistence
STORAGE_BATCH - Static variable in class com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Storage directory for those storage backends that require local storage
STORAGE_HOSTS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
A unique identifier for the machine running the TitanGraph instance.
STORAGE_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
STORAGE_PORT - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configuration key for the port on which to connect to remote storage backend servers.
STORAGE_READ_WAITTIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
STORAGE_READONLY - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Specifies whether this database is read-only, i.e.
STORAGE_TRANSACTIONAL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Enables transactions on storage backends that support them
STORAGE_WRITE_WAITTIME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Number of times the database attempts to execute a read operation against the storage layer in the current transaction.
StorageCallable<T> - Interface in com.thinkaurelius.titan.diskstorage.util
Like Callable, except the exception type is narrowed from Exception to BackendException.
storageConfig - Variable in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreManager
 
store - Variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
STORE_META_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_TIMESTAMPS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_TTL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
STORE_META_VISIBILITY - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
StoreFeatures - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Describes features supported by a storage backend.
StoreManager - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue
Generic interface to a backend storage engine.
StoreMetaData<T> - Interface in com.thinkaurelius.titan.diskstorage
Store-specific (Columnfamily-specific) options passed between Titan core and its underlying KeyColumnValueStore implementation.
StoreMetaData.Container - Class in com.thinkaurelius.titan.diskstorage
 
StoreTransaction - Interface in com.thinkaurelius.titan.diskstorage.keycolumnvalue
A transaction handle uniquely identifies a transaction on the storage backend.
storeTTL(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
StringArraySerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
StringArraySerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringArraySerializer
 
StringEncoding - Class in com.thinkaurelius.titan.util.encoding
 
StringEncoding() - Constructor for class com.thinkaurelius.titan.util.encoding.StringEncoding
 
StringSerializer - Class in com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
stripEntireRelationTypePadding(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
stripRelationTypePadding(long) - Static method in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
 
subList(int, int) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
subList(int, int) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
submit() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
submit(Runnable) - Method in class com.thinkaurelius.titan.graphdb.util.WorkerPool
 
subrange(int, boolean) - Method in interface com.thinkaurelius.titan.diskstorage.ReadBuffer
 
subrange(int, int) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
subrange(int, int, boolean) - Method in interface com.thinkaurelius.titan.diskstorage.StaticBuffer
 
subrange(int, boolean) - Method in class com.thinkaurelius.titan.diskstorage.util.ReadArrayBuffer
 
subrange(int, int) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
subrange(int, int, boolean) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
subsumedBy(Class<? extends Element>) - Method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
 
subsumes(KeyRangeQuery) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
subsumes(KeySliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
subsumes(SliceQuery) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
SUCCESS_TX - Static variable in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
sum(int[]) - Static method in class com.thinkaurelius.titan.util.datastructures.ArraysUtil
 
supportedStringMappings(Mapping...) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
supports(KeyInformation, TitanPredicate) - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexInformation
Whether the index supports indexing a key with the given information
supports(KeyInformation, TitanPredicate) - Method in class com.thinkaurelius.titan.graphdb.database.indexing.StandardIndexInformation
 
supports(KeyInformation) - Method in class com.thinkaurelius.titan.graphdb.database.indexing.StandardIndexInformation
 
supports(MixedIndexType, ParameterIndexField) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
supports(MixedIndexType, ParameterIndexField, TitanPredicate) - Method in class com.thinkaurelius.titan.graphdb.database.IndexSerializer
 
supports(BiPredicate) - Static method in class com.thinkaurelius.titan.graphdb.query.TitanPredicate.Converter
 
supports(String) - Method in interface com.thinkaurelius.titan.graphdb.vertices.PreloadedVertex.PropertyMixing
 
supportsAnyTTL(StoreFeatures) - Static method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
Returns true if the parameter supports at least one of the following: cell-level TTL StoreFeatures.hasCellTTL() store-level TTL StoreFeatures.hasStoreTTL()
supportsBulkPlacement() - Method in interface com.thinkaurelius.titan.graphdb.database.idassigner.placement.IDPlacementStrategy
Whether this placement strategy supports bulk placement.
supportsBulkPlacement() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.SimpleBulkPlacementStrategy
 
supportsCardinality(Cardinality) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
supportsCardinality(Cardinality) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
supportsDocumentTTL() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
supportsDocumentTTL() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
supportsInterruption() - Method in interface com.thinkaurelius.titan.diskstorage.IDAuthority
Whether IDAuthority.getIDBlock(int, int, Duration) may be safely interrupted.
supportsInterruption() - Method in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority
 
supportsInterruption(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
supportsInterruption() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
supportsInterruption() - Method in interface com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures.Builder
 
supportsNanoseconds() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
SupportsNullSerializer - Interface in com.thinkaurelius.titan.graphdb.database.serialize
Marker interface to indicate that a given serializer supports serializing null values effectively.
supportsPersistence() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures
 
supportsPersistence() - Method in interface com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures
Whether the backend supports data persistence.
supportsStringMapping(Mapping) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexFeatures
 
system() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Restricts the result set of this query to only system types.
SYSTEM_CONFIGURATION_IDENTIFIER - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_LOG_TRANSACTIONS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_MGMT_LOG_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
SYSTEM_PROPERTIES_STORE_NAME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
SYSTEM_TX_LOG_NAME - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
SystemConfiguration - Interface in com.thinkaurelius.titan.diskstorage.configuration
 
systemETprefix - Static variable in class com.thinkaurelius.titan.graphdb.internal.Token
 
SystemRelationType - Interface in com.thinkaurelius.titan.graphdb.types.system
 
SystemTypeManager - Class in com.thinkaurelius.titan.graphdb.types.system
 
SystemTypeManager() - Constructor for class com.thinkaurelius.titan.graphdb.types.system.SystemTypeManager
 

T

take(StoreTransaction, KeyColumn, S) - Method in class com.thinkaurelius.titan.diskstorage.locking.LockerState
 
Temporals - Class in com.thinkaurelius.titan.diskstorage.util.time
Created by bryn on 30/04/15.
Temporals() - Constructor for class com.thinkaurelius.titan.diskstorage.util.time.Temporals
 
TemporaryBackendException - Exception in com.thinkaurelius.titan.diskstorage
This exception signifies a (potentially) temporary exception in a Titan storage backend, that is, an exception that is due to a temporary unavailability or other exception that is not permanent in nature.
TemporaryBackendException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.TemporaryBackendException
 
TemporaryBackendException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.TemporaryBackendException
 
TemporaryBackendException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.TemporaryBackendException
Constructs an exception with a generic message
TemporaryLockingException - Exception in com.thinkaurelius.titan.diskstorage.locking
This exception signifies a (potentially) temporary exception while attempting to acquire a lock in the Titan storage backend.
TemporaryLockingException(String) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.TemporaryLockingException
 
TemporaryLockingException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.TemporaryLockingException
 
TemporaryLockingException(Throwable) - Constructor for exception com.thinkaurelius.titan.diskstorage.locking.TemporaryLockingException
Constructs an exception with a generic message
terminate(Thread[]) - Static method in class com.thinkaurelius.titan.util.system.Threads
 
test(Object, Object) - Method in interface com.thinkaurelius.titan.graphdb.query.TitanPredicate
 
Text - Enum in com.thinkaurelius.titan.core.attribute
Comparison relations for text objects.
TEXT_COMRPESSION_THRESHOLD - Static variable in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
textContains(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
textContainsPrefix(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
textContainsRegex(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
textPrefix(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
textRegex(V) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
THREAD_POOL_SIZE_SCALE_FACTOR - Static variable in class com.thinkaurelius.titan.diskstorage.Backend
 
threadBound() - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
Threads - Class in com.thinkaurelius.titan.util.system
Utility class for dealing with Thread
Threads() - Constructor for class com.thinkaurelius.titan.util.system.Threads
 
timeout - Variable in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
 
timeout(long, TemporalUnit) - Method in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher
Set the maximum amount of wallclock time that Callable.call() will wait for the index to reach the target status.
Timer - Class in com.thinkaurelius.titan.diskstorage.util.time
A utility to measure time durations.
Timer(TimestampProvider) - Constructor for class com.thinkaurelius.titan.diskstorage.util.time.Timer
 
times - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
times - Variable in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
times(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker.Builder
 
times - Variable in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker
Sole source of time.
TIMESLICE_INTERVAL - Static variable in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
The time period that is stored under one key in the underlying KCVS.
TIMESTAMP - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
TIMESTAMP_PROVIDER - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
timestampProvider(TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder
 
TimestampProvider - Interface in com.thinkaurelius.titan.diskstorage.util.time
System time interface that abstracts time units, resolution, and measurements of time.
TimestampProviders - Enum in com.thinkaurelius.titan.diskstorage.util.time
Implementations of TimestampProvider for different resolutions of time: NANO: nano-second time resolution based on System.nanoTime using a base-time established by System.currentTimeMillis().
TimestampRid - Class in com.thinkaurelius.titan.diskstorage.locking.consistentkey
 
TimestampRid(Instant, StaticBuffer) - Constructor for class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid
 
timestamps(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
timeUnit(ChronoUnit) - Static method in class com.thinkaurelius.titan.diskstorage.util.time.Temporals
 
Titan - Class in com.thinkaurelius.titan.core
Contains constants for this Titan Graph Database.
Titan() - Constructor for class com.thinkaurelius.titan.core.Titan
 
TITAN_PROPERTIES_FILE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.TitanConstants
 
TitanBlueprintsGraph - Class in com.thinkaurelius.titan.graphdb.tinkerpop
Blueprints specific implementation for TitanGraph.
TitanBlueprintsGraph() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
TitanBlueprintsTransaction - Class in com.thinkaurelius.titan.graphdb.tinkerpop
Blueprints specific implementation of TitanTransaction.
TitanBlueprintsTransaction() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
TitanCleanup - Class in com.thinkaurelius.titan.core.util
Utility class containing methods that simplify Titan clean-up processes.
TitanCleanup() - Constructor for class com.thinkaurelius.titan.core.util.TitanCleanup
 
TitanConfiguration - Interface in com.thinkaurelius.titan.core.schema
Used to read and change the global Titan configuration.
TitanConfigurationException - Exception in com.thinkaurelius.titan.core
Exception thrown due to invalid configuration options or when errors occur during the configuration and initialization of Titan.
TitanConfigurationException(String) - Constructor for exception com.thinkaurelius.titan.core.TitanConfigurationException
 
TitanConfigurationException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.core.TitanConfigurationException
 
TitanConfigurationException(Throwable) - Constructor for exception com.thinkaurelius.titan.core.TitanConfigurationException
Constructs an exception with a generic message
TitanConstants - Class in com.thinkaurelius.titan.graphdb.configuration
Collection of constants used throughput the Titan codebase.
TitanConstants() - Constructor for class com.thinkaurelius.titan.graphdb.configuration.TitanConstants
 
TitanDefaultSchemaMaker - Class in com.thinkaurelius.titan.graphdb.tinkerpop
DefaultSchemaMaker implementation for Blueprints graphs
TitanEdge - Interface in com.thinkaurelius.titan.core
A TitanEdge connects two TitanVertex.
TitanElement - Interface in com.thinkaurelius.titan.core
TitanElement represents the abstract concept of an entity in the graph and specifies basic methods for interacting with entities.
TitanException - Exception in com.thinkaurelius.titan.core
Most general type of exception thrown by the Titan graph database.
TitanException(String) - Constructor for exception com.thinkaurelius.titan.core.TitanException
 
TitanException(String, Throwable) - Constructor for exception com.thinkaurelius.titan.core.TitanException
 
TitanException(Throwable) - Constructor for exception com.thinkaurelius.titan.core.TitanException
Constructs an exception with a generic message
TitanFactory - Class in com.thinkaurelius.titan.core
TitanFactory is used to open or instantiate a Titan graph database.
TitanFactory() - Constructor for class com.thinkaurelius.titan.core.TitanFactory
 
TitanFactory.Builder - Class in com.thinkaurelius.titan.core
 
TitanFeatures - Class in com.thinkaurelius.titan.graphdb.tinkerpop
Blueprint's features of a TitanGraph.
TitanGraph - Interface in com.thinkaurelius.titan.core
Titan graph database implementation of the Blueprint's interface.
TitanGraphComputer - Interface in com.thinkaurelius.titan.core
 
TitanGraphComputer.ResultMode - Enum in com.thinkaurelius.titan.core
 
TitanGraphIndex - Interface in com.thinkaurelius.titan.core.schema
A TitanGraphIndex is an index installed on the graph in order to be able to efficiently retrieve graph elements by their properties.
TitanGraphIndexWrapper - Class in com.thinkaurelius.titan.graphdb.database.management
 
TitanGraphIndexWrapper(IndexType) - Constructor for class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
TitanGraphQuery<Q extends TitanGraphQuery<Q>> - Interface in com.thinkaurelius.titan.core
Constructs a query against a mixed index to retrieve all elements (either vertices or edges) that match all conditions.
TitanGraphSONModule - Class in com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson
 
TitanGraphSONModule.RelationIdentifierDeserializer - Class in com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson
 
TitanGraphSONModule.RelationIdentifierSerializer - Class in com.thinkaurelius.titan.graphdb.tinkerpop.io.graphson
 
TitanGraphStep<E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanGraphStep(GraphStep<E>) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
TitanGraphStepStrategy - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanGraphTransaction - Interface in com.thinkaurelius.titan.core
TitanGraphTransaction defines a transactional context for a TitanGraph.
TitanGraphVariables - Class in com.thinkaurelius.titan.graphdb.tinkerpop
 
TitanGraphVariables(WriteConfiguration) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.TitanGraphVariables
 
TitanId - Class in com.thinkaurelius.titan.core.util
Utility methods for handling Titan ids and converting them between indexing and storage backend representations.
TitanId() - Constructor for class com.thinkaurelius.titan.core.util.TitanId
 
TITANID - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
TitanIndex - Interface in com.thinkaurelius.titan.core.schema
Schema Elements that represent an index in the graph
TitanIndexQuery - Interface in com.thinkaurelius.titan.core
A GraphQuery that queries for graph elements directly against a particular indexing backend and hence allows this query mechanism to exploit the full range of features and functionality of the indexing backend.
TitanIndexQuery.Result<V extends org.apache.tinkerpop.gremlin.structure.Element> - Interface in com.thinkaurelius.titan.core
Container of a query result with its score.
TitanIoRegistry - Class in com.thinkaurelius.titan.graphdb.tinkerpop
 
TitanIoRegistry() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.TitanIoRegistry
 
TitanLocalQueryOptimizerStrategy - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanManagement - Interface in com.thinkaurelius.titan.core.schema
The TitanManagement interface provides methods to define, update, and inspect the schema of a Titan graph.
TitanManagement.IndexBuilder - Interface in com.thinkaurelius.titan.core.schema
Builder for TitanGraphIndex.
TitanManagement.IndexJobFuture - Interface in com.thinkaurelius.titan.core.schema
 
TitanMultiVertexQuery<Q extends TitanMultiVertexQuery<Q>> - Interface in com.thinkaurelius.titan.core
A MultiVertexQuery is identical to a TitanVertexQuery but executed against a set of vertices simultaneously.
TitanPredicate - Interface in com.thinkaurelius.titan.graphdb.query
A special kind of BiPredicate which marks all the predicates that are natively supported by Titan and known to the query optimizer.
TitanPredicate.Converter - Class in com.thinkaurelius.titan.graphdb.query
 
TitanPropertiesStep<E> - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanPropertiesStep(PropertiesStep<E>) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
TitanProperty<V> - Interface in com.thinkaurelius.titan.core
 
TitanRelation - Interface in com.thinkaurelius.titan.core
TitanRelation is the most abstract form of a relation between a vertex and some other entity, where relation is understood in its mathematical sense.
TitanSchemaCategory - Enum in com.thinkaurelius.titan.graphdb.internal
 
TitanSchemaElement - Interface in com.thinkaurelius.titan.core.schema
Marks any element that is part of a Titan Schema.
TitanSchemaType - Interface in com.thinkaurelius.titan.core.schema
A TitanSchemaType is a TitanSchemaElement that represents a label or key used in the graph.
TitanSchemaVertex - Class in com.thinkaurelius.titan.graphdb.types.vertices
 
TitanSchemaVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
TitanTransaction - Interface in com.thinkaurelius.titan.core
TitanTransaction defines a transactional context for a TitanGraph.
TitanTraversalUtil - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanTraversalUtil() - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanTraversalUtil
 
TitanVertex - Interface in com.thinkaurelius.titan.core
TitanVertex is the basic unit of a TitanGraph.
TitanVertexProperty<V> - Interface in com.thinkaurelius.titan.core
TitanProperty is a TitanRelation connecting a vertex to a value.
TitanVertexQuery<Q extends TitanVertexQuery<Q>> - Interface in com.thinkaurelius.titan.core
A TitanVertexQuery is a VertexQuery executed for a single vertex.
TitanVertexStep<E extends org.apache.tinkerpop.gremlin.structure.Element> - Class in com.thinkaurelius.titan.graphdb.tinkerpop.optimize
 
TitanVertexStep(VertexStep<E>) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
toArray() - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
toArray(E[]) - Method in class com.thinkaurelius.titan.util.datastructures.RandomRemovalList
 
Token - Class in com.thinkaurelius.titan.graphdb.internal
 
Token() - Constructor for class com.thinkaurelius.titan.graphdb.internal.Token
 
tokenize(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
 
toLockCol(Instant, StaticBuffer, TimestampProvider) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
toLockKey(StaticBuffer, StaticBuffer) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer
 
top() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Returns the least element of the PriorityQueue in constant time.
toPersist() - Method in enum com.thinkaurelius.titan.core.TitanGraphComputer.ResultMode
 
toResultGraph() - Method in enum com.thinkaurelius.titan.core.TitanGraphComputer.ResultMode
 
toString() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.Point
 
toString() - Method in class com.thinkaurelius.titan.core.attribute.Geoshape
 
toString() - Method in exception com.thinkaurelius.titan.core.InvalidElementException
 
toString() - Method in interface com.thinkaurelius.titan.core.QueryDescription
Returns a string representation of the entire query
toString() - Method in class com.thinkaurelius.titan.core.schema.Parameter
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
toString(ConfigElement) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery.OrderEntry
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRange
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.locking.LocalLockMediator
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.log.util.FutureMessage
 
toString(ByteBuffer, String) - Static method in class com.thinkaurelius.titan.diskstorage.util.ByteBufferUtil
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.util.KeyColumn
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
toString(String) - Method in class com.thinkaurelius.titan.diskstorage.util.StaticArrayBuffer
 
toString() - Method in class com.thinkaurelius.titan.diskstorage.util.time.Timer
 
toString() - Method in enum com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders
 
toString() - Method in class com.thinkaurelius.titan.graphdb.configuration.RegisteredAttributeClass
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.idassigner.placement.PartitionIDRange
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.management.GraphIndexStatusReport
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem.IndexJobStatus
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationIndexStatusReport
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.management.RelationTypeIndexWrapper
 
toString() - Method in class com.thinkaurelius.titan.graphdb.database.management.TitanGraphIndexWrapper
 
toString() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList.OrderEntry
 
toString() - Method in class com.thinkaurelius.titan.graphdb.internal.OrderList
 
toString() - Method in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId
 
toString() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraGraphComputer
 
toString() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraMemory
 
toString() - Method in interface com.thinkaurelius.titan.graphdb.query.condition.Condition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.DirectionCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.FixedCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.IncidenceDirectionCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
toString(String) - Method in class com.thinkaurelius.titan.graphdb.query.condition.MultiCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.Not
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.PredicateCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.RelationTypeCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQuery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQuery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
toString() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
toString() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
toString() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
toString() - Method in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
toString() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
toString() - Method in class com.thinkaurelius.titan.graphdb.schema.SchemaElementDefinition
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanGraphStep
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanPropertiesStep
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.optimize.TitanVertexStep
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanFeatures
 
toString() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanGraphVariables
 
toString() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.IndexLockTuple
 
toString() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.LockTuple
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.IndexField
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.indextype.IndexTypeWrapper
 
toString() - Method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.system.BaseVertexLabel
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyRelationType
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
toString() - Method in class com.thinkaurelius.titan.graphdb.types.vertices.TitanSchemaVertex
 
toString() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
toString() - Method in class com.thinkaurelius.titan.util.datastructures.PointInterval
 
toString() - Method in class com.thinkaurelius.titan.util.datastructures.RangeInterval
 
toString() - Method in class com.thinkaurelius.titan.util.system.ConfigurationLint.Status
 
TOSTRING_DELIMITER - Static variable in class com.thinkaurelius.titan.graphdb.relations.RelationIdentifier
 
toStringSingle(ConfigElement) - Static method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement
 
toVertexArrayList() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
toVertexId(long) - Static method in class com.thinkaurelius.titan.core.util.TitanId
Converts a user provided long id into a Titan vertex id.
toVertexLongList() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
Tp3DefaultSchemaMaker - Class in com.thinkaurelius.titan.graphdb.tinkerpop
 
TP3ProfileWrapper - Class in com.thinkaurelius.titan.graphdb.tinkerpop.profile
 
TP3ProfileWrapper(MutableMetrics) - Constructor for class com.thinkaurelius.titan.graphdb.tinkerpop.profile.TP3ProfileWrapper
 
TRANSACTION_LOG - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_LOG_DEFAULT_TTL - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
TRANSACTION_RECOVERY_NS - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
transactional - Variable in class com.thinkaurelius.titan.diskstorage.common.AbstractStoreManager
 
transactional(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
TransactionalConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
 
TransactionalConfiguration(WriteConfiguration) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.TransactionalConfiguration
 
TransactionBuilder - Interface in com.thinkaurelius.titan.core
Constructor returned by TitanGraph.buildTransaction() to build a new transaction.
TransactionConfiguration - Interface in com.thinkaurelius.titan.graphdb.transaction
Provides configuration options for TitanTransaction.
TransactionId - Interface in com.thinkaurelius.titan.core.log
Identifies a transaction.
TransactionLock - Interface in com.thinkaurelius.titan.graphdb.transaction.lock
 
TransactionLogHeader - Class in com.thinkaurelius.titan.graphdb.database.log
 
TransactionLogHeader(long, Instant, TimestampProvider) - Constructor for class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader
 
TransactionLogHeader.Entry - Class in com.thinkaurelius.titan.graphdb.database.log
 
TransactionLogHeader.Modification - Class in com.thinkaurelius.titan.graphdb.database.log
 
TransactionLogHeader.SecondaryFailures - Class in com.thinkaurelius.titan.graphdb.database.log
 
TransactionRecovery - Interface in com.thinkaurelius.titan.core.log
TransactionRecovery is a process that runs in the background and read's from the transaction write-ahead log to determine which transactions have not been successfully persisted against all backends.
transformation(Condition<E>, Function<Condition<E>, Condition<E>>) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.ConditionUtil
 
traversal(Condition<E>, Predicate<Condition<E>>) - Static method in class com.thinkaurelius.titan.graphdb.query.condition.ConditionUtil
 
TRUNCATED_ENTRY_LISTS - Static variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
Number of result sets that got (possibly) truncated due to an applied query limit
tryLock() - Method in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
tryLock(long, TimeUnit) - Method in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
TTL - Static variable in interface com.thinkaurelius.titan.diskstorage.StoreMetaData
 
TTL - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
TTLKCVS - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl
 
TTLKCVS(KeyColumnValueStore, int) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVS
 
TTLKCVSManager - Class in com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl
Turns a store with fine-grained cell-level TTL support into a store with coarse-grained store-level (columnfamily-level) TTL support.
TTLKCVSManager(KeyColumnValueStoreManager) - Constructor for class com.thinkaurelius.titan.diskstorage.keycolumnvalue.ttl.TTLKCVSManager
 
tx() - Method in interface com.thinkaurelius.titan.graphdb.internal.InternalElement
Returns the transaction to which the element is currently bound or should be refreshed into
tx - Variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
tx - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
Transaction in which this query is executed
tx() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
tx() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
tx() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
tx - Variable in class com.thinkaurelius.titan.graphdb.types.StandardRelationTypeMaker
 
tx() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
tx() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
TX_CACHE_SIZE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configures the maximum number of recently-used vertices cached by a transaction.
TX_DIRTY_SIZE - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
Configures the initial size of the dirty (modified) vertex map used by a transaction.
TXUtils - Class in com.thinkaurelius.titan.util.system
This class may become obsolete in and is subject for removal in Titan 0.9, since we can assume try-with-resources and transactions implement AutoCloseable.
TXUtils() - Constructor for class com.thinkaurelius.titan.util.system.TXUtils
 
type(RelationType) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
type(RelationType) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
type - Variable in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
TYPE_LEN_RESERVE - Static variable in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
Number of bits that need to be reserved from the type ids for storing additional information during serialization
TYPE_MODIFIER_DEFINITION_CATEGORIES - Static variable in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
TypeDefinitionCategory - Enum in com.thinkaurelius.titan.graphdb.types
 
TypeDefinitionDescription - Class in com.thinkaurelius.titan.graphdb.types
 
TypeDefinitionDescription(TypeDefinitionCategory, Object) - Constructor for class com.thinkaurelius.titan.graphdb.types.TypeDefinitionDescription
 
TypeDefinitionDescriptionSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
TypeDefinitionDescriptionSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.TypeDefinitionDescriptionSerializer
 
TypeDefinitionMap - Class in com.thinkaurelius.titan.graphdb.types
 
TypeDefinitionMap() - Constructor for class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
TypeDefinitionMap(TypeDefinitionMap) - Constructor for class com.thinkaurelius.titan.graphdb.types.TypeDefinitionMap
 
TypedInterval(PropertyKey, Interval) - Constructor for class com.thinkaurelius.titan.graphdb.database.EdgeSerializer.TypedInterval
 
typeId - Variable in class com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler.RelationTypeParse
 
typeId - Variable in class com.thinkaurelius.titan.graphdb.relations.RelationCache
 
TypeInspector - Interface in com.thinkaurelius.titan.graphdb.types
 
types(String...) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Query for only those relations matching one of the given relation types.
types(RelationType...) - Method in interface com.thinkaurelius.titan.core.BaseVertexQuery
Query for only those relations matching one of the given relation types.
types(String...) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
types(RelationType...) - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
 
types(String...) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
types(RelationType...) - Method in interface com.thinkaurelius.titan.core.TitanVertexQuery
 
types(RelationType...) - Method in class com.thinkaurelius.titan.graphdb.olap.QueryContainer.QueryBuilder
 
types - Variable in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
The relation types (labels or keys) to query for.
types(RelationType...) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
types(String...) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BaseVertexCentricQueryBuilder
 
TypeUtil - Class in com.thinkaurelius.titan.graphdb.types
 
TypeUtil() - Constructor for class com.thinkaurelius.titan.graphdb.types.TypeUtil
 

U

uid - Variable in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
uidBytes - Variable in class com.thinkaurelius.titan.diskstorage.idmanagement.AbstractIDAuthority
 
UKNOWN_FIELD_NAME - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
umbrellaElements - Variable in class com.thinkaurelius.titan.diskstorage.configuration.ConfigElement.PathIdentifier
 
uncaughtException(Thread, Throwable) - Method in class com.thinkaurelius.titan.diskstorage.util.UncaughtExceptionLogger
 
UncaughtExceptionLogger - Class in com.thinkaurelius.titan.diskstorage.util
 
UncaughtExceptionLogger(UncaughtExceptionLogger.UELevel) - Constructor for class com.thinkaurelius.titan.diskstorage.util.UncaughtExceptionLogger
 
UncaughtExceptionLogger.UELevel - Enum in com.thinkaurelius.titan.diskstorage.util
 
UncheckedCallable<T> - Interface in com.thinkaurelius.titan.diskstorage.util
 
unidirected() - Method in interface com.thinkaurelius.titan.core.schema.EdgeLabelMaker
Configures the label to be unidirected.
unidirected() - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
unidirected(Direction) - Method in class com.thinkaurelius.titan.graphdb.types.StandardEdgeLabelMaker
 
unique() - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement.IndexBuilder
Makes this a unique index for the configured element type, i.e.
UNIQUE_INSTANCE_ID - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
UNIQUE_INSTANCE_ID_SUFFIX - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
unlock(KeyColumn, T) - Method in class com.thinkaurelius.titan.diskstorage.locking.LocalLockMediator
Release the lock specified by kc and which was previously locked by requestor, if it is possible to release it.
unlock() - Method in class com.thinkaurelius.titan.diskstorage.util.NoLock
 
unlock() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.CombinerLock
 
unlock() - Method in class com.thinkaurelius.titan.graphdb.transaction.lock.FakeLock
 
unlock() - Method in interface com.thinkaurelius.titan.graphdb.transaction.lock.TransactionLock
 
unorderedScan(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
unregisterReader(MessageReader) - Method in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog
 
unregisterReader(MessageReader) - Method in interface com.thinkaurelius.titan.diskstorage.log.Log
Removes the given reader from the list of registered readers and returns whether this reader was registered in the first place.
unsetBitb(byte, int) - Static method in class com.thinkaurelius.titan.util.datastructures.BitMap
 
unsignedBitLength(long) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
unsignedByte(byte) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
unsignedByte(int) - Static method in class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
unwrapTx(StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.cache.KCVSCache
 
unwrapTx(StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KCVSProxy
 
unwrapTx(StoreTransaction) - Method in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ExpectedValueCheckingStore
 
update(byte, ElementLifeCycle.Event) - Static method in class com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle
 
updateIndex(TitanIndex, SchemaAction) - Method in interface com.thinkaurelius.titan.core.schema.TitanManagement
Updates the provided index according to the given SchemaAction
updateIndex(TitanIndex, SchemaAction) - Method in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem
 
updateLifeCycle(ElementLifeCycle.Event) - Method in class com.thinkaurelius.titan.graphdb.vertices.StandardVertex
 
updateLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.indexing.IndexQuery
 
updateLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeyRangeQuery
 
updateLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.KeySliceQuery
 
updateLimit(int) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.SliceQuery
 
updateLimit(int) - Method in interface com.thinkaurelius.titan.graphdb.query.BackendQuery
Creates a new query identical to the current one but with the specified limit.
updateLimit(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery.Subquery
 
updateLimit(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.JointIndexQuery
 
updateLimit(int) - Method in class com.thinkaurelius.titan.graphdb.query.graph.MultiKeySliceQuery
 
updateSchemaVertex(TitanSchemaVertex) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
updateTop() - Method in class com.thinkaurelius.titan.graphdb.util.PriorityQueue
Should be called when the Object at top changes values.
USE_MULTIQUERY - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
useMultiQuery() - Method in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
USER_CONFIGURATION_IDENTIFIER - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
USER_LOG - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
USER_LOG_PREFIX - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
userLogFailure - Variable in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader.SecondaryFailures
 
UserModifiableConfiguration - Class in com.thinkaurelius.titan.diskstorage.configuration
Helper class for inspecting and modifying a configuration for Titan.
UserModifiableConfiguration(ModifiableConfiguration) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
 
UserModifiableConfiguration(ModifiableConfiguration, UserModifiableConfiguration.ConfigVerifier) - Constructor for class com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration
 
UserModifiableConfiguration.ConfigVerifier - Interface in com.thinkaurelius.titan.diskstorage.configuration
 
username - Variable in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager
 
USERVERTEX_PADDING_BITWIDTH - Static variable in class com.thinkaurelius.titan.graphdb.idmanagement.IDManager
The padding bit with for user vertices
useSimpleQueryProcessor(BaseVertexCentricQuery, InternalVertex...) - Method in class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder
 
UUIDSerializer - Class in com.thinkaurelius.titan.graphdb.database.serialize.attribute
 
UUIDSerializer() - Constructor for class com.thinkaurelius.titan.graphdb.database.serialize.attribute.UUIDSerializer
 

V

validate(String) - Static method in class com.thinkaurelius.titan.util.system.ConfigurationLint
 
validateIndexStatus() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRemoveJob
 
validateIndexStatus() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexRepairJob
Check that our target index is in either the ENABLED or REGISTERED state.
validateIndexStatus() - Method in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob
 
validDataType(Class) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.AttributeHandler
 
validDataType(Class) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
validDataType(Class) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
validTitanHas(HasContainer) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
validTitanHas(Iterable<HasContainer>) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
validTitanOrder(OrderGlobalStep, Traversal, boolean) - Static method in interface com.thinkaurelius.titan.graphdb.tinkerpop.optimize.HasStepFolder
 
value() - Method in class com.thinkaurelius.titan.core.schema.Parameter
 
value(String) - Method in interface com.thinkaurelius.titan.core.TitanRelation
Retrieves the value associated with the given key on this vertex and casts it to the specified type.
value - Variable in class com.thinkaurelius.titan.diskstorage.indexing.IndexEntry
 
value() - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
value(String) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
value(String) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
value() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractVertexProperty
 
value() - Method in class com.thinkaurelius.titan.graphdb.relations.SimpleTitanProperty
 
value(String) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
VALUE - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Cmp
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Contain
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Geo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Geoshape.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.attribute.Text
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.Cardinality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.log.Change
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.Multiplicity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.schema.ConsistencyModifier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.schema.JobStatus.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.schema.Mapping
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.schema.SchemaAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.schema.SchemaStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.TitanGraphComputer.ResultMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.Deployment
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration.Restriction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.configuration.ConfigOption.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.EntryMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.idmanagement.ConflictAvoidanceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.keycolumnvalue.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.keycolumnvalue.scan.ScanMetrics.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.locking.LocalLockMediators
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.util.CacheMetricsAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.util.HashingUtil.HashLength
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.util.HashUtility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.diskstorage.util.UncaughtExceptionLogger.UELevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.database.idhandling.IDHandler.DirectionID
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxMeta
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.database.log.LogTxStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.database.management.MgmtLogType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.database.management.ModifierType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.idmanagement.IDManager.VertexIDType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.ElementCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.ElementLifeCycle.Event
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.query.condition.Condition.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition.Visibility
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.types.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.thinkaurelius.titan.util.stats.MetricManager
Returns the enum constant of this type with the specified name.
valueOrNull(PropertyKey) - Method in interface com.thinkaurelius.titan.core.TitanElement
Retrieves the value associated with the given key on this element and casts it to the specified type.
valueOrNull(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.olap.computer.FulgoraVertexProperty
 
valueOrNull(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
 
valueOrNull(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
valueOrNull(PropertyKey) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
values() - Static method in enum com.thinkaurelius.titan.core.attribute.Cmp
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.attribute.Contain
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.attribute.Geo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.attribute.Text
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.Cardinality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.log.Change
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.Multiplicity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.schema.ConsistencyModifier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.core.schema.Mapping
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.schema.SchemaAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.schema.SchemaStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.TitanGraphComputer.ResultMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.core.util.ReflectiveConfigOptionLoader
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.EntryMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.diskstorage.idmanagement.ConflictAvoidanceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.diskstorage.keycolumnvalue.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.locking.LocalLockMediators
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardIndexProvider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.diskstorage.StandardStoreManager
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.diskstorage.util.CacheMetricsAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.diskstorage.util.HashUtility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.internal.ElementCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.internal.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.graphdb.internal.RelationCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.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 com.thinkaurelius.titan.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 com.thinkaurelius.titan.graphdb.types.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.thinkaurelius.titan.util.datastructures.CompactMap
 
values() - Static method in enum com.thinkaurelius.titan.util.stats.MetricManager
Returns an array containing the constants of this enum type, in the order they are declared.
variableKeyLength - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
variableKeyLengthSize - Static variable in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.keyvalue.OrderedKeyValueStoreAdapter
 
VariableLong - Class in com.thinkaurelius.titan.graphdb.database.idhandling
 
VariableLong() - Constructor for class com.thinkaurelius.titan.graphdb.database.idhandling.VariableLong
 
variables() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
variables() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
VERBOSE_TX_RECOVERY - Static variable in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration
 
verify(Object) - Method in class com.thinkaurelius.titan.diskstorage.configuration.ConfigOption
 
verifyAccess() - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractTypedRelation
Cannot currently throw exception when removed since internal logic relies on access to the edge beyond its removal.
verifyAccess(TitanVertex...) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
verifyAccess() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
verifyArgsMustBeEitherIdorElement(Object...) - Static method in class com.thinkaurelius.titan.graphdb.tinkerpop.ElementUtils
 
verifyAttribute(V) - Method in interface com.thinkaurelius.titan.core.attribute.AttributeSerializer
Verifies the given (not-null) attribute value is valid.
verifyAttribute(Geoshape) - Method in class com.thinkaurelius.titan.core.attribute.Geoshape.GeoshapeSerializer
 
verifyAttribute(String) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.StringSerializer
 
verifyAttribute(Class<V>, Object) - Method in interface com.thinkaurelius.titan.graphdb.database.serialize.AttributeHandler
 
verifyAttribute(V) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.NoSerializer
 
verifyAttribute(Class<V>, Object) - Method in class com.thinkaurelius.titan.graphdb.database.serialize.StandardSerializer
 
verifyAttribute(PropertyKey, Object) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTitanTx
 
verifyAttribute(Object) - Method in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
verifyElement(ConfigElement) - Method in class com.thinkaurelius.titan.diskstorage.configuration.AbstractConfiguration
 
verifyModification(ConfigOption) - Method in interface com.thinkaurelius.titan.diskstorage.configuration.UserModifiableConfiguration.ConfigVerifier
Throws an exception if the given configuration option is not allowed to be changed.
verifyName(String) - Static method in class com.thinkaurelius.titan.graphdb.internal.Token
 
verifyOpen(boolean, String, String...) - Static method in exception com.thinkaurelius.titan.diskstorage.ResourceUnavailableException
 
verifyOption(ConfigOption) - Method in class com.thinkaurelius.titan.diskstorage.configuration.BasicConfiguration
 
verifyValidDefinition(TypeDefinitionMap) - Method in enum com.thinkaurelius.titan.graphdb.internal.TitanSchemaCategory
 
version() - Static method in class com.thinkaurelius.titan.core.Titan
The version of this Titan graph database
VERSION - Static variable in class com.thinkaurelius.titan.graphdb.configuration.TitanConstants
Runtime version of Titan, as read from a properties file inside the core jar
vertex(Direction) - Method in interface com.thinkaurelius.titan.core.TitanEdge
Returns the vertex for the specified direction.
vertex(Direction) - Method in class com.thinkaurelius.titan.graphdb.relations.AbstractEdge
 
vertex() - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanFeatures
 
VERTEX_EXISTS_QUERY - Static variable in class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
VERTEX_ID_COMPARATOR - Static variable in class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
VertexArrayList - Class in com.thinkaurelius.titan.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(StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexArrayList
 
VertexCache - Interface in com.thinkaurelius.titan.graphdb.transaction.vertexcache
 
vertexCacheSize(int) - Method in interface com.thinkaurelius.titan.core.TransactionBuilder
Configures the size of the internal caches used in the transaction.
vertexCacheSize(int) - Method in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder
 
VertexCentricEdgeIterable<R extends TitanRelation> - Class in com.thinkaurelius.titan.graphdb.util
 
VertexCentricEdgeIterable(Iterable<InternalVertex>, RelationCategory) - Constructor for class com.thinkaurelius.titan.graphdb.util.VertexCentricEdgeIterable
 
VertexCentricQuery - Class in com.thinkaurelius.titan.graphdb.query.vertex
A vertex-centric query which implements ElementQuery so that it can be executed by QueryProcessor.
VertexCentricQuery(InternalVertex, Condition<TitanRelation>, Direction, List<BackendQueryHolder<SliceQuery>>, OrderList, int) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
VertexCentricQuery(InternalVertex, BaseVertexCentricQuery) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
 
VertexCentricQuery(InternalVertex) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQuery
Constructs an empty query
VertexCentricQueryBuilder - Class in com.thinkaurelius.titan.graphdb.query.vertex
Implementation of TitanVertexQuery that extends BasicVertexCentricQueryBuilder for all the query building and optimization and adds only the execution logic in BasicVertexCentricQueryBuilder.constructQuery(com.thinkaurelius.titan.graphdb.internal.RelationCategory).
VertexCentricQueryBuilder(InternalVertex) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
VertexConstructor() - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexConstructor
 
vertexExistenceQuery - Variable in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph
 
VertexExists - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseKey
 
VertexFactory - Interface in com.thinkaurelius.titan.graphdb.transaction
 
VertexIDAssigner - Class in com.thinkaurelius.titan.graphdb.database.idassigner
 
VertexIDAssigner(Configuration, IDAuthority, StoreFeatures) - Constructor for class com.thinkaurelius.titan.graphdb.database.idassigner.VertexIDAssigner
 
VertexIdConstructor() - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.BasicVertexCentricQueryBuilder.VertexIdConstructor
 
vertexIds() - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
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 com.thinkaurelius.titan.core.TitanVertexQuery
Retrieves all vertices connected to this query's base vertex by edges matching the conditions defined in this query.
vertexIds() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
vertexIds() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.SimpleVertexQueryProcessor
Returns the list of adjacent vertex ids for this query.
vertexIds() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
VertexIterable - Class in com.thinkaurelius.titan.graphdb.transaction
 
VertexIterable(StandardTitanGraph, StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.transaction.VertexIterable
 
VertexJobConverter - Class in com.thinkaurelius.titan.graphdb.olap
 
VertexJobConverter(TitanGraph, VertexScanJob) - Constructor for class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
VertexJobConverter(VertexJobConverter) - Constructor for class com.thinkaurelius.titan.graphdb.olap.VertexJobConverter
 
VertexJobConverter.GraphProvider - Class in com.thinkaurelius.titan.graphdb.olap
 
vertexLabel() - Method in interface com.thinkaurelius.titan.core.TitanVertex
Returns the vertex label of this vertex.
VertexLabel - Interface in com.thinkaurelius.titan.core
A vertex label is a label attached to vertices in a Titan graph.
vertexLabel() - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
vertexLabel() - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
VERTEXLABEL_DEFINITION_CATEGORIES - Static variable in enum com.thinkaurelius.titan.graphdb.types.TypeDefinitionCategory
 
VertexLabelDefinition - Class in com.thinkaurelius.titan.graphdb.schema
 
VertexLabelDefinition(String, long, boolean, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.schema.VertexLabelDefinition
 
VertexLabelDefinition(VertexLabel) - Constructor for class com.thinkaurelius.titan.graphdb.schema.VertexLabelDefinition
 
VertexLabelEdge - Static variable in class com.thinkaurelius.titan.graphdb.types.system.BaseLabel
 
VertexLabelMaker - Interface in com.thinkaurelius.titan.core.schema
A builder to create new VertexLabels.
VertexLabelVertex - Class in com.thinkaurelius.titan.graphdb.types
 
VertexLabelVertex(StandardTitanTx, long, byte) - Constructor for class com.thinkaurelius.titan.graphdb.types.VertexLabelVertex
 
VertexList - Interface in com.thinkaurelius.titan.core
List of TitanVertexs.
VertexListInternal - Interface in com.thinkaurelius.titan.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 com.thinkaurelius.titan.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(StandardTitanTx) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
VertexLongList(StandardTitanTx, LongArrayList, boolean) - Constructor for class com.thinkaurelius.titan.graphdb.query.vertex.VertexLongList
 
VertexMapJob - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
VertexMapJob.Executor - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
VertexProgramScanJob<M> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
VertexProgramScanJob.Executor - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
VertexScanJob - Interface in com.thinkaurelius.titan.graphdb.olap
Expresses a computation over all vertices ina a graph database.
VertexState<M> - Class in com.thinkaurelius.titan.graphdb.olap.computer
 
VertexState(Map<String, Integer>) - Constructor for class com.thinkaurelius.titan.graphdb.olap.computer.VertexState
 
vertices(Direction) - Method in interface com.thinkaurelius.titan.core.TitanEdge
 
vertices() - Method in interface com.thinkaurelius.titan.core.TitanGraphQuery
Returns all vertices that match the conditions.
vertices() - Method in interface com.thinkaurelius.titan.core.TitanIndexQuery
Returns all vertices that match the query in the indexing backend.
vertices() - Method in interface com.thinkaurelius.titan.core.TitanMultiVertexQuery
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 com.thinkaurelius.titan.core.TitanVertexQuery
 
vertices() - Method in class com.thinkaurelius.titan.graphdb.query.graph.GraphCentricQueryBuilder
 
vertices() - Method in class com.thinkaurelius.titan.graphdb.query.graph.IndexQueryBuilder
 
vertices() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.MultiVertexCentricQueryBuilder
 
vertices() - Method in class com.thinkaurelius.titan.graphdb.query.vertex.VertexCentricQueryBuilder
 
vertices(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsGraph
 
vertices(Object...) - Method in class com.thinkaurelius.titan.graphdb.tinkerpop.TitanBlueprintsTransaction
 
vertices(Direction, String...) - Method in class com.thinkaurelius.titan.graphdb.types.system.EmptyVertex
 
vertices(Direction, String...) - Method in class com.thinkaurelius.titan.graphdb.vertices.AbstractVertex
 
visibility(boolean) - Method in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder
 
VISIBILITY - Static variable in class com.thinkaurelius.titan.graphdb.types.system.ImplicitKey
 
VisibilityFilterCondition<E extends TitanElement> - Class in com.thinkaurelius.titan.graphdb.query.condition
Evaluates elements based on their visibility
VisibilityFilterCondition(VisibilityFilterCondition.Visibility) - Constructor for class com.thinkaurelius.titan.graphdb.query.condition.VisibilityFilterCondition
 
VisibilityFilterCondition.Visibility - Enum in com.thinkaurelius.titan.graphdb.query.condition
 

W

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

Z

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

Copyright © 2012–2015. All rights reserved.